A B C D E F G H I J K L M N O P Q R S T U V W X Z 
All Classes All Packages
All Classes All Packages
All Classes All Packages
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,T,E,R> - Class in com.tangosol.util.aggregator
- 
Abstract base class implementation ofInvocableMap.EntryAggregatorthat 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 ofInvocableMap.Entryobjects.
- AbstractAggregator(String) - Constructor for class com.tangosol.util.aggregator.AbstractAggregator
- 
Construct an AbstractAggregator that will aggregate values extracted from a set ofInvocableMap.Entryobjects.
- AbstractAsynchronousAggregator<K,V,P,R> - Class in com.tangosol.util.aggregator
- 
Abstract base class for asynchronous entry aggregators.
- AbstractAsynchronousAggregator(InvocableMap.StreamingAggregator<K, V, P, R>, int) - Constructor for class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
- 
Construct an AsynchronousAggregator for a given streaming aggregator.
- AbstractAsynchronousAggregator(InvocableMap.StreamingAggregator<K, V, P, R>, int, Executor) - Constructor for class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
- 
Construct an AsynchronousAggregator for a given streaming aggregator.
- AbstractAsynchronousProcessor<K,V,R,T> - Class in com.tangosol.util.processor
- 
Abstract base class for asynchronous entry processors.
- AbstractAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int) - Constructor for class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
Construct AbstractAsynchronousProcessor instance.
- AbstractAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int, Executor) - 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 processesNumbervalues extracted from a set of entries in a Map and returns a result in a form of aBigDecimalvalue.
- 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 extends ServiceDependencies> - Class in com.tangosol.coherence.config.scheme
- 
AnAbstractCachingSchemeis 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 forCertificateLoaderimplementations.
- AbstractCertificateLoader(String) - Constructor for class com.tangosol.net.ssl.AbstractCertificateLoader
- 
Create anAbstractCertificateLoader.
- AbstractCodec() - Constructor for class com.tangosol.io.pof.reflect.Codecs.AbstractCodec
- AbstractCoherenceBasedCache<K,V,C extends CoherenceBasedConfiguration<K,V>> - Class in com.tangosol.coherence.jcache
- 
The base implementation of aCoherenceBasedCache.
- AbstractCoherenceBasedCache(CoherenceBasedCacheManager, String, C) - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Constructs anAbstractCoherenceBasedCache.
- AbstractCoherenceBasedCompleteConfiguration<K,V> - Class in com.tangosol.coherence.jcache
- 
A base implementation of aCoherenceBasedCompleteConfiguration.
- AbstractCoherenceBasedCompleteConfiguration() - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
Constructs anAbstractCoherenceBasedCompleteConfiguration.
- AbstractCoherenceBasedCompleteConfiguration(CompleteConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
Constructs anAbstractCoherenceBasedCompleteConfigurationbased 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
- 
TheAbstractCompositeSchememanages 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
- 
AConditionalElementProcessorthat provides defined behaviors for processing emptyXmlElements.
- AbstractEmptyElementProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
- 
Constructs anAbstractEmptyElementProcessorthat will attempt to process emptyXmlElements.
- AbstractEmptyElementProcessor(AbstractEmptyElementProcessor.EmptyElementBehavior) - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
- 
Constructs anAbstractEmptyElementProcessorwith the specified behavior for processing emptyXmlElements (with a default value ofnull).
- AbstractEmptyElementProcessor(T) - Constructor for class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
- 
Constructs anAbstractEmptyElementProcessorthat will return the specified default value when it encounters an emptyXmlElement.
- AbstractEmptyElementProcessor.EmptyElementBehavior - Enum in com.tangosol.coherence.config.xml.processor
- 
The behavior of theConditionalElementProcessorwhen 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,R> - Class in com.tangosol.util.processor
- 
An Evolvable AbstractProcessor that is a partial EntryProcessor implementation that provides the default implementation of theAbstractEvolvableProcessor.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
- 
TheAbstractJournalSchemecontains 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 aCacheEventobject 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 (viaMap.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 forKeyStoreLoaderimplementations.
- AbstractKeyStoreLoader(String) - Constructor for class com.tangosol.net.ssl.AbstractKeyStoreLoader
- AbstractLocalCachingScheme<T> - Class in com.tangosol.coherence.config.scheme
- 
TheAbstractLocalCachingSchemeis 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
- 
AnAbstractNamespaceHandlerprovides a base implementation of aNamespaceHandlerwith support for implicit and explicit registration ofElementProcessors andAttributeProcessors for those xml attributes and elements occurring in the associated xml namespace.
- AbstractNamespaceHandler() - Constructor for class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Construct anAbstractNamespaceHandler.
- 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 extends AbstractPersistenceManager.AbstractPersistentStore> - Class in com.tangosol.persistence
- 
Abstract implementation of a ReadBuffer-based PersistentManager.
- AbstractPersistenceManager(File, File, String) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager
- 
Create a new AbstractPersistenceManager.
- AbstractPersistenceManager.AbstractPersistenceSnapshotTools - Class in com.tangosol.persistence
- 
Abstract implementation of PersistenceTools which can be extended to support local snapshot operations for specific implementations.
- AbstractPersistenceManager.AbstractPersistentStore - Class in com.tangosol.persistence
- 
Abstract implementation of a ReadBuffer-based PersistentStore.
- AbstractPersistenceManager.AbstractPersistentStore.BatchTask - Class in com.tangosol.persistence
- 
Runnable implementation that is used to perform and commit a sequence of mutating persistent store operations asynchronously.
- AbstractPersistenceManager.AbstractPersistentStore.BatchTask.EraseOperation - Class in com.tangosol.persistence
- 
An erase() Operation.
- AbstractPersistenceManager.AbstractPersistentStore.BatchTask.Operation - Class in com.tangosol.persistence
- 
Base class for Runnable implementations that encapsulate a persistent store operation.
- AbstractPersistenceManager.AbstractPersistentStore.BatchTask.StoreOperation - Class in com.tangosol.persistence
- 
A store() Operation.
- AbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTask - Class in com.tangosol.persistence
- 
A Task implementation that deletes an extent from the associated store.
- AbstractPersistenceManager.AbstractPersistentStore.OpenTask - Class in com.tangosol.persistence
- 
An OpenTask opens the store (parent of this inner class) with the provided store and notifies the Collector when complete.
- AbstractPersistenceManager.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 ofPersistenceToolsthat can be utilized for both local or archived snapshot operations.
- AbstractPersistenceTools.StatsVisitor - Class in com.tangosol.persistence
- 
An implementation of aCachePersistenceHelper.Visitorto 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 ofPofNavigatorinterface.
- 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 forPrivateKeyLoaderimplementations.
- AbstractPrivateKeyLoader(String) - Constructor for class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- 
Create aAbstractPrivateKeyLoader.
- AbstractProcessor<K,V,R> - Class in com.tangosol.util.processor
- 
An AbstractProcessor is a partial EntryProcessor implementation that provides the default implementation of theAbstractProcessor.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
- 
AnOPTokenimplementation 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 onStatement.
- AbstractQueryRecorderFilter<T> - Class in com.tangosol.util.filter
- 
Abstract base class implementation ofQueryRecorderFilter.
- 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,M> - Class in com.oracle.coherence.repository
- 
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-basedAbstractRepositoryBase.Listener.
- AbstractRepositoryBase.MapListenerAdapter<ID,T> - Class in com.oracle.coherence.repository
- 
Adapter fromAbstractRepositoryBase.ListenertoMapListenerthat can be registered with the backingNamedMap.
- AbstractSafeLongArray<V> - Class in com.tangosol.util
- 
An abstract base class for thread-safeLongArrays 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
- 
TheAbstractSchemeis 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 extends Service,T extends ServiceLoad> - Class in com.tangosol.net
- 
An abstract base for ServiceLoadBalancer implementations.
- AbstractServiceLoadBalancer() - Constructor for class com.tangosol.net.AbstractServiceLoadBalancer
- AbstractServiceScheme<D extends ServiceDependencies> - Class in com.tangosol.coherence.config.scheme
- 
TheAbstractServiceSchemeprovides 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 aSnapshotArchiverwhich 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 anAbstractStatementproviding functionality useful for generic snapshot statements.
- AbstractSnapshotStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Create a AbstractSnapshotStatement that will prove base functionality for other snapshot commands.
- AbstractSparseArray<V> - Class in com.tangosol.util
- 
A data structure resembling an array indexed by long values, stored as an AVL tree.
- AbstractSparseArray() - Constructor for class com.tangosol.util.AbstractSparseArray
- 
Default constructor.
- AbstractSparseArray.Crawler - Class in com.tangosol.util
- 
A tree node iterator.
- AbstractSparseArray.Node<V> - Class in com.tangosol.util
- 
An AVL tree node.
- AbstractSQLSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
An abstract implementation of a snapshot operation which can be extended to support different persistence operations.
- AbstractSQLSnapshotOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.AbstractSQLSnapshotOPToken
- 
Construct a new AbstractSQLSnapshotOPToken.
- AbstractSQLSnapshotOPToken(String, String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.AbstractSQLSnapshotOPToken
- 
Construct a new AbstractSQLSnapshotOPToken.
- AbstractStableIterator - Class in com.tangosol.util
- 
Deprecated.As of Coherence 12.1.2, replaced byAbstractStableIterator
- AbstractStableIterator() - Constructor for class com.tangosol.util.AbstractStableIterator
- 
Deprecated.
- AbstractStatement - Class in com.tangosol.coherence.dslquery.statement
- 
A base class forStatementimplementations.
- AbstractStatement() - Constructor for class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractStatement
- AbstractStatement() - Constructor for class com.tangosol.coherence.dslquery.statement.AbstractStatement
- AbstractStatementBuilder<T extends Statement> - Class in com.tangosol.coherence.dslquery.statement
- 
A base class forStatementBuilderimplementations.
- AbstractStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- AbstractStoreManager - Class in com.tangosol.io.nio
- 
A base implementation of BinaryStoreManager interface that usesBinaryMapobjects built on aByteBufferManagerto provideBinaryStoreobjects.
- AbstractStoreManager(int, int) - Constructor for class com.tangosol.io.nio.AbstractStoreManager
- 
Construct a AbstractStoreManager that uses BinaryMap objests built on the ByteBufferManager(s) with certain initial and maximum size.
- AbstractStoreManagerBuilder<T> - Class in com.tangosol.coherence.config.builder.storemanager
- 
The AbstractStoreManagerBuilder class builds an instance of a BinaryStoreManager.
- AbstractStoreManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.AbstractStoreManagerBuilder
- AbstractUpdater<K,V,U> - Class in com.tangosol.util.extractor
- 
Abstract base for ValueUpdater implementations.
- AbstractUpdater() - Constructor for class com.tangosol.util.extractor.AbstractUpdater
- AbstractWrapperCollection() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- 
Default constructor
- AbstractWrapperCollection(Collection<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- 
Create an AbstractWrapperCollection which delegates to the specified Collection.
- AbstractWrapperEntry(Map.Entry<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- 
Create an AbstractWrapperEntry which delegates to the specified Entry.
- AbstractWrapperIterator(Iterator<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- 
Create an AbstractWrapperIterator which delegates to the specified Iterator.
- AbstractWrapperList() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperList
- 
Default constructor.
- AbstractWrapperList(List<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperList
- 
Create an AbstractWrapperList which delegates to the specified List.
- AbstractWrapperListIterator(ListIterator<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
- 
Create an AbstractWrapperListIterator which delegates to the specified ListIterator.
- AbstractWrapperLongArray() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- AbstractWrapperMap() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- 
Default constructor
- AbstractWrapperMap(Map<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- 
Create an AbstractWrapperMap which delegates to the specified Map.
- AbstractWrapperSet() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSet
- 
Default constructor.
- AbstractWrapperSet(Set<E>) - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSet
- 
Create an AbstractWrapperSet which delegates to the specified Set.
- AbstractWrapperSortedMap() - Constructor for class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- 
Construct instance which wraps an instance of aSortedMap.
- 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 Type 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 theSocketAddressProvider.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 theSocketAddressProvider.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 theSocketAddressProvider.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 theSocketAddressProvider.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 theSocketAddressProvider.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 theSocketAddressProvider.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 theSocketAddressProvider.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 rightTerms for the operator and result in the creation of aFilteror 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
- 
AnElementProcessorthat 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 specifiedXmlElementshould be processed.
- accepts(ProcessingContext, XmlElement) - Method in interface com.tangosol.config.xml.ConditionalElementProcessor
- 
Determines if the specifiedXmlElementshould 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 theJCacheEntryMetaInfbased 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 abstractActionPolicyBuilderis 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
- 
ActionPolicyBuilderwrapper 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 thisSession.
- Activated - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any ACTIVATED event.
- ACTIVATED - com.tangosol.net.events.application.LifecycleEvent.Type
- 
ThisLifecycleEventis dispatched when aConfigurableCacheFactoryhas been activated.
- Activated.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theActivatedannotation.
- Activating - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any ACTIVATING event.
- ACTIVATING - com.tangosol.net.events.application.LifecycleEvent.Type
- 
ThisLifecycleEventis dispatched prior to the activation of aConfigurableCacheFactory.
- Activating.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theActivatingannotation.
- 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
- 
addJCacheStatisticsstats 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 aParameterto the end of theParameterListor replaces an existingParameterin theParameterList.
- add(Parameter) - Method in class com.tangosol.coherence.config.ResolvableParameterList
- 
Adds aParameterto the end of theParameterListor replaces an existingParameterin theParameterList.
- add(Parameter) - Method in class com.tangosol.coherence.config.SimpleParameterList
- 
Adds aParameterto the end of theParameterListor replaces an existingParameterin theParameterList.
- add(Parameter) - Method in class com.tangosol.config.expression.ScopedParameterResolver
- 
Adds the specifiedParameterto 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 theParameterListas 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 aSocketAddress.
- 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 aCacheEntryListener.
- addCacheMappingRegistry(SchemeMappingRegistry) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Add cache scheme mappings to theSchemeMappingRegistry.
- 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 theProcessingContext.
- addCookie(Class<T>, String, T) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Adds the specified named and typed cookie to theProcessingContext.
- addCookie(Class<T>, T) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Adds the specified cookie to theProcessingContext.
- addCookie(Class<T>, T) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Adds the specified cookie to theProcessingContext.
- 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 anEventInterceptorto this dispatcher to be used to processEvents.
- addEventInterceptor(String, EventInterceptor<E>) - Method in interface com.tangosol.net.events.EventDispatcher
- 
Add a uniquely identifiedEventInterceptorto this dispatcher to be used to processEvents.
- addEventInterceptor(String, EventInterceptor<E>, Set<T>, boolean) - Method in interface com.tangosol.net.events.EventDispatcher
- 
Add a uniquely identifiedEventInterceptorto this dispatcher to be used to processEvents.
- addFilterMapListener(String, String, String, ByteString, long, boolean, boolean, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aMapListenerRequestthat will subscribe toMapEventsfor 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 CohQLParameterizedBuilderto 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 theAddIndexRequestrequest.
- 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
- 
IfContinuousQueryCache.isCacheValues()istrue, the index will be created locally as well as on theNamedCachethisContinuousQueryCachewraps, otherwise, the index will be created on the wrappedNamedCacheonly.
- 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 aAddIndexRequest.
- addIndex(String, String, String, ByteString, boolean) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aAddIndexRequest.
- addIndex(String, String, String, ByteString, boolean, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aAddIndexRequest.
- 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, Set<Object>>, 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
- 
ABaseOperatorimplementation 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 aMapListenerRequestthat will subscribe toMapEventsfor a single entry in a cache.
- addLifecycleListener(LifecycleListener) - Method in class com.tangosol.net.DefaultCacheServer
- 
Add aLifecycleListenerthat 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, String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Register SSE event listener for this cache.
- addListener(boolean, UriInfo) - Method in class com.tangosol.coherence.rest.NamedQueryResource
- 
Register SSE event listener for this named query.
- 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 aFiniteStateMachineListenerto theFiniteStateMachine.
- addListener(FiniteStateMachineListener<S>) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Add aFiniteStateMachineListenerto 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 aClusterDependencies.ServiceProvider.
- addLookupCallback(NameService.LookupCallback) - Method in interface com.tangosol.net.NameService
- 
Register aNameService.LookupCallbackto 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.OldCache
- 
Deprecated.Add a standard map listener that will receive all events (inserts, updates, deletes) that occur against the map, with the key, old-value and new-value included.
- addMapListener(MapListener) - 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.OldCache
- 
Deprecated.Add a map listener that receives events based on a filter evaluation.
- 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.OldCache
- 
Deprecated.Add a map listener for a specific key.
- 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
- 
AddSocketProviderFactory.Dependencies.ProviderTypeforsIdidentifier 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
- 
AddSSLSocketProvider.DependenciesforsIdidentifier 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
- 
AddTcpDatagramSocketProvider.DependenciesforsIdidentifier 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 aSocketAddressProvider.
- 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 schemeSchemeMappingRegistryif 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 ofSocketAddressProviderwhich returnsInetSocketAddressfromAddressProvider.getNextAddress().
- AddressProviderBuilder - Interface in com.tangosol.coherence.config.builder
- 
AddressProviderBuilder interface
- AddressProviderBuilderProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat 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 forAddressProviderobjects.
- 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 theStateEntryActionfor the specified state in theModel.
- addStateExitAction(S, StateExitAction<S>) - Method in class com.tangosol.util.fsm.SimpleModel
- 
Adds/overrides theStateExitActionfor 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 givenStatementBuilderto the specified functor name.
- addSubscriptionListener(PagedTopicSubscription.Listener) - Method in interface com.tangosol.net.PagedTopicService
- 
Add a listener that will be notified when changes are made to topic subscriptions.
- 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 givenTokenTable.
- 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 givenTokenTable.
- 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 givenTokenTable.
- 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 givenTokenTable.
- addToTokenTable(TokenTable) - Method in class com.tangosol.coherence.dslquery.operator.XorOperator
- addTransition(Transition<S>) - Method in class com.tangosol.util.fsm.SimpleModel
- 
Adds the specifiedTransitionto 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.OldCache
- 
Deprecated.Adjust current size.
- adjustUnits(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Adjust the number of units for each map with the pool of units provided.
- adjustWaitTime(long, long) - Method in class com.tangosol.util.ThreadGateLite
- 
Calculate the time remaining from the total time allotted for an operation.
- adopt(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 anAggregateRequestagainst 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(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 aAggregateRequest.
- aggregate(String, String, String, Iterable<ByteString>, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aAggregateRequest.
- 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
- aggregate(UriInfo, String) - Method in class com.tangosol.coherence.rest.NamedQueryResource
- 
Perform an aggregating operation against the entries that belong to the named query.
- 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 filteredAggregateRequestrequest.
- aggregateWithFilter(CacheRequestHolder<AggregateRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute the filteredAggregateRequestrequest.
- aggregateWithKeys(AggregateRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute the key-basedAggregateRequestrequest.
- aggregateWithKeys(CacheRequestHolder<AggregateRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute the filteredAggregateRequestrequest.
- AggregatingCacheStatistics() - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- AGGREGATOR_REQUEST_REGEX - Static variable in class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
- 
Regex pattern that defines the aggregator request syntax.
- AggregatorConfig - Class in com.tangosol.coherence.rest.config
- 
The AggregatorConfig class encapsulates information related to a Coherence REST EntryAggregator configuration.
- AggregatorConfig(String, Class) - Constructor for class com.tangosol.coherence.rest.config.AggregatorConfig
- 
Construct a AggregatorConfig.
- AggregatorFactory<K,V,R> - Interface in com.tangosol.coherence.rest.util.aggregator
- 
A factory for aggregators.
- AggregatorRegistry - Class in com.tangosol.coherence.rest.util.aggregator
- 
A registry forAggregatorFactoryinstances.
- 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
- 
Returnstrueif the all the registeredhealth checksare live.
- allHealthChecksReady() - Method in interface com.tangosol.net.management.Registry
- 
Returnstrueif the all the registeredhealth checksare ready.
- allHealthChecksSafe() - Method in interface com.tangosol.net.management.Registry
- 
Returnstrueif the all the registeredhealth checksare safe.
- allHealthChecksStarted() - Method in interface com.tangosol.net.management.Registry
- 
Returnstrueif the all the registeredhealth checksare 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 aMapof 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.
- allOrNothing(MapIndex, NavigableMap<E, Set<?>>, Set) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Determine if the filter will match all or none of the entries in the index.
- allOrNothing(MapIndex, NavigableMap<E, Set<?>>, Set) - Method in class com.tangosol.util.filter.GreaterFilter
- 
Determine if the filter will match all or none of the entries in the index.
- allOrNothing(MapIndex, NavigableMap<E, Set<?>>, Set) - Method in class com.tangosol.util.filter.LessFilter
- 
Determine if the filter will match all or none of the entries in the index.
- ALLOW_INCONSISTENCIES - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
- allowEndangered() - Method in class com.tangosol.coherence.config.xml.processor.HealthProcessor.XMLHealthCheckDependencies
- AlreadyCommitted - 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
- 
ARefreshPolicythat always returnstrue.
- ALWAYS - 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 Type in com.oracle.coherence.cdi
- 
AFilterBindingannotation 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 theAlwaysFilterannotation.
- 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 composedBiConsumerthat performs, in sequence, this operation followed by theafteroperation.
- andThen(Remote.Consumer<? super T>) - Method in interface com.tangosol.util.function.Remote.Consumer
- 
Returns a composedConsumerthat performs, in sequence, this operation followed by theafteroperation.
- andThen(Remote.DoubleConsumer) - Method in interface com.tangosol.util.function.Remote.DoubleConsumer
- 
Returns a composedDoubleConsumerthat performs, in sequence, this operation followed by theafteroperation.
- 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 theafteroperator 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 theafterfunction 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 theafterfunction to the result.
- andThen(Remote.IntConsumer) - Method in interface com.tangosol.util.function.Remote.IntConsumer
- 
Returns a composedIntConsumerthat performs, in sequence, this operation followed by theafteroperation.
- 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 theafteroperator to the result.
- andThen(Remote.LongConsumer) - Method in interface com.tangosol.util.function.Remote.LongConsumer
- 
Returns a composedLongConsumerthat performs, in sequence, this operation followed by theafteroperation.
- 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 theafteroperator to the result.
- andThen(MapEventTransformer<K, U, T>) - Method in interface com.tangosol.util.MapEventTransformer
- 
Returns a composedMapEventTransformerthat performs, in sequence, this transformation followed by theaftertransformation.
- 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 theafterextractor to the result.
- AnnotatedMapListener<K,V> - Class in com.oracle.coherence.cdi.events
- 
MapListenerimplementation that dispatchesMapEvents 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 ofFilterinstances.
- AnnotatedMapListener.MapEventObserver<K,V> - Interface in com.oracle.coherence.cdi.events
- AnnotatedMapListener.MapEventTransformerProducer - Interface in com.oracle.coherence.cdi.events
- 
A producer ofMapEventTransformerinstances.
- AnnotatedMapListenerManager - Class in com.oracle.coherence.cdi.events
- 
Registers discovered CDI observer-basedMapListeners 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 aStandardEmitterMBeanthat uses theDescriptionandNotificationannotations 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 silentNotificationEmitterimplementation for all NotificationEmitter methods exceptgetNotificationInfo().
- AnnotatedStandardMBean - Class in com.tangosol.net.management
- 
AnnotatedStandardMBean is an extension of aStandardMBeanthat uses theDescriptionannotation for describing the attributes, operations and the bean on the designated MBean interface.
- AnnotatedStandardMBean(T, Class<T>) - Constructor for class com.tangosol.net.management.AnnotatedStandardMBean
- 
Make a DynamicMBean out of the MBean implementation, using the specified mbeanInterface class.
- AnnotatedStandardMBean(T, Class<T>, boolean) - Constructor for class com.tangosol.net.management.AnnotatedStandardMBean
- 
Make a DynamicMBean out of the MBean implementation, using the specified mbeanInterface class.
- AnnotationDrivenModel<S extends Enum<S>> - Class in com.tangosol.util.fsm
- 
AnAnnotationDrivenModelis aModelcreated through extracting information defined byTransitionsannotation.
- AnnotationDrivenModel(Class<S>, Object) - Constructor for class com.tangosol.util.fsm.AnnotationDrivenModel
- 
Constructs anAnnotationDrivenModelbased on the specified annotated class.
- AnnotationInstance - Class in com.oracle.coherence.cdi
- 
A representation of anAnnotationthat can be used for equality tests where methods in theAnnotationannotated withNonbindingare ignored.
- AnnotationLiteral<T extends Annotation> - 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 newAnyEvent.
- 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 type 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.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.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
- 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(MapIndex, Set, NavigableMap<E, Set<?>>) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Called by theBetweenFilter.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 aStatementBuilderthat 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 Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any ARRIVED event.
- ARRIVED - com.tangosol.net.events.partition.TransferEvent.Type
- 
ThisTransferEventis dispatched when a set ofentrieshave been transferred to thelocal memberor restored from backup.
- Arrived.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theArrivedannotation.
- as(Class<C>) - Method in interface com.tangosol.net.NamedCache
- 
Request a specific type of reference to aNamedCachethat thisNamedCachemay additionally implement or support.
- as(Class<T>) - Method in class com.tangosol.config.expression.Value
- 
Attempts to return the value of theValuecoerced 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 aBinaryEntry.
- 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 aDoubleStreamconsisting of the elements of this stream, converted todouble.
- asDoubleStream() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns aDoubleStreamconsisting 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 aLongStreamconsisting 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 in com.tangosol.util
- 
An AssertionException is thrown when an assertion fails.
- AssertionException() - Constructor for exception com.tangosol.util.AssertionException
- 
Constructs a AssertionException with no detail message.
- AssertionException(String) - Constructor for exception com.tangosol.util.AssertionException
- 
Constructs a AssertionException with the specified detail message.
- 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
- 
ThrowsIllegalStateExceptionif this factory has been disposed via invocation ofExtensibleConfigurableCacheFactory.dispose().
- assertNotDisposed() - Method in class com.tangosol.net.SimpleServiceMonitor
- 
ThrowsIllegalStateExceptionif 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 theCacheMappingthat defines the cache.
- assertTypeSafety(String, CacheMapping, boolean) - Method in interface com.tangosol.net.cache.TypeAssertion
- 
Asserts the type compatibility of a named cache given theCacheMappingthat 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 theCacheMappingthat defines the cache.
- assertTypeSafety(String, TopicMapping) - Method in interface com.tangosol.net.ValueTypeAssertion
- 
Asserts the type compatibility of a topic given theTopicMappingthat defines the topic.
- assertTypeSafety(String, TopicMapping) - Method in class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
- 
Asserts the type compatibility of a topic given theTopicMappingthat 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 Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any ASSIGNED event.
- ASSIGNED - com.tangosol.net.events.partition.TransferEvent.Type
- 
ThisTransferEventis dispatched when a partition has been assigned to thelocal member.
- Assigned.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theAssignedannotation.
- 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 theAssociated.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 theAssociator.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.ContinuousQueryCache
- 
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
- 
Abooleanvalue that may be updated atomically.
- AsyncAtomicInteger - Interface in com.oracle.coherence.concurrent.atomic
- 
Aintvalue that may be updated atomically.
- AsyncAtomicLong - Interface in com.oracle.coherence.concurrent.atomic
- 
Alongvalue that may be updated atomically.
- AsyncAtomicMarkableReference<V> - Interface in com.oracle.coherence.concurrent.atomic
- 
AnAtomicMarkableReferencemaintains 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
- 
AnAtomicStampedReferencemaintains an object reference along with an integer "stamp", that can be updated atomically.
- AsyncBackupProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor 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(InvocableMap.StreamingAggregator<K, V, P, R>, int, Executor) - Static method in class com.tangosol.util.Aggregators
- 
Return an AsynchronousAggregator for a given streaming aggregator.
- asynchronous(InvocableMap.StreamingAggregator<K, V, P, R>, Executor) - 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 theFutureinterface.
- AsynchronousAgent(int) - Constructor for class com.tangosol.util.AsynchronousAgent
- 
Construct the agent.
- AsynchronousAgent(int, Executor) - Constructor for class com.tangosol.util.AsynchronousAgent
- 
Construct the agent.
- AsynchronousAggregator<K,V,P,R> - Class in com.tangosol.util.aggregator
- 
A markerEntryAggregatorwrapper 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.
- AsynchronousAggregator(InvocableMap.StreamingAggregator<K, V, P, R>, int, Executor) - Constructor for class com.tangosol.util.aggregator.AsynchronousAggregator
- 
Construct an AsynchronousAggregator for a given streaming aggregator.
- AsynchronousAggregator(InvocableMap.StreamingAggregator<K, V, P, R>, Executor) - Constructor for class com.tangosol.util.aggregator.AsynchronousAggregator
- 
Construct an AsynchronousAggregator for a given streaming aggregator.
- AsynchronousProcessor<K,V,R> - Class in com.tangosol.util.processor
- 
AnEntryProcessorwrapper 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.
- AsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int, Executor) - Constructor for class com.tangosol.util.processor.AsynchronousProcessor
- 
Construct an AsynchronousProcessor for a given processor.
- AsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, Executor) - 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 ofAsyncAtomicBooleaninterface, that simply wrapsjava.util.concurrent.atomic.AtomicBooleaninstance and returns an already completed future from each method.
- AsyncLocalAtomicBoolean(AtomicBoolean) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
- 
ConstructLocalAtomicBooleaninstance.
- AsyncLocalAtomicInteger - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAsyncAtomicIntegerinterface, that simply wrapsjava.util.concurrent.atomic.AtomicIntegerinstance and returns an already completed future from each method.
- AsyncLocalAtomicInteger(AtomicInteger) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- 
ConstructLocalAtomicIntegerinstance.
- AsyncLocalAtomicLong - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAsyncAtomicLonginterface, that simply wrapsjava.util.concurrent.atomic.AtomicLonginstance and returns an already completed future from each method.
- AsyncLocalAtomicLong(AtomicLong) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- 
ConstructLocalAtomicLonginstance.
- AsyncLocalAtomicMarkableReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAsyncAtomicMarkableReferenceinterface, that simply wrapsjava.util.concurrent.atomic.AtomicMarkableReferenceinstance and returns an already completed future from each method.
- AsyncLocalAtomicMarkableReference(AtomicMarkableReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
- 
ConstructAsyncLocalAtomicMarkableReferenceinstance.
- AsyncLocalAtomicReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAsyncAtomicReferenceinterface, that simply wrapsjava.util.concurrent.atomic.AtomicReferenceinstance and returns an already completed future from each method.
- AsyncLocalAtomicReference(AtomicReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- 
ConstructLocalAtomicReference<V>instance.
- AsyncLocalAtomicStampedReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAsyncAtomicStampedReferenceinterface, that simply wrapsjava.util.concurrent.atomic.AtomicStampedReferenceinstance and returns an already completed future from each method.
- AsyncLocalAtomicStampedReference(AtomicStampedReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
- 
ConstructAsyncLocalAtomicStampedReferenceinstance.
- AsyncNamedCache<K,V> - Interface in com.tangosol.net
- 
AsynchronousNamedCache.
- AsyncNamedMap<K,V> - Interface in com.tangosol.net
- 
AsynchronousNamedMap.
- AsyncNamedMap.Complete - Class in com.tangosol.net
- 
AnAsyncNamedMap.Optionto use to specify theExecutorto use to complete theCompletableFuturereturned from async methods.
- AsyncNamedMap.Option - Interface in com.tangosol.net
- 
An immutable option for creating and configuringAsyncNamedMaps.
- 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 ofAsyncAtomicBoolean, backed by a CoherenceNamedMapentry.
- AsyncRemoteAtomicBoolean(AsyncNamedMap<String, AtomicBoolean>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- 
Constructs a newAsyncRemoteAtomicBoolean.
- AsyncRemoteAtomicInteger - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAsyncAtomicInteger, backed by a CoherenceNamedMapentry.
- AsyncRemoteAtomicInteger(AsyncNamedMap<String, AtomicInteger>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- 
Constructs a newAsyncRemoteAtomicInteger.
- AsyncRemoteAtomicLong - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAsyncAtomicLong, backed by a CoherenceNamedMapentry.
- AsyncRemoteAtomicLong(AsyncNamedMap<String, AtomicLong>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- 
Constructs a newAsyncRemoteAtomicLong.
- AsyncRemoteAtomicMarkableReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAsyncAtomicMarkableReference, backed by a CoherenceNamedMapentry.
- AsyncRemoteAtomicMarkableReference(AsyncNamedMap<String, AtomicMarkableReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- 
Constructs a newAsyncRemoteAtomicMarkableReference.
- AsyncRemoteAtomicReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAsyncAtomicReference, backed by a CoherenceNamedMapentry.
- AsyncRemoteAtomicReference(AsyncNamedMap<String, AtomicReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- 
Constructs a newAsyncRemoteAtomicReference.
- AsyncRemoteAtomicStampedReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAsyncAtomicStampedReference, backed by a CoherenceNamedMapentry.
- AsyncRemoteAtomicStampedReference(AsyncNamedMap<String, AtomicStampedReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- 
Constructs a newAsyncRemoteAtomicStampedReference.
- 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
- 
Abooleanvalue 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
- 
Anintvalue 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
- 
Alongvalue 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
- 
AnAtomicMarkableReferencemaintains 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 toAtomicMarkableReferenceto allow Java serialization.
- Atomics.SerializableAtomicStampedReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
Extension toAtomicStampedReferenceto allow Java serialization.
- AtomicStampedReference<V> - Interface in com.oracle.coherence.concurrent.atomic
- 
AnAtomicStampedReferencemaintains 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
- 
AnAttributeProcessoris responsible for processingXmlAttributecontent 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
- 
AnElementProcessorfor <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 anOptionalDoubledescribing 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 anOptionalDoubledescribing 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 anOptionalDoubledescribing 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 aCollectorthat 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 aCollectorthat 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 aCollectorthat 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'stimeout.
- 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'stimeout.
- 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'stimeout.
- 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 asEntryProcessorsandEntryAggregators.
- BackingMapManager - Interface in com.tangosol.net
- 
A callback interface used by CacheService implementations.
- BackingMapManagerBuilder - Interface in com.tangosol.coherence.config.builder
- 
ABackingMapManagerBuilderrealizesBackingMapManagers.
- 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
- 
TheBackingMapSchemeclass 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-schemeXmlElementto produce aBackingMapScheme.
- BackingMapSchemeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.BackingMapSchemeProcessor
- Backlog - Annotation Type 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 theBacklogannotation.
- Backlog.Type - Enum 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
- 
TheBackupMapConfiginterface 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 aStatementBuilderthat 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 type 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 extends Service> - Class in com.tangosol.coherence.config.scheme
- 
TheBaseGrpcCacheSchemeis responsible for building a remote gRPC cache service.
- BaseGrpcCacheScheme() - Constructor for class com.tangosol.coherence.config.scheme.BaseGrpcCacheScheme
- 
Constructs aBaseGrpcCacheScheme.
- BaseGrpcScheme<T extends com.tangosol.internal.net.grpc.DefaultRemoteGrpcServiceDependencies,S extends Service> - Class in com.tangosol.coherence.config.scheme
- 
TheBaseGrpcSchemeis responsible for building a remote gRPC service.
- BaseGrpcScheme(T) - Constructor for class com.tangosol.coherence.config.scheme.BaseGrpcScheme
- 
Constructs aBaseGrpcScheme.
- 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 aBaseGrpcServiceImpl.
- BaseGrpcServiceImpl.DefaultDependencies - Class in com.oracle.coherence.grpc.proxy
- 
The defaultBaseGrpcServiceImpl.Dependenciesimplementation.
- BaseGrpcServiceImpl.Dependencies - Interface in com.oracle.coherence.grpc.proxy
- 
The dependencies to configure aBaseGrpcServiceImpl.
- BaseOperator<F extends Filter> - Class in com.tangosol.coherence.dslquery.operator
- 
A base class for CohQL Operator implementations.
- BaseOperator(String, boolean, String...) - Constructor for class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
Create an instance of a BaseOperator with the specified symbol, conditional flag and aliases.
- BaseRemoteStream<T,S extends BaseStream<T,S>> - Interface in com.tangosol.util.stream
- 
An extension ofBaseStreamthat adds support for theRemotePipelineretrieval.
- 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 in com.tangosol.coherence.dsltools.base
- 
BaseTokenScannerExpression is the RuntimeException thrown by the BaseTokenScanner when expectations are not met.
- BaseTokenScannerException() - Constructor for exception com.tangosol.coherence.dsltools.base.BaseTokenScannerException
- 
Construct a new BaseTokenException.
- BaseTokenScannerException(String) - Constructor for exception 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 CoherenceBeanManagerthat theSerializerProducerwill use to discover namedSerializers 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 extends Comparable<? super E>> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value for "Between" condition.
- BetweenFilter() - Constructor for class com.tangosol.util.filter.BetweenFilter
- 
Default constructor (necessary for serialization).
- BetweenFilter(ValueExtractor<? super T, ? extends E>, E, E) - Constructor for class com.tangosol.util.filter.BetweenFilter
- 
Construct a BetweenFilter for testing "Between" condition.
- BetweenFilter(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 theBigDecimalAverageaggregator.
- BIG_DECIMAL_MAX_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theBigDecimalMaxaggregator.
- BIG_DECIMAL_MIN_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theBigDecimalMinaggregator.
- BIG_DECIMAL_SUM_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theBigDecimalSumaggregator.
- 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 aBigDecimalvalue.
- 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 aBigDecimalvalue.
- 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 aBigDecimalvalue.
- 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 aBigDecimalvalue.
- 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_ERASE_PENDING - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Binary representation of a decorated null for write-behind remove.
- 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
- 
ANamedTopic.ElementCalculatorthat 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 theCacheStore, but operates onBinaryEntryobjects.
- 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 betweenBinaryinstances 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 aBinaryand 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
- 
ABinaryStoreManagerBuilderis responsible for realizingBinaryStoreManagers.
- BinaryStoreManagerBuilderCustomization - Interface in com.tangosol.coherence.config.builder.storemanager
- 
ABinaryStoreManagerBuilderCustomizationclass is one that allows or potentially requires, aBinaryStoreManagerBuilderfor 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 givenObservableSplittingBackingMapinstance.
- 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 - 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 aStreamconsisting of the elements of this stream, boxed toDouble.
- boxed() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns aStreamconsisting of the elements of this stream, each boxed to anInteger.
- boxed() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns aStreamconsisting 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
- 
AnElementProcessorfor 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 aSerializerProducer.
- build() - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.Listener.Builder
- 
BuildAbstractRepositoryBase.Listenerinstance.
- build() - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
- 
Build comparator.
- build() - Method in class com.tangosol.net.Coherence.Builder
- 
Build aCoherenceinstance.
- build() - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Build aCoherenceConfigurationfrom 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 aviewof theNamedMapprovided to this builder.
- build() - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Build theSessionConfiguration.
- build() - Method in class com.tangosol.net.ViewBuilder
- 
Construct aviewof theNamedCacheprovided to this builder.
- build(boolean) - Method in class com.tangosol.net.Coherence.Builder
- build(ClassLoader) - Method in class com.tangosol.net.Coherence.Builder
- 
Build aCoherenceinstance.
- build(ClassLoader, boolean) - Method in class com.tangosol.net.Coherence.Builder
- builder() - Static method in class com.oracle.coherence.cdi.SerializerProducer
- 
Create an instance of aSerializerProducer.Builder.
- builder() - Static method in interface com.oracle.coherence.repository.AbstractRepositoryBase.Listener
- 
Create newAbstractRepositoryBase.Listener.Builderinstance.
- builder() - Static method in interface com.tangosol.net.CoherenceConfiguration
- 
Returns aCoherenceConfiguration.Builderthat can configure and build instances ofCoherenceConfiguration.
- builder() - Static method in interface com.tangosol.net.SessionConfiguration
- 
Create aSessionConfigurationbuilder.
- 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 aCoherence.Builderinstance that can build aCoherenceinstance using the specifiedCoherenceConfiguration.
- builder(CoherenceConfiguration, Coherence.Mode) - Static method in class com.tangosol.net.Coherence
- 
Returns aCoherence.Builderinstance that can build aCoherenceinstance using the specifiedCoherenceConfiguration.
- Builder<T> - Interface in com.tangosol.util
- 
ABuilderprovides 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 implementsBuilderCustomizationis 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 withBuilders.
- 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 aConfigurableCacheFactoryfor the specified cache config URI andClassLoader.
- buildFactory(String, ClassLoader, ParameterResolver) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Construct and configure aConfigurableCacheFactoryfor 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
- 
TheBundleManagerclass is responsible for configuring caches to use bundling.
- BundleManager() - Constructor for class com.tangosol.coherence.config.scheme.BundleManager
- BundleManager.BundleConfig - Class in com.tangosol.coherence.config.scheme
- 
The BundleConfig class contains the configuration for a Bundle.
- BundlingNamedCache - Class in com.tangosol.net.cache
- 
Bundling NamedCache implementation.
- BundlingNamedCache(NamedCache) - Constructor for class com.tangosol.net.cache.BundlingNamedCache
- 
Construct a BundlingNamedCache based on the specified NamedCache.
- BundlingNamedCache.GetBundler - Class in com.tangosol.net.cache
- BundlingNamedCache.PutBundler - Class in com.tangosol.net.cache
- BundlingNamedCache.RemoveBundler - Class in com.tangosol.net.cache
- BundlingScheme - Interface in com.tangosol.coherence.config.scheme
- 
BundlingSchemes define how the bundling (batching) of operations will occur and theBundleManagerused 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
- 
Bytesis a specializedMemorySizewhose 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 aBytesrepresenting aMemorySizemeasured in bytes.
- Bytes(MemorySize) - Constructor for class com.tangosol.coherence.config.unit.Bytes
- 
Constructs aBytesbased on anotherMemorySize.
- Bytes(String) - Constructor for class com.tangosol.coherence.config.unit.Bytes
- 
Constructs aBytesrepresenting aMemorySizemeasured 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 thisAsyncAtomicIntegeras abyteafter a narrowing primitive conversion.
- byteValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Returns the value of the specified number as abyte.
- 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 thisAtomicIntegeras abyteafter a narrowing primitive conversion.
- byteValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Returns the current value of thisAtomicLongas abyteafter 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 Type 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 theCacheAddannotation.
- 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 theCacheAddInterceptor.
- 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
- 
ACacheConfigis 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 aCacheConfig.
- CacheConfigNamespaceHandler - Class in com.tangosol.coherence.config.xml
- 
TheCacheConfigNamespaceHandleris 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 theCacheConfigNamespaceHandler.
- CacheConfigOverrideProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
Implementation ofOverrideProcessorthat 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
- 
ACacheDefaultsPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat 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 aCacheDefaultsPreprocessorwith 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 in com.tangosol.net.cache
- 
TransformationState describes how a CacheEvent has been or should betransformed.
- CacheEventFilter<K,V> - Class in com.tangosol.util.filter
- 
An extension of theMapEventFilterwhich 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 toQueryMap.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 Type 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 theCacheGetannotation.
- 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 theCacheGetInterceptor
- CacheInfo(String, String, Map) - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.Construct a CacheInfo object.
- CacheKey - Annotation Type 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 in com.tangosol.net.events.partition.cache
- 
The emitted event types for aCacheLifecycleEvent.
- CacheLifecycleEventDispatcher - Interface in com.tangosol.net.events.partition.cache
- 
A CacheLifecycleEventDispatcher raisesCacheLifecycleEvents.
- CacheLifecycleEventHandler(EventObserverSupport.EventObserver<CacheLifecycleEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.CacheLifecycleEventHandler
- CacheLifecycleEvents - Annotation Type in com.tangosol.net.events.annotation
- 
CacheLifecycleEvents is an annotation that should be applied toEventInterceptorimplementations that want to receiveCacheLifecycleEvents.
- 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
- 
ACacheMappingcaptures configuration information for a pattern-match-based mapping from a proposedNamedCachename to a caching scheme.
- CacheMapping(String, String) - Constructor for class com.tangosol.coherence.config.CacheMapping
- 
Construct aCacheMappingfor caches that will use rawtypes by default.
- CacheMappingProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnCacheMappingProcessoris responsible for processing <cache-mapping>XmlElements 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, useResourceMappingRegistry.
- CacheMappingRegistry() - Constructor for class com.tangosol.coherence.config.CacheMappingRegistry
- 
Deprecated.Construct aCacheMappingRegistry.
- CacheMappingRegistry(ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.CacheMappingRegistry
- 
Deprecated.CacheMappingRegistry delegates toResourceMappingRegistry.
- CacheName - Annotation Type 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 theCacheNameannotation.
- 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 withCacheValueinto cache, invokes target method and returns result of the invocation.
- CachePut - Annotation Type 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 theCachePutannotation.
- 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 theCachePutInterceptor
- CacheRefExpression(Expression<?>, ClassLoader, CacheMappingRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CacheRefExpression
- 
Deprecated.As of Coherence 14.1.1, useCacheRefExpression(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 Type 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 theCacheRemoveannotation.
- 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 theCacheRemoveInterceptor
- CacheRequestHolder<Req,Res> - Class in com.oracle.coherence.grpc
- 
A class that holds a gRPC request, an associatedNamedCacheandBinaryconverters.
- CacheRequestHolder(Req, AsyncNamedCache<Binary, Binary>, Supplier<NamedCache<?, ?>>, String, Serializer, Executor) - Constructor for class com.oracle.coherence.grpc.CacheRequestHolder
- 
Create aCacheRequestHolder.
- CacheResource - Class in com.tangosol.coherence.rest
- 
RESTful wrapper around a CoherenceNamedCache.
- 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
- 
AnElementProcessorthat will parse cache-service-proxy configuration element tp produce aDefaultCacheServiceProxyDependenciesobject.
- 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
- 
ConstructsPartitionedJCacheStatistics.CacheStatisticsExtractorto 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
- 
TheCacheStoreSchemeclass 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 Type in com.oracle.coherence.cdi
- 
Marks a parameter as the cache value.
- cacheValues() - Method in annotation type com.oracle.coherence.cdi.View
- 
A flag that istrueto cache both the keys and values of the materialized view locally, orfalseto only cache the keys (the default value istrue).
- cacheValues() - Method in class com.oracle.coherence.cdi.View.Literal
- 
Obtain the flag that istrueto cache both the keys and values of the materialized view locally, orfalseto 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
- 
TheCachingSchemeis a multi-builder for cache-based infrastructure.
- CachingSchemeMappingProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnCachingSchemeMappingProcessoris responsible for processing <caching-scheme-mapping>XmlElements to update theResourceMappingRegistrywithCacheMappings.
- CachingSchemeMappingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.CachingSchemeMappingProcessor
- CachingSchemesProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
ACachingSchemesProcessoris anElementProcessorfor 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
- 
AConfigurableCacheMapbacked by Caffeine.
- CaffeineCache() - Constructor for class com.oracle.coherence.caffeine.CaffeineCache
- 
CreateCaffeineCacheinstance.
- CaffeineScheme - Class in com.tangosol.coherence.config.scheme
- 
TheCaffeineSchemeclass 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.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.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.
- 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.
- 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.OldCache.Entry
- 
Deprecated.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.OldCache.InternalUnitCalculator
- 
Deprecated.Calculate a cache cost for the specified cache entry key and value.
- calculateUnits(Object, Object) - Method in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
Calculate a cache cost for the specified cache entry key and value.
- calculateVersion(Object) - Method in class com.tangosol.run.jca.SimpleValidator
- 
Generate the Comparable version indicator for a given resource value.
- calculateWaitTime(long) - Method in class com.tangosol.net.partition.FailoverAccessPolicy
- 
Return the amount of time that a request should be delayed before being allowed to proceed.
- calcUnitFairShare(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Return the fair share of units for each child maps.
- calcUTF(String) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Figure out how many bytes it will take to hold the passed String.
- calibrate() - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Determine the grow and shrink thresholds based on the current capacity.
- CALL_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The AST node name for a Method Call Node.
- callable(Remote.Callable<V>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable Callable.
- cancel() - 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 iffsMacrocontains 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
- 
Returnstrueif theSocketProviderFactorycan 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 betweenServiceLoaderand CDI, by registering itself as a service and using CDI to discover available CDI-managedConfigSources.
- CdiConfigSourceProvider() - Constructor for class com.oracle.coherence.mp.config.CdiConfigSourceProvider
- CdiEventObserver<E extends Event> - Class in com.oracle.coherence.cdi
- 
An observer of events that wraps a CDIProcessObserverMethod.
- CdiEventObserver(ObserverMethod<E>) - Constructor for class com.oracle.coherence.cdi.CdiEventObserver
- 
Create aCdiEventObserverfrom anObserverMethod
- CdiEventObserver(ProcessObserverMethod<E, ?>) - Constructor for class com.oracle.coherence.cdi.CdiEventObserver
- 
Create aCdiEventObserverfrom an observed method event.
- CdiInjector - Class in com.oracle.coherence.cdi
- 
An implementation ofInjectorthat 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 ofInterceptorMetadataResolverthat 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 aAnnotatedMapListener.MapEventObserverthat wraps a CDIObserverMethodthat observesMapEvent.
- CdiMapEventObserver(ObserverMethod<MapEvent<K, V>>) - Constructor for class com.oracle.coherence.cdi.CdiMapEventObserver
- 
Create aCdiMapEventObserverfrom anObserverMethod
- CdiMapEventObserver(ProcessObserverMethod<MapEvent<K, V>, ?>) - Constructor for class com.oracle.coherence.cdi.CdiMapEventObserver
- 
Create aCdiMapEventObserverfrom an observed method event.
- CdiMapListenerManager - Class in com.oracle.coherence.cdi
- 
Registers discovered CDI observer-basedMapListeners 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 betweenServiceLoaderand CDI, by registering itself as a service and delegating to all discovered CDI beans that implementMetricsRegistryAdapterinterface.
- CdiMetricsRegistryAdapter() - Constructor for class com.oracle.coherence.mp.metrics.CdiMetricsRegistryAdapter
- CdiNamespaceHandler - Class in com.oracle.coherence.cdi.server
- 
Custom namespace handler forcdinamespace.
- CdiNamespaceHandler() - Constructor for class com.oracle.coherence.cdi.server.CdiNamespaceHandler
- 
ConstructCdiNamespaceHandlerinstance.
- 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 ofcertificates.
- 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 Type in com.oracle.coherence.cdi
- 
AExtractorBindingannotation 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 Type in com.oracle.coherence.cdi
- 
A holder for the repeatableChainedExtractorannotation.
- ChainedExtractor.Extractors.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theChainedExtractor.Extractorsannotation.
- ChainedExtractor.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theChainedExtractorannotation.
- ChainedExtractorBuilder - Class in com.tangosol.coherence.dslquery
- 
AnExtractorBuilderimplementation that delegates buildingValueExtractors 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 ofExtractorBuilders to realize instances ofValueExtractors.
- 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
- 
AValueExtractorthat extracts aFragmentfrom 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
- 
ConstructChainedFragmentExtractorinstance.
- 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
- 
AChainedParameterResolveris aParameterResolverthat consults zero or more providedParameterResolvers 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 aChainedParameterResolverbased on the specifiedParameterResolvers.
- ChainedResourceResolver - Class in com.tangosol.util
- 
AChainedResourceResolveris aResourceResolverthat chains together one or more otherResourceResolvers, 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 aChainedResourceResolver.
- 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 givenChangeRecordwhile processing theFederatedChangeEvent.
- changeState(int) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Change the state of theContinuousQueryCache.
- changeState(int, Daemon.DaemonWorker) - Method in class com.tangosol.util.Daemon
- 
Change the state of the daemon.
- ChangeTracker(ReadBuffer.BufferInput, ReadBuffer.BufferInput) - Constructor for class com.tangosol.io.pof.PofDeltaCompressor.ChangeTracker
- 
Construct a ChangeTracker that will produce a delta between the two passed streams.
- CHAR_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
- 
An empty array of chars.
- CHAR_BUF_MASK - Static variable in class com.tangosol.io.AbstractWriteBuffer
- 
Bitmask used against a raw offset to determine the offset within the temporary character buffer.
- CHAR_BUF_SIZE - Static variable in class com.tangosol.io.AbstractWriteBuffer
- 
Size of the temporary character buffer.
- characteristics() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- characteristics() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- characteristics() - Method in class com.tangosol.util.aggregator.BigDecimalAverage
- characteristics() - Method in class com.tangosol.util.aggregator.BigDecimalMax
- characteristics() - Method in class com.tangosol.util.aggregator.BigDecimalMin
- characteristics() - Method in class com.tangosol.util.aggregator.BigDecimalSum
- characteristics() - Method in class com.tangosol.util.aggregator.ComparableMax
- characteristics() - Method in class com.tangosol.util.aggregator.ComparableMin
- characteristics() - Method in class com.tangosol.util.aggregator.CompositeAggregator
- characteristics() - Method in class com.tangosol.util.aggregator.Count
- characteristics() - Method in class com.tangosol.util.aggregator.DistinctValues
- characteristics() - Method in class com.tangosol.util.aggregator.DoubleAverage
- characteristics() - Method in class com.tangosol.util.aggregator.DoubleMax
- characteristics() - Method in class com.tangosol.util.aggregator.DoubleMin
- characteristics() - Method in class com.tangosol.util.aggregator.DoubleSum
- characteristics() - Method in class com.tangosol.util.aggregator.GroupAggregator
- characteristics() - Method in class com.tangosol.util.aggregator.LongMax
- characteristics() - Method in class com.tangosol.util.aggregator.LongMin
- characteristics() - Method in class com.tangosol.util.aggregator.LongSum
- characteristics() - Method in class com.tangosol.util.aggregator.PriorityAggregator
- characteristics() - Method in class com.tangosol.util.aggregator.QueryRecorder
- characteristics() - Method in class com.tangosol.util.aggregator.ReducerAggregator
- characteristics() - Method in class com.tangosol.util.aggregator.ScriptAggregator
- characteristics() - Method in class com.tangosol.util.aggregator.TopNAggregator
- characteristics() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A bit mask representing the set of characteristics of this aggregator.
- characteristics() - Method in 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 thisStreamer.
- 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.OldCache
- 
Deprecated.as of Coherence 3.5, useOldCache.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() - Method in annotation type 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
- 
TheClassSchemeclass is responsible for building customCachingSchemes and customCacheStoreSchemes.
- ClassScheme() - Constructor for class com.tangosol.coherence.config.scheme.ClassScheme
- 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 theWriteBuffer.length()method to zero.
- clear() - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Set the length of the buffer as indicated by theWriteBuffer.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 theWriteBuffer.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
- 
Removes all mappings from this map.
- clear() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Removes all mappings from this map.
- clear() - Method in class com.tangosol.net.cache.OverflowMap
- 
Clear all key/value mappings.
- clear() - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Remove everything from the Map.
- clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- 
Removes all of the elements from this set of Keys by clearing the underlying Map.
- clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- 
Removes all of the elements from this set of Keys by clearing the underlying Map.
- clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Remove all keys from the queue.
- clear() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ValuesCollection
- 
Removes all of the elements from this Collection of values by clearing the underlying Map.
- clear() - Method in class com.tangosol.net.cache.SerializationCache
- 
Clear all key/value mappings.
- clear() - Method in class com.tangosol.net.cache.SerializationMap
- 
Clear all key/value mappings.
- clear() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Clear all key/value mappings.
- clear() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Clear all key/value mappings.
- clear() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Clear all key/value mappings.
- clear() - Method in interface com.tangosol.net.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 aClearRequest.
- 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 defaultCoherenceclient instance, creating it if it does not already exist.
- client(Coherence.Mode) - Static method in class com.tangosol.net.Coherence
- 
Return the defaultCoherenceclient instance, creating it if it does not already exist.
- client(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
- 
Create a clientCoherenceinstance from the specifiedCoherenceConfiguration.
- Client - com.tangosol.net.Coherence.Mode
- 
TheCoherenceinstance 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 aCoherence.Builderinstance that can build aCoherenceinstance using the specifiedCoherenceConfiguration.
- clientBuilder(CoherenceConfiguration, Coherence.Mode) - Static method in class com.tangosol.net.Coherence
- 
Returns aCoherence.Builderinstance that can build aCoherenceinstance using the specifiedCoherenceConfiguration.
- clientDirect() - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set the session'scoherence.clientparameter to "direct".
- clientFixed() - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set the session'scoherence.clientparameter to "remote-fixed".
- ClientFixed - com.tangosol.net.Coherence.Mode
- 
TheCoherenceinstance 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'scoherence.clientparameter to "remote".
- clone() - Method in interface com.oracle.coherence.common.base.Cloneable
- 
Create and return a copy of this object as described by theObject.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 theCloneablemethod-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 theObject.clone()contract.
- close() - Method in interface com.oracle.coherence.common.base.Disposable
- 
Default implementation invokesDisposable.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 thisCoherenceinstance.
- 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 theSessioninstances provided by thisSessionProvider.
- close() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- close() - Method in interface com.tangosol.net.topic.Publisher
- 
Close thisPublisher.
- 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 allCoherenceinstances.
- 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 inboundchannel.
- 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 aCluster.
- 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 in com.tangosol.net
- 
Deprecated.As of release 3.4, replaced byPortableException
- ClusterException() - Constructor for exception com.tangosol.net.ClusterException
- 
Deprecated.Constructs a ClusterException with no detail message.
- ClusterException(String) - Constructor for exception com.tangosol.net.ClusterException
- 
Deprecated.Constructs a ClusterException with the specified detail message.
- ClusterException(String, Throwable) - Constructor for exception com.tangosol.net.ClusterException
- 
Deprecated.Construct a ClusterException from a Throwable object and an additional description.
- ClusterException(Throwable) - Constructor for exception com.tangosol.net.ClusterException
- 
Deprecated.Construct a ClusterException from a Throwable object.
- clusterMember() - Static method in class com.tangosol.net.Coherence
- 
Return the defaultCoherencecluster member instance, creating it if it does not already exist.
- clusterMember(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
- 
Create aCoherenceinstance from the specifiedCoherenceConfiguration.
- ClusterMember - com.tangosol.net.Coherence.Mode
- 
TheCoherenceinstance should run as a cluster member client.
- clusterMemberBuilder(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
- 
Returns aCoherence.Builderinstance that can build aCoherenceinstance using the specifiedCoherenceConfiguration.
- ClusterPermission - Class in com.tangosol.net
- 
This class represents access to a clustered resource such as a Service or NamedCache.
- ClusterPermission(String, String) - Constructor for class com.tangosol.net.ClusterPermission
- 
Construct a ClusterPermission object.
- ClusterPermission(String, String, String) - Constructor for class com.tangosol.net.ClusterPermission
- 
Construct a ClusterPermission object.
- ClusterProducer - Class in com.oracle.coherence.cdi.server
- 
A CDI producer that produces instances of the singleton CoherenceCluster.
- ClusterProducer() - Constructor for class com.oracle.coherence.cdi.server.ClusterProducer
- ClusterQuorumPolicy(Map<String, Integer>) - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Construct a ClusterQuorumPolicy with the specified quorum map.
- ClusterQuorumPolicyBuilder - Class in com.tangosol.coherence.config.builder
- 
Defer cache configuration validation of aClusterQuorumPolicyBuilderuntil realized.
- ClusterQuorumPolicyBuilder(Map<String, Integer>, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ClusterQuorumPolicyBuilder
- 
ConstructsClusterQuorumPolicyBuilderfrommapQuorum
- CMP_AUTO - Static variable in class com.tangosol.util.comparator.EntryComparator
- 
Indicates that this EntryComparator should choose the comparison style based on the underying comparator type.
- CMP_ENTRY - Static variable in class com.tangosol.util.comparator.EntryComparator
- 
Indicates that entries that implementQueryMap.Entryinterface will be compared using thecompareEntries()method.
- CMP_KEY - Static variable in class com.tangosol.util.comparator.EntryComparator
- 
Indicates that this EntryComparator should compare the entries' keys.
- CMP_VALUE - Static variable in class com.tangosol.util.comparator.EntryComparator
- 
Indicates that this EntryComparator should compare the entries' values.
- CoalescedEvent(Event<S>) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
- 
Constructs aNonBlockingFiniteStateMachine.CoalescedEventof the specifiedEventtype usingNonBlockingFiniteStateMachine.CoalescedEvent.Process.FIRST.
- CoalescedEvent(Event<S>, NonBlockingFiniteStateMachine.CoalescedEvent.Process) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
- 
Constructs aNonBlockingFiniteStateMachine.CoalescedEventof the specifiedEventtype.
- CoalescedEvent(Event<S>, NonBlockingFiniteStateMachine.CoalescedEvent.Process, Object) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
- 
Constructs aNonBlockingFiniteStateMachine.CoalescedEventwith the specified discriminator andEvent.
- codec() - Method in annotation type com.tangosol.io.pof.annotation.PortableProperty
- 
Deprecated.ACodecto use to override the default behavior in serializing and deserializing a property.
- Codec - Interface in com.tangosol.io.pof.reflect
- 
A Codec provides an interception point for any specific code that needs to be executed pre or post (de)serialization.
- Codecs - Class in com.tangosol.io.pof.reflect
- 
Codecs is a container for accessing defaultCodecimplementations.
- Codecs() - Constructor for class com.tangosol.io.pof.reflect.Codecs
- Codecs.AbstractCodec - Class in com.tangosol.io.pof.reflect
- 
AbstractCodecimplementations that encodes objects by simply delegating toPofWriter.writeObject(int, Object).
- Codecs.ArrayCodec - Class in com.tangosol.io.pof.reflect
- 
Implementation ofCodecthat delegates toPofReader.readObjectArray(int, Object[])andPofWriter.writeObjectArray(int, Object[])to deserialize and serialize an object.
- Codecs.CollectionCodec - Class in com.tangosol.io.pof.reflect
- 
Implementation ofCodecthat delegates toPofReader.readCollection(int, Collection)andPofWriter.writeCollection(int, Collection)to deserialize and serialize an object.
- Codecs.DefaultCodec - Class in com.tangosol.io.pof.reflect
- 
Implementation ofCodecthat simply delegates toPofReader.readObject(int)andPofWriter.writeObject(int, Object)to deserialize and serialize an object.
- Codecs.LongArrayCodec - Class in com.tangosol.io.pof.reflect
- 
Implementation ofCodecthat delegates toPofReader.readLongArray(int, LongArray)andPofWriter.writeLongArray(int, LongArray)to deserialize and serialize an object.
- Codecs.MapCodec - Class in com.tangosol.io.pof.reflect
- 
Implementation ofCodecthat delegates toPofReader.readMap(int, Map)andPofWriter.writeMap(int, Map)to deserialize and serialize an object.
- Coherence - Class in com.tangosol.net
- Coherence.Builder - Class in com.tangosol.net
- 
A builder to buildCoherenceinstances.
- Coherence.LifecycleListener - Interface in com.tangosol.net
- 
An interface implemented by listeners ofCoherenceLifecycleEvents.
- Coherence.Mode - Enum in com.tangosol.net
- 
An enum representing the different modes that aCoherenceinstance can run in.
- CoherenceBasedCache<K,V> - Interface in com.tangosol.coherence.jcache
- 
An Coherence-based implementation of aCache.
- CoherenceBasedCacheManager - Class in com.tangosol.coherence.jcache
- 
The Coherence-based implementation of aCacheManager.
- CoherenceBasedCacheManager(CoherenceBasedCachingProvider, ConfigurableCacheFactory, URI, ClassLoader, Properties) - Constructor for class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- 
Constructs a newCoherenceBasedCacheManager.
- CoherenceBasedCachingProvider - Class in com.tangosol.coherence.jcache
- 
The Coherence-based implementation of aCachingProvider.
- CoherenceBasedCachingProvider() - Constructor for class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- 
Constructs aCoherenceBasedCachingProvider.
- CoherenceBasedCompleteConfiguration<K,V> - Interface in com.tangosol.coherence.jcache
- 
An Coherence-basedCompleteConfigurationthat provides setter methods.
- CoherenceBasedConfiguration<K,V> - Interface in com.tangosol.coherence.jcache
- 
AConfigurationfor aCoherenceBasedCache.
- CoherenceCacheEntry<K,V> - Class in com.tangosol.coherence.jcache.common
- 
ACache.Entryimplementation.
- CoherenceCacheEntry(Map.Entry<K, V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- 
Constructs aCoherenceCacheEntrygiven aMap.Entry.
- CoherenceCacheEntry(K, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- 
Constructs aCoherenceCacheEntrygiven a key and value
- CoherenceCacheEntry(K, V, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- 
Constructs aCoherenceCacheEntrygiven a key, value and previous value.
- CoherenceCacheEntryEvent<K,V> - Class in com.tangosol.coherence.jcache.common
- 
A minimal implementation of theCacheEntryEvent.
- CoherenceCacheEntryEvent(Cache<K, V>, EventType, K, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
- 
Constructs aCoherenceCacheEntryEventbased on a specific key and value.
- CoherenceCacheEntryEvent(Cache<K, V>, EventType, K, V, V) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
- 
Constructs aCoherenceCacheEntryEventbased on a specific key, value and old value.
- CoherenceCacheEntryEventFilteringIterable<K,V> - Class in com.tangosol.coherence.jcache.common
- 
An adapter to provideIterables over Cache Entries, those of which are filtered using aCacheEntryEventFilter.
- CoherenceCacheEntryEventFilteringIterable(Iterable<CacheEntryEvent<K, V>>, CacheEntryEventFilter<? super K, ? super V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterable
- 
Constructs anCoherenceCacheEntryEventFilteringIterable.
- CoherenceCacheEntryEventFilteringIterator<K,V> - Class in com.tangosol.coherence.jcache.common
- 
AnIterators to allow filtering ofCacheEntryEvents.
- CoherenceCacheEntryEventFilteringIterator(Iterator<CacheEntryEvent<K, V>>, CacheEntryEventFilter<? super K, ? super V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterator
- 
Constructs anCoherenceCacheEntryEventFilteringIterator.
- CoherenceCacheEntryListenerRegistration<K,V> - Class in com.tangosol.coherence.jcache.common
- 
A runtime representation of aCacheEntryListenerregistration, including itsCacheEntryListenerConfiguration.
- CoherenceCacheEntryListenerRegistration(CacheEntryListenerConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
- 
Constructs aCoherenceCacheEntryListenerRegistrationbased on aCacheEntryListenerConfiguration.
- CoherenceCacheEventEventDispatcher<K,V> - Class in com.tangosol.coherence.jcache.common
- 
Collects and appropriately dispatchesCacheEntryEvents toCacheEntryListeners.
- CoherenceCacheEventEventDispatcher() - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheEventEventDispatcher
- 
Constructs anCoherenceCacheEventEventDispatcher.
- CoherenceCacheMXBean<K,V> - Class in com.tangosol.coherence.jcache.common
- 
The Coherence implementation of aCacheMXBean.
- CoherenceCacheMXBean(CoherenceBasedCache<K, V>) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
- 
Constructs aCoherenceCacheMXBean.
- CoherenceConfigSource - Class in com.oracle.coherence.mp.config
- 
An implementation ofConfigSourcethat reads configuration properties from a Coherence map.
- CoherenceConfigSource() - Constructor for class com.oracle.coherence.mp.config.CoherenceConfigSource
- 
ConstructCoherenceConfigSourceinstance.
- CoherenceConfiguration - Interface in com.tangosol.net
- 
The immutable configuration for aCoherenceinstance.
- CoherenceConfiguration.Builder - Class in com.tangosol.net
- 
A builder to build aCoherenceConfigurationinstance.
- CoherenceConfiguration.SimpleConfig - Class in com.tangosol.net
- 
A simple immutable implementation ofCoherenceConfiguration.
- CoherenceConverterAdapter<T> - Class in com.tangosol.coherence.jcache.common
- 
AnInternalConverterthat uses two CoherenceConverters as a means of performing conversions to and from internal representations.
- CoherenceConverterAdapter(Converter, Converter) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceConverterAdapter
- 
Constructs aCoherenceConverterAdaptergiven two CoherenceConverters.
- CoherenceDefaultsConfigSource - Class in com.oracle.coherence.mp.config
- 
A staticConfigSourceimplementation that overrides default Coherence configuration to: Usejava.util.loggingas a logging destination Usecom.oracle.coherenceas a logger name Changes default message format to(thread={thread}, member={member}, up={uptime}): {text}, in order to allowjava.util.loggingto control overall message formatting ThisConfigSourcehas an ordinal of 0, so the default configuration values above will only be used if none of the higher priority configuration sources provides an override for a configuration property.
- CoherenceDefaultsConfigSource() - Constructor for class com.oracle.coherence.mp.config.CoherenceDefaultsConfigSource
- 
ConstructCoherenceDefaultsConfigSourceinstance.
- CoherenceDispatcher - Interface in com.tangosol.net.events
- 
A CoherenceDispatcher raisesEvents pertaining to operations on aCoherenceinstance:CoherenceLifecycleEvents
- CoherenceEntryProcessorResult<T> - Class in com.tangosol.coherence.jcache.common
- 
A Coherence-basedEntryProcessorResult.
- CoherenceEntryProcessorResult() - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
- 
Constructs aCoherenceEntryProcessorResult(for serialization).
- CoherenceEntryProcessorResult(Exception) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
- 
Constructs aCoherenceEntryProcessorResultfor anException.
- CoherenceEntryProcessorResult(T) - Constructor for class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
- 
Constructs anCoherenceEntryProcessorResultfor a specific value.
- CoherenceExtension - Class in com.oracle.coherence.cdi
- 
A Coherence CDIExtensionthat is used on both cluster members and the clients.
- CoherenceExtension() - Constructor for class com.oracle.coherence.cdi.CoherenceExtension
- CoherenceExtension.InterceptorProvider - Interface in com.oracle.coherence.cdi
- 
A provider ofNamedEventInterceptorinstances.
- CoherenceLifecycleEvent - Interface in com.tangosol.net.events
- 
ACoherenceLifecycleEventallows subscribers to capture events pertaining to the lifecycle of aCoherenceinstance.
- CoherenceLifecycleEvent.Type - Enum in com.tangosol.net.events
- 
The emitted event types for aCoherenceLifecycleEvent.
- CoherenceLifecycleEventHandler(EventObserverSupport.EventObserver<CoherenceLifecycleEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.CoherenceLifecycleEventHandler
- CoherenceLifecycleEvents - Annotation Type in com.tangosol.net.events.annotation
- 
CoherenceLifecycleEvents is an annotation that should be applied toEventInterceptorimplementations that want to receiveCoherenceLifecycleEvents.
- CoherenceProducer - Class in com.oracle.coherence.cdi
- 
A producer that creates the defaultCoherencebean.
- CoherenceProducer() - Constructor for class com.oracle.coherence.cdi.CoherenceProducer
- CoherenceQueryLanguage - Class in com.tangosol.coherence.dslquery
- 
CoherenceQueryLanguage is a simple language for building Filters and doing simple queries that are similar in style to SQL.
- CoherenceQueryLanguage() - Constructor for class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Construct a CoherenceQueryLanguage instance.
- CoherenceQueryLanguageEngine - Class in com.tangosol.coherence.rest.query
- 
Coherence QL-based implementation ofQueryEngine.
- CoherenceQueryLanguageEngine() - Constructor for class com.tangosol.coherence.rest.query.CoherenceQueryLanguageEngine
- CoherenceServerExtension - Class in com.oracle.coherence.cdi.server
- 
A Coherence CDIExtensionthat should only be used within the cluster members.
- CoherenceServerExtension() - Constructor for class com.oracle.coherence.cdi.server.CoherenceServerExtension
- CoherenceSession - Class in com.tangosol.net
- 
An implementation of aSessionallowing applications to use the new operator to create aSessionvia the defaultSessionProvider.
- CoherenceSession() - Constructor for class com.tangosol.net.CoherenceSession
- 
Constructs aCoherenceSessionusing the default session configuration.
- CoherenceSession(Session.Option...) - Constructor for class com.tangosol.net.CoherenceSession
- 
Deprecated.since 20.12 useCoherenceSession(SessionConfiguration, Coherence.Mode, Iterable)
- CoherenceSession(SessionConfiguration, Coherence.Mode, Iterable<? extends EventInterceptor<?>>) - Constructor for class com.tangosol.net.CoherenceSession
- 
Constructs aCoherenceSessionbased on the specifiedSessionConfiguration.
- CoherenceTagsConfigSource - Class in com.oracle.coherence.mp.metrics
- 
Allows us to register Coherence-specific tags by augmenting the value returned by theMetricID.GLOBAL_TAGS_VARIABLEconfig property.
- CoherenceTagsConfigSource() - Constructor for class com.oracle.coherence.mp.metrics.CoherenceTagsConfigSource
- CohQLException - Exception in com.tangosol.coherence.dslquery
- 
An exception thrown when errors occur building CohQL queries.
- CohQLException(String) - Constructor for exception com.tangosol.coherence.dslquery.CohQLException
- 
Construct a new exception with the specified detail message.
- CohQLException(String, Throwable) - Constructor for exception com.tangosol.coherence.dslquery.CohQLException
- 
Construct a new exception with the specified detail message and cause.
- collect(Remote.Supplier<R>, Remote.BiConsumer<R, ? super T>, Remote.BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a mutable reduction operation on the elements of this stream.
- collect(Remote.Supplier<R>, Remote.ObjDoubleConsumer<R>, Remote.BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Performs a mutable reduction operation on the elements of this stream.
- collect(Remote.Supplier<R>, Remote.ObjIntConsumer<R>, Remote.BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Performs a mutable reduction operation on the elements of this stream.
- collect(Remote.Supplier<R>, Remote.ObjLongConsumer<R>, Remote.BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Performs a mutable reduction operation on the elements of this stream.
- collect(RemoteCollector<? super T, A, R>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a mutable reduction operation on the elements of this stream using aCollector.
- collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a mutable reduction operation on the elements of this stream.
- collect(Supplier<R>, ObjDoubleConsumer<R>, BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Performs a mutable reduction operation on the elements of this stream.
- collect(Supplier<R>, ObjIntConsumer<R>, BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Performs a mutable reduction operation on the elements of this stream.
- collect(Supplier<R>, ObjLongConsumer<R>, BiConsumer<R, R>) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Performs a mutable reduction operation on the elements of this stream.
- collect(Collector<? super T, A, R>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a mutable reduction operation on the elements of this stream using aCollector.
- collectEndangered(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return a partition set representing the subset of the specified partitions that are "endangered".
- collectingAndThen(RemoteCollector<T, A, R>, Remote.Function<R, RR>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Adapts aCollectorto perform an additional finishing transformation.
- COLLECTION_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
- 
An empty (and immutable) collection.
- CollectionAdapter - Class in com.tangosol.run.xml
- 
A CollectionAdapter supports properties whose types implement the java.util.Collection interface.
- CollectionAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.CollectionAdapter
- 
Construct a CollectionAdapter.
- CollectionCodec(Class<? extends Collection<Object>>) - Constructor for class com.tangosol.io.pof.reflect.Codecs.CollectionCodec
- 
Construct a CollectionCodec.
- CollectionHelper - Class in com.tangosol.util
- 
Deprecated.As of Coherence 12.1.2
- CollectionHelper() - Constructor for class com.tangosol.util.CollectionHelper
- 
Deprecated.
- CollectionRefExpression(Expression<?>, ClassLoader, ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CollectionRefExpression
- 
Constructs a CollectionRefExpression.
- collectListeners(MapEvent) - Method in class com.tangosol.util.MapListenerSupport
- 
Collect all Listeners that should be notified for a given event.
- Collector<V> - Interface in com.oracle.coherence.common.base
- 
A Collector is mechanism for receiving items.
- collectOrphaned(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return a partition set representing the subset of the specified partitions that are "orphaned".
- collectRemoved(Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Given that the old value is known to be a Collection or an array, collect all the enclosed elements that are not part of the new value.
- collectScheduledDistributions() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Collect the scheduled partition distributions, grouped by the primary owner and storage index.
- collectServiceSchemes(XmlElement) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Collect a map keyed by service names with values of corresponding service schemes in the specified cache configuration.
- collectServiceSchemes(XmlElement, XmlElement, HashMap) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Collect the service-schemes referenced by the specified scheme element in the cache configuration and update the specified mapping of service names to the associated service schemes.
- collectWeak(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return a partition set representing the subset of the specified partitions that are "weak" or "vulnerable" (as defined by the backup strength).
- ColonToken - Class in com.tangosol.coherence.dsltools.termlanguage
- 
Colon is used to make attributes in a list or bag.
- ColonToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.termlanguage.ColonToken
- 
Construct a new ColonToken with the given parameters.
- com.oracle.coherence.caffeine - package com.oracle.coherence.caffeine
- 
Contains interfaces and classes related to the Caffeine backing map implementation.
- com.oracle.coherence.cdi - package com.oracle.coherence.cdi
- 
Coherence CDI provides support for CDI (Contexts and Dependency Injection) within Coherence cluster members.
- com.oracle.coherence.cdi.events - package com.oracle.coherence.cdi.events
- 
Support for adapting Coherence interceptors to standard CDI events.
- com.oracle.coherence.cdi.server - package com.oracle.coherence.cdi.server
- 
Simple CDI-based Cache Server implementation.
- com.oracle.coherence.common.base - package com.oracle.coherence.common.base
- 
The base package provides a number of classes to complement those in the java.lang package.
- com.oracle.coherence.concurrent - package com.oracle.coherence.concurrent
- 
Coherence Concurrent utilities based on java.util.concurrent.
- com.oracle.coherence.concurrent.atomic - package com.oracle.coherence.concurrent.atomic
- 
A small toolkit of classes that support lock-free thread-safe programming on single variables.
- com.oracle.coherence.concurrent.cdi - package com.oracle.coherence.concurrent.cdi
- 
CDI-related annotations for Coherence-Concurrent.
- com.oracle.coherence.concurrent.executor - package com.oracle.coherence.concurrent.executor
- 
Classes to allow submission of tasks to the grid for execution.
- com.oracle.coherence.concurrent.executor.management - package com.oracle.coherence.concurrent.executor.management
- 
MBeans for Coherence Concurrent executors.
- com.oracle.coherence.concurrent.locks - package com.oracle.coherence.concurrent.locks
- 
Interfaces and classes providing a framework for locking and waiting for conditions that is distinct from built-in synchronization and monitors.
- com.oracle.coherence.grpc - package com.oracle.coherence.grpc
- 
Low-level utilities for Coherence gRPC server and client implementation.
- com.oracle.coherence.grpc.proxy - package com.oracle.coherence.grpc.proxy
- 
The Coherence gRPC server implementation.
- com.oracle.coherence.mp.config - package com.oracle.coherence.mp.config
- 
Coherence support for Eclipse MicroProfile Config.
- com.oracle.coherence.mp.metrics - package com.oracle.coherence.mp.metrics
- 
MicroProfile Metrics support.
- com.oracle.coherence.repository - package com.oracle.coherence.repository
- 
Contains classes to enable Repository-like access to Coherence data.
- com.tangosol.coherence.config - package com.tangosol.coherence.config
- 
Defines the Coherence configuration object model for accessing, customizing and or modifying configuration.
- com.tangosol.coherence.config.builder - package com.tangosol.coherence.config.builder
- 
Defines the typical runtime configuration builders for the Coherence configuration object model.
- com.tangosol.coherence.config.builder.storemanager - package com.tangosol.coherence.config.builder.storemanager
- 
Defines external Store Manager Builder implementations for Coherence caches.
- com.tangosol.coherence.config.scheme - package com.tangosol.coherence.config.scheme
- 
Defines the Coherence configuration object model classes and interfaces for Caching and Service Schemes.
- com.tangosol.coherence.config.unit - package com.tangosol.coherence.config.unit
- 
Defines the standard units of measure for the Coherence configuration object model.
- com.tangosol.coherence.config.xml - package com.tangosol.coherence.config.xml
- 
Defines the Xml Document Pre-Processors and Xml Element Processors for converting Coherence Cache Configuration files into Coherence configuration object models.
- com.tangosol.coherence.config.xml.preprocessor - package com.tangosol.coherence.config.xml.preprocessor
- 
Defines the Xml document Pre-Processors for Coherence Cache Configuration files.
- com.tangosol.coherence.config.xml.processor - package com.tangosol.coherence.config.xml.processor
- 
Defines the Xml document Element and Attribute Processors for Coherence Cache Configuration files.
- com.tangosol.coherence.dslquery - package com.tangosol.coherence.dslquery
- 
Contains packages and classes supporting the Coherence CohQL command line tool.
- com.tangosol.coherence.dslquery.function - package com.tangosol.coherence.dslquery.function
- 
This package contains builders for the various CohQL functions.
- com.tangosol.coherence.dslquery.operator - package com.tangosol.coherence.dslquery.operator
- 
This package contains implementations of theBaseOperatorinterface.
- com.tangosol.coherence.dslquery.queryplus - package com.tangosol.coherence.dslquery.queryplus
- 
This package contains commands that are specific to theQueryPlustool rather than general CohQL commands.
- com.tangosol.coherence.dslquery.statement - package com.tangosol.coherence.dslquery.statement
- 
This package containsStatementBuilderimplementations.
- com.tangosol.coherence.dslquery.statement.persistence - package com.tangosol.coherence.dslquery.statement.persistence
- 
This package contains classes for persistence related statement builders.
- com.tangosol.coherence.dslquery.token - package com.tangosol.coherence.dslquery.token
- 
This package contains implementations ofOPTokenspecifically for parsing CohQL statements.
- com.tangosol.coherence.dslquery.token.persistence - package com.tangosol.coherence.dslquery.token.persistence
- 
This package contains implementations ofOPTokenspecifically for parsing persistence related CohQL statements.
- com.tangosol.coherence.dsltools.base - package com.tangosol.coherence.dsltools.base
- 
Contains base classes for all tokens processed by dsltools.
- com.tangosol.coherence.dsltools.precedence - package com.tangosol.coherence.dsltools.precedence
- 
This package contains implementations ofOPTokens.
- com.tangosol.coherence.dsltools.termlanguage - package com.tangosol.coherence.dsltools.termlanguage
- 
This package contains implementations ofTermLanguage.
- com.tangosol.coherence.dsltools.termtrees - package com.tangosol.coherence.dsltools.termtrees
- 
This package contains implementations of dsltools buildingTerms.
- com.tangosol.coherence.federation - package com.tangosol.coherence.federation
- 
Contains Federation conflict resolution interfaces.
- com.tangosol.coherence.jcache - package com.tangosol.coherence.jcache
- 
Contains classes related to Coherence JCache.
- com.tangosol.coherence.jcache.common - package com.tangosol.coherence.jcache.common
- 
Common utilities used by Coherence JCache.
- com.tangosol.coherence.jcache.localcache - package com.tangosol.coherence.jcache.localcache
- 
Contains classes related to local cache implementation of Coherence JCache.
- com.tangosol.coherence.jcache.partitionedcache - package com.tangosol.coherence.jcache.partitionedcache
- 
Contains classes related to partitioned cache implementation of Coherence JCache.
- com.tangosol.coherence.jcache.passthroughcache - package com.tangosol.coherence.jcache.passthroughcache
- 
Contains classes related to pass-through cache implementation of Coherence JCache.
- com.tangosol.coherence.jcache.remotecache - package com.tangosol.coherence.jcache.remotecache
- 
Contains classes related to remote cache implementation of Coherence JCache.
- com.tangosol.coherence.rest - package com.tangosol.coherence.rest
- 
Contains classes related to the Coherence REST API.
- com.tangosol.coherence.rest.config - package com.tangosol.coherence.rest.config
- 
Contains classes related to the Coherence REST configuration.
- com.tangosol.coherence.rest.events - package com.tangosol.coherence.rest.events
- 
Contains classes related to the Coherence REST APIMapEvents.
- com.tangosol.coherence.rest.io - package com.tangosol.coherence.rest.io
- 
Contains classes related to REST marshalling.
- com.tangosol.coherence.rest.providers - package com.tangosol.coherence.rest.providers
- 
Contains classes related to the Coherence REST API providers.
- com.tangosol.coherence.rest.query - package com.tangosol.coherence.rest.query
- 
Contains classes related to the Coherence REST pluggable query engine.
- com.tangosol.coherence.rest.server - package com.tangosol.coherence.rest.server
- 
Contains classes related to embedded HTTP server integration.
- com.tangosol.coherence.rest.servlet - package com.tangosol.coherence.rest.servlet
- 
Contains classes related to J2EE server integration.
- com.tangosol.coherence.rest.util - package com.tangosol.coherence.rest.util
- 
Contains packages and classes related to the Coherence REST API utilities.
- com.tangosol.coherence.rest.util.aggregator - package com.tangosol.coherence.rest.util.aggregator
- 
Contains classes related to REST-based aggregation.
- com.tangosol.coherence.rest.util.extractor - package com.tangosol.coherence.rest.util.extractor
- 
Contains classes related to REST-based extractor.
- com.tangosol.coherence.rest.util.processor - package com.tangosol.coherence.rest.util.processor
- 
Contains classes related to REST-based entry processing.
- com.tangosol.coherence.rest.util.updater - package com.tangosol.coherence.rest.util.updater
- 
Contains classes related to REST-based updater.
- com.tangosol.config - package com.tangosol.config
- 
Defines commonly required, generic and helper classes, interfaces and annotations used to simplify the configuration of objects, services, caches and components.
- com.tangosol.config.annotation - package com.tangosol.config.annotation
- 
Defines annotations typically used for configuring, documenting and injecting values into objects.
- com.tangosol.config.expression - package com.tangosol.config.expression
- 
Defines classes and interfaces for representing and evaluating expressions.
- com.tangosol.config.xml - package com.tangosol.config.xml
- 
Defines classes and interfaces for processing Xml documents and building object models, like configuration, based on said documents though the use of injection.
- com.tangosol.io - package com.tangosol.io
- 
Contains classes providing cache persistence of serialized objects.
- com.tangosol.io.bdb - package com.tangosol.io.bdb
- 
Contains Sleepycat Berkeley DB BinaryStore implementation classes.
- com.tangosol.io.nio - package com.tangosol.io.nio
- 
Contains classes related to J2SE 1.4 NIO functionality.
- com.tangosol.io.pof - package com.tangosol.io.pof
- 
Contains classes related to POF serialization and deserialization.
- com.tangosol.io.pof.annotation - package com.tangosol.io.pof.annotation
- 
Contains POF Annotation classes.
- com.tangosol.io.pof.reflect - package com.tangosol.io.pof.reflect
- 
Contains classes related to POF stream navigation and manipulation.
- com.tangosol.net - package com.tangosol.net
- 
Contains basic cluster interfaces and factories.
- com.tangosol.net.cache - package com.tangosol.net.cache
- 
Contains classes providing various caching strategies.
- com.tangosol.net.events - package com.tangosol.net.events
- 
Contains classes related to the Coherence Live Event Model.
- com.tangosol.net.events.annotation - package com.tangosol.net.events.annotation
- 
Contains annotations related to the Coherence Live Event Model.
- com.tangosol.net.events.application - package com.tangosol.net.events.application
- 
Contains classes related to application events within the Coherence Live Event Model, including ConfigurableCacheFactory events.
- com.tangosol.net.events.partition - package com.tangosol.net.events.partition
- 
Contains classes related to PartitionedService events within the Coherence Live Event Model.
- com.tangosol.net.events.partition.cache - package com.tangosol.net.events.partition.cache
- 
Contains classes related to PartitionedCache events within the Coherence Live Event Model.
- com.tangosol.net.management - package com.tangosol.net.management
- 
Contains classes related to the Coherence Management Framework.
- com.tangosol.net.management.annotation - package com.tangosol.net.management.annotation
- 
Contains annotations used by the Coherence Management Framework.
- com.tangosol.net.messaging - package com.tangosol.net.messaging
- 
Contains exception classes related to connection error.
- com.tangosol.net.partition - package com.tangosol.net.partition
- 
Contains interfaces and classes related to partitioned services.
- com.tangosol.net.proxy - package com.tangosol.net.proxy
- 
Contains interfaces and classes related to proxy services.
- com.tangosol.net.security - package com.tangosol.net.security
- 
Contains classes related to the Coherence Security Framework.
- com.tangosol.net.ssl - package com.tangosol.net.ssl
- 
Contains interfaces and classes related to custom SSL certificate and key store loaders.
- com.tangosol.net.topic - package com.tangosol.net.topic
- 
Contains classes that providing topic entities for publish/subscribe messaging.
- com.tangosol.persistence - package com.tangosol.persistence
- 
Contains classes and helpers for implementing various types of persistence.
- com.tangosol.run.jca - package com.tangosol.run.jca
- 
Contains classes providing Java 2 Connector Architecture functionality.
- com.tangosol.run.xml - package com.tangosol.run.xml
- 
Contains classes providing basic XML related functionality.
- com.tangosol.util - package com.tangosol.util
- 
Contains various generic utilities.
- com.tangosol.util.aggregator - package com.tangosol.util.aggregator
- 
Contains concreteInvocableMap.EntryAggregatorimplementations.
- com.tangosol.util.comparator - package com.tangosol.util.comparator
- 
Contains concreteComparatorimplementations and related interfaces.
- com.tangosol.util.extractor - package com.tangosol.util.extractor
- 
ContainsValueExtractorandValueUpdaterrelated classes.
- com.tangosol.util.filter - package com.tangosol.util.filter
- 
Contains concreteFilterimplementations and related interfaces.
- com.tangosol.util.fsm - package com.tangosol.util.fsm
- 
Contains Finite state machine interfaces.
- com.tangosol.util.function - package com.tangosol.util.function
- 
Contains Functional interfaces allowing remote execution of lambda expressions and method references.
- com.tangosol.util.processor - package com.tangosol.util.processor
- 
Contains concreteInvocableMap.EntryProcessorimplementations.
- com.tangosol.util.stream - package com.tangosol.util.stream
- 
Contains classes to support functional-style operations on remote streams of elements, such as map-reduce transformations on collections.
- com.tangosol.util.transformer - package com.tangosol.util.transformer
- 
Contains concreteMapEventTransformerimplementations.
- combine(TopNAggregator.PartialResult<E>) - Method in class com.tangosol.util.aggregator.TopNAggregator
- combine(Converter<F, I>, Converter<I, T>) - Static method in class com.tangosol.util.ConverterCollections
- 
Create a new converter by combining two existing converters.
- combine(QueryRecord.PartialResult) - Method in class com.tangosol.util.aggregator.QueryRecorder
- combine(Integer) - Method in class com.tangosol.util.aggregator.Count
- combine(Object) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- combine(Object) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- combine(Object) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- combine(Object) - Method in class com.tangosol.util.aggregator.CompositeAggregator
- combine(Map<E, Object>) - Method in class com.tangosol.util.aggregator.GroupAggregator
- combine(P) - Method in class com.tangosol.util.aggregator.PriorityAggregator
- combine(P) - Method in class com.tangosol.util.aggregator.ScriptAggregator
- combine(P) - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
Merge another partial result into the result.
- CommandsOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder.CommandsOPToken
- 
Construct a CommandsOPToken.
- CommandsQueryPlusStatement() - Constructor for class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder.CommandsQueryPlusStatement
- CommandsStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
- 
A class that builds the QueryPlus "COMMANDS" command.
- CommandsStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
- 
Construct a CommandsStatementBuilder that builds aCommandsStatementBuilder.CommandsQueryPlusStatement.
- CommandsStatementBuilder.CommandsOPToken - Class in com.tangosol.coherence.dslquery.queryplus
- 
A CohQL OPToken representing the QueryPlus "commands" command.
- CommandsStatementBuilder.CommandsQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
- 
The implementation of the QueryPlus "commands" command.
- commit() - Method in interface com.tangosol.net.topic.Subscriber.Element
- 
Commit this position in the element's owning channel.
- commit() - Method in interface com.tangosol.util.TransactionMap
- 
Commit the changes made to the TransactionMap.
- commit(int, Position) - Method in interface com.tangosol.net.topic.Subscriber
- 
Commit the specified channel and position.
- commit(Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Commit a sequence of mutating operations represented by the given token as an atomic unit.
- commit(Object) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Commit a sequence of mutating operations represented by the given token as an atomic unit.
- commit(Object) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- commit(Map<Integer, Position>) - Method in interface com.tangosol.net.topic.Subscriber
- 
Commit the specified channels and positions.
- commitAndMaybeInvalidate() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Finish the commit for the entry for which this Status exists.
- commitAndMaybeInvalidate() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Finish the commit for the entry for which this Status exists.
- commitAsync() - Method in interface com.tangosol.net.topic.Subscriber.Element
- 
Commit this position in the element's owning channel.
- commitAsync(int, Position) - Method in interface com.tangosol.net.topic.Subscriber
- 
Asynchronously commit the specified channel and position.
- commitAsync(Map<Integer, Position>) - Method in interface com.tangosol.net.topic.Subscriber
- 
Asynchronously commit the specified channels and positions.
- commitInternal(Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Commit a sequence of mutating operations represented by the given token as an atomic unit.
- CommitResult() - Constructor for class com.tangosol.net.topic.Subscriber.CommitResult
- 
Default constructor for serialization.
- CommitResult(int, Position, Subscriber.CommitResultStatus) - Constructor for class com.tangosol.net.topic.Subscriber.CommitResult
- 
Create aSubscriber.CommitResult.
- CommitResult(int, Position, Subscriber.CommitResultStatus, Throwable) - Constructor for class com.tangosol.net.topic.Subscriber.CommitResult
- 
Create a rejectedSubscriber.CommitResult.
- CommitResult(int, Position, Throwable) - Constructor for class com.tangosol.net.topic.Subscriber.CommitResult
- 
Create a rejectedSubscriber.CommitResult.
- Committed - com.tangosol.net.topic.Subscriber.CommitResultStatus
- 
The position was successfully committed.
- Committed - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any COMMITTED event.
- COMMITTED - com.tangosol.net.events.partition.TransactionEvent.Type
- 
A COMMITTED event is raised after any mutations have been committed to the underlying backing maps.
- COMMITTED - com.tangosol.net.events.partition.UnsolicitedCommitEvent.Type
- 
A COMMITTED event is the only event raised by theUnsolicitedCommitEventas the mutation has already occurred to the underlying backing map(s).
- Committed.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theCommittedannotation.
- Committing - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any COMMITTING event.
- COMMITTING - com.tangosol.net.events.partition.TransactionEvent.Type
- 
A COMMITTING event is raised prior to any updates to the underlying backing map.
- Committing.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theCommittingannotation.
- CommittingLocal - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any COMMITTING_LOCAL event.
- CommittingLocal.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theCommittingLocalannotation.
- CommittingRemote - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any COMMITTING_REMOTE event.
- CommittingRemote.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theCommittingRemoteannotation.
- commitTransactionCollection(Collection, int) - Static method in class com.tangosol.net.CacheFactory
- 
Commit the transaction represented by a collection of TransactionMap objects.
- compactAll() - Method in class com.tangosol.io.nio.BinaryMap
- 
Full linear compaction of the buffer.
- compactBegin() - Method in class com.tangosol.io.nio.BinaryMap
- 
Configure the incremental compact.
- compactComplete() - Method in class com.tangosol.io.nio.BinaryMap
- 
Complete the incremental compact.
- compactNext() - Method in class com.tangosol.io.nio.BinaryMap
- 
Perform an incremental compaction of the next block.
- compactUntil(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Perform an an incremental compact at the specified block.
- comparableMax(ValueExtractor<? super T, ? extends R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of theComparablevalues extracted from a set of entries in a Map.
- comparableMax(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of the values extracted from a set of entries in a Map.
- comparableMax(String) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of theComparablevalues extracted from a set of entries in a Map.
- comparableMax(String, Comparator<? super R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of the values extracted from a set of entries in a Map.
- ComparableMax<T,R> - Class in com.tangosol.util.aggregator
- 
Calculates a maximum among values extracted from a set of entries in a Map.
- ComparableMax() - Constructor for class com.tangosol.util.aggregator.ComparableMax
- 
Default constructor (necessary for the ExternalizableLite interface).
- ComparableMax(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.aggregator.ComparableMax
- 
Construct a ComparableMax aggregator.
- ComparableMax(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Constructor for class com.tangosol.util.aggregator.ComparableMax
- 
Construct a ComparableMax aggregator.
- ComparableMax(String) - Constructor for class com.tangosol.util.aggregator.ComparableMax
- 
Construct a ComparableMax aggregator.
- comparableMin(ValueExtractor<? super T, ? extends R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of theComparablevalues extracted from a set of entries in a Map.
- comparableMin(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of the values extracted from a set of entries in a Map.
- comparableMin(String) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of theComparablevalues extracted from a set of entries in a Map.
- comparableMin(String, Comparator<? super R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of the values extracted from a set of entries in a Map.
- ComparableMin<T,R> - Class in com.tangosol.util.aggregator
- 
Calculates a minimum among values extracted from a set of entries in a Map.
- ComparableMin() - Constructor for class com.tangosol.util.aggregator.ComparableMin
- 
Default constructor (necessary for the ExternalizableLite interface).
- ComparableMin(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.aggregator.ComparableMin
- 
Construct a ComparableMin aggregator.
- ComparableMin(ValueExtractor<? super T, ? extends R>, Comparator<? super R>) - Constructor for class com.tangosol.util.aggregator.ComparableMin
- 
Construct a ComparableMin aggregator.
- ComparableMin(String) - Constructor for class com.tangosol.util.aggregator.ComparableMin
- 
Construct a ComparableMin aggregator.
- comparator() - Method in annotation type com.oracle.coherence.repository.Indexed
- 
An optionalComparatorclass to use for ordering.
- comparator() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- comparator() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- comparator() - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns the comparator associated with this sorted set, or null if it uses its elements' natural ordering.
- comparator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedMap
- 
Returns the comparator associated with this sorted map, or null if it uses its keys' natural ordering.
- comparator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedSet
- 
Returns the comparator associated with this sorted set, or null if it uses its elements' natural ordering.
- comparator() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- comparator() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- comparator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- comparator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
- comparator(Remote.Comparator<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable Comparator.
- comparator(ValueExtractor<? super T, ? extends E>) - Static method in class com.tangosol.util.function.Remote
- 
CreateRemote.Comparatorfor the specified extractor that returns aComparablevalue.
- ComparatorBuilder - Class in com.tangosol.coherence.rest.util
- 
Comparator builder that provides a small set of builder methods to simplify creation of a chain ofExtractorComparators from givenValueExtractors.
- ComparatorBuilder() - Constructor for class com.tangosol.coherence.rest.util.ComparatorBuilder
- ComparatorHelper - Class in com.tangosol.coherence.rest.util
- 
ComparatorHelper is a utility class that provides a factory method used to create a java.util.Comparator instance from a string expression.
- ComparatorHelper() - Constructor for class com.tangosol.coherence.rest.util.ComparatorHelper
- compare(Object, Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap.HashcodeComparator
- compare(Object, Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.LoadComparator
- compare(Object, Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
- compare(Object, Object) - Method in class com.tangosol.util.comparator.EntryComparator
- 
Compares two arguments for order.
- compare(Object, Object) - Method in class com.tangosol.util.extractor.AbstractExtractor
- 
Compares its two arguments for order.
- compare(Object, Object) - Method in class com.tangosol.util.SortedBag.WrapperComparator
- compare(String, String) - Method in class com.tangosol.util.CacheCollator
- 
Compares the source string to the target string according to the collation rules for this Collator.
- compare(T, T) - Method in class com.oracle.coherence.common.base.InverseComparator
- compare(T, T) - Method in class com.oracle.coherence.common.base.NaturalComparator
- compare(T, T) - Method in interface com.tangosol.net.ServiceLoadBalancer
- 
Compare to ServerLoad objects.
- compare(T, T) - Method in class com.tangosol.net.SimpleServiceLoadBalancer
- compare(T, T) - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Compares its two arguments for order.
- compare(T, T) - Method in class com.tangosol.util.comparator.ExtractorComparator
- 
Compares extracted values (by specified ValueExtractor) of given arguments for order.
- compare(T, T) - Method in class com.tangosol.util.comparator.InverseComparator
- 
Use the wrapped Comparator to compare the two arguments for order and negate the result.
- compare(T, T) - Method in class com.tangosol.util.comparator.PriorityComparator
- compare(T, T) - Method in class com.tangosol.util.comparator.SafeComparator
- 
Compares its two arguments for order.
- compare(T, T) - Method in class com.tangosol.util.ConverterCollections.ConverterComparator
- compareAndExchange(boolean, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicBoolean
- 
Atomically sets the value tonewValueif the current value, referred to as the witness value,== expectedValue.
- compareAndExchange(boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
- compareAndExchange(boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- compareAndExchange(boolean, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicBoolean
- 
Atomically sets the value tonewValueif the current value, referred to as the witness value,== expectedValue.
- compareAndExchange(boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- compareAndExchange(boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- compareAndExchange(int, int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically sets the value tonewValueif the current value, referred to as the witness value,== expectedValue.
- compareAndExchange(int, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- compareAndExchange(int, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- compareAndExchange(int, int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically sets the value tonewValueif the current value, referred to as the witness value,== expectedValue.
- compareAndExchange(int, int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- compareAndExchange(int, int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- compareAndExchange(long, long) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically sets the value tonewValueif the current value, referred to as the witness value,== expectedValue.
- compareAndExchange(long, long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- compareAndExchange(long, long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- compareAndExchange(long, long) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically sets the value tonewValueif the current value, referred to as the witness value,== expectedValue.
- compareAndExchange(long, long) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- compareAndExchange(long, long) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- compareAndExchange(V, V) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Atomically sets the value tonewValueif the current value, referred to as the witness value, is equal to theexpectedValue.
- compareAndExchange(V, V) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- compareAndExchange(V, V) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- compareAndExchange(V, V) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Atomically sets the value tonewValueif the current value, referred to as the witness value, is equal to the== expectedValue.
- compareAndExchange(V, V) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- compareAndExchange(V, V) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- compareAndSet(boolean, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicBoolean
- 
Atomically sets the value tonewValueif the current value== expectedValue.
- compareAndSet(boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
- compareAndSet(boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- compareAndSet(boolean, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicBoolean
- 
Atomically sets the value tonewValueif the current value== expectedValue.
- compareAndSet(boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- compareAndSet(boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- compareAndSet(int, int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically sets the value tonewValueif the current value== expectedValue.
- compareAndSet(int, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- compareAndSet(int, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- compareAndSet(int, int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically sets the value tonewValueif the current value== expectedValue.
- compareAndSet(int, int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- compareAndSet(int, int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- compareAndSet(long, long) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically sets the value tonewValueif the current value== expectedValue.
- compareAndSet(long, long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- compareAndSet(long, long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- compareAndSet(long, long) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically sets the value tonewValueif the current value== expectedValue.
- compareAndSet(long, long) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- compareAndSet(long, long) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- compareAndSet(V, V) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Atomically sets the value tonewValueif the current value is equal to theexpectedValue.
- compareAndSet(V, V) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- compareAndSet(V, V) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- compareAndSet(V, V) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Atomically sets the value tonewValueif the current value is equal to theexpectedValue.
- compareAndSet(V, V) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- compareAndSet(V, V) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- compareAndSet(V, V, boolean, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicMarkableReference
- 
Atomically sets the value of both the reference and mark to the given update values if the current reference is equal to the expected reference and the current mark is equal to the expected mark.
- compareAndSet(V, V, boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
- compareAndSet(V, V, boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- compareAndSet(V, V, boolean, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicMarkableReference
- 
Atomically sets the value of both the reference and mark to the given update values if the current reference is equal to the expected reference and the current mark is equal to the expected mark.
- compareAndSet(V, V, boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- compareAndSet(V, V, boolean, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- compareAndSet(V, V, int, int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicStampedReference
- 
Atomically sets the value of both the reference and stamp to the given update values if the current reference is equal to the expected reference and the current stamp is equal to the expected stamp.
- compareAndSet(V, V, int, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
- compareAndSet(V, V, int, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- compareAndSet(V, V, int, int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicStampedReference
- 
Atomically sets the value of both the reference and stamp to the given update values if the current reference is==to the expected reference and the current stamp is equal to the expected stamp.
- compareAndSet(V, V, int, int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- compareAndSet(V, V, int, int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- compareEntries(QueryMap.Entry<?, T>, QueryMap.Entry<?, T>) - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Compare two entries based on the rules specified byComparator.
- compareEntries(QueryMap.Entry<?, T>, QueryMap.Entry<?, T>) - Method in interface com.tangosol.util.comparator.QueryMapComparator
- 
Compare two entries based on the rules specified byComparator.
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.comparator.ExtractorComparator
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.comparator.InverseComparator
- 
Compare two entries using the underlying comparator and negate the result.
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.comparator.SafeComparator
- 
Compare two entries using the underlying comparator.
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.extractor.AbstractExtractor
- 
Compare two entries based on the rules specified byComparator.
- compareEntries(QueryMap.Entry, QueryMap.Entry) - Method in class com.tangosol.util.extractor.MultiExtractor
- 
Compare two entries based on the rules specified byComparator.
- compareKeyList(ObjectName, ObjectName) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Compare twoglobal MBean namesforcing numeric comparison of the node ID while using string comparison on all other key properties.
- compareSafe(Comparator, Object, Object) - Static method in class com.tangosol.util.comparator.SafeComparator
- 
Compares its two arguments for order.
- compareSafe(Comparator, Object, Object, boolean) - Static method in class com.tangosol.util.comparator.SafeComparator
- 
Compares its two arguments for order.
- compareTo(AnnotatedMapListener<?, ?>) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- compareTo(MutableLong) - Method in class com.oracle.coherence.common.base.MutableLong
- compareTo(GrpcServerBuilderProvider) - Method in interface com.oracle.coherence.grpc.proxy.GrpcServerBuilderProvider
- 
Deprecated.
- compareTo(PropertySpec) - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Compare this object to another.
- compareTo(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Compare this Rule to another one based on thethreshold.
- compareTo(MapJsonBodyHandler) - Method in interface com.tangosol.net.management.MapJsonBodyHandler
- compareTo(SessionConfiguration) - Method in interface com.tangosol.net.SessionConfiguration
- 
Order SessionConfiguration by priority, the lowest priority comes first.
- compareTo(SessionConfiguration) - Method in class com.tangosol.net.WrapperSessionConfiguration
- compareTo(SessionProvider) - Method in interface com.tangosol.net.SessionProvider
- compareTo(Binary) - Method in class com.tangosol.util.Binary
- 
Compares this object with the specified object for order.
- compareTo(ArrayFilter.WeightedFilter) - Method in class com.tangosol.util.filter.ArrayFilter.WeightedFilter
- 
Compares this WeightedFilter with the specified WeightedFilter for order.
- compareTo(Object) - Method in class com.tangosol.util.ImmutableArrayList
- 
Compare this ImmutableArrayList with the passed Object to determine order.
- compareTo(Object) - Method in class com.tangosol.util.SortedBag.UniqueElement
- compareTo(Object) - Method in class com.tangosol.util.UID
- 
Compares this object with the specified object for order.
- compareTo(Object) - Method in class com.tangosol.util.UUID
- 
Compares this object with the specified object for order.
- comparing(Remote.Function<? super T, ? extends U>) - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Accepts a function that extracts aComparablesort key from a typeT, and returns aComparator<T>that compares by that sort key.
- comparing(Remote.Function<? super T, ? extends U>, Remote.Comparator<? super U>) - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Accepts a function that extracts a sort key from a typeT, and returns aComparator<T>that compares by that sort key using the specifiedRemote.Comparator.
- comparingDouble(Remote.ToDoubleFunction<? super T>) - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Accepts a function that extracts adoublesort key from a typeT, and returns aComparator<T>that compares by that sort key.
- comparingInt(Remote.ToIntFunction<? super T>) - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Accepts a function that extracts anintsort key from a typeT, and returns aComparator<T>that compares by that sort key.
- comparingLong(Remote.ToLongFunction<? super T>) - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Accepts a function that extracts alongsort key from a typeT, and returns aComparator<T>that compares by that sort key.
- ComparisonFilter<T,E,C> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value.
- ComparisonFilter() - Constructor for class com.tangosol.util.filter.ComparisonFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- ComparisonFilter(ValueExtractor<? super T, ? extends E>, C) - Constructor for class com.tangosol.util.filter.ComparisonFilter
- 
Construct a ComparisonFilter.
- ComparisonFilter(String, C) - Constructor for class com.tangosol.util.filter.ComparisonFilter
- 
Construct a ComparisonFilter.
- ComparisonOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A base class for comparison operators, which are operators that are used in conditional clauses such as equals, greater than, less than, etc.
- ComparisonOperator(String, String...) - Constructor for class com.tangosol.coherence.dslquery.operator.ComparisonOperator
- 
Construct a comparison operator with the given symbol and aliases.
- ComparisonValueExtractor<T,E extends Number> - Class in com.tangosol.util.extractor
- 
A synthetic ValueExtractor that returns a result of comparison between two values extracted from the same target.
- ComparisonValueExtractor() - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Default constructor (necessary for the ExternalizableLite interface).
- ComparisonValueExtractor(ValueExtractor<T, E>, ValueExtractor<T, E>) - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Construct a ComparisonValueExtractor based on two specified extractors.
- ComparisonValueExtractor(ValueExtractor<T, E>, ValueExtractor<T, E>, Comparator<? super E>) - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Construct a ComparisonValueExtractor based on two specified extractors and a Comparator object.
- ComparisonValueExtractor(String, String) - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Construct a ComparisonValueExtractor based on two method names.
- ComparisonValueExtractor(String, String, Comparator<? super E>) - Constructor for class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Construct a ComparisonValueExtractor based on two method names and a Comparator object.
- compileExpression(String, Object) - Static method in class com.tangosol.coherence.rest.util.MvelHelper
- 
CompilesExprwithin ParserContextctx.
- compileSetExpression(String, Object) - Static method in class com.tangosol.coherence.rest.util.MvelHelper
- 
CompilesExprusing ParserContextctx.
- complete() - Method in interface com.tangosol.net.SessionProvider.Context
- 
Complete this context without a session.
- complete() - Method in class com.tangosol.net.SessionProvider.DefaultContext
- complete(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Register the completion of the parsing of a value.
- complete(int) - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Register the completion of the parsing of a value.
- complete(Session) - Method in interface com.tangosol.net.SessionProvider.Context
- 
Complete this context.
- complete(Session) - Method in class com.tangosol.net.SessionProvider.DefaultContext
- complete(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
- 
Complete the load operation.
- complete(Supplier<T>) - Method in class com.tangosol.util.AsynchronousAgent
- 
Should be called if the operation completed successfully.
- Complete(Executor) - Constructor for class com.tangosol.net.AsyncNamedMap.Complete
- 
Create aAsyncNamedMap.Completeoption.
- completeExceptionally(Throwable) - Method in class com.tangosol.util.AsynchronousAgent
- 
Should be called if the operation failed for any reason.
- completeOnEmpty() - Static method in interface com.tangosol.net.topic.Subscriber
- 
Obtain the Option indicating futures should complete if the topic is empty.
- CompleteOnEmpty() - Constructor for class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
- 
Default constructor for serialization.
- Complex(ValidatingPofHandler.Complex, int, boolean) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
Construct a Complex object for a data collection or user type.
- Complex(ValidatingPofHandler.Complex, int, boolean, int) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
Construct a Complex object for a uniformly-typed data collection.
- Complex(WritingPofHandler.Complex, boolean) - Constructor for class com.tangosol.io.pof.WritingPofHandler.Complex
- 
Construct a Complex object for a data collection or user type.
- Complex(WritingPofHandler.Complex, boolean, int) - Constructor for class com.tangosol.io.pof.WritingPofHandler.Complex
- 
Construct a Complex object for a uniformly-typed data collection.
- ComplexMap(ValidatingPofHandler.Complex, int) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
- 
Construct a Complex object for a uniform-keys map.
- ComplexMap(ValidatingPofHandler.Complex, int, int) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
- 
Construct a Complex object for a uniform-keys map.
- ComplexMap(ValidatingPofHandler.Complex, int, int, int) - Constructor for class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
- 
Construct a Complex object for a uniform map.
- ComplexMap(WritingPofHandler.Complex, int) - Constructor for class com.tangosol.io.pof.WritingPofHandler.ComplexMap
- 
Construct a ComplexMap object for maps with uniformly-typed keys.
- ComplexMap(WritingPofHandler.Complex, int, int) - Constructor for class com.tangosol.io.pof.WritingPofHandler.ComplexMap
- 
Construct a ComplexMap object for maps with uniformly-typed keys and values.
- ComplexPofValue - Class in com.tangosol.io.pof.reflect
- 
An abstract base class for complex POF types, such as collections, arrays, maps, and user types.
- ComplexPofValue(PofValue, ReadBuffer, PofContext, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Construct a PofValue instance wrapping the supplied buffer.
- compose(Remote.DoubleUnaryOperator) - Method in interface com.tangosol.util.function.Remote.DoubleUnaryOperator
- 
Returns a composed operator that first applies thebeforeoperator to its input, and then applies this operator to the result.
- compose(Remote.Function<? super V, ? extends T>) - Method in interface com.tangosol.util.function.Remote.Function
- 
Returns a composed function that first applies thebeforefunction to its input, and then applies this function to the result.
- compose(Remote.IntUnaryOperator) - Method in interface com.tangosol.util.function.Remote.IntUnaryOperator
- 
Returns a composed operator that first applies thebeforeoperator to its input, and then applies this operator to the result.
- compose(Remote.LongUnaryOperator) - Method in interface com.tangosol.util.function.Remote.LongUnaryOperator
- 
Returns a composed operator that first applies thebeforeoperator to its input, and then applies this operator to the result.
- compose(ValueExtractor<? super V, ? extends T>) - Method in class com.tangosol.util.extractor.ChainedExtractor
- compose(ValueExtractor<? super V, ? extends T>) - Method in interface com.tangosol.util.ValueExtractor
- 
Returns a composed extractor that first applies thebeforeextractor to its input, and then applies this extractor to the result.
- composite(InvocableMap.EntryAggregator...) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the the combined set of results from a number of aggregators.
- composite(InvocableMap.EntryProcessor<K, V, ?>[]) - Static method in class com.tangosol.util.Processors
- 
Construct a composite processor for the specified array of individual entry processors.
- CompositeActionPolicy - Class in com.tangosol.net
- 
CompositeActionPolicy represents the "intersection" of two policies.
- CompositeActionPolicy(ActionPolicy, ActionPolicy) - Constructor for class com.tangosol.net.CompositeActionPolicy
- 
Construct a CompositeActionPolicy representing the specified policies.
- CompositeAddressProvider - Class in com.tangosol.net
- 
CompositeAddressProvider is a composite of one or more AddressProviders or addresses that also implements the Set interface.
- CompositeAddressProvider() - Constructor for class com.tangosol.net.CompositeAddressProvider
- 
Default constructor.
- CompositeAddressProvider(AddressProvider) - Constructor for class com.tangosol.net.CompositeAddressProvider
- 
Construct a CompositeAddressProvider from the specified AddressProvider.
- CompositeAddressProvider.AddressIterator - Class in com.tangosol.net
- 
An Iterator over the addresses in this AddressProvider.
- CompositeAddressProvider.SingleProvider - Class in com.tangosol.net
- 
AddressProvider wrapper for a single address dynamically added to this AddressSet.
- CompositeAggregator<K,V> - Class in com.tangosol.util.aggregator
- 
CompositeAggregator provides an ability to execute a collection of aggregators against the same subset of the entries in an InvocableMap, resulting in a list of corresponding aggregation results.
- CompositeAggregator() - Constructor for class com.tangosol.util.aggregator.CompositeAggregator
- 
Default constructor (necessary for the ExternalizableLite interface).
- CompositeAggregator(InvocableMap.EntryAggregator[]) - Constructor for class com.tangosol.util.aggregator.CompositeAggregator
- 
Construct a CompositeAggregator based on a specified EntryAggregator array.
- CompositeAggregator.Parallel - Class in com.tangosol.util.aggregator
- 
Deprecated.As of Coherence 12.2.1. Use CompositeAggregator instead.
- CompositeKey<P,S> - Class in com.tangosol.util
- 
Key class that consists of a primary and secondary component.
- CompositeKey() - Constructor for class com.tangosol.util.CompositeKey
- 
Default constructor.
- CompositeKey(P, S) - Constructor for class com.tangosol.util.CompositeKey
- 
Create a new CompositeKey that consists of the given primary and secondary components.
- CompositeProcessor<K,V> - Class in com.tangosol.util.processor
- 
The CompositeProcessor represents a collection of entry processors that are invoked sequentially against the same Entry.
- CompositeProcessor() - Constructor for class com.tangosol.util.processor.CompositeProcessor
- 
Default constructor (necessary for the ExternalizableLite interface).
- CompositeProcessor(InvocableMap.EntryProcessor<K, V, ?>[]) - Constructor for class com.tangosol.util.processor.CompositeProcessor
- 
Construct a CompositeProcessor for the specified array of individual entry processors.
- CompositeSchemeProcessor<T extends AbstractCompositeScheme> - Class in com.tangosol.coherence.config.xml.processor
- 
ACompositeSchemeProcessoris aCustomizableBuilderProcessorfor schemes that consist of a front and back scheme.
- CompositeSchemeProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.CompositeSchemeProcessor
- 
Constructs aCompositeSchemeProcessorfor the specifiedClass.
- CompositeSocketAddressProvider - Class in com.tangosol.net
- 
CompositeSocketAddressProvider is a composite of one or more SocketAddressProviders.
- CompositeSocketAddressProvider(SocketAddressProvider) - Constructor for class com.tangosol.net.CompositeSocketAddressProvider
- 
Construct a CompositeSocketAddressProvider from the specifiedSocketAddressProvider.
- CompositeSocketAddressProvider(SocketAddress) - Constructor for class com.tangosol.net.CompositeSocketAddressProvider
- 
Construct a CompositeSocketAddressProvider from the specifiedSocketAddress.
- CompositeUpdater - Class in com.tangosol.util.extractor
- 
A ValueUpdater implementation based on an extractor-updater pair that could also be used as a ValueManipulator.
- CompositeUpdater() - Constructor for class com.tangosol.util.extractor.CompositeUpdater
- 
Default constructor (necessary for the ExternalizableLite interface).
- CompositeUpdater(ValueExtractor, ValueUpdater) - Constructor for class com.tangosol.util.extractor.CompositeUpdater
- 
Construct a CompositeUpdater based on the specified extractor and updater.
- CompositeUpdater(String) - Constructor for class com.tangosol.util.extractor.CompositeUpdater
- 
Construct a CompositeUpdater for a specified method name sequence.
- CompoundBaseToken - Class in com.tangosol.coherence.dsltools.base
- 
CompoundBaseToken is the abstract base class for all tokens processed by the low level BaseTokenScanner that are made up of two or more BaseTokens.
- CompoundBaseToken() - Constructor for class com.tangosol.coherence.dsltools.base.CompoundBaseToken
- CompressionFilter - Class in com.tangosol.net
- 
Deprecated.As of Coherence 3.7
- CompressionFilter() - Constructor for class com.tangosol.net.CompressionFilter
- 
Deprecated.
- CompressionFilter.DeflaterOutputShell - Class in com.tangosol.net
- 
Deprecated.DeflaterOutputShell enforces the "end" call for the corresponding Deflater object.
- CompressionFilter.InflaterInputShell - Class in com.tangosol.net
- 
Deprecated.InflaterInputShell enforces the "end" call for the corresponding Inflater object.
- compute(Object, BiFunction) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- compute(Object, BiFunction) - Method in class com.tangosol.util.SafeSortedMap
- compute(Object, BiFunction) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- compute(K, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Compute a new mapping for the specified key and its current value.
- compute(K, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- 
Compute a new mapping for the specified key and its current value.
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.SafeHashMap
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- computeCanonicalName(String) - Static method in class com.tangosol.util.extractor.UniversalUpdater
- 
Compute the canonical name for this updater.
- computeCanonicalName(String, Object[]) - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Compute the canonical name for this extractor.
- computeChannelCount(int) - Static method in interface com.tangosol.net.topic.TopicDependencies
- 
Compute the channel count based on the supplied partition count.
- computeIfAbsent(Object, Function) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- computeIfAbsent(Object, Function) - Method in class com.tangosol.util.SafeSortedMap
- computeIfAbsent(Object, Function) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- computeIfAbsent(K, Remote.Function<? super K, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Compute the value using the given mapping function and enter it into this map (unlessnull), if the specified key is not already associated with a value (or is mapped tonull).
- computeIfAbsent(K, Remote.Function<? super K, ? extends V>) - Method in class com.tangosol.net.cache.NearCache
- 
Compute the value using the given mapping function and enter it into this map (unlessnull), if the specified key is not already associated with a value (or is mapped tonull).
- computeIfAbsent(K, Remote.Function<? super K, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- 
Compute the value using the given mapping function and enter it into this map (unlessnull), if the specified key is not already associated with a value (or is mapped tonull).
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.tangosol.net.cache.NearCache
- 
Note that the previous example will not work as expected if this method is called on a distributed map, as theaddmethod will be called on a client-side copy of the collection stored on the server.
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- 
Note that the previous example will not work as expected if this method is called on a distributed map, as theaddmethod will be called on a client-side copy of the collection stored on the server.
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.tangosol.util.SafeHashMap
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- computeIfPresent(Object, BiFunction) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- computeIfPresent(Object, BiFunction) - Method in class com.tangosol.util.SafeSortedMap
- computeIfPresent(Object, BiFunction) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- computeIfPresent(K, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Compute a new mapping given the key and its current mapped value, if the value for the specified key is present and non-null.
- computeIfPresent(K, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- 
Compute a new mapping given the key and its current mapped value, if the value for the specified key is present and non-null.
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.SafeHashMap
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- computeSafeWaitTime(long) - Static method in class com.oracle.coherence.common.base.TimeHelper
- 
compute the number of milliseconds until the specified time.
- computeSafeWaitTime(long) - Static method in class com.tangosol.util.Base
- 
compute the number of milliseconds until the specified time.
- computeTarget() - Method in class com.tangosol.util.extractor.ChainedExtractor
- 
Return the target of the first extractor in composite extractor.
- computeTmpDir() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
compute the system's temp directory.
- concat(Binary) - Method in class com.tangosol.util.Binary
- 
Concatenate the passed Binary onto this Binary.
- CONCAT_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will result in a concatenation of all function arguments to a single string result.
- CONCUR_EXTERNAL - Static variable in interface com.tangosol.util.TransactionMap
- 
External concurrency.
- CONCUR_OPTIMISTIC - Static variable in interface com.tangosol.util.TransactionMap
- 
Optimistic concurrency.
- CONCUR_PESSIMISTIC - Static variable in interface com.tangosol.util.TransactionMap
- 
Pessimistic concurrency.
- ConcurrentMap<K,V> - Interface in com.tangosol.util
- 
Map with additional concurrency features.
- ConcurrentNotifier - Class in com.oracle.coherence.common.base
- 
A Condition-like object, usable by multiple threads to both wait and signal.
- ConcurrentNotifier() - Constructor for class com.oracle.coherence.common.base.ConcurrentNotifier
- ConcurrentNotifier.Link - Class in com.oracle.coherence.common.base
- 
A link in a stack of waiting threads.
- ConcurrentWrapperCollection(Collection<E>) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- 
Create an ConcurrentWrapperCollection which delegates to the specified Collection.
- ConcurrentWrapperCollection(Collection<E>, ReadWriteLock) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- 
Create an ConcurrentWrapperCollection which delegates to the specified Collection.
- ConcurrentWrapperEntry(Map.Entry<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- 
Create an ConcurrentWrapperEntry which delegates to the specified Map Entry.
- ConcurrentWrapperEntry(Map.Entry<K, V>, ReadWriteLock) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- 
Create an ConcurrentWrapperEntry which delegates to the specified Map Entry.
- ConcurrentWrapperEntry(Map.Entry<K, V>, ReadWriteLock, boolean) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- 
Create an ConcurrentWrapperEntry which delegates to the specified Map Entry.
- ConcurrentWrapperEntrySet(Set<Map.Entry<K, V>>, ReadWriteLock, boolean) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntrySet
- 
Create an ConcurrentWrapperSet which delegates to the specified Set.
- ConcurrentWrapperMap() - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- ConcurrentWrapperMap(Map<K, V>) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
Create an ConcurrentWrapperMap which delegates to the specified Map.
- ConcurrentWrapperMap(Map<K, V>, ReadWriteLock) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
Create an ConcurrentWrapperMap which delegates to the specified Map.
- ConcurrentWrapperMap(Map<K, V>, ReadWriteLock, boolean) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
Create an ConcurrentWrapperMap which delegates to the specified Map.
- ConcurrentWrapperSet(Set<E>) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperSet
- 
Create an ConcurrentWrapperSet which delegates to the specified Set.
- ConcurrentWrapperSet(Set<E>, ReadWriteLock) - Constructor for class com.tangosol.util.WrapperCollections.ConcurrentWrapperSet
- 
Create an ConcurrentWrapperSet which delegates to the specified Set.
- conditional(Filter<V>, InvocableMap.EntryProcessor<K, V, T>) - Static method in class com.tangosol.util.Processors
- 
Construct a conditional processor for a specified filter and the processor.
- ConditionalElementProcessor<T> - Interface in com.tangosol.config.xml
- 
AConditionalElementProcessoris anElementProcessorthat supports conditionally processingXmlElements.
- ConditionalExtractor<T,E> - Class in com.tangosol.util.extractor
- 
An IndexAwareExtractor implementation that is only used to create aConditionalIndex.
- ConditionalExtractor() - Constructor for class com.tangosol.util.extractor.ConditionalExtractor
- 
Construct the ConditionalExtractor.
- ConditionalExtractor(Filter, ValueExtractor<T, E>, boolean) - Constructor for class com.tangosol.util.extractor.ConditionalExtractor
- 
Construct the ConditionalExtractor.
- ConditionalExtractor(Filter, ValueExtractor<T, E>, boolean, boolean) - Constructor for class com.tangosol.util.extractor.ConditionalExtractor
- 
Construct the ConditionalExtractor.
- ConditionalIndex - Class in com.tangosol.util
- 
ConditionalIndex is aMapIndeximplementation that uses an associated filter to evaluate whether or not an entry should be indexed.
- ConditionalIndex(Filter, ValueExtractor, boolean, Comparator, boolean, BackingMapContext) - Constructor for class com.tangosol.util.ConditionalIndex
- 
Construct a ConditionalIndex.
- ConditionalProcessor<K,V,T> - Class in com.tangosol.util.processor
- 
Conditional entry processor represents a processor that is invoked conditionally based on the result of an entry evaluation.
- ConditionalProcessor() - Constructor for class com.tangosol.util.processor.ConditionalProcessor
- 
Default constructor (necessary for the ExternalizableLite interface).
- ConditionalProcessor(Filter<V>, InvocableMap.EntryProcessor<K, V, T>) - Constructor for class com.tangosol.util.processor.ConditionalProcessor
- 
Construct a ConditionalProcessor for the specified filter and the processor.
- ConditionalPut<K,V> - Class in com.tangosol.util.processor
- 
ConditionalPut is an EntryProcessor that performs anEntry.setValueoperation if the specified condition is satisfied.
- ConditionalPut() - Constructor for class com.tangosol.util.processor.ConditionalPut
- 
Default constructor (necessary for the ExternalizableLite interface).
- ConditionalPut(Filter, V) - Constructor for class com.tangosol.util.processor.ConditionalPut
- 
Construct a ConditionalPut that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.
- ConditionalPut(Filter, V, boolean) - Constructor for class com.tangosol.util.processor.ConditionalPut
- 
Construct a ConditionalPut that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.
- ConditionalPutAll<K,V> - Class in com.tangosol.util.processor
- 
ConditionalPutAll is an EntryProcessor that performs aEntry.setValueoperation for multiple entries that satisfy the specified condition.
- ConditionalPutAll() - Constructor for class com.tangosol.util.processor.ConditionalPutAll
- 
Default constructor (necessary for the ExternalizableLite interface).
- ConditionalPutAll(Filter, Map<? extends K, ? extends V>) - Constructor for class com.tangosol.util.processor.ConditionalPutAll
- 
Construct a ConditionalPutAll processor that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.
- ConditionalRemove<K,V> - Class in com.tangosol.util.processor
- 
ConditionalRemove is an EntryProcessor that performs anEntry.removeoperation if the specified condition is satisfied.
- ConditionalRemove() - Constructor for class com.tangosol.util.processor.ConditionalRemove
- 
Default constructor (necessary for the ExternalizableLite interface).
- ConditionalRemove(Filter) - Constructor for class com.tangosol.util.processor.ConditionalRemove
- 
Construct a ConditionalRemove processor that removes an InvocableMap entry if and only if the filter applied to the entry evaluates to true.
- ConditionalRemove(Filter, boolean) - Constructor for class com.tangosol.util.processor.ConditionalRemove
- 
Construct a ConditionalRemove processor that removes an InvocableMap entry if and only if the filter applied to the entry evaluates to true.
- ConditionalRemoveAction() - Constructor for class com.tangosol.util.SegmentedConcurrentMap.ConditionalRemoveAction
- config(String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.CONFIGseverity.
- config(String, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.CONFIGseverity.
- config(Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) withLogger.CONFIGseverity.
- config(Supplier<String>) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.CONFIGseverity.
- config(Supplier<String>, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.CONFIGseverity.
- Config - Class in com.tangosol.coherence.config
- 
Configis a helper class for processing a Coherence configuration system properties.
- Config() - Constructor for class com.tangosol.coherence.config.Config
- CONFIG - Static variable in class com.oracle.coherence.common.base.Logger
- 
Severity 4 indicates configuration related log message.
- ConfigPropertyChanged - Class in com.oracle.coherence.mp.config
- 
An event that will be raised whenever any config property is added to, updated in, or removed from theCoherenceConfigSource.
- ConfigPropertyResolver - Class in com.oracle.coherence.mp.config
- 
An implementation of Coherence property resolvers that reads system properties and environment variables from MP Config.
- ConfigPropertyResolver() - Constructor for class com.oracle.coherence.mp.config.ConfigPropertyResolver
- 
ConstructConfigPropertyResolverinstance.
- ConfigurableAddressProvider - Class in com.tangosol.net
- 
ConfigurableAddressProvider is an implementation of the AddressProvider interface based on a static list of addresses configured in an XML element that contains one or more items in the following format:
- ConfigurableAddressProvider(XmlElement) - Constructor for class com.tangosol.net.ConfigurableAddressProvider
- 
Deprecated.
- ConfigurableAddressProvider(XmlElement, boolean) - Constructor for class com.tangosol.net.ConfigurableAddressProvider
- 
Deprecated.
- ConfigurableAddressProvider(Iterable<ConfigurableAddressProvider.AddressHolder>, boolean) - Constructor for class com.tangosol.net.ConfigurableAddressProvider
- 
Constructs aConfigurableAddressProviderusing the specifiedConfigurableAddressProvider.AddressHolders.
- ConfigurableAddressProvider.AddressHolder - Class in com.tangosol.net
- 
A stateful holder for an obtaining an InetSocketAddress object.
- ConfigurableAddressProviderFactory - Class in com.tangosol.net
- 
Deprecated.
- ConfigurableAddressProviderFactory() - Constructor for class com.tangosol.net.ConfigurableAddressProviderFactory
- 
Deprecated.Default constructor.
- ConfigurableCacheFactory - Interface in com.tangosol.net
- 
An interface for cache factory.
- ConfigurableCacheFactorySuppliers - Interface in com.oracle.coherence.grpc.proxy
- 
A factory ofConfigurableCacheFactorysupplier functions that can return aConfigurableCacheFactoryfor a given scope name.
- ConfigurableCacheFactorySuppliers.DefaultCacheFactorySupplier - Class in com.oracle.coherence.grpc.proxy
- 
The defaultConfigurableCacheFactorysupplier.
- ConfigurableCacheFactorySuppliers.FixedCacheFactorySupplier - Class in com.oracle.coherence.grpc.proxy
- 
A fixedConfigurableCacheFactorysupplier that only supplies theConfigurableCacheFactoryinstances provided when it was constructed.
- ConfigurableCacheMap - Interface in com.tangosol.net.cache
- 
An extension to the CacheMap interface that supports runtime configuration and monitoring of various caching properties.
- ConfigurableCacheMap.Entry - Interface in com.tangosol.net.cache
- 
A cache Entry carries information additional to the base Map Entry in order to support eviction and expiry.
- ConfigurableCacheMap.EvictionApprover - Interface in com.tangosol.net.cache
- 
EvictionApprover is used to approve the eviction of an entry from the underlying ConfigurableCacheMap.
- ConfigurableCacheMap.EvictionPolicy - Interface in com.tangosol.net.cache
- 
An eviction policy is an object that the cache provides with access information, and when requested, the eviction policy selects and evicts entries from the cache.
- ConfigurableCacheMap.UnitCalculator - Interface in com.tangosol.net.cache
- 
A unit calculator is an object that can calculate the cost of caching an object.
- ConfigurableLocalAddressProvider - Class in com.tangosol.net
- 
ConfigurableLocalAddressProvider is an AddressProvider which is only capable of returning local addresses.
- ConfigurableLocalAddressProvider(int) - Constructor for class com.tangosol.net.ConfigurableLocalAddressProvider
- 
Constructs a ConfigurableLocalAddressProvider for all local IPs and the given port.
- ConfigurableLocalAddressProvider(XmlElement) - Constructor for class com.tangosol.net.ConfigurableLocalAddressProvider
- 
Deprecated.
- ConfigurableLocalAddressProvider(XmlElement, boolean) - Constructor for class com.tangosol.net.ConfigurableLocalAddressProvider
- 
Deprecated.
- ConfigurableLocalAddressProvider(Iterable<ConfigurableAddressProvider.AddressHolder>, boolean) - Constructor for class com.tangosol.net.ConfigurableLocalAddressProvider
- 
Constructs a ConfigurableLocalAddressProvider using the specifiedConfigurableAddressProvider.AddressHolders.
- ConfigurablePofContext - Class in com.tangosol.io.pof
- 
This class implements thePofContextinterface using information provided in a configuration file (or in a passed XML configuration) as well as classes annotated withPortableType.
- ConfigurablePofContext() - Constructor for class com.tangosol.io.pof.ConfigurablePofContext
- 
Default constructor.
- ConfigurablePofContext(ConfigurablePofContext) - Constructor for class com.tangosol.io.pof.ConfigurablePofContext
- 
Copy constructor for a ConfigurablePofContext.
- ConfigurablePofContext(XmlElement) - Constructor for class com.tangosol.io.pof.ConfigurablePofContext
- 
Create a ConfigurablePofContext that will use the passed configuration information.
- ConfigurablePofContext(String) - Constructor for class com.tangosol.io.pof.ConfigurablePofContext
- 
Create a ConfigurablePofContext that will load configuration information from the specified locator.
- ConfigurablePofContext.PofConfig - Class in com.tangosol.io.pof
- 
The information related to the configuration of a particular PofContext for a specific URI and ClassLoader.
- ConfigurableQuorumPolicy - Class in com.tangosol.net
- 
ConfigurableQuorumPolicy provides a Quorum-basedActionPolicyfor services based on the cluster-configuration.
- ConfigurableQuorumPolicy() - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy
- 
Create a ConfigurableQuorumPolicy.
- ConfigurableQuorumPolicy.ClusterQuorumPolicy - Class in com.tangosol.net
- 
ClusterQuorumPolicy defines an action policy that is applicable to the cluster.
- ConfigurableQuorumPolicy.MembershipQuorumPolicy - Class in com.tangosol.net
- 
MembershipQuorumPolicy is a quorum policy that is stateless and based solely on service membership sizes.
- ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener - Class in com.tangosol.net
- 
QuorumListener is used to subscribe the quorum policy to receive service membership events.
- ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule - Class in com.tangosol.net
- 
A quorum rule defines a set of allowable actions beyond the rule's threshold size.
- ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy - Class in com.tangosol.net
- 
PartitionedCacheQuorumPolicy defines a configurable quorum policy that is applicable to a DistributedCacheService.
- ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule - Enum in com.tangosol.net
- 
Action Rules forConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.Notification - Class in com.tangosol.net
- 
Notification is a simple struct carrying the notification info.
- ConfigurableQuorumPolicy.ProxyQuorumPolicy - Class in com.tangosol.net
- 
ProxyQuorumPolicy defines a configurable quorum policy that is applicable to a proxy service.
- ConfigurableSerializerFactory - Class in com.tangosol.io
- 
Deprecated.
- ConfigurableSerializerFactory() - Constructor for class com.tangosol.io.ConfigurableSerializerFactory
- 
Deprecated.
- ConfigurableSnapshotArchiverFactory - Class in com.tangosol.persistence
- 
ASnapshotArchiverFactoryimplementation that creates instances of a SnapshotArchiver class configured using an XmlElement.
- ConfigurableSnapshotArchiverFactory() - Constructor for class com.tangosol.persistence.ConfigurableSnapshotArchiverFactory
- Configuration - com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility.ObjectNameType
- 
Cache Configuration
- ConfigurationException - Exception in com.tangosol.config
- 
AConfigurationExceptioncaptures information concerning an invalid configuration of Coherence.
- ConfigurationException(String, String) - Constructor for exception com.tangosol.config.ConfigurationException
- 
Constructs aConfigurationException.
- ConfigurationException(String, String, Throwable) - Constructor for exception com.tangosol.config.ConfigurationException
- 
Constructs aConfigurationException(with a cause).
- ConfigurationProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AConfigurationProcessoris responsible for processing a configurationXmlElementto produce aCacheConfigobject.
- ConfigurationProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ConfigurationProcessor
- configure() - Method in class com.tangosol.coherence.rest.server.InjectionBinder
- configure() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Performs final configuration of anExtensibleConfigurableCacheFactoryinstance prior to it being used by Coherence.
- configure(BerkeleyDBBinaryStoreManager) - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Configure the new Environment.
- configure(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[]) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Configure and initialize this policy with the specified quorum rules.
- configure(TcpDatagramSocket) - Method in class com.tangosol.net.TcpDatagramSocketProvider
- 
Configure the socket.
- configure(XmlElement) - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- configure(XmlElement) - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- configure(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Configures this RestConfig instance using the specified XML element.
- configure(XmlElement) - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Deprecated.
- configure(XmlElement) - Method in class com.tangosol.net.WrapperService
- 
Configure the controllable service.
- configure(XmlElement) - Method in interface com.tangosol.util.Controllable
- 
Deprecated.
- configure(ServerBuilder<?>, InProcessServerBuilder) - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- configure(ServerBuilder<?>, InProcessServerBuilder) - Method in interface com.oracle.coherence.grpc.proxy.GrpcServerConfiguration
- 
Configure the server builders.
- configureBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Configures a backing map according to the scheme.
- configureCache(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Ensures a cache for given scheme.
- configureCacheStore(ReadWriteBackingMap.StoreWrapper, boolean, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set up the StoreWrapper that this backing map will use.
- CONFIGURED - com.tangosol.util.SimpleMapIndex.IndexCalculator.CalculatorState
- configureEviction(int, ConfigurableCacheMap.EvictionPolicy) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Configure the eviction type and policy.
- configureFile(File) - Method in class com.tangosol.io.nio.MappedBufferManager
- 
Configure the buffer manager based on the passed file, which may be null to imply a default temp file, a directory to imply that a file be created in that directory, or it may be the temp file itself.
- configureInterceptors(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Using the provided base XML find all interceptors instantiating as appropriate and registering with the EventsRegistry.
- configureInternalCache(ObservableMap) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Configure the internal cache that this backing map uses to store its "in-memory" data.
- configureJaxbMarshaller(Marshaller) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
- 
Configure a JAXB marshaller.
- configureJaxbUnmarshaller(Unmarshaller) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
- 
Configure a JAXB unmarshaller.
- configureReadThread(double) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set up the optional refresh-ahead thread and queue that this backing map will use.
- configureSynchronization(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Set up the listeners that keep theContinuousQueryCacheup-to-date.
- configureUnitCalculator(int, ConfigurableCacheMap.UnitCalculator) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Configure the unit calculator type and implementation.
- configureUnitCalculator(XmlElement, ConfigurableCacheMap, DefaultConfigurableCacheFactory.CacheInfo, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Configure a UnitCalculator for the specified ConfigurableCacheMap.
- configureWorker(Daemon.DaemonWorker) - Method in class com.tangosol.util.Daemon
- 
Configure a worker to use as a daemon.
- configureWriteThread(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set up the optional write-behind thread and queue that this backing map will use.
- ConfigUri - Annotation Type in com.oracle.coherence.cdi
- 
A qualifier annotation used to indicate a configuration resource URI.
- ConfigUri.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theConfigUriannotation.
- connect(Socket, SocketAddress) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Connect a socket while still respecting the calling thread'stimeout.
- connect(Socket, SocketAddress, int) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Connect a socket within a given timeout while still respecting the calling thread'stimeout.
- CONNECT - Static variable in interface com.tangosol.net.ProxyService.ProxyAction
- 
Singleton action for accepting a client connection.
- CONNECT_RULE_NAME - Static variable in class com.tangosol.coherence.config.builder.ProxyQuorumPolicyBuilder
- 
Connect description and also xml configuration element name.
- Connecting - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any CONNECTING event.
- Connecting.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theConnectingannotation.
- CONNECTION_MANAGER_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the ConnectionManagerMBean.
- CONNECTION_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the ConnectionMBean.
- ConnectionException - Exception in com.tangosol.net.messaging
- 
Signals that an underlying communication channel used by a Connection may have been closed, severed, or become unusable.
- ConnectionException() - Constructor for exception com.tangosol.net.messaging.ConnectionException
- 
Construct a ConnectionException with no detail message.
- ConnectionException(String) - Constructor for exception com.tangosol.net.messaging.ConnectionException
- 
Construct a ConnectionException with the specified detail message.
- ConnectionException(String, Connection) - Constructor for exception com.tangosol.net.messaging.ConnectionException
- 
Construct a ConnectionException with the specified detail message and Connection.
- ConnectionException(String, Throwable) - Constructor for exception com.tangosol.net.messaging.ConnectionException
- 
Construct a ConnectionException from a Throwable and an additional description.
- ConnectionException(String, Throwable, Connection) - Constructor for exception com.tangosol.net.messaging.ConnectionException
- 
Construct a ConnectionException from a Throwable, additional description, and a Connection.
- ConnectionException(Throwable) - Constructor for exception com.tangosol.net.messaging.ConnectionException
- 
Construct a ConnectionException from a Throwable.
- ConnectionException(Throwable, Connection) - Constructor for exception com.tangosol.net.messaging.ConnectionException
- 
Construct a ConnectionException from a Throwable and Connection.
- Constants - Class in com.tangosol.coherence.jcache
- 
Constants used by the Coherence JCache Adapter.
- Constants() - Constructor for class com.tangosol.coherence.jcache.Constants
- consumer(Remote.Consumer<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable Consumer.
- consumeSignal() - Method in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- consumeSignal() - Method in class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
- 
Consume the signal.
- ContainerHelper - Class in com.tangosol.coherence.jcache.common
- 
Helpers for supporting Coherence JCache in Container Environment.
- ContainerHelper() - Constructor for class com.tangosol.coherence.jcache.common.ContainerHelper
- ContainerHelper.JCacheLifecycleInterceptor - Class in com.tangosol.coherence.jcache.common
- 
AnEventInterceptorthat initializes JCache for running within a container.
- ContainerPassThroughResourceConfig - Class in com.tangosol.coherence.rest.server
- 
An extension ofPassThroughResourceConfigthat should be used for container deployments of Coherence REST when pass-through is required.
- ContainerPassThroughResourceConfig() - Constructor for class com.tangosol.coherence.rest.server.ContainerPassThroughResourceConfig
- ContainerResourceConfig - Class in com.tangosol.coherence.rest.server
- 
An extension ofDefaultResourceConfigthat should be used for container deployments of Coherence REST.
- ContainerResourceConfig() - Constructor for class com.tangosol.coherence.rest.server.ContainerResourceConfig
- 
Default constructor.
- contains(int) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Return true if the current rule contains the specified action mask.
- contains(int) - Method in class com.tangosol.net.partition.PartitionSet
- 
Check whether or not the specified partition belongs to the set.
- contains(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSet
- 
Check whether or not the specified partition set belongs to this set.
- contains(ValueExtractor<T, C>, E) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted collection contains the specified value.
- contains(Comparable) - Method in class com.tangosol.util.Tree
- 
Determine if the passed key is in the tree.
- contains(Object) - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
- 
Returns true if this collection contains the specified element.
- contains(Object) - Method in class com.tangosol.io.nio.BinaryMap.KeySet
- 
Determine if a particular key is present in the Set.
- contains(Object) - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- contains(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- 
Returns true if this collection contains the specified element.
- contains(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- 
Determine if a particular key is present in the Set.
- contains(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
- 
Returns true if this collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
- 
Returns true if this collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
- 
Returns true if this collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.ChainedCollection
- contains(Object) - Method in class com.tangosol.util.ChainedMap.EntrySet
- 
Returns true if this collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.ChainedSet
- contains(Object) - Method in class com.tangosol.util.CircularArrayList
- contains(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- contains(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- contains(Object) - Method in class com.tangosol.util.CopyOnWriteMap.EntrySet
- contains(Object) - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
- contains(Object) - Method in class com.tangosol.util.DeltaSet
- 
Returns true if this Collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns true if this List contains the specified element.
- contains(Object) - Method in class com.tangosol.util.ImmutableMultiList
- 
Returns true if this List contains the specified element.
- contains(Object) - Method in class com.tangosol.util.InflatableCollection
- contains(Object) - Method in class com.tangosol.util.LiteSet
- 
Returns true if this Set contains the specified element.
- contains(Object) - Method in class com.tangosol.util.MapSet
- 
Returns true if this Set contains the specified element.
- contains(Object) - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Returns true if this Collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.OpenHashSet
- contains(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Returns true if this Collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Returns true if this Collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.SafeHashMap.EntrySet
- 
Returns true if this collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.SafeHashMap.KeySet
- 
Determine if a particular key is present in the Set.
- contains(Object) - Method in class com.tangosol.util.SafeLinkedList
- 
Returns true if this List contains the specified element.
- contains(Object) - Method in class com.tangosol.util.SafeSortedMap.Values
- contains(Object) - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
- 
Returns true if this collection contains the specified element.
- contains(Object) - Method in class com.tangosol.util.SegmentedHashMap.KeySet
- 
Determine if a particular key is present in the Set.
- contains(Object) - Method in class com.tangosol.util.SimpleLongArray
- 
Determine if the LongArray contains the specified element.
- contains(Object) - Method in class com.tangosol.util.SortedBag
- contains(Object) - Method in class com.tangosol.util.SubList
- contains(Object) - Method in class com.tangosol.util.SubSet
- contains(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- contains(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- contains(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- contains(String) - Method in class com.tangosol.util.StringTable
- 
Determine if the passed string is in the table.
- contains(EventListener) - Method in class com.tangosol.util.Listeners
- 
Check if a listener is in the list of listeners.
- contains(T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- contains(V) - Method in class com.tangosol.util.AbstractLongArray
- 
Determine if the LongArray contains the specified element.
- contains(V) - Method in class com.tangosol.util.AbstractSafeLongArray
- contains(V) - Method in interface com.tangosol.util.LongArray
- 
Determine if the LongArray contains the specified element.
- contains(V) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- contains(V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- containsAll(ValueExtractor<T, C>, E...) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted collection contains all of the specified values.
- containsAll(ValueExtractor<T, C>, Set<? extends E>) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted collection contains all of the specified values.
- containsAll(Collection) - Method in class com.tangosol.util.MapSet
- 
Returns true if this Set contains all of the elements in the specified Collection.
- containsAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Returns true if this Collection contains all of the elements in the specified Collection.
- containsAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Returns true if this Collection contains all of the elements in the specified Collection.
- containsAll(Collection) - Method in class com.tangosol.util.SafeLinkedList
- 
Returns true if this List contains all of the elements of the specified collection.
- containsAll(Collection<?>) - Method in class com.tangosol.util.ChainedCollection
- containsAll(Collection<?>) - Method in class com.tangosol.util.ChainedSet
- containsAll(Collection<?>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- containsAll(Collection<?>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- containsAll(Collection<?>) - Method in class com.tangosol.util.LiteSet
- 
Returns true if this Set contains all of the elements in the specified Collection.
- containsAll(Collection<?>) - Method in class com.tangosol.util.SubList
- containsAll(Collection<?>) - Method in class com.tangosol.util.SubSet
- containsAll(Collection<?>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- containsAll(Collection<?>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- ContainsAllFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which tests aCollectionor Object array value returned from a method invocation for containment of all values in a Set.
- ContainsAllFilter() - Constructor for class com.tangosol.util.filter.ContainsAllFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- ContainsAllFilter(ValueExtractor<? super T, ? extends E>, Set<?>) - Constructor for class com.tangosol.util.filter.ContainsAllFilter
- 
Construct an ContainsAllFilter for testing containment of the given Set of values.
- ContainsAllFilter(String, Set<?>) - Constructor for class com.tangosol.util.filter.ContainsAllFilter
- 
Construct an ContainsAllFilter for testing containment of the given Set of values.
- ContainsAllOperator - Class in com.tangosol.coherence.dslquery.operator
- 
An operator representing the conditional "contains all" operation.
- ContainsAllOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.ContainsAllOperator
- 
Construct a ContainsAllOperator.
- containsAny(ValueExtractor<T, C>, E...) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted collection contains any of the specified values.
- containsAny(ValueExtractor<T, C>, Set<? extends E>) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted collection contains any of the specified values.
- ContainsAnyFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which tests aCollectionor Object array value returned from a method invocation for containment of any value in a Set.
- ContainsAnyFilter() - Constructor for class com.tangosol.util.filter.ContainsAnyFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- ContainsAnyFilter(ValueExtractor<? super T, ? extends E>, Set<?>) - Constructor for class com.tangosol.util.filter.ContainsAnyFilter
- 
Construct an ContainsAnyFilter for testing containment of any value in the given Set.
- ContainsAnyFilter(String, Set<?>) - Constructor for class com.tangosol.util.filter.ContainsAnyFilter
- 
Construct an ContainsAnyFilter for testing containment of any value in the given Set.
- ContainsAnyOperator - Class in com.tangosol.coherence.dslquery.operator
- 
An operator representing the conditional "contains any" operation.
- ContainsAnyOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.ContainsAnyOperator
- 
Construct a ContainsAnyOperator.
- containsEntry(CacheRequestHolder<ContainsEntryRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theContainsEntryRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of the contains entry request as a serialized Boolean.
- containsEntry(ContainsEntryRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Returnstrueif this map contains a mapping for the specified key to the specified value.
- containsEntry(ContainsEntryRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- containsEntry(ContainsEntryRequest, StreamObserver<BoolValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- containsEntry(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aContainsEntryRequest.
- ContainsFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which tests aCollectionor Object array value returned from a method invocation for containment of a given value.
- ContainsFilter() - Constructor for class com.tangosol.util.filter.ContainsFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- ContainsFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.ContainsFilter
- 
Construct an ContainsFilter for testing containment of the given object.
- ContainsFilter(String, E) - Constructor for class com.tangosol.util.filter.ContainsFilter
- 
Construct an ContainsFilter for testing containment of the given object.
- containsKey(CacheRequestHolder<ContainsKeyRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theContainsKeyRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of the contains key request.
- containsKey(ContainsKeyRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Returnstrueif this map contains a mapping for the specified key.
- containsKey(ContainsKeyRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- containsKey(ContainsKeyRequest, StreamObserver<BoolValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- containsKey(Binary) - Method in interface com.tangosol.io.BinaryStore.KeySetAware
- 
Return true iff this BinaryStore contains a mapping for the specified key.
- containsKey(Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- containsKey(Object) - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.cache.CachingMap
- containsKey(Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.cache.OverflowMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- containsKey(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- containsKey(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.util.ChainedMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in interface com.tangosol.util.ConcurrentMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- containsKey(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- containsKey(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- containsKey(Object) - Method in class com.tangosol.util.OpenHashMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.util.SafeHashMap
- 
Returns true if this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.util.SafeSortedMap
- containsKey(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- containsKey(Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns true iff this map contains a mapping for the specified key.
- containsKey(Object) - Method in class com.tangosol.util.SetMap
- containsKey(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- containsKey(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- containsKey(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aClearRequest.
- containsKey(K) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- containsKey(K) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- containsKey(K) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- containsKey(K) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- containsKey(K) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Returns true if this map contains a mapping for the specified key.
- containsMacro() - Method in class com.tangosol.config.expression.ValueMacroExpression
- 
Check if this contains a macro.
- containsMacro(String) - Static method in class com.tangosol.config.expression.ValueMacroExpression
- 
Check if string contains a macro.
- containsNamedQuery(String) - Method in class com.tangosol.coherence.rest.config.QueryConfig
- 
Return true if this configuration contains a query with given name.
- ContainsOperator - Class in com.tangosol.coherence.dslquery.operator
- 
An operator representing the conditional "contains" operation.
- ContainsOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.ContainsOperator
- 
Construct a ContainsOperator.
- ContainsOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
ContainsOPToken is used to implement a contains operation that checks for membership in a list.
- ContainsOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.ContainsOPToken
- 
Construct a new ContainsOPToken with the given parameters.
- containsRegisteredDelimiter(String) - Static method in class com.tangosol.config.expression.ValueMacroExpression
- 
Return true ifsMacrocontains aregistered delimiter.
- containsStandardListeners(Filter) - Method in class com.tangosol.util.MapListenerSupport
- 
Checks whether or not this MapListenerSupport object contains any standard (not lite) listeners for a given filter.
- containsStandardListeners(Object) - Method in class com.tangosol.util.MapListenerSupport
- 
Checks whether or not this MapListenerSupport object contains any standard (not lite) listeners for a given key.
- containsValue(CacheRequestHolder<ContainsValueRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theContainsValueRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of the contains value request as a serialized Boolean.
- containsValue(ContainsValueRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Returnstrueif this map contains a mapping for the specified value.
- containsValue(ContainsValueRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- containsValue(ContainsValueRequest, StreamObserver<BoolValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- containsValue(Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- containsValue(Object) - Method in class com.tangosol.net.cache.CachingMap
- containsValue(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Returns true if this CachingMap maps one or more keys to the specified value.
- containsValue(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Returns true if this Map maps one or more keys to the specified value.
- containsValue(Object) - Method in class com.tangosol.net.cache.SerializationMap
- 
Returns true if this Map maps one or more keys to the specified value.
- containsValue(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns true if this Map maps one or more keys to the specified value.
- containsValue(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns true if this Map maps one or more keys to the specified value.
- containsValue(Object) - Method in interface com.tangosol.util.ConcurrentMap
- 
Returns true if this map maps one or more keys to the specified value.
- containsValue(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- containsValue(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- containsValue(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- containsValue(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns true if this map maps one or more keys to the specified value.
- containsValue(Object) - Method in class com.tangosol.util.SafeSortedMap
- containsValue(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- containsValue(Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns true if this map maps one or more keys to the specified value.
- containsValue(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- containsValue(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- containsValue(Object) - Method in class com.tangosol.util.WrapperObservableMap
- 
Returns true if this Map maps one or more keys to the specified value.
- containsValue(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aContainsValueRequest.
- ContainsValueAction() - Constructor for class com.tangosol.util.SegmentedHashMap.ContainsValueAction
- contendForSegment(int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Wait for a segment to be unlocked.
- Context(Guardable, long, float) - Constructor for class com.tangosol.net.GuardSupport.Context
- 
Construct a Context.
- contextDestroyed(ServletContextEvent) - Method in class com.tangosol.coherence.rest.servlet.DefaultServletContextListener
- 
Notification that the servlet context is about to be shut down.
- contextInitialized(ServletContextEvent) - Method in class com.tangosol.coherence.rest.servlet.DefaultServletContextListener
- 
Notification that the web application initialization process is starting.
- ContextJCacheStatistics - Class in com.tangosol.coherence.jcache.common
- 
JCache Statistics implementation.
- ContextJCacheStatistics() - Constructor for class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- 
Constructs ...
- ContextJCacheStatistics(JCacheIdentifier) - Constructor for class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- 
Constructs JCacheStatistics for cacheid
- Continuation<R> - Interface in com.oracle.coherence.common.base
- 
Continuation interface is used to implement asynchronous post-processing, the pattern that is also known as the "Continuation-passing style".
- Continue - com.tangosol.net.topic.Publisher.OnFailure
- 
If an individualPublisher.publish(Object)fails then skip that value and continue to publish other values.
- ContinuousQueryCache<K,V_BACK,V_FRONT> - Class in com.tangosol.net.cache
- 
Create a materialized view of aNamedCacheusing theCoherenceContinuous Query capability.
- ContinuousQueryCache(NamedCache<K, V_BACK>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a locally materialized view of aNamedCacheusing aFilter.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a locally materialized view of aNamedCacheusing a Filter.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, boolean) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a materialized view of aNamedCacheusing a Filter.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, boolean, MapListener<? super K, ? super V_FRONT>, ValueExtractor<? super V_BACK, ? extends V_FRONT>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Construct the ContinuousQueryCache.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, MapListener<? super K, ? super V_FRONT>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a materialized view of aNamedCacheusing a Filter.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, MapListener<? super K, ? super V_FRONT>, ValueExtractor<? super V_BACK, ? extends V_FRONT>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a materialized view of aNamedCacheusing aFilter.
- ContinuousQueryCache(NamedCache<K, V_BACK>, Filter, ValueExtractor<? super V_BACK, ? extends V_FRONT>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a locally materialized view of aNamedCacheusing aFilterand a transformer.
- ContinuousQueryCache(Supplier<NamedCache<K, V_BACK>>) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a locally materialized view of aNamedCacheusing aFilter.
- ContinuousQueryCache(Supplier<NamedCache<K, V_BACK>>, Filter) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a locally materialized view of aNamedCacheusing aFilter.
- ContinuousQueryCache(Supplier<NamedCache<K, V_BACK>>, Filter, boolean, MapListener<? super K, ? super V_FRONT>, ValueExtractor<? super V_BACK, ? extends V_FRONT>, ClassLoader) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a materialized view of aNamedCacheusing aFilter.
- ContinuousQueryCache.AddListener - Class in com.tangosol.net.cache
- 
AMapListenerfor adding items to theContinuousQueryCache.
- ContinuousQueryCache.ConverterAsynchronousProcessor - Class in com.tangosol.net.cache
- 
Wraps anAsynchronousProcessorto ensure the result of the EntryProcessor execution is deserialized prior to passing to the provided AsynchronousProcessor.
- ContinuousQueryCache.DeactivationListener - Class in com.tangosol.net.cache
- 
DeactivationListener for the underlying NamedCache.
- ContinuousQueryCache.EventRouter<K,V> - Class in com.tangosol.net.cache
- 
An EventRouter routes events from the internal cache of theContinuousQueryCacheto the client listeners, and it can do so asynchronously when appropriate.
- ContinuousQueryCache.InternalMapListener - Class in com.tangosol.net.cache
- 
This listener allows interception of all events triggered by the the internalObservableMapof theContinuousQueryCache.
- ContinuousQueryCache.RemoveListener - Class in com.tangosol.net.cache
- 
AMapListenerfor evicting items from theContinuousQueryCache.
- ContinuousQueryCache.ServiceListener - Class in com.tangosol.net.cache
- 
MemberListenerfor the underlying cache's service.
- ContinuousQueryCacheScheme - Class in com.tangosol.coherence.config.scheme
- 
This scheme is internally used to provide theParameterizedBuilderthat constructs theview-filterfor theViewScheme.
- ContinuousQueryCacheScheme() - Constructor for class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- Controllable - Interface in com.tangosol.util
- 
The Controllable interface represents a configurable daemon-like object, quite often referred to as a service, that usually operates on its own thread and has a controllable life cycle.
- convert(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder.DownConverter
- convert(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder.UpConverter
- convert(F) - Method in interface com.oracle.coherence.common.base.Converter
- 
Convert the passed object to another object.
- convert(F) - Method in class com.oracle.coherence.grpc.RequestHolder.ErrorHandlingConverter
- convert(Object) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy.KeyConverter
- convert(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap.FrontFilterConverter
- 
Extracts the key from the Status object.
- convert(Object) - Method in class com.tangosol.util.NullImplementation.NullConverter
- 
Convert the passed object to another object.
- convert(Object, int) - Method in class com.tangosol.run.xml.SimpleValue
- 
Convert the passed Object to the specified type.
- convert(Object, int) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Convert the passed Object to the specified type.
- convert(Collection, Converter) - Static method in class com.tangosol.util.CollectionHelper
- 
Deprecated.Convert a collection from one set of objects to a new set of objects.
- convert(Enumeration, Converter) - Static method in class com.tangosol.util.CollectionHelper
- 
Deprecated.Convert an Enumeration from one set of objects to a new set of objects.
- convert(Iterator, Converter) - Static method in class com.tangosol.util.CollectionHelper
- 
Deprecated.Convert an Iterator from one set of objects to a new set of objects.
- Convert() - Constructor for class com.tangosol.net.topic.Subscriber.Convert
- 
Default constructor for serialization.
- Convert(ValueExtractor<? super V, U>) - Constructor for class com.tangosol.net.topic.Subscriber.Convert
- convertArray(Object[], Converter) - Static method in class com.tangosol.util.ConverterCollections
- 
Convert the contents of the passed array.
- convertArray(Object[], Converter, Object[]) - Static method in class com.tangosol.util.ConverterCollections
- 
Convert the contents of the passed source array into an array with the component type of the passed destination array, using the destination array itself if it is large enough, and placing a null in the first unused element of the destination array if it is larger than the source array.
- convertConfiguration(Configuration<K, V>, ClassLoader) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- 
Converts aConfigurationinto aCoherenceBasedConfigurationso that we may createCoherenceBasedCaches.
- convertDouble(XmlValue) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Convert the value in the specifiedXmlValueto a double.
- convertDown(ByteString) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Convert theByteStringdata serialized in the request format to aBinaryserialized in the cache's serialization format.
- convertDown(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- convertDown(Supplier<ByteString>) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Convert theByteStringdata serialized in the request format to aBinaryserialized in the cache's serialization format.
- Converter<F,T> - Interface in com.oracle.coherence.common.base
- 
Provide for "pluggable" object conversions.
- Converter<F,T> - Interface in com.tangosol.util
- 
Provide for "pluggable" object conversions.
- CONVERTER_FROM_BINARY - Static variable in class com.tangosol.util.ExternalizableHelper
- 
A converter from Binary to Object format, which uses the DefaultSerializer.
- CONVERTER_STRIP_INTDECO - Static variable in class com.tangosol.util.ExternalizableHelper
- 
A pass-through Binary converter that removes an IntDecoration if present.
- CONVERTER_TO_BINARY - Static variable in class com.tangosol.util.ExternalizableHelper
- 
A converter from Object to Binary format that uses the DefaultSerializer.
- ConverterAsynchronousProcessor(AsynchronousProcessor) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- 
Construct the processor to wrap the providedAsynchronousProcessorin order to ensure results are properly converted prior to return.
- ConverterCacheEntry(ConfigurableCacheMap.Entry, Converter, Converter, Converter) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- ConverterCacheEvent(ObservableMap<K, V>, CacheEvent<K, V>, Converter<K, K>, Converter<V, V>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheEvent
- 
Constructor.
- ConverterCacheEvent(ObservableMap<K, V>, CacheEvent<K, V>, Converter<K, K>, Converter<V, V>, BackingMapManagerContext) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheEvent
- 
Construct a ConverterMapEvent.
- ConverterCacheListener(NamedCache<K, V>, MapListener<K, V>, Converter<K, K>, Converter<V, V>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheListener
- 
Constructor.
- ConverterCacheMap(CacheMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCacheMap
- 
Constructor.
- ConverterCollection(Collection<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Constructor.
- ConverterCollections - Class in com.tangosol.util
- 
A collection of Collection implementation classes that use the Converter interface to convert the items stored in underlying collection objects.
- ConverterCollections() - Constructor for class com.tangosol.util.ConverterCollections
- ConverterCollections.AbstractConverterEntry<FK,TK,FV,TV> - Class in com.tangosol.util
- 
An abstract Map Entry that lazily converts the key and value.
- ConverterCollections.ConverterCacheEntry - Class in com.tangosol.util
- 
A ConfigurableCacheMap.Entry that lazily converts the key and value.
- ConverterCollections.ConverterCacheEvent<K,V> - Class in com.tangosol.util
- 
A Converter CacheEvent views an underlying CacheEvent through a set of key and value Converters.
- ConverterCollections.ConverterCacheListener<K,V> - Class in com.tangosol.util
- 
A converter MapListener that converts events of the underlying MapListener for the underlying NamedCache.
- ConverterCollections.ConverterCacheMap<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter CacheMap views an underlying CacheMap through a set of key and value Converters.
- ConverterCollections.ConverterCollection<F,T> - Class in com.tangosol.util
- 
A Converter Collection views an underlying Collection through a Converter.
- ConverterCollections.ConverterComparator<F,T> - Class in com.tangosol.util
- 
A Comparator that Converts the elements before comparing them.
- ConverterCollections.ConverterConcurrentMap<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter ConcurrentMap views an underlying ConcurrentMap through a set of key and value Converters.
- ConverterCollections.ConverterEntry<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Map Entry that lazily converts the key and value.
- ConverterCollections.ConverterEntrySet<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter Entry Set views an underlying Entry Set through a set of key and value Converters.
- ConverterCollections.ConverterEntrySet.ConverterEntry - Class in com.tangosol.util
- 
A Map Entry that lazily converts the key and value.
- ConverterCollections.ConverterEntrySet.ConverterIterator - Class in com.tangosol.util
- 
A Map Entry Iterator that converts the key and value types.
- ConverterCollections.ConverterEnumerator<F,T> - Class in com.tangosol.util
- 
Provide an implementation of an enumerator which converts each of the items which it enumerates.
- ConverterCollections.ConverterHolder<F,T> - Class in com.tangosol.util
- 
A Holder that converts the element before returning them.
- ConverterCollections.ConverterInvocableMap<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter InvocableMap views an underlying InvocableMap through a set of key and value Converters.
- ConverterCollections.ConverterList<F,T> - Class in com.tangosol.util
- 
A Converter List views an underlying List through a Converter.
- ConverterCollections.ConverterListIterator<F,T> - Class in com.tangosol.util
- 
A Converter ListIterator views an underlying ListIterator through a Converter.
- ConverterCollections.ConverterLongArray<F,T> - Class in com.tangosol.util
- 
ConverterLongArray converts the value of the LongArray from its raw form (typeF) to the desired from (typeT).
- ConverterCollections.ConverterLongArray.ConverterLongArrayIterator - Class in com.tangosol.util
- 
An Iterator that can convert from raw types to desired types.
- ConverterCollections.ConverterMap<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter Map views an underlying Map through a set of key and value Converters.
- ConverterCollections.ConverterMapEvent<K,V> - Class in com.tangosol.util
- 
A ConverterMapEvent views an underlying MapEvent through a set of key and value Converters.
- ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry - Class in com.tangosol.util
- 
ConverterMapEventBinaryEntry provides both the Map Entry and the BinaryEntry interfaces to the information encapsulated inside the ConverterMapEvent.
- ConverterCollections.ConverterMapEvent.ConverterMapEventEntry - Class in com.tangosol.util
- 
ConverterMapEventEntry provides the Map Entry interface to the information encapsulated inside the ConverterMapEvent.
- ConverterCollections.ConverterMapListener<K,V> - Class in com.tangosol.util
- 
A converter MapListener that converts events of the underlying MapListener for the underlying map.
- ConverterCollections.ConverterNamedCache<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter NamedCache views an underlying NamedCache through a set of key and value Converters.
- ConverterCollections.ConverterObservableMap<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter ObservableMap views an underlying ObservableMap through a set of key and value Converters.
- ConverterCollections.ConverterQueryMap<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter QueryMap views an underlying QueryMap through a set of key and value Converters.
- ConverterCollections.ConverterSet<F,T> - Class in com.tangosol.util
- 
A Converter Set views an underlying Set through a Converter.
- ConverterCollections.ConverterSortedMap<FK,TK,FV,TV> - Class in com.tangosol.util
- 
A Converter SortedMap views an underlying SortedMap through a set of key and value Converters.
- ConverterCollections.ConverterSortedSet<F,T> - Class in com.tangosol.util
- 
A Converter SortedSet views an underlying SortedSet through a Converter.
- ConverterComparator(Comparator<? super F>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterComparator
- 
Constructor.
- ConverterConcurrentMap(ConcurrentMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterConcurrentMap
- 
Constructor.
- ConverterEntry(Map.Entry<FK, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterEntry
- 
Constructor.
- ConverterEntry(Map.Entry<FK, FV>, Converter<FK, TK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEntry
- 
Constructor.
- ConverterEntrySet(Collection<Map.Entry<FK, FV>>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Constructor.
- ConverterEnumerator - Class in com.tangosol.util
- 
Deprecated.As of Coherence 12.1.2, replaced byConverterCollections.ConverterEnumerator
- ConverterEnumerator(Object[], Converter) - Constructor for class com.tangosol.util.ConverterEnumerator
- 
Deprecated.Construct the Converter enumerator based on an array of objects.
- ConverterEnumerator(Object[], Converter<F, T>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Construct the Converter enumerator based on an array of objects.
- ConverterEnumerator(Enumeration<F>, Converter<F, T>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Construct the Converter enumerator based on an Enumeration.
- ConverterEnumerator(Enumeration, Converter) - Constructor for class com.tangosol.util.ConverterEnumerator
- 
Deprecated.Construct the Converter enumerator based on an Enumeration.
- ConverterEnumerator(Iterator<F>, Converter<F, T>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Construct the Converter enumerator based on an Iterator.
- ConverterEnumerator(Iterator, Converter) - Constructor for class com.tangosol.util.ConverterEnumerator
- 
Deprecated.Construct the Converter enumerator based on an Iterator.
- ConverterHolder(F, Converter<F, T>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterHolder
- 
Constructor.
- ConverterInvocableMap(InvocableMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- 
Constructor.
- ConverterIterator(Iterator<Map.Entry<FK, FV>>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
- 
Constructor.
- ConverterList(List<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterList
- 
Constructor.
- ConverterListIterator(ListIterator<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterListIterator
- 
Constructor.
- ConverterLongArray(LongArray<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterLongArray
- 
Construct a LongArray that converts the values from typeFto typeT.
- ConverterLongArrayIterator(LongArray.Iterator<F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterLongArray.ConverterLongArrayIterator
- 
Construct a converting iterator.
- ConverterMap(Map<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMap
- 
Constructor.
- ConverterMapEvent(ObservableMap<K, V>, MapEvent<K, V>, Converter<K, K>, Converter<V, V>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Construct a ConverterMapEvent.
- ConverterMapEvent(ObservableMap<K, V>, MapEvent<K, V>, Converter<K, K>, Converter<V, V>, BackingMapManagerContext) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Construct a ConverterMapEvent.
- ConverterMapEventBinaryEntry(boolean) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Constructor.
- ConverterMapEventEntry(boolean) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- 
Constructor.
- ConverterMapListener(ObservableMap<K, V>, MapListener<K, V>, Converter<K, K>, Converter<V, V>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterMapListener
- 
Constructor.
- ConverterNamedCache(NamedCache<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Constructor.
- ConverterObservableMap(ObservableMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterObservableMap
- 
Constructor.
- ConverterQueryMap(QueryMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterQueryMap
- 
Constructor.
- ConverterSet(Collection<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterSet
- 
Constructor.
- ConverterSortedMap(SortedMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterSortedMap
- 
Constructor.
- ConverterSortedSet(SortedSet<F>, Converter<F, T>, Converter<T, F>) - Constructor for class com.tangosol.util.ConverterCollections.ConverterSortedSet
- 
Constructor.
- convertEvent(MapEvent, ObservableMap, Converter, Converter) - Static method in class com.tangosol.util.MapListenerSupport
- 
Convert the specified map event into another MapEvent that ensures the lazy event data conversion using the specified converters.
- convertInt(XmlValue) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Convert the value in the specifiedXmlValueto an int.
- convertInt(XmlValue, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Convert the value in the specifiedXmlValueto an int.
- convertKeyDown(ByteString) - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- 
Convert theByteStringdata serialized in the request format to aBinarykey serialized in the cache's serialization format.
- convertKeyDown(Binary) - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- convertKeys(CacheRequestHolder<GetAllRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Convert the keys for aGetAllRequestfrom the request's serialization format to the cache's serialization format.
- convertList(List<String>, Class) - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine
- 
Convert all elements of the source list into the specified type.
- convertLong(XmlValue) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Convert the value in the specifiedXmlValueto a long.
- convertNumber(Number, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Convert the passed number to the specified type.
- convertSafe(Converter, Object) - Static method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- 
Convert the provided value with the given converter.
- convertToDate(Object) - Static method in class com.tangosol.io.pof.PofHelper
- 
Convert a date, time or date/time value to a Java Date.
- convertUp(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- convertUTF(byte[], int, int, char[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Convert binary UTF-8 encode data to a String.
- convertUTF(int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Convert a UTF-8 encoded section of the binary stream into a String.
- convertUTF(int, int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Convert a UTF-8 encoded section of the binary stream into a String.
- convertUTF(int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Convert a UTF-8 encoded section of the binary stream into a String.
- copy(InputStream, OutputStream, byte[]) - Method in class com.tangosol.net.LoadBalancer.SocketHandler
- 
Process the transfer of data from one stream to another.
- copyAndOpenInternal(PersistentStore<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Copy the provided store to ensure both the contents are available in the new store and it is open thus ready to receive requests.
- copyArray(LongArray<V>) - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Return a shallow copy of the specified LongArray.
- copyBufferInputPortion(int, ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Read a portion of the specified BufferInput and write it to the specified offset within this buffer.
- copyBufferInputRemainder(int, ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Read the remaining contents of the specified BufferInput and write it to the specified offset within this buffer.
- copyBytes(int, int, byte[], int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Copies bytes from this ReadBuffer into the destination byte array.
- copyBytes(int, int, byte[], int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Copies bytes from this ReadBuffer into the destination byte array.
- copyBytes(int, int, byte[], int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Copies bytes from this ReadBuffer into the destination byte array.
- copyBytes(int, int, byte[], int) - Method in interface com.tangosol.io.ReadBuffer
- 
Copies bytes from this ReadBuffer into the destination byte array.
- copyClassAnnotations(ClassNode, ClassNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Copy class-level annotations.
- copyDir(File, File) - Static method in class com.tangosol.io.FileHelper
- 
Create a deep copy of the specified directory into the specified target directory.
- copyFile(File, File) - Static method in class com.tangosol.io.FileHelper
- 
Copy the specified file according to the source and destination File objects preserving the time-stamp of the source.
- copyFrom(PartitionStatistics) - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Copy the statistics from the specified PartitionStatistics reference.
- copyFrom(SafeHashMap.Entry) - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Copy this Entry's information from another Entry.
- copyFrom(SafeHashMap.Entry<K, V>) - Method in class com.tangosol.util.SafeHashMap.Entry
- 
Copy this Entry's information from another Entry.
- copyMap(Map<K, V>) - Method in class com.tangosol.util.CopyOnWriteMap
- 
Create an instance ofMapbased on the contents of the provided map.
- copyMetadata(File, File) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Copy the metadata file from one directory to another.
- CopyOnWriteLongArray<V> - Class in com.tangosol.util
- 
A thread-safe variant ofLongArrayin which all mutating operations (e.g.
- CopyOnWriteLongArray() - Constructor for class com.tangosol.util.CopyOnWriteLongArray
- 
Default constructor.
- CopyOnWriteLongArray(LongArray<V>) - Constructor for class com.tangosol.util.CopyOnWriteLongArray
- 
Construct a CopyOnWriteLongArray, initialized with the contents of the specified LongArray.
- CopyOnWriteLongArray(Class<? extends LongArray<V>>) - Constructor for class com.tangosol.util.CopyOnWriteLongArray
- 
Construct a CopyOnWriteLongArray with an underlying array of the specified type.
- CopyOnWriteLongArray.UnmodifiableIterator<V> - Class in com.tangosol.util
- 
Unmodifiable view of a LongArray.Iterator.
- CopyOnWriteMap<K,V> - Class in com.tangosol.util
- 
A thread-safe variant ofMapin which all mutating operations (e.g.
- CopyOnWriteMap(Class) - Constructor for class com.tangosol.util.CopyOnWriteMap
- CopyOnWriteMap(Map<K, V>) - Constructor for class com.tangosol.util.CopyOnWriteMap
- 
Construct a CopyOnWriteMap, initialized with the contents of the specified map.
- CopyOnWriteMap.EntrySet - Class in com.tangosol.util
- 
A set of entries backed by this map.
- CopyOnWriteMap.KeySet - Class in com.tangosol.util
- 
A set of keys backed by this map.
- copyOptions(SocketOptions) - Method in class com.tangosol.net.SocketOptions
- 
Copy the options in the specified SocketOptions into this SocketOptions.
- copyStream(int, InputStreaming, int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Store the remaining contents of the specified InputStreaming object at the specified offset within this buffer.
- copyStream(int, InputStreaming, int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Store the remaining contents of the specified InputStreaming object at the specified offset within this buffer.
- copyStream(int, InputStreaming, int) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Store the remaining contents of the specified InputStreaming object at the specified offset within this buffer.
- copyToTrash() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Copy the store to trash if the meta.properties file exist.
- copyTransients(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Copy transient values from another, generally the previous, AnalysisContext to this AnalysisContext.
- count() - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the number of entities in this repository.
- count() - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the number of entities in this repository.
- count() - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the count of the entries in a Map.
- count() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns the count of elements in this stream.
- count() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns the count of elements in this stream.
- count() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns the count of elements in this stream.
- count() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns the count of elements in this stream.
- count(Filter<?>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the number of entities in this repository that satisfy specified filter.
- count(Filter<?>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the number of entities in this repository that satisfy specified filter.
- Count<K,V> - Class in com.tangosol.util.aggregator
- 
Calculates a number of values in an entry set.
- Count - Annotation Type in com.oracle.coherence.concurrent.cdi
- 
A qualifier annotation used when injecting Coherence resource to specify the latch count.
- Count() - Constructor for class com.tangosol.util.aggregator.Count
- 
Default constructor (necessary for the ExternalizableLite interface).
- COUNT_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theCountaggregator.
- Count.Literal - Class in com.oracle.coherence.concurrent.cdi
- 
An annotation literal for theCountannotation.
- countBits(byte) - Static method in class com.tangosol.util.BitHelper
- 
Count the number of bits set in the passed integral value.
- countBits(int) - Static method in class com.tangosol.util.BitHelper
- 
Count the number of bits set in the passed integral value.
- countBits(long) - Static method in class com.tangosol.util.BitHelper
- 
Count the number of bits set in the passed integral value.
- countDown() - Method in interface com.oracle.coherence.concurrent.CountDownLatch
- 
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
- countDown() - Method in class com.oracle.coherence.concurrent.LocalCountDownLatch
- countDown() - Method in class com.oracle.coherence.concurrent.RemoteCountDownLatch
- 
Decrements the latch count, releasing all waiting threads if the count reaches zero.
- CountDownLatch - Interface in com.oracle.coherence.concurrent
- counting() - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectoraccepting elements of typeTthat counts the number of input elements.
- Crawler(AbstractSparseArray.Node<V>, int, boolean) - Constructor for class com.tangosol.util.AbstractSparseArray.Crawler
- 
Crawler constructor.
- CRC32_TABLE - Static variable in class com.oracle.coherence.common.base.Formatting
- create() - Static method in class com.oracle.coherence.cdi.SerializerProducer
- 
Create an instance ofSerializerProducer.
- create() - Method in interface com.oracle.coherence.common.base.Factory
- 
Create a new instance.
- create() - Static method in class com.tangosol.coherence.rest.config.RestConfig
- 
Return a singleton instance of RestConfig based on the REST configuration descriptor.
- create() - Static method in class com.tangosol.net.Coherence
- 
Return the defaultCoherenceinstance, creating it if it does not already exist.
- create() - Static method in interface com.tangosol.net.CoherenceConfiguration
- 
Returns an immutable defaultCoherenceConfigurationinstance.
- create() - Static method in interface com.tangosol.net.Session
- 
Obtain the default Session.
- create() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- create(A) - Method in interface com.oracle.coherence.cdi.ExtractorFactory
- 
Create aValueExtractorinstance.
- create(A) - Method in interface com.oracle.coherence.cdi.FilterFactory
- 
Create aFilterinstance.
- create(A) - Method in interface com.oracle.coherence.cdi.MapEventTransformerFactory
- 
Create aMapEventTransformerinstance.
- create(AlwaysFilter) - Method in class com.oracle.coherence.cdi.FilterProducer.AlwaysFilterSupplier
- create(ChainedExtractor) - Method in class com.oracle.coherence.cdi.ExtractorProducer.ChainedExtractorSupplier
- create(ChainedExtractor.Extractors) - Method in class com.oracle.coherence.cdi.ExtractorProducer.ChainedExtractorsSupplier
- create(PofExtractor) - Method in class com.oracle.coherence.cdi.ExtractorProducer.PofExtractorSupplier
- create(PofExtractor.Extractors) - Method in class com.oracle.coherence.cdi.ExtractorProducer.PofExtractorsSupplier
- create(PropertyExtractor) - Method in class com.oracle.coherence.cdi.ExtractorProducer.UniversalExtractorSupplier
- create(PropertyExtractor.Extractors) - Method in class com.oracle.coherence.cdi.ExtractorProducer.UniversalExtractorsSupplier
- create(WhereFilter) - Method in class com.oracle.coherence.cdi.FilterProducer.WhereFilterSupplier
- create(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
- 
Create a defaultCoherenceinstance.
- create(CoherenceConfiguration, Coherence.Mode) - Static method in class com.tangosol.net.Coherence
- 
Create a defaultCoherenceinstance.
- create(CoherenceConfiguration, Coherence.Mode, ClassLoader) - Static method in class com.tangosol.net.Coherence
- 
Create a defaultCoherenceinstance.
- create(Session.Option...) - Static method in interface com.tangosol.net.Session
- 
Deprecated.since 20.12 useSession.create(SessionConfiguration)
- create(SessionConfiguration) - Static method in interface com.tangosol.net.Session
- 
Possibly obtain aSessionbased on the specified configuration.
- create(SessionConfiguration, Coherence.Mode) - Static method in interface com.tangosol.net.Session
- 
Possibly obtain aSessionbased on the specified configuration.
- create(SessionConfiguration, Coherence.Mode, Iterable<? extends EventInterceptor<?>>) - Static method in interface com.tangosol.net.Session
- 
Possibly obtain aSessionbased on the specified configuration.
- create(ID) - Method in interface com.oracle.coherence.repository.EntityFactory
- 
Create an entity instance with the specified identity.
- create(Annotation) - Static method in class com.oracle.coherence.cdi.AnnotationInstance
- 
Create anAnnotationInstancefrom anAnnotation.
- create(Class, PropertySet, Map<String, Object>) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Create a PartialObject instance based on an already extracted set of properties.
- create(Object, PropertySet) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Create a PartialObject instance.
- create(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Create a Tree of Terms using the Term Language in the given String
- create(String) - Static method in interface com.tangosol.net.SessionConfiguration
- 
Create aSessionConfigurationfor the defaultSessionwith the specified configuration file.
- create(String, CoherenceQueryLanguage) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Create a Tree of Terms using the Term Language in the given String
- create(String, String) - Static method in interface com.tangosol.net.SessionConfiguration
- 
Create aSessionConfigurationfor aSessionwith a specific name and configuration file.
- create(String, String, String) - Static method in interface com.tangosol.net.SessionConfiguration
- 
Create aSessionConfigurationfor aSessionwith a specific name and configuration file.
- CREATE - Static variable in class com.tangosol.net.ClusterPermission
- 
Create action.
- CREATE_SNAPSHOT_BEGIN - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the start of snapshot creation.
- CREATE_SNAPSHOT_END - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the end of snapshot creation.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
- 
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.coherence.config.builder.FactoryBasedAddressProviderBuilder
- 
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
- 
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in interface com.tangosol.net.AddressProviderFactory
- 
Create a new AddressProvider using the specified class loader.
- createAddressProvider(ClassLoader) - Method in class com.tangosol.net.ConfigurableAddressProviderFactory
- 
Deprecated.Instantiate an AddressProvider configured according to the specified XML.
- createAggregator(ValueExtractor) - Method in class com.tangosol.coherence.rest.util.aggregator.DefaultAggregatorFactory
- 
Create and initialize a new aggregator instance.
- createAggregator(String, NodeTerm, String, boolean, SelectListMaker) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
- 
Create theInvocableMap.EntryAggregatorthat will aggregate the results of this select query.
- createAggregatorMap(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Create a collection of AggregatorConfig objects from the given XML configuration.
- createBinaryStore() - Method in class com.tangosol.io.AsyncBinaryStoreManager
- 
Factory method: Returns a new BinaryStore.
- createBinaryStore() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Factory method: Returns a new BinaryStore.
- createBinaryStore() - Method in interface com.tangosol.io.BinaryStoreManager
- 
Factory method: Returns a new BinaryStore.
- createBinaryStore() - Method in class com.tangosol.io.nio.AbstractStoreManager
- 
Factory method: Returns a new BinaryStore.
- createBinaryStore() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Create and register a new BinaryStore object, using this cache's BinaryStoreManager.
- createBindings(Map<String, Object>, Map<String, Class>) - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine
- 
Converts string parameters to their required types.
- createBoolean(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Create new LiteralBaseToken representing a Boolean with given value
- createBoolean(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a Boolean with given value
- createBufferManager() - Method in class com.tangosol.io.nio.AbstractStoreManager
- 
Create a ByteBufferManager to be used by a BinaryStore.
- createBufferManager() - Method in class com.tangosol.io.nio.MappedStoreManager
- 
Create a ByteBufferManager to be used by a BinaryStore.
- createBytes(int) - Static method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Create a byte array of the specified size.
- createCache(CoherenceBasedCacheManager, String) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedConfiguration
- 
Creates aCoherenceBasedCachebased on the current state of theCoherenceBasedConfiguration, to be owned by the specifiedCoherenceBasedCacheManager.
- createCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheConfiguration
- createCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfiguration
- createCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- createCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCacheConfiguration
- createCache(String, C) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- createCacheMananger(URI, ClassLoader, Properties) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- 
Constructs a suitableCacheManagerfor the specified parameters.
- CreateCacheStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder.CreateCacheStatement
- 
Construct a CreateCacheStatement that will create a cache with the specified name.
- CreateCacheStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aCreateCacheStatementBuilder.CreateCacheStatement.
- CreateCacheStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
- CreateCacheStatementBuilder.CreateCacheStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "CREATE CACHE" command.
- createChannelCredentials(String) - Static method in class com.oracle.coherence.grpc.CredentialsHelper
- 
Deprecated.server credentials are configured by the socket provider for a gRPC channel, seeCredentialsHelper.createChannelCredentials(String, SocketProviderBuilder)
- createChannelCredentials(String, SocketProviderBuilder) - Static method in class com.oracle.coherence.grpc.CredentialsHelper
- 
Create theChannelCredentialsto use for the client channel.
- createClass(ClassNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Create partial class based on partial class definition.
- createCoherence(BeanManager) - Method in class com.oracle.coherence.cdi.CoherenceProducer
- 
Create the defaultCoherencebean.
- createCoherence(BeanManager) - Method in class com.oracle.coherence.cdi.server.ServerCoherenceProducer
- 
Create the defaultCoherencebean.
- createCommonExecutionContext() - Static method in class com.tangosol.util.QueryHelper
- 
Create a newExecutionContext.
- createComparator(ValueExtractor) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
- 
Create extractor comparator.
- createComparator(String) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
- 
Create extractor comparator.
- createComparator(String) - Static method in class com.tangosol.coherence.rest.util.ComparatorHelper
- 
Create a new Comparator from the specified string.
- createCompositeType(String, String, String[], String[], OpenType<?>[]) - Static method in class com.tangosol.net.management.OpenMBeanHelper
- 
Constructs aCompositeTypeinstance, checking for the validity of the given parameters.
- createConfiguration(ParameterResolver, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Create aPagedTopicDependenciesbased on the values contained in this scheme.
- createConfiguration(BeanManager) - Method in class com.oracle.coherence.cdi.CoherenceProducer
- createConstructors(ClassNode) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Implement partial class constructors.
- createConverterDown() - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- createConverterDown() - Method in class com.oracle.coherence.grpc.RequestHolder
- Created - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any CREATED event.
- CREATED - com.tangosol.net.events.partition.cache.CacheLifecycleEvent.Type
- 
CacheLifecycleEvents of the typeCREATEDare raised when the relevant data structures to support a cache are created locally.
- Created.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theCreatedannotation.
- createDefaultExecutor(String) - Static method in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
Create the defaultExecutor.
- createDefaultMarshaller(Class, String) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Create default marshaller for the specified class and media type.
- createDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.BinaryDeltaCompressor
- 
Actually create a delta in the binary delta format.
- createDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Actually create a delta in the binary delta format.
- createDouble(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Create new LiteralBaseToken representing a Double with given value
- createDouble(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a Double with given value
- createEvent(String, MapEvent<? extends K, ? extends V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- 
Convert MapEvent to JSON-based OutboundEvent that can be sent to the client.
- createExecutionContext(ConfigurableCacheFactory) - Static method in class com.tangosol.util.QueryHelper
- 
Create a newExecutionContext.
- createExecutionContext(Session) - Static method in class com.tangosol.util.QueryHelper
- 
Create a newExecutionContext.
- createExtentInternal(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Create the extent with the given identifier in the persistent store.
- createExtractor(String) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
- 
Create expression extractor.
- createExtractor(String) - Static method in class com.tangosol.util.extractor.UniversalExtractor
- 
Return a ValueExtractor representing dot separated list of property and/or method names.
- createExtractor(String) - Static method in class com.tangosol.util.QueryHelper
- 
Make a new ValueExtractor from the given String.
- createExtractor(String, CoherenceQueryLanguage) - Static method in class com.tangosol.util.QueryHelper
- 
Make a new ValueExtractor from the given String.
- createExtractors(String) - Static method in class com.tangosol.util.extractor.ChainedExtractor
- 
Parse a dot-delimited sequence of method names and instantiate a corresponding array ofReflectionExtractorobjects.
- createExtractors(String) - Static method in class com.tangosol.util.extractor.MultiExtractor
- 
Parse a comma-delimited sequence of method names and instantiate a corresponding array ofValueExtractorobjects.
- createFactory(Serializer) - Static method in exception com.tangosol.net.topic.TopicPublisherException
- 
Create a factory function that creates aTopicPublisherException.
- createFactory(Serializer, String) - Static method in exception com.tangosol.net.topic.TopicPublisherException
- 
Create a factory function that creates aTopicPublisherException.
- createFilter(String) - Static method in class com.tangosol.util.QueryHelper
- 
Make a new Filter from the given String.
- createFilter(String, Object[]) - Static method in class com.tangosol.util.QueryHelper
- 
Make a new Filter from the given String.
- createFilter(String, Object[], Map) - Static method in class com.tangosol.util.QueryHelper
- 
Make a new Filter from the given String.
- createFilter(String, Object[], Map, CoherenceQueryLanguage) - Static method in class com.tangosol.util.QueryHelper
- 
Make a new Filter from the given String.
- createFilter(String, Map) - Static method in class com.tangosol.util.QueryHelper
- 
Make a new Filter from the given String.
- createFloat(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Create new LiteralBaseToken representing a float with given value
- createFloat(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a float with given value
- createGrpcServices() - Static method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- 
Obtain the list of gRPC proxy services to bind to a gRPC server.
- createGrpcServices() - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Deprecated.
- createGrpcServices(GrpcServiceDependencies) - Static method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- 
Obtain the list of gRPC proxy services to bind to a gRPC server.
- createHiddenSnapshotDirectory(String) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return a Path to a hidden directory within the snapshot directory that does not exist.
- createHolderAsync(Req, String, String, String) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Asynchronously create aCacheRequestHolderfor a given request.
- createIndex(boolean, Comparator, Map<ValueExtractor<T, E>, MapIndex>, BackingMapContext) - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Create an index and associate it with the corresponding extractor.
- createIndex(boolean, Comparator, Map<ValueExtractor<T, E>, MapIndex>, BackingMapContext) - Method in interface com.tangosol.util.extractor.IndexAwareExtractor
- 
Create an index and associate it with the corresponding extractor.
- createIndex(boolean, Comparator, Map, BackingMapContext) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Create an index and associate it with the corresponding extractor.
- createIndexRegistrationKey(long, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Create a key representing an index registration.
- CreateIndexStatement(String, ValueExtractor) - Constructor for class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder.CreateIndexStatement
- 
Construct a CreateIndexStatement that will create an index on the specified cache using the specifiedValueExtractor.
- CreateIndexStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aCreateIndexStatementBuilder.CreateIndexStatement.
- CreateIndexStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
- CreateIndexStatementBuilder.CreateIndexStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "CREATE INDEX" command.
- createIndices() - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Creates indices for this repository that are defined via@Acceleratedand@Indexedannotations.
- createInProcessServerBuilder(GrpcAcceptorDependencies) - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- createInsertKey(Term, UpdateSetListMaker, Object) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
- 
Create the key to use in the insert statement.
- createInsertValue(Term, UpdateSetListMaker) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
- 
Create the instance of the value that will be inserted into the cache.
- createInstance(XmlElement, ClassLoader, XmlHelper.ParameterResolver) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Create an instance of the class configured using an XmlElement of the following structure:
- createInstance(XmlElement, ClassLoader, XmlHelper.ParameterResolver, Class) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Create an instance of the class configured using an XmlElement of the following structure:
- createInstance(InvocableMap.EntryAggregator[]) - Static method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Create an instance of CompositeAggregator based on a specifiedEntryAggregatorarray.
- createInstance(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<? super K, ? super V, R>, Filter) - Static method in class com.tangosol.util.aggregator.GroupAggregator
- 
Create an instance of GroupAggregator based on a specified extractor and anEntryAggregatorand a result evaluation filter.
- createInstance(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<K, V, R>) - Static method in class com.tangosol.util.aggregator.GroupAggregator
- 
Create an instance of GroupAggregator based on a specified extractor and anEntryAggregator.
- createInstance(String, InvocableMap.EntryAggregator<K, V, R>) - Static method in class com.tangosol.util.aggregator.GroupAggregator
- 
Create an instance of GroupAggregator based on a specified method name(s) and anEntryAggregator.
- createInstance(String, InvocableMap.EntryAggregator<K, V, R>, Filter) - Static method in class com.tangosol.util.aggregator.GroupAggregator
- 
Create an instance of GroupAggregator based on a specified method name(s), anEntryAggregatorand a result evaluation filter.
- createInteger(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Create new LiteralBaseToken representing a Integer with given value
- createInteger(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a Integer with given value
- createKey(Class, PropertySet) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Create key for the partial class/constructor cache.
- createKey(Class, String) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Create a key for the marshallers map.
- createKeyConverter() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Create key converter instance.
- createKeyStore(String) - Method in interface com.tangosol.net.ssl.KeyStoreLoader
- 
Create aKeyStoreof the specified type.
- createListenerRegistrationKey(long, long, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Create a key representing a cache listener registration.
- createLoadedLocalCacheValue(Object, long, ExpiryPolicy) - Static method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Create a LocalCacheValue marked with Synthetic marker that it was loaded.
- createLocalCacheValue(Object, long, ExpiryPolicy) - Static method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Create a LocalCacheValue for an LocalCache entry.
- createLockRegistrationKey(long, long, long, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Create a key representing a cache entry lock.
- createLong(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Create new LiteralBaseToken representing a Long with given value
- createLong(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a Long with given value
- createMapAdapterMbean(Map<String, String>, Map<String, ?>) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Create a DynamicMBean driven by maps containing attribute descriptions and values.
- createMapEventResponse(MapEvent<?, ?>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Factory method to create newMapEventResponseinstances using the information in the suppliedMapEvent.
- createMarshaller(Class<?>, String, Class<?>) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Create marshaller instance.
- createMarshallerMap(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Create a map of REST marshaller classes keyed by media type from the given XML configuration.
- createNamedDatabase(String) - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Create a named Database instance.
- createNestedPofReader(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Obtain a PofReader that can be used to read a set of properties from a single property of the current user type.
- createNestedPofReader(int) - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Obtain a PofReader that can be used to read a set of properties from a single property of the current user type.
- createNestedPofReader(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Obtain a PofReader that can be used to read a set of properties from a single property of the current user type.
- createNestedPofWriter(int) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Obtain a PofWriter that can be used to write a set of properties into a single property of the current user type.
- createNestedPofWriter(int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Obtain a PofWriter that can be used to write a set of properties into a single property of the current user type.
- createNestedPofWriter(int) - Method in interface com.tangosol.io.pof.PofWriter
- 
Obtain a PofWriter that can be used to write a set of properties into a single property of the current user type.
- createNestedPofWriter(int, int) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Obtain a PofWriter that can be used to write a set of properties into a single property of the current user type.
- createNestedPofWriter(int, int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Obtain a PofWriter that can be used to write a set of properties into a single property of the current user type.
- createNestedPofWriter(int, int) - Method in interface com.tangosol.io.pof.PofWriter
- 
Obtain a PofWriter that can be used to write a set of properties into a single property of the current user type.
- createNull() - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a null.
- createNull(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Create new LiteralBaseToken representing a null with given value
- createNull(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a null with given value
- createObject(String, ClassLoader) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Create an Object via reflection (using the specifiedClassLoader).
- createObject(String, Object[], ClassLoader) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Create an Object via reflection (using the specifiedClassLoader).
- createObserver(Class<E>, EventObserverSupport.EventObserver<E>) - Static method in class com.oracle.coherence.cdi.events.EventObserverSupport
- createParameterResolver(ClassLoader, BackingMapManagerContext) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return the ParameterResolver that has been initialized with the built-in Coherence parameters.
- createPartialClass(Class, PropertySet<T>) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Create a partial class for the specified source class and property set.
- createPartition(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Add a partition to the PartitionAwareBackingMap.
- createPartition(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Add a partition to the PartitionAwareBackingMap.
- createPartition(int) - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
- 
Add a partition to the PartitionAwareBackingMap.
- createPartition(int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Add a partition to the PartitionAwareBackingMap.
- createPartition(int) - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Add a partition to the PartitionAwareBackingMap.
- createPersistentEnvironment() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Create a persistent Environment.
- createPofConfig() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Create a PofConfig object based on a configuration that was either provided as XML, or can be loaded from the specified (or default) URI using the provided ClassLoader.
- createProcessor(String) - Method in class com.tangosol.coherence.rest.util.processor.DefaultProcessorFactory
- 
Create and initialize a new processor instance.
- createProcessorMap(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Create a collection of ProcessorConfig objects from the given XML configuration.
- createPublisher() - Method in interface com.tangosol.net.topic.NamedTopic
- 
Create aPublisherthat can publish values into thisNamedTopic.
- createPublisher(Publisher.Option<? super V>...) - Method in interface com.tangosol.net.topic.NamedTopic
- 
Create aPublisherthat can publish values into thisNamedTopic.
- createPublisher(String) - Method in interface com.tangosol.net.Session
- 
Create aPublisherthat can publish values into aNamedTopic.
- createPublisher(String, Publisher.Option...) - Method in interface com.tangosol.net.Session
- 
Create aPublisherthat can publish values into aNamedTopic.
- createQueryConfig(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Create a map ofQueryConfigobjects from the given XML configuration.
- createQueryEngine(Class) - Static method in class com.tangosol.coherence.rest.query.QueryEngineRegistry
- 
Create a query engine instance.
- createQueryEngines(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Create a collection ofQueryEngineConfigobjects from the given XML configuration.
- createRequestHolder(Req, String, String, String) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Create aCacheRequestHolderfor a given request.
- createRequestHolder(Req, String, String, String) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Create aCacheRequestHolderfor a given request.
- createResolver(String, String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Create aresolverbased on the provided cluster, service name and the state of this builder (active, snapshot and trash directories).
- createResourceMap(XmlElement) - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Create a map of ResourceConfig keyed by cache name or alias (if defined) from the given XML configuration.
- createSelectListMaker(List, ParameterResolver, CoherenceQueryLanguage) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
- 
Create an instance of aSelectListMaker.
- createSerializer(ClassLoader) - Method in class com.tangosol.io.ConfigurableSerializerFactory
- 
Deprecated.Create a new Serializer.
- createSerializer(ClassLoader) - Method in interface com.tangosol.io.SerializerFactory
- 
Create a new Serializer.
- createServerBuilder(GrpcAcceptorDependencies) - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- createServerCredentials() - Static method in class com.oracle.coherence.grpc.CredentialsHelper
- 
Deprecated.server credentials are configured by the socket provider for a gRPC proxy service, seeCredentialsHelper.createServerCredentials(SocketProviderBuilder)
- createServerCredentials(SocketProviderBuilder) - Static method in class com.oracle.coherence.grpc.CredentialsHelper
- 
Create theServerCredentialsto use for the gRPC Proxy.
- createService(String, Cluster) - Method in interface com.tangosol.net.ClusterDependencies.ServiceProvider
- 
Create a new instance of a service.
- createSession(Session.Option...) - Method in interface com.tangosol.net.SessionProvider
- 
Deprecated.
- createSession(SessionConfiguration) - Method in interface com.tangosol.net.SessionProvider.Context
- 
Returns theSessionProvider.Contextfrom calling the defaultSessionProvider.Context.defaultProvider()SessionProvider.createSession(SessionConfiguration, Coherence.Mode, Iterable)method to create a session.
- createSession(SessionConfiguration, Coherence.Mode) - Method in interface com.tangosol.net.SessionProvider
- 
Create aSessionfrom the specified configuration.
- createSession(SessionConfiguration, Coherence.Mode, Iterable<? extends EventInterceptor<?>>) - Method in interface com.tangosol.net.SessionProvider
- 
Create aSessionfrom the specified configuration.
- createSession(SessionConfiguration, Coherence.Mode, String, Iterable<? extends EventInterceptor<?>>) - Method in interface com.tangosol.net.SessionProvider
- 
Create aSessionfrom the specified configuration.
- createSession(SessionConfiguration, SessionProvider.Context) - Method in interface com.tangosol.net.CacheFactoryBuilder
- createSession(SessionConfiguration, SessionProvider.Context) - Method in interface com.tangosol.net.SessionProvider
- 
Create aSessionfrom the specified configuration.
- createShort(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Create new LiteralBaseToken representing a Integer with given value
- createShort(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a Short with given value
- createSnapshot(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Create a snapshot of the service with the specified name.
- createSnapshot(String, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Create a PersistenceManager used to manage the snapshot with the specified identifier.
- createSnapshot(String, PersistenceManager<R>) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Create a PersistenceManager used to manage the snapshot with the specified identifier.
- createSnapshot(String, PersistenceManager<R>) - Method in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
- 
Create a PersistenceManager used to manage the snapshot with the specified identifier.
- createSnapshotArchiver(String, String) - Method in class com.tangosol.persistence.ConfigurableSnapshotArchiverFactory
- 
Create a new SnapshotArchiver.
- createSnapshotArchiver(String, String) - Method in interface com.tangosol.persistence.SnapshotArchiverFactory
- 
Create a new SnapshotArchiver.
- createSnapshotInternal(File, String, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Create a snapshot with the specified identifier.
- CreateSnapshotStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder.CreateSnapshotStatement
- 
Create a new CreateSnapshotStatement for the snapshot and service name.
- CreateSnapshotStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aCreateSnapshotStatementBuilder.CreateSnapshotStatement.
- CreateSnapshotStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
- CreateSnapshotStatementBuilder.CreateSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "CREATE SNAPSHOT" command.
- createSortedEntries(Map<K, Object[]>) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Return an array ofentriesbased on the provided map ensuring the value (Objectarray) is sorted.
- createSSLSettings(SSLSocketProvider.Dependencies) - Static method in class com.tangosol.net.SocketProviderFactory
- 
Return an SSLSettings initialize viaSSLSocketProvider.Dependencies
- createStatement(String, ExecutionContext) - Static method in class com.tangosol.util.QueryHelper
- 
Creates a newCoherence Query LanguageStatementfrom the provided query string.
- createStatement(String, ExecutionContext, Object[]) - Static method in class com.tangosol.util.QueryHelper
- 
Creates a newCoherence Query LanguageStatementfrom the provided query string.
- createStatement(String, ExecutionContext, Object[], Map<String, Object>) - Static method in class com.tangosol.util.QueryHelper
- 
Creates a newCoherence Query LanguageStatementfrom the provided query string.
- createStatement(String, ExecutionContext, Map<String, Object>) - Static method in class com.tangosol.util.QueryHelper
- 
Creates a newCoherence Query LanguageStatementfrom the provided query string.
- createStatements() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Create the CohQLStatementBuildermap and initialise it with the standard CohQL statements.
- createStore(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Create aPersistentStoreassociated with the specified identifier.
- createStore(String) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Create aPersistentStoreassociated with the specified identifier.
- createStore(String) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- createString(String) - Static method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Create new LiteralBaseToken representing a String with given value
- createString(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a String with given value
- createSubscriber() - Method in interface com.tangosol.net.topic.NamedTopic
- 
Create a directSubscriberto the topic that receives all values from thisNamedTopic.
- createSubscriber(Subscriber.Option<? super V, U>...) - Method in interface com.tangosol.net.topic.NamedTopic
- 
Create aSubscriberthat can receive values from thisNamedTopic.
- createSubscriber(String) - Method in interface com.tangosol.net.Session
- 
Create aSubscriberthat can subscribe to aNamedTopic.
- createSubscriber(String, Subscriber.Option...) - Method in interface com.tangosol.net.Session
- 
Create aSubscriberthat can subscribe to aNamedTopic.
- createSymbol(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Create new AtomicTerm representing a Symbol with given value
- createTabularType(String, String, CompositeType, String[]) - Static method in class com.tangosol.net.management.OpenMBeanHelper
- 
Constructs aTabularTypeinstance, checking for the validity of the given parameters.
- createTempDir() - Static method in class com.tangosol.io.FileHelper
- 
Create a unique temporary directory.
- createTempEnvironment(File, String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Create a temporary PersistenceEnvironment to write archived snapshots to in the given format.
- createTemporaryEnvironment() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Create a temporary Environment.
- createThreadLocal() - Static method in class com.oracle.coherence.common.base.MutableLong
- 
Return a ThreadLocal of MutableLong.
- createTransformerFilter(MapEventFilter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Wrap specifiedMapEventFilterwith aMapEventTransformerFilterthat will either transform cache value using transformer defined for thisContinuousQueryCache, or remove the old value from the event usingSemiLiteEventTransformer, if no transformer is defined for thisContinuousQueryCache.
- createTriggerRegistrationKey(long, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Create a key representing an trigger registration.
- createUnexpectedStateException(int, int) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Simple helper to create an exception for communicating invalid state transitions.
- createUpdater(String) - Static method in class com.tangosol.util.extractor.UniversalUpdater
- 
Return aValueUpdaterforsNames
- createUpdateSetListMaker(ExecutionContext, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
- 
Create anUpdateSetListMaker.
- createUpdateSetListMaker(ExecutionContext, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
- 
Create an instance of anUpdateSetListMaker.
- CREDENTIALS_INSECURE - Static variable in class com.oracle.coherence.grpc.Requests
- 
The value used for theRequests.PROP_CREDENTIALSsystem property to indicate an insecure server.
- CREDENTIALS_PLAINTEXT - Static variable in class com.oracle.coherence.grpc.Requests
- 
The credentials to use to connect to a non-TLS enabled server.
- CREDENTIALS_TLS - Static variable in class com.oracle.coherence.grpc.Requests
- 
The value used for theRequests.PROP_CREDENTIALSsystem property to indicate the server should use TLS.
- CredentialsHelper - Class in com.oracle.coherence.grpc
- 
A helper class to resolve gRPC credentials.
- CurlyToken - Class in com.tangosol.coherence.dsltools.termlanguage
- 
CurlyToken is used to process expressions between bracketing characters such as are between "{" and "}" which should result in a bag such as {1,3,4,5}.
- CurlyToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.termlanguage.CurlyToken
- 
Construct a new CurlyToken with the given parameters.
- current - Variable in class com.tangosol.util.AbstractSparseArray.Crawler
- current() - Method in class com.tangosol.run.xml.SimpleParser
- 
Returns the current token and advances to the next token.
- currentNode() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Returns the current Node in the iteration.
- custom(IntSupplier) - Static method in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
Return the order that will use the specified supplier to provide unit-of-order for each async operation.
- CUSTOM - Static variable in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
A custom backup storage.
- CustomAddressProviderBuilder - Class in com.tangosol.coherence.config.builder
- 
This class builds an AddressProviderBuilder from a customizedParameterizedBuilderofAddressProvider.
- CustomAddressProviderBuilder(ParameterizedBuilder<AddressProvider>) - Constructor for class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
- 
ConstructsCustomAddressProviderBuilder
- CustomAddressProviderBuilder(ParameterizedBuilder<AddressProvider>, ParameterResolver) - Constructor for class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
- 
ConstructsCustomAddressProviderBuilder
- CustomAddressProviderBuilder(ParameterizedBuilder<AddressProvider>, ParameterResolver, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
- 
ConstructsCustomAddressProviderBuilder
- CustomizableBinaryStoreManagerBuilderProcessor<T extends BinaryStoreManagerBuilderCustomization> - Class in com.tangosol.coherence.config.xml.processor
- 
ACustomizableBinaryStoreManagerBuilderProcessoris aCustomizableBuilderProcessorthat additionally processes the required definition of aBinaryStoreManagerBuilderfor those classes supportingBinaryStoreManagerBuilderCustomization.
- CustomizableBinaryStoreManagerBuilderProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.CustomizableBinaryStoreManagerBuilderProcessor
- 
Constructs aCustomizableBinaryStoreManagerBuilderProcessorfor the specifiedBinaryStoreManagerBuilderCustomizationClass.
- CustomizableBuilderProcessor<T> - Class in com.tangosol.coherence.config.xml.processor
- 
ACustomizableBuilderProcessoris a multi-purposeElementProcessorresponsible for processing xml elements that produce objects supportingBuilderCustomization.
- CustomizableBuilderProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.CustomizableBuilderProcessor
- 
Constructs aCustomizableBuilderProcessorfor the specifiedClass.
- CustomScheme - Class in com.tangosol.coherence.config.scheme
- CustomScheme(ParameterizedBuilder<Map>) - Constructor for class com.tangosol.coherence.config.scheme.CustomScheme
- 
Construct aCustomScheme.
- CustomStoreManagerBuilder - Class in com.tangosol.coherence.config.builder.storemanager
- 
The CustomStoreManagerBuilder class builds an instance of a custom BinaryStoreManager.
- CustomStoreManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.CustomStoreManagerBuilder
D
- Daemon - Class in com.tangosol.util
- 
A abstract Daemon thread handler.
- Daemon() - Constructor for class com.tangosol.util.Daemon
- 
Default constructor.
- Daemon(String) - Constructor for class com.tangosol.util.Daemon
- 
Creates a Daemon with the specified name.
- Daemon(String, int, boolean) - Constructor for class com.tangosol.util.Daemon
- 
Creates a Daemon with a specified name and priority.
- Daemon.DaemonWorker - Class in com.tangosol.util
- 
The sub-class of Thread that this Daemon uses as the actual thread of execution.
- DaemonPoolBuilder - Class in com.tangosol.coherence.config.builder
- 
AParameterizedBuilderthat builds aDaemonPool.
- DaemonPoolBuilder() - Constructor for class com.tangosol.coherence.config.builder.DaemonPoolBuilder
- DaemonPoolExecutor - Class in com.oracle.coherence.grpc.proxy
- 
AnExecutorthat uses aDaemonPoolto execute tasks.
- DaemonPoolExecutor(DaemonPool) - Constructor for class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor
- 
Create aDaemonPoolExecutor.
- DaemonPoolExecutor.DaemonPoolManagement - Class in com.oracle.coherence.grpc.proxy
- 
Daemon pool metrics and management.
- DaemonPoolManagement(DaemonPool) - Constructor for class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- 
Construct a newDaemonPoolManagementinstance.
- DaemonPoolProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorto process a daemon pool configuration.
- DaemonPoolProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.DaemonPoolProcessor
- DaemonThreadFactory - Class in com.tangosol.util
- 
DaemonThreadFactory is a ThreadFactory which produces daemon threads.
- DaemonThreadFactory() - Constructor for class com.tangosol.util.DaemonThreadFactory
- 
Construct a new DameonThreadFacotry.
- DaemonThreadFactory(String) - Constructor for class com.tangosol.util.DaemonThreadFactory
- 
Construct a new DameonThreadFacotry.
- DaemonWorker() - Constructor for class com.tangosol.util.Daemon.DaemonWorker
- DATA_VERSION - Static variable in class com.tangosol.net.topic.Subscriber.CommitResult
- 
The evolvable version of this class.
- DatabaseFactory - Class in com.tangosol.io.bdb
- 
Factory for Berkeley DB Environments and Databases.
- DatabaseFactory(BerkeleyDBBinaryStoreManager) - Constructor for class com.tangosol.io.bdb.DatabaseFactory
- 
Construct a DatabaseFactory for a given Berkeley DB Environment.
- DatabaseFactory.EnvironmentHolder - Class in com.tangosol.io.bdb
- 
Holder for Berkeley DB Environment and its Databases.
- DatabaseFactory.EnvironmentHolder.DirectoryLock - Class in com.tangosol.io.bdb
- 
Directory based lock.
- DatabaseFactoryManager - Class in com.tangosol.io.bdb
- 
A manager for Berkeley DB Database factories.
- DatabaseFactoryManager() - Constructor for class com.tangosol.io.bdb.DatabaseFactoryManager
- 
Construct a new DatabaseFactoryManager.
- DatabaseHolder(String) - Constructor for class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
Construct a DatabaseHolder, including a Database.
- DatagramPacketOutputStream - Class in com.tangosol.net
- 
Provides an OutputStream on top of a DatagramPacket.
- DatagramPacketOutputStream(DatagramPacket) - Constructor for class com.tangosol.net.DatagramPacketOutputStream
- DatagramSocketProvider - Interface in com.tangosol.net
- 
DatagramSocketProivder defines an interface for creating datagram and multicast sockets.
- DataStructureRefExpression(Expression<?>, ClassLoader, ResourceMappingRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.DataStructureRefExpression
- 
Constructs a DataStructureRefExpression.
- DATE - com.tangosol.io.pof.DateMode
- DATE_FORMAT - Static variable in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
DateFormat instance that will be used to convert Date keys.
- DATE_TIME - com.tangosol.io.pof.DateMode
- DateAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.DateAdapter
- 
Construct a SimpleAdapter.
- DateFormatAdapter - Class in com.tangosol.run.xml
- 
A property adapter for formatting formatting and parsing dates in a locale-sensitive manner.
- DateFormatAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.DateFormatAdapter
- 
Construct a DateFormatAdapter.
- DateMode - Enum in com.tangosol.io.pof
- 
Enumeration that defines different ways for serialization of date/time values.
- DateTimeAdapter - Class in com.tangosol.run.xml
- 
A property adapter for the <xs:dateTime> format conforming to ISO 8601
- DateTimeAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.DateTimeAdapter
- 
Construct a DateTimeAdapter.
- deactivate() - Method in class com.tangosol.util.AbstractKeyBasedMap.DeferredCacheEvent
- 
Deactivate this DeferredCacheEvent instance.
- deactivate() - Method in class com.tangosol.util.SafeHashMap.EntrySet.EntrySetIterator
- 
Shut down the Iterator.
- deactivate() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet.EntrySetIterator
- 
Shut down the Iterator.
- deactivatePage(SerializationPagedCache.WrapperBinaryStore) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Deactivate a page that is no longer active.
- DeactivationListener() - Constructor for class com.tangosol.net.cache.CachingMap.DeactivationListener
- DeactivationListener() - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.DeactivationListener
- DeactivationListener(MapListenerProxy) - Constructor for class com.oracle.coherence.grpc.proxy.MapListenerProxy.DeactivationListener
- 
Construct the DeactivationListener for the providedMapListenerProxy.
- DebugDataOutputStream - Class in com.tangosol.io
- 
This is an imitation DataOutputStream class that logs the output in a human-readable format for debugging purposes.
- DebugDataOutputStream(OutputStream) - Constructor for class com.tangosol.io.DebugDataOutputStream
- 
Construct a DebugDataOutputStream that will output to the specified Stream object.
- decimalValue(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Returns the integer value of a decimal digit.
- decimalValue(char) - Static method in class com.tangosol.util.Base
- 
Returns the integer value of a decimal digit.
- DECO_APP_1 - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Application-assignable decoration; this decoration will not be used, modified or overwritten by Coherence or other Oracle products.
- DECO_APP_2 - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Application-assignable decoration; this decoration will not be used, modified or overwritten by Coherence or other Oracle products.
- DECO_APP_3 - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Application-assignable decoration; this decoration will not be used, modified or overwritten by Coherence or other Oracle products.
- DECO_BACKUP - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Suggests the backup is not in sync.
- DECO_CUSTOM - Static variable in interface com.tangosol.net.BackingMapManagerContext
- 
The decoration id for a client specific (opaque) value information.
- DECO_CUSTOM - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: A client specific value (opaque).
- DECO_EXPIRY - Static variable in interface com.tangosol.net.BackingMapManagerContext
- 
The decoration id for the value expiry information.
- DECO_EXPIRY - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: The expiry for the value.
- DECO_ID_MAX - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration range: The maximum decoration identifier.
- DECO_ID_MIN - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration range: The minimum decoration identifier.
- DECO_JCACHE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Holds JCache specific meta-information for an entry.
- DECO_JCACHE_SYNTHETIC - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Indicates if an update or delete is considered to be synthetic for JCache.
- DECO_MEMCACHED - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Information managed on behalf of Memcached acceptor.
- DECO_PUSHREP - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Information managed on behalf of Push Replication.
- DECO_QUEUE_METADATA - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Information about a queue element
- DECO_RSVD_1 - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Reserved for future use by Coherence; do not use.
- DECO_STORE - Static variable in interface com.tangosol.net.BackingMapManagerContext
- 
The decoration id for the persistent state of the decorated value.
- DECO_STORE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: The persistent state for the value.
- DECO_TX - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Information managed on behalf of the transactions implementation.
- DECO_VALUE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: The original value (before being decorated).
- DECO_WLS - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Decoration: Information managed on behalf of WebLogic.
- decode(char) - Static method in class com.tangosol.io.Base64InputStream
- 
Decode one base64 alphabet character.
- decode(char[]) - Static method in class com.tangosol.io.Base64InputStream
- 
Decode the passed character data that was encoded using Base64 encoding.
- decode(char[], boolean) - Static method in class com.tangosol.io.Base64InputStream
- 
Decode the passed character data that was encoded using Base64 encoding.
- decode(char[], int, int) - Static method in class com.tangosol.io.Base64InputStream
- 
Decode the passed character data that was encoded using Base64 encoding.
- decode(char[], int, int, boolean) - Static method in class com.tangosol.io.Base64InputStream
- 
Decode the passed character data that was encoded using Base64 encoding.
- decode(PofReader, int) - Method in interface com.tangosol.io.pof.reflect.Codec
- 
Deserialize an object from the providedPofReader.
- decode(PofReader, int) - Method in class com.tangosol.io.pof.reflect.Codecs.ArrayCodec
- 
Deserialize an object from the providedPofReader.
- decode(PofReader, int) - Method in class com.tangosol.io.pof.reflect.Codecs.CollectionCodec
- 
Deserialize an object from the providedPofReader.
- decode(PofReader, int) - Method in class com.tangosol.io.pof.reflect.Codecs.DefaultCodec
- 
Deserialize an object from the providedPofReader.
- decode(PofReader, int) - Method in class com.tangosol.io.pof.reflect.Codecs.LongArrayCodec
- 
Deserialize an object from the providedPofReader.
- decode(PofReader, int) - Method in class com.tangosol.io.pof.reflect.Codecs.MapCodec
- 
Deserialize an object from the providedPofReader.
- decodeAttribute(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Decode an attribute value that was quoted.
- decodeContent(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Decode an element's content value.
- decodeCookie(Service, ByteString) - Static method in class com.oracle.coherence.grpc.proxy.PagedQueryHelper
- 
Decode the binary cookie used in a paged request.
- decodeExpiry(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Decode the expiry time from the specified ReadBuffer.
- decodeString(String) - Static method in class com.tangosol.run.xml.SimpleAdapter
- 
Parse escaped string into a string.
- decodeTinyInt(int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Decode an integer value from one of the reserved single-byte combined type and value indicators.
- decodeUri(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Decode a System Identifier as per the XML 1.0 Specification 2nd ed section 4.2.2.
- decorate(ReadBuffer, int, ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Decorate the passed value with the specified decoration and return the resulting ReadBuffer.
- decorate(ReadBuffer, ReadBuffer[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Decorate the passed Binary with the passed decorations.
- decorate(Binary, int, Binary) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Decorate the passed value with the specified decoration and return the resulting Binary.
- decorate(Binary, Binary[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Deprecated.as of Coherence 3.7.2
- decorate(Object, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Decorate the specified value with the specified integer decoration.
- decorateBinary(ReadBuffer, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Decorate the specified ReadBuffer with the specified integer decoration.
- DecoratedBinaryDeltaCompressor - Class in com.tangosol.io
- 
A DeltaCompressor implementation that works with decorated binary values.
- DecoratedBinaryDeltaCompressor(DeltaCompressor) - Constructor for class com.tangosol.io.DecoratedBinaryDeltaCompressor
- 
Construct a DecoratedBinaryDeltaCompressor.
- DecoratedMultiBufferReadBuffer(ReadBuffer, ReadBuffer[]) - Constructor for class com.tangosol.util.ExternalizableHelper.DecoratedMultiBufferReadBuffer
- 
Construct a DecoratedMultiBufferReadBuffer for the specified value.
- DecorationOnlyDeltaCompressor - Class in com.tangosol.io
- 
DecorationOnlyDeltaCompressor is a DeltaCompressor which optimizes for "decoration-only" updates.
- DecorationOnlyDeltaCompressor() - Constructor for class com.tangosol.io.DecorationOnlyDeltaCompressor
- decrementAndGet() - Method in class com.oracle.coherence.common.base.MutableLong
- 
Decrement the long and return the new value.
- decrementAndGet() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically decrements the current value.
- decrementAndGet() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically decrements the current value.
- decrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- decrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- decrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- decrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- decrementAndGet() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically decrements the current value.
- decrementAndGet() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically decrements the current value.
- decrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- decrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- decrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- decrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- decrypt(SignedObject, PublicKey) - Method in class com.tangosol.net.security.DefaultController
- 
Decrypt the specified SignedObject using the specified public key.
- decrypt(SignedObject, Subject, Subject) - Method in interface com.tangosol.net.security.AccessController
- 
Decrypt the specified SignedObject using the public credentials for a given encryptor Subject in a context represented by the decryptor Subject which is usually associated with the current thread.
- decrypt(SignedObject, Subject, Subject) - Method in class com.tangosol.net.security.DefaultController
- 
Decrypt the specified SignedObject using the public credentials for a given encryptor Subject in a context represented by the decryptor Subject which is usually associated with the current thread.
- Default() - Constructor for class com.tangosol.coherence.config.EnvironmentVariableResolver.Default
- Default() - Constructor for class com.tangosol.coherence.config.SystemPropertyResolver.Default
- DEFAULT - Static variable in annotation type com.oracle.coherence.cdi.Scope
- 
Predefined constant for system scope.
- DEFAULT - Static variable in interface com.oracle.coherence.grpc.proxy.ConfigurableCacheFactorySuppliers
- 
The default instance of the DefaultCacheFactorySupplier.
- DEFAULT - Static variable in interface com.tangosol.coherence.rest.query.QueryEngine
- 
The name of the default (CohQL) query engine.
- DEFAULT - Static variable in interface com.tangosol.io.NamedSerializerFactory
- 
The default implementation ofNamedSerializerFactorythat looks upSerializerinstances by name in the Coherence operational configuration.
- DEFAULT - Static variable in annotation type com.tangosol.net.management.annotation.MetricsTag
- DEFAULT - Static variable in annotation type com.tangosol.net.management.annotation.MetricsValue
- DEFAULT_ACTIVE_DIR - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Default active directory name.
- DEFAULT_BACKUP_DIR - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Default backup directory name.
- DEFAULT_BASE_DIR - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Default base persistence directory name.
- DEFAULT_BASE_DIR_PROPERTY - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Default persistence directory system property.
- DEFAULT_CHANNEL_COUNT - Static variable in interface com.tangosol.net.topic.NamedTopic
- 
The topic should have the default number of channels.
- DEFAULT_CODEC - Static variable in class com.tangosol.io.pof.reflect.Codecs
- 
A singleton instance of aCodecs.DefaultCodec
- DEFAULT_COHERENCE_CONFIGURATION_URI_SYSTEM_PROPERTY - Static variable in class com.tangosol.coherence.jcache.Constants
- 
The system property to specify an alternativeConstants.DEFAULT_COHERENCE_JCACHE_CONFIGURATION_URI.
- DEFAULT_COHERENCE_JCACHE_CONFIGURATION_CLASS_NAME_SYSTEM_PROPERTY - Static variable in class com.tangosol.coherence.jcache.Constants
- 
The system property to specify the Coherence-based JCache Configuration class to use as the default type of JCache Configuration when a standard (non-Coherence-based) JCache configuration is provided.
- DEFAULT_COHERENCE_JCACHE_CONFIGURATION_URI - Static variable in class com.tangosol.coherence.jcache.Constants
- 
The uri of the Coherence Cache Configuration file to use as the default when one is not specified by an application.
- DEFAULT_COHERENCE_JCACHE_EXTEND_CLIENT_CONFIGURATION_URI - Static variable in class com.tangosol.coherence.jcache.Constants
- 
The uri of the Coherence Cache Configuration file to use as the default when one is not specified by an application and the propertyConstants.DEFAULT_COHERENCE_JCACHE_CONFIGURATION_CLASS_NAME_SYSTEM_PROPERTYis "remote" or "extend" orRemoteCacheConfiguration.
- DEFAULT_DATAGRAM_SOCKET_PROVIDER - Static variable in class com.tangosol.net.SocketProviderFactory
- 
The factory's default Datagram SocketProvider.
- DEFAULT_EVENTS_DIR - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Default events directory name.
- DEFAULT_EXECUTOR_NAME - Static variable in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
The name of thedefaultexecutor; a single-threaded executor on each member running thecoherence-concurrentmodule.
- DEFAULT_EXPIRE - Static variable in class com.tangosol.net.cache.LocalCache
- 
By default, the cache entries never expire.
- DEFAULT_EXPIRE - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.By default, the cache entries expire after one hour.
- DEFAULT_EXPIRY_DURATION - Static variable in class com.tangosol.coherence.jcache.Constants
- 
The default expiryDuration.
- DEFAULT_FACTORY - Static variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Default failure continuation factory that provides continuations that only throw PersistenceExceptions.
- DEFAULT_FACTORY - Static variable in class com.tangosol.persistence.SafePersistenceWrappers
- 
Default failure continuation factory that provides null continuations.
- DEFAULT_FILTER_LIST - Static variable in class com.tangosol.util.ClassHelper
- 
Composed ofClassHelper.DEFAULT_REFLECT_ALLOWED_BLACKLISTfollowed by allowing reflection against all other classes.
- DEFAULT_FLUSH - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.as of Coherence 3.5
- DEFAULT_GROWTHRATE - Static variable in class com.tangosol.util.SafeHashMap
- 
Using the default growth rate, the bucket array will grow by a factor of four.
- DEFAULT_GROWTHRATE - Static variable in class com.tangosol.util.SegmentedHashMap
- 
Using the default growth rate, the bucket array will grow by a factor of four.
- DEFAULT_HTTP_PORT - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Default HTTP port (8888).
- DEFAULT_INDEX_FILE_NAME - Static variable in class com.tangosol.io.pof.ConfigurablePofContext
- 
Default Jandex index file.
- DEFAULT_INITIALSIZE - Static variable in class com.tangosol.util.SafeHashMap
- 
Default initial size provides a prime modulo and is large enough that resize is not immediate.
- DEFAULT_INITIALSIZE - Static variable in class com.tangosol.util.SegmentedHashMap
- 
Default initial size provides a prime modulo and is large enough that resize is not immediate.
- DEFAULT_KEY_MASK - Variable in class com.tangosol.net.cache.LocalCache
- 
The default key mask that ignores nothing.
- DEFAULT_LEGACY_SOCKET_PROVIDER - Static variable in class com.tangosol.net.SocketProviderFactory
- 
The factory's default legacy SocketProvider.
- DEFAULT_LIMIT - Static variable in class com.tangosol.io.AsyncBinaryStore
- 
Default size limit for write-queued data.
- DEFAULT_LOAD_FACTOR - Static variable in class com.tangosol.util.Base
- 
Default load factor for hashing collections.
- DEFAULT_LOADFACTOR - Static variable in class com.tangosol.util.SafeHashMap
- 
The default load factor is 100%, which means that the hash map will not resize until there is (on average) one entry in every bucket.
- DEFAULT_LOADFACTOR - Static variable in class com.tangosol.util.SegmentedHashMap
- 
The default load factor is 100%, which means that the hash map will not resize until there is (on average) one entry in every bucket.
- DEFAULT_LOCK_DIR - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Default lock directory name.
- DEFAULT_MAX_SIZE - Static variable in class com.tangosol.io.nio.MappedBufferManager
- 
Default maximum size for a memory mapped file.
- DEFAULT_MAXLOADFACTOR - Static variable in class com.tangosol.io.nio.BinaryMap
- 
Default value for the percentage of the modulo that the entry count must reach before going to the next bucket level.
- DEFAULT_MIN_SIZE - Static variable in class com.tangosol.io.nio.MappedBufferManager
- 
Default minimum size for a memory mapped file.
- DEFAULT_MINLOADFACTOR - Static variable in class com.tangosol.io.nio.BinaryMap
- 
Default value for the percentage of the next lower bucket level's modulo that the entry count must drop to before reverting to the next lower bucket level.
- DEFAULT_NAME - Static variable in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry
- 
The name to use for the registration of a singleton and thus default resource.
- DEFAULT_NAME - Static variable in class com.tangosol.net.Coherence
- 
The default session name.
- DEFAULT_NAME - Static variable in interface com.tangosol.util.ResourceRegistry
- 
The name to use for the registration of a singleton and thus default resource.
- DEFAULT_PAGE_CAPACITY_BYTES - Static variable in interface com.tangosol.net.topic.NamedTopic
- 
The default capacity of pages when using the default binary calculator (1MB).
- DEFAULT_PARTITIONED_CACHE_STATISTICS_REFRESHTIME - Static variable in class com.tangosol.coherence.jcache.Constants
- 
By default, throttle constant updating of JCacheStatistics across storage-enabled members of a PartitionedCache.
- DEFAULT_PRIORITY - Static variable in interface com.oracle.coherence.grpc.proxy.GrpcServerBuilderProvider
- 
Deprecated.The default priority for providers without a specific priority.
- DEFAULT_PRIORITY - Static variable in interface com.tangosol.net.management.MapJsonBodyHandler
- 
The default priority.
- DEFAULT_PRIORITY - Static variable in interface com.tangosol.net.SessionConfiguration
- 
The default priority for a configuration.
- DEFAULT_PRUNE - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.By default, when the cache prunes, it reduces its entries to this percentage.
- DEFAULT_RECONNECT_RETRY_SECONDS - Static variable in interface com.tangosol.net.topic.NamedTopic
- 
The default reconnect retry.
- DEFAULT_RECONNECT_TIMEOUT_SECONDS - Static variable in interface com.tangosol.net.topic.NamedTopic
- 
The default reconnect timeout.
- DEFAULT_RECONNECT_WAIT_SECONDS - Static variable in interface com.tangosol.net.topic.NamedTopic
- 
The default reconnect wait.
- DEFAULT_RECYCLE_MAX - Static variable in class com.tangosol.util.RecyclingLinkedList
- 
The default maximum number of Nodes to recycle.
- DEFAULT_REFLECT_ALLOWED_BLACKLIST - Static variable in class com.tangosol.util.ClassHelper
- 
Default reflection filter list which disables reflection against the following types: java.lang.Class java.lang.System java.lang.Runtime
- DEFAULT_RESOURCE - Static variable in class com.tangosol.io.pof.ConfigurablePofContext
- 
The name of the application resource that contains the default set of wire-format-to-object bindings.
- DEFAULT_RMI_CONNECTION_PORT - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Default RMI connection port (0 ephemeral).
- DEFAULT_RMI_HOST - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Default RMI host (wildcard).
- DEFAULT_RMI_REGISTRY_PORT - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Default RMI registry port (9000).
- DEFAULT_SCOPE - Static variable in class com.tangosol.net.Coherence
- 
The default scope name.
- DEFAULT_SIZE - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
The default size of an entry used if the calculator is unable to calculate the size.
- DEFAULT_SNAPSHOT_DIR - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Default snapshot directory name.
- DEFAULT_SOCKET_PROVIDER - Static variable in class com.tangosol.net.SocketProviderFactory
- 
The factory's default SocketProvider.
- DEFAULT_START_TIMEOUT - Static variable in class com.tangosol.net.Coherence
- 
The default start up timeout.
- DEFAULT_SUBSCRIBER_TIMEOUT_SECONDS - Static variable in interface com.tangosol.net.topic.NamedTopic
- 
The default subscriber timeout.
- DEFAULT_TRANSFER_THRESHOLD - Static variable in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
The default transfer threshold.
- DEFAULT_TRASH_DIR - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Default trash directory name.
- DEFAULT_UNITS - Static variable in class com.tangosol.net.cache.LocalCache
- 
By default, the cache size (in units) is infinite.
- DEFAULT_UNITS - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.By default, the cache size (in units).
- DEFAULT_WAIT_MILLIS - Static variable in class com.tangosol.net.DefaultCacheServer
- 
The default number of milliseconds between checks for service restart.
- DEFAULT_WAIT_MILLIS - Static variable in class com.tangosol.net.SimpleServiceMonitor
- 
The default time interval by which we check the alive status.
- DefaultAggregatorFactory - Class in com.tangosol.coherence.rest.util.aggregator
- 
The default implementation ofAggregatorFactory.
- DefaultAggregatorFactory(Class) - Constructor for class com.tangosol.coherence.rest.util.aggregator.DefaultAggregatorFactory
- 
Construct a DefaultAggregatorFactory instance.
- DefaultBuilderCustomization<T> - Class in com.tangosol.coherence.config.builder
- 
TheDefaultBuilderCustomizationclass is the default implementation ofBuilderCustomization.
- DefaultBuilderCustomization() - Constructor for class com.tangosol.coherence.config.builder.DefaultBuilderCustomization
- DefaultCacheFactoryBuilder - Class in com.tangosol.net
- 
DefaultCacheFactoryBuilderis the default implementation ofCacheFactoryBuilder.
- DefaultCacheFactoryBuilder() - Constructor for class com.tangosol.net.DefaultCacheFactoryBuilder
- DefaultCacheFactorySupplier() - Constructor for class com.oracle.coherence.grpc.proxy.ConfigurableCacheFactorySuppliers.DefaultCacheFactorySupplier
- DefaultCacheServer - Class in com.tangosol.net
- 
DefaultCacheServer is a simple command line facility and convenience API that starts all services that are declared as requiring an "autostart" in the configurable factory XML descriptor.
- DefaultCacheServer(ConfigurableCacheFactory) - Constructor for class com.tangosol.net.DefaultCacheServer
- 
Construct a DefaultCacheServer using the provided factory.
- DefaultCacheServer.LifecycleContext - Class in com.tangosol.net
- DefaultCodec() - Constructor for class com.tangosol.io.pof.reflect.Codecs.DefaultCodec
- DefaultConfigurableCacheFactory - Class in com.tangosol.net
- 
Deprecated.
- DefaultConfigurableCacheFactory() - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a default DefaultConfigurableCacheFactory using the default configuration file name.
- DefaultConfigurableCacheFactory(XmlElement) - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a DefaultConfigurableCacheFactory using the specified configuration XML.
- DefaultConfigurableCacheFactory(XmlElement, ClassLoader) - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a DefaultConfigurableCacheFactory using the specified configuration XML.
- DefaultConfigurableCacheFactory(String) - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a DefaultConfigurableCacheFactory using the specified path to a "coherence-cache-config.xsd" compliant configuration file or resource.
- DefaultConfigurableCacheFactory(String, ClassLoader) - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a DefaultConfigurableCacheFactory using the specified path to a "coherence-cache-config.xsd" compliant configuration file or resource.
- DefaultConfigurableCacheFactory.CacheInfo - Class in com.tangosol.net
- 
Deprecated.CacheInfo is a placeholder for cache attributes retrieved during parsing the corresponding cache mapping element.
- DefaultConfigurableCacheFactory.Manager - Class in com.tangosol.net
- 
Deprecated.BackingMapManager implementation that uses the configuration XML to create the required backing maps and provides client access to those maps.
- DefaultConfigurableCacheFactory.PartitionedBackingMapManager - Class in com.tangosol.net
- 
Deprecated.BackingMapManager implementation used by PartitionAwareBackingMap(s) to lazily configure the enclosing PABM based on the configuration settings of the enclosed maps.
- DefaultContext(Coherence.Mode, SessionProvider, Iterable<? extends EventInterceptor<?>>, String) - Constructor for class com.tangosol.net.SessionProvider.DefaultContext
- 
Create a new default context.
- DefaultController - Class in com.tangosol.net.security
- 
The default implementation of the AccessController interface.
- DefaultController(File, File) - Constructor for class com.tangosol.net.security.DefaultController
- 
Construct DefaultController for the specified key store file and permissions description (XML) file.
- DefaultController(File, File, boolean) - Constructor for class com.tangosol.net.security.DefaultController
- 
Construct DefaultController for the specified key store file, permissions description (XML) file and the audit flag.
- DefaultController(File, File, boolean, PasswordProvider) - Constructor for class com.tangosol.net.security.DefaultController
- 
Construct DefaultController for the specified key store file, permissions description (XML) file, the audit flag, and key store password provider.
- DefaultController(File, File, boolean, String) - Constructor for class com.tangosol.net.security.DefaultController
- 
Construct DefaultController for the specified key store file, permissions description (XML) file, the audit flag, and key store password.
- DefaultDelimiterExpansionProcessor(String) - Constructor for class com.tangosol.config.expression.ValueMacroExpression.DefaultDelimiterExpansionProcessor
- 
Perform default delimiter expansion usingsDefaultDelimiter.
- DefaultDependencies() - Constructor for class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl.DefaultDependencies
- DefaultDependencies() - Constructor for class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- DefaultDependencies() - Constructor for class com.oracle.coherence.grpc.proxy.NamedCacheService.DefaultDependencies
- DefaultDependencies() - Constructor for class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Constructs aDocumentProcessor.DefaultDependencies.
- DefaultDependencies() - Constructor for class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
Construct a DefaultSocketProviderDependencies object.
- DefaultDependencies() - Constructor for class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Construct a DefaultDependencies object.
- DefaultDependencies(BaseGrpcServiceImpl.Dependencies) - Constructor for class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl.DefaultDependencies
- DefaultDependencies(GrpcServiceDependencies) - Constructor for class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl.DefaultDependencies
- DefaultDependencies(GrpcServiceDependencies) - Constructor for class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- DefaultDependencies(GrpcServiceDependencies) - Constructor for class com.oracle.coherence.grpc.proxy.NamedCacheService.DefaultDependencies
- DefaultDependencies(NamedCacheService.Dependencies) - Constructor for class com.oracle.coherence.grpc.proxy.NamedCacheService.DefaultDependencies
- DefaultDependencies(CacheConfig) - Constructor for class com.tangosol.net.ExtensibleConfigurableCacheFactory.DefaultDependencies
- 
Constructs aExtensibleConfigurableCacheFactory.DefaultDependencieswith the ContextClassLoaderbeing theClassLoaderof theCacheConfiginstance and an emptyResourceRegistry.
- DefaultDependencies(CacheConfig, ClassLoader, ResourceRegistry) - Constructor for class com.tangosol.net.ExtensibleConfigurableCacheFactory.DefaultDependencies
- 
Constructs aExtensibleConfigurableCacheFactory.DefaultDependencies.
- DefaultDependencies(NamespaceHandler) - Constructor for class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Constructs aDocumentProcessor.DefaultDependencieswith a defaultNamespaceHandler.
- DefaultDependencies(TcpDatagramSocketProvider.Dependencies) - Constructor for class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Construct a DefaultDependencies object copying the values from the specified dependencies object
- DefaultDependencies(PrintWriter, BufferedReader, CoherenceQueryLanguage) - Constructor for class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Create a DefaultDependencies instance that will use the specifiedPrintWriterandBufferedReaderfor output and input.
- DefaultFailureContinuation(Object) - Constructor for class com.tangosol.persistence.AbstractPersistenceEnvironment.DefaultFailureContinuation
- 
Create a new DefaultFailureContinuation for the given exception source.
- DefaultGrpcAcceptorController - Class in com.oracle.coherence.grpc.proxy
- 
The defaultGrpcAcceptorControllerimplementation.
- DefaultGrpcAcceptorController() - Constructor for class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- DefaultIdentityAsserter - Class in com.tangosol.net.security
- 
The default implementation of the IdentityAsserter interface.
- DefaultIdentityAsserter() - Constructor for class com.tangosol.net.security.DefaultIdentityAsserter
- DefaultIdentityTransformer - Class in com.tangosol.net.security
- 
The default implementation of the IdentityTransformer interface, which simply returns the Subject that is passed to it.
- DefaultIdentityTransformer() - Constructor for class com.tangosol.net.security.DefaultIdentityTransformer
- DefaultKeyAssociator - Class in com.tangosol.net.partition
- 
A DefaultKeyAssociator provides key associations on behalf of keys that implement theKeyAssociationinterface.
- DefaultKeyAssociator() - Constructor for class com.tangosol.net.partition.DefaultKeyAssociator
- 
Default constructor.
- DefaultKeyConverter - Class in com.tangosol.coherence.rest
- 
Default implementation ofKeyConverterfor a given key class.
- DefaultKeyConverter(Class) - Constructor for class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Construct a DefaultKeyConverter instance.
- DefaultKeyPartitioningStrategy - Class in com.tangosol.net.partition
- 
DefaultKeyPartitioningStrategy provides a simple strategy for assigning keys to partitions which is based on the hash code of keys in internal (serialized to Binary) form.
- DefaultKeyPartitioningStrategy() - Constructor for class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
- 
Default constructor.
- defaultLed(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
The default led method that will be called if there is noOPTokenmapped for the token parsed from the token stream.
- defaultNud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
The default nud method that will be called if there is noOPTokenmapped for the token parsed from the token stream.
- DefaultObjectStreamFactory() - Constructor for class com.tangosol.util.ExternalizableHelper.DefaultObjectStreamFactory
- DefaultPasswordProvider() - Constructor for class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor.DefaultPasswordProvider
- DefaultPasswordProvider(String) - Constructor for class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor.DefaultPasswordProvider
- 
Constructor sets the password-string as a char[] when "get()" is called.
- DefaultProcessingContext - Class in com.tangosol.config.xml
- 
The default implementation of aProcessingContext.
- DefaultProcessingContext() - Constructor for class com.tangosol.config.xml.DefaultProcessingContext
- DefaultProcessingContext(DefaultProcessingContext, XmlElement) - Constructor for class com.tangosol.config.xml.DefaultProcessingContext
- 
Constructs a sub-ProcessingContextof anotherProcessingContext.
- DefaultProcessingContext(DocumentProcessor.Dependencies) - Constructor for class com.tangosol.config.xml.DefaultProcessingContext
- 
Constructs a rootProcessingContextwith the specifiedDocumentProcessorDocumentProcessor.Dependencies.
- DefaultProcessingContext(DocumentProcessor.Dependencies, XmlElement) - Constructor for class com.tangosol.config.xml.DefaultProcessingContext
- 
Constructs a rootProcessingContextfor a givenXmlElement.
- DefaultProcessingContext(XmlElement) - Constructor for class com.tangosol.config.xml.DefaultProcessingContext
- 
Constructs a rootProcessingContextfor a givenXmlElementusing default DocumentProcessor dependencies.
- DefaultProcessorFactory - Class in com.tangosol.coherence.rest.util.processor
- 
The default implementation ofProcessorFactory.
- DefaultProcessorFactory(Class) - Constructor for class com.tangosol.coherence.rest.util.processor.DefaultProcessorFactory
- 
Construct a DefaultProcessorFactory instance.
- defaultProvider() - Method in interface com.tangosol.net.SessionProvider.Context
- 
Returns the default session provider that may be used to delegate to for session creation.
- defaultProvider() - Method in class com.tangosol.net.SessionProvider.DefaultContext
- DefaultProxyServiceLoadBalancer - Class in com.tangosol.net.proxy
- 
Default ProxyServiceLoadBalancer implementation.
- DefaultProxyServiceLoadBalancer() - Constructor for class com.tangosol.net.proxy.DefaultProxyServiceLoadBalancer
- 
Default constructor.
- DefaultProxyServiceLoadBalancer(Comparator) - Constructor for class com.tangosol.net.proxy.DefaultProxyServiceLoadBalancer
- 
Create a new DefaultProxyServiceLoadBalancer that will order ProxyServiceLoad objects using the specified Comparator.
- DefaultResourceConfig - Class in com.tangosol.coherence.rest.server
- 
An extension of org.glassfish.jersey.server.ResourceConfig that registers the Coherence REST root resource and provider classes, in addition to user defined package names.
- DefaultResourceConfig() - Constructor for class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Default constructor.
- DefaultResourceConfig(Class<?>) - Constructor for class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Construct an instance of ResourceConfig that initialized with a given set of resource/provider classes and Coherence predefined root resource and providers.
- DefaultResourceConfig(String...) - Constructor for class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Construct an instance of ResourceConfig that initialize Coherence predefined properties and searches for root resource classes and providers in the specified packages.
- DefaultRootResource - Class in com.tangosol.coherence.rest
- 
Default root resource implementation.
- DefaultRootResource() - Constructor for class com.tangosol.coherence.rest.DefaultRootResource
- DefaultsCreationPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
ADefaultsCreationPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat creates necessary defaults, like for <serializer>s, if they are missing from the <defaults> element.
- DefaultsCreationPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.DefaultsCreationPreprocessor
- 
Constructs aDefaultsCreationPreprocessor.
- DefaultSerializer - Class in com.tangosol.io
- 
A Serializer implementation that uses the ExternalizableHelper implementation for serialization and deserialization of objects.
- DefaultSerializer() - Constructor for class com.tangosol.io.DefaultSerializer
- 
Default constructor.
- DefaultSerializer(ClassLoader) - Constructor for class com.tangosol.io.DefaultSerializer
- 
Construct a DefaultSerializer that will use the passed ClassLoader.
- DefaultServletContextListener - Class in com.tangosol.coherence.rest.servlet
- 
A simple implementation of the ServletContextListener interface that callsCacheFactory.shutdown()during servlet context shutdown.
- DefaultServletContextListener() - Constructor for class com.tangosol.coherence.rest.servlet.DefaultServletContextListener
- defaultSession() - Static method in interface com.tangosol.net.SessionConfiguration
- 
Create aSessionConfigurationfor the defaultSession.
- DefaultsProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
TheDefaultsProcessoris responsible for processing the <defaults>XmlElementin a Coherence Cache Configuration file, registering each of the processed elements with theResourceRegistry.
- DefaultsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.DefaultsProcessor
- DefaultStatementResult - Class in com.tangosol.coherence.dslquery.statement
- 
A default implementation of aStatementResult.
- DefaultStatementResult(Object) - Constructor for class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
Construct a DefaultStatementResult with the specified result value.
- DefaultStatementResult(Object, boolean) - Constructor for class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
Construct a DefaultStatementResult with the specified result value.
- DefaultTaskDependencies() - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DefaultTaskDependencies
- 
Default constructor.
- DefaultTaskDependencies(NonBlockingFiniteStateMachine.TaskDependencies) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DefaultTaskDependencies
- 
Create a DefaultTaskDependencies with providedNonBlockingFiniteStateMachine.TaskDependencies.
- DefaultVersionedPartitions - Class in com.tangosol.net.partition
- 
Default implementation ofVersionedPartitions,
- DefaultVersionedPartitions() - Constructor for class com.tangosol.net.partition.DefaultVersionedPartitions
- 
Default no-arg constructor.
- DefaultVersionedPartitions(VersionedPartitions) - Constructor for class com.tangosol.net.partition.DefaultVersionedPartitions
- 
Copy-like constructor based on the providedVersionedPartitions.
- DefaultVersionedPartitions(PrimitiveSparseArray) - Constructor for class com.tangosol.net.partition.DefaultVersionedPartitions
- 
Create a DefaultVersionedPartitions instance based on the providedPrimitiveSparseArray.
- DeferredCacheEvent(ObservableMap<K, V>, int, K, V, V, boolean) - Constructor for class com.tangosol.util.AbstractKeyBasedMap.DeferredCacheEvent
- 
Constructs a new DeferredCacheEvent.
- defineClass(String, byte[]) - Method in class com.tangosol.coherence.rest.util.PartialObject.PartialClassLoader
- 
Define a class.
- definePropertyPath(String, String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Defines the xml path to locate a specific Java Bean property with in anXmlElementin theProcessingContext.
- definePropertyPath(String, String) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Defines the xml path to locate a specific Java Bean property with in anXmlElementin theProcessingContext.
- DeflaterOutputShell(OutputStream, Deflater) - Constructor for class com.tangosol.net.CompressionFilter.DeflaterOutputShell
- 
Deprecated.Create a new input stream with the specified decompressor.
- DeflaterOutputShell(OutputStream, Deflater, int) - Constructor for class com.tangosol.net.CompressionFilter.DeflaterOutputShell
- 
Deprecated.Create a new input stream with the specified decompressor and buffer size.
- DelayedTransitionTo(S) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DelayedTransitionTo
- 
Constructs aNonBlockingFiniteStateMachine.DelayedTransitionTowithout a specified time (to be schedule as soon as possible).
- DelayedTransitionTo(S, long, TimeUnit) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DelayedTransitionTo
- 
Constructs aNonBlockingFiniteStateMachine.DelayedTransitionTowith the specified time.
- delegate() - Method in class com.oracle.coherence.grpc.SafeStreamObserver
- 
Obtain the wrappedStreamObserver.
- delegate() - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Return the internal LongArray.
- delegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- 
Return the delegate LongArray.
- DelegatingBufferOutput(int) - Constructor for class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Construct an AbstractBufferOutput that will begin writing at the start of the containing WriteBuffer.
- DelegatingWriteBuffer - Class in com.tangosol.io
- 
A DelegatingWriteBuffer is a WriteBuffer that writes through to an underlying (or "containing") WriteBuffer.
- DelegatingWriteBuffer(WriteBuffer, int, int) - Constructor for class com.tangosol.io.DelegatingWriteBuffer
- 
Construct a DelegatingWriteBuffer that will delegate to the containing WriteBuffer.
- DelegatingWriteBuffer.DelegatingBufferOutput - Class in com.tangosol.io
- 
A BufferOutput implementation that delegates to a BufferOutput implementation, except that its offset range is shifted and limited.
- delete() - Method in class com.tangosol.coherence.rest.EntryResource
- 
Remove the entry.
- delete() - Method in class com.tangosol.coherence.rest.EntrySetResource
- 
Remove the entries.
- delete(boolean) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Release any resources held by this persistent store and delete any underlying persistent storage.
- delete(String, boolean) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Remove the PersistentStore associated with the specified identifier.
- delete(String, boolean) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Remove the PersistentStore associated with the specified identifier.
- delete(String, boolean) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Remove the PersistentStore associated with the specified identifier.
- delete(Map.Entry) - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Update this index in response to a remove operation on a cache.
- delete(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
- 
Update this index in response to a remove operation on a cache.
- delete(Map.Entry<? extends K, ? extends V>) - Method in interface com.tangosol.util.MapIndex
- 
Update this index in response to a remove operation on a cache.
- Deleted - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any DELETED event.
- DELETED - Static variable in class com.tangosol.io.AsyncBinaryStore
- 
A special token that is used to signify a queued erase operation.
- DELETED_PREFIX - Static variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
A filename prefix for deleted snapshots used to handle concurrent deletions.
- Deleted.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theDeletedannotation.
- deleteDir(File) - Static method in class com.tangosol.io.FileHelper
- 
Delete a directory recursively.
- deleteDirSilent(File) - Static method in class com.tangosol.io.FileHelper
- 
Recursively delete a directory suppressing any raised exceptions.
- deleteExtent(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Delete the specified extent from the persistent store, ensuring that any key-value mappings associated with the extent are no longer valid.
- deleteExtent(long) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Delete the specified extent from the persistent store, ensuring that any key-value mappings associated with the extent are no longer valid.
- deleteExtent(long) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- deleteExtentInternal(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Delete the specified extent from the persistent store.
- deleteExtents(PersistentStore, long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Delete the provided extent from the specifiedstoreand all associated extents (meta extents).
- DeleteExtentTask(Long) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTask
- 
Construct a DeleteExtentTask with the provided extent id.
- deleteInternal() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Remove the underlying persistent storage.
- deleteInternal(Map.Entry) - Method in class com.tangosol.util.ConditionalIndex
- 
Update this index in response to a remove operation on a cache.
- deleteInternal(Map.Entry) - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Update this index in response to a remove operation on a cache.
- deleteInternal(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
- 
Update this index in response to a remove operation on a cache.
- DeleteStatement(String, Filter) - Constructor for class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder.DeleteStatement
- 
Create an instance ofDeleteStatementBuilder.DeleteStatementthat will delete all entries from the specified cache that match the givenFilter.
- DeleteStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aDeleteStatementBuilder.DeleteStatement.
- DeleteStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder
- DeleteStatementBuilder.DeleteStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "DELETE" query.
- DELIM_APPLICATION_SCOPE - Static variable in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Delimiter for the Application Scope in thescoped service name
- DELIM_DOMAIN_PARTITION - Static variable in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Delimiter for the Domain Partition name in thescoped service name
- delink() - Method in class com.tangosol.util.SafeLinkedList.Node
- 
Remove this Node from the List.
- DELTA_TRUNCATE - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
A delta value that indicates an empty new value.
- DeltaCompressor - Interface in com.tangosol.io
- 
The DeltaCompressor interface provides the capability of comparing two in-memory buffers containing an old and a new value, and producing a result (called a "delta") that can be applied to the old value to create the new value.
- DeltaCompressorProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
An ElementProcessor for processing <compressor> configurations.
- DeltaCompressorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.DeltaCompressorProcessor
- DeltaIterator() - Constructor for class com.tangosol.util.DeltaSet.DeltaIterator
- 
Construct an iterator for a delta set.
- DeltaSet - Class in com.tangosol.util
- 
Implements a set which is based on another set, which is assumed to be immutable.
- DeltaSet(Set) - Constructor for class com.tangosol.util.DeltaSet
- 
Construct this set based on an existing set.
- DeltaSet.DeltaIterator - Class in com.tangosol.util
- 
Iterator for the contents of a delta set.
- Departed - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any DEPARTED event.
- DEPARTED - com.tangosol.net.events.partition.TransferEvent.Type
- 
ThisTransferEventis dispatched when a partition has been successfully transferred from thelocal member.
- Departed.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theDepartedannotation.
- Departing - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any DEPARTING event.
- DEPARTING - com.tangosol.net.events.partition.TransferEvent.Type
- Departing.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theDepartingannotation.
- Dependencies(ConfigurableCacheFactory, BackingMapManagerContext, ClassLoader, String, String) - Constructor for class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Constructs aMapBuilder.Dependencies.
- Dependencies(ConfigurableCacheFactory, BackingMapManagerContext, ClassLoader, String, String, Map<Map, MapListener>) - Constructor for class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Constructs aMapBuilder.Dependencies.
- DependenciesHelper() - Constructor for class com.tangosol.coherence.dslquery.QueryPlus.DependenciesHelper
- DependenciesHelper() - Constructor for class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- Dequeue - Class in com.tangosol.util
- 
Represents a double-ended queue (dequeue) of objects.
- Dequeue() - Constructor for class com.tangosol.util.Dequeue
- 
Constructs a dequeue.
- DEREF_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The AST node name for a De-referencing Node.
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- desc(ValueExtractor) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
- 
Add comparator to this builder.
- desc(String) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
- 
Add comparator to builder.
- descendingIterator() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- descendingKeySet() - Method in class com.tangosol.util.SafeSortedMap
- descendingKeySet() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- descendingMap() - Method in class com.tangosol.util.SafeSortedMap
- descendingMap() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- descendingSet() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- DescribableAddressProvider - Interface in com.tangosol.net
- 
An AddressProvider that additionally allows to retrieve a human readable description of underlying addresses without doing a DNS lookup.
- description() - Method in annotation type com.tangosol.net.management.annotation.Notification
- 
A description of the notification.
- Description - Annotation Type in com.tangosol.net.management.annotation
- 
The Description annotation allows a description to be specified for a method on an MBean, and for an MBean interface itself.
- DESCRIPTOR_KEY - Static variable in annotation type com.tangosol.net.management.annotation.MetricsLabels
- 
The MBean descriptor key that this annotation creates.
- DESCRIPTOR_KEY - Static variable in annotation type com.tangosol.net.management.annotation.MetricsTag
- DESCRIPTOR_KEY - Static variable in annotation type com.tangosol.net.management.annotation.MetricsValue
- DESCRIPTOR_NAME - Static variable in class com.tangosol.coherence.rest.config.RestConfig
- 
The default name of the Coherence REST XML descriptor.
- DESCRIPTOR_PROPERTY - Static variable in class com.tangosol.coherence.rest.config.RestConfig
- 
The name of the system property that can be used to override the default Coherence REST configuration file "coherence-rest-config.xml".
- DeserializationAccelerator - Class in com.tangosol.util.extractor
- 
DeserializationAccelerator is anIndexAwareExtractorimplementation that is used to create aForwardOnlyMapIndex, which in turn is used for deserialization optimization.
- DeserializationAccelerator() - Constructor for class com.tangosol.util.extractor.DeserializationAccelerator
- 
Construct the DeserializationAccelerator.
- DeserializationAccelerator(ValueExtractor) - Constructor for class com.tangosol.util.extractor.DeserializationAccelerator
- 
Construct the DeserializationAccelerator.
- DeserializationAccelerator(ValueExtractor, boolean) - Constructor for class com.tangosol.util.extractor.DeserializationAccelerator
- 
Construct the DeserializationAccelerator.
- deserialize(PofReader) - Method in class com.oracle.coherence.concurrent.atomic.AtomicBoolean.Serializer
- deserialize(PofReader) - Method in class com.oracle.coherence.concurrent.atomic.AtomicInteger.Serializer
- deserialize(PofReader) - Method in class com.oracle.coherence.concurrent.atomic.AtomicLong.Serializer
- deserialize(PofReader) - Method in class com.oracle.coherence.concurrent.atomic.AtomicMarkableReference.Serializer
- deserialize(PofReader) - Method in class com.oracle.coherence.concurrent.atomic.AtomicReference.Serializer
- deserialize(PofReader) - Method in class com.oracle.coherence.concurrent.atomic.AtomicStampedReference.Serializer
- deserialize(PofReader) - Method in class com.tangosol.coherence.rest.util.JsonMap.Serializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.EnumPofSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.ExternalizableLitePofSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.ExternalizablePofSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.InetAddressSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.InetSocketAddressSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.OptionalDoubleSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.OptionalIntSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.OptionalLongSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.OptionalSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.PofAnnotationSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in interface com.tangosol.io.pof.PofSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.PortableObjectSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.PortableTypeSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.PrincipalPofSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext.ExternalSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext.SafePofSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.SerializableSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.SubjectPofSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(PofReader) - Method in class com.tangosol.io.pof.ThrowablePofSerializer
- deserialize(PofReader) - Method in class com.tangosol.io.pof.XmlSerializablePofSerializer
- 
Deserialize a user type instance from a POF stream by reading its state using the specified PofReader object.
- deserialize(ReadBuffer.BufferInput) - Method in class com.tangosol.io.DefaultSerializer
- deserialize(ReadBuffer.BufferInput) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Deserialize an object from a ReadBuffer by reading its state using the specified BufferInput object.
- deserialize(ReadBuffer.BufferInput) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Deserialize an object from a ReadBuffer by reading its state using the specified BufferInput object.
- deserialize(ReadBuffer.BufferInput) - Method in interface com.tangosol.io.Serializer
- 
Deserialize an object from a ReadBuffer by reading its state using the specified BufferInput object.
- deserialize(ReadBuffer.BufferInput) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Deserialize an object from a ReadBuffer by reading its state using the specified BufferInput object.
- deserialize(ReadBuffer.BufferInput, Class<? extends T>) - Method in class com.tangosol.io.MultiplexingSerializer
- deserialize(ReadBuffer.BufferInput, Class<? extends T>) - Method in interface com.tangosol.io.Serializer
- 
Deserialize an object as an instance of the specified class by reading its state using the specified BufferInput object.
- deserialize(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Obtain the deserializedBinaryvalue using the cache's serializer.
- deserializeComparator(ByteString, Serializer) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Obtain aComparatorfrom the serialized data in aByteString.
- deserializeRequest(ByteString) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Obtain the deserializedByteStringvalue using the request's serializer.
- deserializeToBytesValue(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Convert theBinaryserialized in the cache's serialization format to aBytesValueserialized in the request's serialization format.
- destroy() - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
Destroys aCoherenceBasedCachedue to a request from aCoherenceBasedCacheManager.
- destroy() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- destroy() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- destroy() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- destroy() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- destroy() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- destroy() - Method in class com.tangosol.net.cache.NearCache
- 
Release and destroy this instance of NamedCollection.
- destroy() - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- destroy() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Destroy the underlying BinaryStore.
- destroy() - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Release and destroy this instance of NamedCollection.
- destroy() - Method in interface com.tangosol.net.NamedCollection
- 
Release and destroy this instance of NamedCollection.
- destroy() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Release and destroy this instance of NamedCollection.
- destroy(DestroyRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Destroy a cache.
- destroy(DestroyRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- destroy(DestroyRequest, StreamObserver<Empty>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- destroy(String, String) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aDestroyRequest.
- DESTROY - Static variable in class com.tangosol.net.ClusterPermission
- 
Create action.
- destroyBinaryStore(BinaryStore) - Method in class com.tangosol.io.AsyncBinaryStoreManager
- 
Lifecycle method: Destroy a BinaryStore previously created by this manager.
- destroyBinaryStore(BinaryStore) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Destroy a BinaryStore previously created by this manager.
- destroyBinaryStore(BinaryStore) - Method in interface com.tangosol.io.BinaryStoreManager
- 
Lifecycle method: Destroy a BinaryStore previously created by this manager.
- destroyBinaryStore(BinaryStore) - Method in class com.tangosol.io.nio.AbstractStoreManager
- 
Lifecycle method: Destroy a BinaryStore previously created by this manager.
- destroyBinaryStore(BinaryStore) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Destroy and unregister a BinaryStore object that was previously created using this cache's BinaryStoreManager by the createBinaryStore method.
- destroyCache(CoherenceBasedCacheManager, JCacheIdentifier) - Static method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Destroy a partitioned cache when there is no PartitionedCache object.
- destroyCache(CoherenceBasedCacheManager, JCacheIdentifier, NamedCache) - Static method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Destroy a partitioned cache.
- destroyCache(CoherenceBasedCacheManager, String) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedConfiguration
- 
Destroy aCoherenceBasedCacheimplementation.
- destroyCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheConfiguration
- destroyCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfiguration
- destroyCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- destroyCache(CoherenceBasedCacheManager, String) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCacheConfiguration
- destroyCache(NamedCache) - Static method in class com.tangosol.net.CacheFactory
- 
Releases and destroys the specified NamedCache.
- destroyCache(NamedCache) - Method in interface com.tangosol.net.CacheService
- 
Release and destroy the specified cache.
- destroyCache(NamedCache) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Release and destroy this instance of NamedCache.
- destroyCache(NamedCache) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Release and destroy this instance of NamedCache.
- destroyCache(NamedCache) - Method in class com.tangosol.net.WrapperCacheService
- 
Release and destroy the specified cache.
- destroyCache(NamedCache<?, ?>) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Release and destroy this instance of NamedCache.
- destroyCache(String) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- Destroyed - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any DESTROYED event.
- DESTROYED - com.tangosol.net.events.partition.cache.CacheLifecycleEvent.Type
- 
CacheLifecycleEvents of the typeDESTROYEDare raised when a storage for a given cache is destroyed (usually as a result of a call todestroy).
- Destroyed.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theDestroyedannotation.
- destroyIndex(Map) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Destroy an existing index and remove it from the given map of indexes.
- destroyIndex(Map<ValueExtractor<T, E>, MapIndex>) - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Destroy an existing index and remove it from the given map of indexes.
- destroyIndex(Map<ValueExtractor<T, E>, MapIndex>) - Method in interface com.tangosol.util.extractor.IndexAwareExtractor
- 
Destroy an existing index and remove it from the given map of indexes.
- destroyPartition(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Remove a partition from the PartitionAwareBackingMap.
- destroyPartition(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Remove a partition from the PartitionAwareBackingMap.
- destroyPartition(int) - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
- 
Remove a partition from the PartitionAwareBackingMap.
- destroyPartition(int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Remove a partition from the PartitionAwareBackingMap.
- destroyPartition(int) - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Remove a partition from the PartitionAwareBackingMap.
- destroySubscriberGroup(String) - Method in interface com.tangosol.net.topic.NamedTopic
- 
Destroy thenamedsubscriber group for the associated topic.
- destroySubscriberGroup(String, String) - Method in interface com.tangosol.net.PagedTopicService
- 
Destroy an existing subscriber group.
- destroySubscription(long) - Method in interface com.tangosol.net.PagedTopicService
- 
Remove an existing subscriber group.
- destroySubscription(long, Subscriber.Id) - Method in interface com.tangosol.net.PagedTopicService
- 
Remove an existing subscriber from a subscriber group.
- destroyTopic(NamedTopic) - Method in interface com.tangosol.net.TopicService
- 
Release and destroy the specified topic.
- destroyTopic(NamedTopic<?>) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Release and destroy this instance ofNamedTopic.
- destroyTopic(NamedTopic<?>) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.This method will throw anUnsupportedOperationExceptionasNamedTopics are not supported by DefaultConfigurableCacheFactory.
- destroyTopic(NamedTopic<?>) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Release and destroy this instance ofNamedTopic.
- diffCollection(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare an array or collection.
- diffMap(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a Map of keys and values.
- diffPackedInt(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a packed integer value.
- diffPackedInts(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker, int) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a series of packed integer values.
- diffPackedLong(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a packed long integer value.
- diffPackedLongs(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker, int) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a series of packed long integer values.
- diffSparseArray(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a sparse array.
- diffTimeZone(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare time zone information.
- diffUniformCollection(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare an array or collection of uniform types.
- diffUniformKeysMap(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a Map of keys (of a uniform type) and values.
- diffUniformMap(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a Map of keys and values, both of uniform types.
- diffUniformSparseArray(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a sparse array of uniform types.
- diffUniformValue(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker, int) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a POF value of the specified type.
- diffUserType(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a user type value.
- diffValue(ReadBuffer.BufferInput, ReadBuffer.BufferInput, PofDeltaCompressor.ChangeTracker) - Method in class com.tangosol.io.pof.PofDeltaCompressor
- 
Within the two passed POF streams, parse and compare a POF value.
- DirectoryFileFilter() - Constructor for class com.tangosol.persistence.ArchiverHelper.DirectoryFileFilter
- 
Deprecated.
- DirectoryLock(File, String) - Constructor for class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
Create a DirectoryLock which can be used to try to lock a directory.
- DirectorySnapshotArchiver - Class in com.tangosol.persistence
- 
An implementation of aSnapshotArchiverthat uses a shared directory to store archived snapshots.
- DirectorySnapshotArchiver(String, String, File) - Constructor for class com.tangosol.persistence.DirectorySnapshotArchiver
- 
Constructs a new DirectorySnapshotArchiver which uses a shared directory available from all members to store archived snapshots.
- DirectQuery - Class in com.tangosol.coherence.rest.config
- 
Holder for direct query configuration.
- DirectQuery(int) - Constructor for class com.tangosol.coherence.rest.config.DirectQuery
- 
Construct an instance of DirectQuery.
- DirectQuery(String, int) - Constructor for class com.tangosol.coherence.rest.config.DirectQuery
- 
Construct an instance of DirectQuery.
- disable(String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Disable an installed token stored under the given name
- disableTokenNamed(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Disable the token named by the given string.
- DISAPPROVER - Static variable in interface com.tangosol.net.cache.ConfigurableCacheMap.EvictionApprover
- 
Never approving EvictionApprover.
- discard() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Recycle the Block object, discarding any changes, resetting its contents and recycling the object.
- discard() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Called to inform the Entry that it is no longer used.
- discard() - Method in class com.tangosol.util.RecyclingLinkedList.Node
- 
Delink this Node and discard its value.
- discard() - Method in class com.tangosol.util.SafeLinkedList.Node
- 
Delink this Node and discard its value.
- Disconnected - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any DISCONNECTED event.
- Disconnected.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theDisconnectedannotation.
- discoverSerializers() - Static method in interface com.tangosol.io.Serializer
- 
Return aMapofSerializerFactoryinstances discovered on the class path.
- discoverSerializers(ClassLoader) - Static method in interface com.tangosol.io.Serializer
- 
Return aMapofSerializerFactoryinstances discovered on the class path.
- discoverSessions() - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Add all of theSessionConfigurationinstances discovered using theServiceLoader.
- Discriminator(NonBlockingFiniteStateMachine<?>, Object) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent.Discriminator
- 
Constructs aNonBlockingFiniteStateMachine.CoalescedEvent.Discriminatorfor the specifiedNonBlockingFiniteStateMachine.
- dispatch(CoherenceCacheEventEventDispatcher<K, V>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
dispatch outstanding JCache Events
- dispatch(Listeners) - Method in class com.tangosol.net.MemberEvent
- 
Dispatch this event to the specified listeners collection.
- dispatch(Listeners) - Method in class com.tangosol.util.MapEvent
- 
Dispatch this event to the specified listeners collection.
- dispatch(Listeners) - Method in class com.tangosol.util.ServiceEvent
- 
Dispatch this event to the specified listeners collection.
- dispatch(Listeners, boolean) - Method in class com.tangosol.util.MapEvent
- 
Dispatch this event to the specified listeners collection.
- dispatch(MapEvent) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
- 
Dispatch the event to the corresponding listeners.
- dispatch(MapListener<? super K, ? super V>) - Method in class com.tangosol.util.MapEvent
- 
Dispatch this event to the specified MapListener.
- dispatch(Iterable<CoherenceCacheEntryListenerRegistration<K, V>>) - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEventEventDispatcher
- 
Dispatches the added events to the listeners defined by the specifiedCacheEntryListenerConfigurations.
- dispatch(EventListener[]) - Method in class com.tangosol.net.MemberEvent
- 
Dispatch this event to the specified array of listeners.
- dispatch(EventListener[]) - Method in class com.tangosol.util.ServiceEvent
- 
Dispatch this event to the specified array of listeners.
- dispatchEvent(CacheEvent) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Dispatch the passed event.
- dispatchEvent(OverflowMap.Status, int, Object, Object, Object, boolean) - Method in class com.tangosol.net.cache.OverflowMap
- 
Dispatch an event containing the passed event information.
- dispatchEvent(OverflowMap.Status, MapEvent) - Method in class com.tangosol.net.cache.OverflowMap
- 
Dispatch the passed event.
- dispatchEvent(MapEvent) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Dispatch the passed event.
- dispatchEvent(MapEvent) - Method in class com.tangosol.util.ObservableHashMap
- 
Dispatch the passed event.
- dispatchEvent(MapEvent<? extends K, ? extends V>) - Method in class com.tangosol.util.WrapperObservableMap
- 
Dispatch the passed event.
- dispatchPendingEvent(Object, int, Object, boolean) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Dispatch an event that has not yet occurred, allowing the cache to potentially avoid reading of the "original value" information.
- dispatchPendingEvent(K, int, V, boolean) - Method in class com.tangosol.util.WrapperObservableMap
- 
Dispatch an event that has not yet occurred, allowing the cache to potentially avoid reading of the "original value" information.
- displayStatistics(Snapshot, String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Display the collected statistics for the given snapshot and type of operation.
- Disposable - Interface in com.oracle.coherence.common.base
- 
The Disposable interface is used for life-cycle management of resources.
- Disposable - Interface in com.tangosol.util
- 
Deprecated.useDisposableinstead
- dispose() - Method in interface com.oracle.coherence.common.base.Disposable
- 
Invoked when all resources owned by the implementer can safely be released.
- dispose() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- dispose() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryValue
- dispose() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- dispose() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Invoked when all resources owned by the implementer can safely be released.
- dispose() - Method in class com.tangosol.io.nio.BinaryMapStore
- 
Invoked when all resources owned by the implementer can safely be released.
- dispose() - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Dispose of this factory.
- dispose() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Dispose of this factory.
- dispose() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Dispose of this factory.
- dispose() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Invoked when all resources owned by the implementer can safely be released.
- dispose() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Invoked when all resources owned by the implementer can safely be released.
- dispose() - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Invoked when all resources owned by the implementer can safely be released.
- dispose() - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
- dispose() - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Invoked when all resources owned by the implementer can safely be released.
- dispose() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryValue
- 
Invoked when all resources owned by the implementer can safely be released.
- Disposing - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any DISPOSING event.
- DISPOSING - com.tangosol.net.events.application.LifecycleEvent.Type
- 
ThisLifecycleEventis dispatched when aConfigurableCacheFactoryis about to be disposed.
- Disposing.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theDisposingannotation.
- distinct() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the distinct elements of this stream.
- distinct() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the distinct elements of this stream.
- distinct() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the distinct elements of this stream.
- distinct() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the distinct elements (according toObject.equals(Object)) of this stream.
- distinct(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the set of distinct values for the specified extractor.
- distinct(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the set of distinct values for the specified extractor.
- distinct(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the set of distinct values for the specified extractor.
- distinct(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the set of distinct values for the specified extractor.
- distinctValues() - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the set of distinct values from the entries in a Map.
- distinctValues(ValueExtractor<? super T, ? extends R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the set of distinct values extracted from the entries in a Map.
- distinctValues(String) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the set of distinct values extracted from the entries in a Map.
- DistinctValues<K,V,T,E> - Class in com.tangosol.util.aggregator
- 
Return the set of unique values extracted from a set of entries in a Map.
- DistinctValues() - Constructor for class com.tangosol.util.aggregator.DistinctValues
- 
Default constructor (necessary for the ExternalizableLite interface).
- DistinctValues(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.aggregator.DistinctValues
- 
Construct a DistinctValues aggregator.
- DistinctValues(String) - Constructor for class com.tangosol.util.aggregator.DistinctValues
- 
Construct an DistinctValues aggregator.
- DISTRIBUTE - Static variable in interface com.tangosol.net.PartitionedService.PartitionedAction
- 
Singleton action for partition distribution/backup.
- DistributedCacheService - Interface in com.tangosol.net
- 
A DistributedCacheService is a clustered cache service that partitions its data across cluster members that provide backing storage.
- DistributedScheme - Class in com.tangosol.coherence.config.scheme
- 
TheDistributedSchemeclass builds a distributed cache.
- DistributedScheme() - Constructor for class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Constructs aDistributedScheme.
- DistributedScheme(PartitionedCacheDependencies) - Constructor for class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Constructs aDistributedScheme.
- DistributedScheme.BackupConfig - Class in com.tangosol.coherence.config.scheme
- 
TheDistributedScheme.BackupConfigclass manages configuration for the partitioned cache backup map.
- DISTRIBUTION - com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- DistributionManager - Interface in com.tangosol.net.partition
- 
A DistributionManager coordinates the distribution of partitions for a partitioned service.
- DivisionOperator - Class in com.tangosol.coherence.dslquery.operator
- 
An operator representing the conditional mathematical division operation.
- DivisionOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.DivisionOperator
- 
Construct a DivisionOperator.
- DoAsAction<T> - Class in com.tangosol.net.security
- 
A helper class to expose theSubject.doAs(javax.security.auth.Subject, java.security.PrivilegedAction<T>)call as a privileged action.
- DoAsAction(PrivilegedAction<T>) - Constructor for class com.tangosol.net.security.DoAsAction
- 
Construct a privileged action.
- DoAsAction(Subject, PrivilegedAction<T>) - Constructor for class com.tangosol.net.security.DoAsAction
- 
Construct a privileged action.
- doBalancePrimary(SimpleAssignmentStrategy.AnalysisContext, Member, PartitionSet, Member[]) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Do balancing transfers for primary distribution.
- DocumentElementPreprocessor - Class in com.tangosol.config.xml
- 
ADocumentElementPreprocessoris aDocumentPreprocessorthat is designed to operate with one or moreDocumentElementPreprocessor.ElementPreprocessors.
- DocumentElementPreprocessor() - Constructor for class com.tangosol.config.xml.DocumentElementPreprocessor
- 
Constructs aDocumentElementPreprocessor.
- DocumentElementPreprocessor.ElementPreprocessor - Interface in com.tangosol.config.xml
- 
AnDocumentElementPreprocessor.ElementPreprocessorprovides a mechanism to examine and optionally mutate anXmlElementprior to it being processed by aElementProcessor.
- DocumentPreprocessor - Interface in com.tangosol.config.xml
- 
ADocumentPreprocessorprovides a mechanism to pre-process anXmlElement, representing part or all of anXmlDocumentprior to the saidXmlElementbeing processes using configuredElementProcessors.
- DocumentProcessor - Class in com.tangosol.config.xml
- 
ADocumentProcessoris responsible for processing in anXmlDocumentto produce a resulting configured resource.
- DocumentProcessor(DocumentProcessor.Dependencies) - Constructor for class com.tangosol.config.xml.DocumentProcessor
- 
Construct aDocumentProcessor.
- DocumentProcessor.DefaultDependencies - Class in com.tangosol.config.xml
- 
TheDocumentProcessor.DefaultDependenciesis the default implementation of theDocumentProcessorDocumentProcessor.Dependenciesinterface.
- DocumentProcessor.Dependencies - Interface in com.tangosol.config.xml
- doHttpRequest(URI) - Method in class com.tangosol.net.URLMemberIdentityProvider
- doSerialization(WriteBuffer.BufferOutput, Object, Serializer[]) - Method in class com.tangosol.io.MultiplexingSerializer
- DOUBLE_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
- 
An empty array of doubles.
- DOUBLE_AVERAGE_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theDoubleAverageaggregator.
- DOUBLE_MAX_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theDoubleMaxaggregator.
- DOUBLE_MIN_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theDoubleMinaggregator.
- DOUBLE_SUM_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theDoubleSumaggregator.
- DoubleAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.DoubleAdapter
- 
Construct a SimpleAdapter.
- DoubleArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Construct a DoubleArrayAdapter.
- DoubleAverage<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.
- DoubleAverage() - Constructor for class com.tangosol.util.aggregator.DoubleAverage
- 
Default constructor (necessary for the ExternalizableLite interface).
- DoubleAverage(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.DoubleAverage
- 
Construct a DoubleAverage aggregator.
- DoubleAverage(String) - Constructor for class com.tangosol.util.aggregator.DoubleAverage
- 
Construct an DoubleAverage object.
- doubleBinaryOperator(Remote.DoubleBinaryOperator) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable DoubleBinaryOperator.
- doubleConsumer(Remote.DoubleConsumer) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable DoubleConsumer.
- doubleFunction(Remote.DoubleFunction<R>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable DoubleFunction.
- DOUBLELITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
The numberic code for a double literal
- DOUBLELITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
The numberic code for a double literal
- doubleMax(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.
- doubleMax(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.
- DoubleMax<T> - Class in com.tangosol.util.aggregator
- 
Calculates a maximum of numeric values extracted from a set of entries in a Map.
- DoubleMax() - Constructor for class com.tangosol.util.aggregator.DoubleMax
- 
Default constructor (necessary for the ExternalizableLite interface).
- DoubleMax(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.DoubleMax
- 
Construct a DoubleMax aggregator.
- DoubleMax(String) - Constructor for class com.tangosol.util.aggregator.DoubleMax
- 
Construct a DoubleMax aggregator.
- doubleMin(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.
- doubleMin(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.
- DoubleMin<T> - Class in com.tangosol.util.aggregator
- 
Calculates a minimum of numeric values extracted from a set of entries in a Map.
- DoubleMin() - Constructor for class com.tangosol.util.aggregator.DoubleMin
- 
Default constructor (necessary for the ExternalizableLite interface).
- DoubleMin(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.DoubleMin
- 
Construct a DoubleMin aggregator.
- DoubleMin(String) - Constructor for class com.tangosol.util.aggregator.DoubleMin
- 
Construct a DoubleMin aggregator.
- doublePredicate(Remote.DoublePredicate) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable DoublePredicate.
- doubleRotate(AbstractSparseArray.Node<V>, boolean) - Method in class com.tangosol.util.AbstractSparseArray
- 
Double rotate a node in a given direction.
- doubleSum(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.
- doubleSum(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.
- DoubleSum<T> - Class in com.tangosol.util.aggregator
- 
Sums up numeric values extracted from a set of entries in a Map.
- DoubleSum() - Constructor for class com.tangosol.util.aggregator.DoubleSum
- 
Default constructor (necessary for the ExternalizableLite interface).
- DoubleSum(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.DoubleSum
- 
Construct a DoubleSum aggregator.
- DoubleSum(String) - Constructor for class com.tangosol.util.aggregator.DoubleSum
- 
Construct a DoubleSum aggregator.
- doubleSupplier(Remote.DoubleSupplier) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable DoubleSupplier.
- doubleToIntFunction(Remote.DoubleToIntFunction) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable DoubleToIntFunction.
- doubleToLongFunction(Remote.DoubleToLongFunction) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable DoubleToLongFunction.
- doubleUnaryOperator(Remote.DoubleUnaryOperator) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable DoubleUnaryOperator.
- doubleValue() - Method in class com.oracle.coherence.common.base.MutableLong
- doubleValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Returns the current value of thisAsyncAtomicIntegeras adoubleafter a widening primitive conversion.
- doubleValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Returns the current value of thisDistributedAtomicLongas adoubleafter a widening primitive conversion.
- doubleValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- doubleValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- doubleValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- doubleValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- doubleValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Returns the current value of thisAtomicIntegeras adoubleafter a widening primitive conversion.
- doubleValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Returns the current value of thisAtomicLongas adoubleafter a widening primitive conversion.
- doubleValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- doubleValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- doubleValue() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- doubleValue() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- doubleValue() - Method in class com.tangosol.io.pof.RawQuad
- 
Returns the value of the specified number as adouble.
- DownConverter(Serializer, Converter<Object, Binary>) - Constructor for class com.oracle.coherence.grpc.RequestHolder.DownConverter
- doWrite(WriteBuffer.BufferOutput, Object, Serializer) - Method in class com.tangosol.io.MultiplexingSerializer
- 
Writes the serialization header and payload.
- drainBacklog(long) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- drainBacklog(long) - Method in interface com.tangosol.net.FlowControl
- 
Check for an excessive backlog and allow blocking the calling thread for up to the specified amount of time.
- drainBacklog(long) - Method in class com.tangosol.util.AsynchronousAgent
- drainPermits() - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- drainPermits() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Acquires and returns all permits that are immediately available, or if negative permits are available, releases them.
- drainPermits() - Method in interface com.oracle.coherence.concurrent.Semaphore
- 
Acquires and returns all permits that are immediately available, or if negative permits are available, releases them.
- DropCacheStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder.DropCacheStatement
- 
Construct a DropCacheStatement.
- DropCacheStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aDropCacheStatementBuilder.DropCacheStatement.
- DropCacheStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder
- DropCacheStatementBuilder.DropCacheStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "DROP CACHE" command.
- DropIndexStatement(String, ValueExtractor) - Constructor for class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder.DropIndexStatement
- 
Construct a DropIndexStatement that will drop the index created with the specifiedValueExtractorfrom the cache with the specified name.
- DropIndexStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aDropIndexStatementBuilder.DropIndexStatement.
- DropIndexStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder
- DropIndexStatementBuilder.DropIndexStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "create index" command.
- dump() - Method in class com.tangosol.io.nio.BinaryMap
- 
Debugging support: Dump the inner structures of the BinaryMap to stdout.
- dump() - Method in class com.tangosol.util.CircularArrayList
- 
Outputs information to standard output about representation for debugging purposes.
- dumpHeldLocks() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Debug aid to dump threads holding locks.
- DumpHeldLocksAction() - Constructor for class com.tangosol.util.SegmentedConcurrentMap.DumpHeldLocksAction
- dumpServiceInfo(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder.ServicesQueryPlusStatement
- 
Return information about the current set of Coherence services.
- dup(char, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Create a String of the specified length containing the specified character.
- dup(char, int) - Static method in class com.tangosol.util.Base
- 
Create a String of the specified length containing the specified character.
- dup(String, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Create a String which is a duplicate of the specified number of the passed String.
- dup(String, int) - Static method in class com.tangosol.util.Base
- 
Create a String which is a duplicate of the specified number of the passed String.
- DuplexingPofHandler - Class in com.tangosol.io.pof
- 
An implementation of PofHandler that passes each call onto two different PofHandler objects.
- DuplexingPofHandler(PofHandler, PofHandler) - Constructor for class com.tangosol.io.pof.DuplexingPofHandler
- 
Construct a duplexing PofHandler that will pass on method calls to two different PofHandler objects.
- duplicateEntrySet(Map<K, V>, Collection<? extends Map.Entry<K, V>>, boolean) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Create a set ofInvocableMap.Entryobjects using the specified collection of Map.Entry objects.
- DURATION_HTTP_TIMEOUT - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The default http connection timeout.
- DURATION_RETRY_PERIOD - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The default retry period.
- DURATION_RETRY_TIMEOUT - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The default retry timeout.
E
- E_ALL - Static variable in class com.tangosol.util.filter.MapEventFilter
- 
This value indicates that all events should be evaluated.
- E_DELETED - Static variable in class com.tangosol.util.filter.MapEventFilter
- 
This value indicates thatENTRY_DELETEDevents should be evaluated.
- E_INSERTED - Static variable in class com.tangosol.util.filter.MapEventFilter
- 
This value indicates thatENTRY_INSERTEDevents should be evaluated.
- E_KEYSET - Static variable in class com.tangosol.util.filter.MapEventFilter
- 
This value indicates that all events that would affect the result of aQueryMap.keySet(com.tangosol.util.Filter)query should be evaluated.
- E_NATURAL - Static variable in class com.tangosol.util.filter.CacheEventFilter
- 
Bitmask to select natural events.
- E_SYNTHETIC - Static variable in class com.tangosol.util.filter.CacheEventFilter
- 
Bitmask to select synthetic events.
- E_UPDATED - Static variable in class com.tangosol.util.filter.MapEventFilter
- 
This value indicates thatENTRY_UPDATEDevents should be evaluated.
- E_UPDATED_ENTERED - Static variable in class com.tangosol.util.filter.MapEventFilter
- 
This value indicates thatENTRY_UPDATEDevents should be evaluated, but only if filter evaluation is false for the old value and true for the new value.
- E_UPDATED_LEFT - Static variable in class com.tangosol.util.filter.MapEventFilter
- 
This value indicates thatENTRY_UPDATEDevents should be evaluated, but only if filter evaluation is true for the old value and false for the new value.
- E_UPDATED_WITHIN - Static variable in class com.tangosol.util.filter.MapEventFilter
- 
This value indicates thatENTRY_UPDATEDevents should be evaluated, but only if filter evaluation is true for both the old and the new value.
- EDITION_COMMUNITY - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Standard edition (SE).
- EDITION_DATA_CLIENT - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Data Client edition (DC).
- EDITION_ENTERPRISE - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Enterprise edition (EE).
- EDITION_GRID - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Grid Edition (GE).
- EDITION_REAL_TIME_CLIENT - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Real time client edition (RTC).
- EDITION_STANDARD - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Standard edition (SE).
- effectiveIndex(int) - Method in class com.tangosol.util.CircularArrayList
- 
Calculate the effective index taking into account offsets and the circular nature of CircularArrayList.
- ELEMENT_NAME - Static variable in class com.tangosol.coherence.config.xml.processor.BackingMapSchemeProcessor
- 
The name of the backing-map-schemeXmlElement.
- ElementCalculatorBuilder - Class in com.tangosol.coherence.config.builder
- 
TheElementCalculatorBuilderclass builds anNamedTopic.ElementCalculator.
- ElementCalculatorBuilder() - Constructor for class com.tangosol.coherence.config.builder.ElementCalculatorBuilder
- ElementCalculatorProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AElementCalculatorProcessoris responsible for processing an element-calculatorXmlElementto produce anElementCalculatorBuilder.
- ElementCalculatorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ElementCalculatorProcessor
- ElementIterator(String) - Constructor for class com.tangosol.run.xml.SimpleElement.ElementIterator
- ElementList() - Constructor for class com.tangosol.run.xml.SimpleElement.ElementList
- ElementProcessor<T> - Interface in com.tangosol.config.xml
- 
AnElementProcessoris responsible for processingXmlElementcontent to return a strongly-typed value.
- ElementProcessorHelper - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorHelperprovides a number of helper methods forElementProcessors.
- ElementProcessorHelper() - Constructor for class com.tangosol.coherence.config.xml.processor.ElementProcessorHelper
- elements() - Method in class com.tangosol.util.LiteSet
- 
Returns an Enumerator over the elements in this Set.
- elements() - Method in class com.tangosol.util.StringTable
- 
Create an enumerator for the values in the table.
- elements() - Method in class com.tangosol.util.Tree
- 
Create an enumerator for the tree's values.
- emitLossNotification(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Emit a partition loss notification for given partitions.
- empty() - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create an emptyNullablevalue.
- empty(V) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
A helper method that always returnsEmpty.
- EMPTY - Static variable in class com.oracle.coherence.grpc.BinaryHelper
- 
SingletonEmpty.
- EMPTY - Static variable in class com.tangosol.io.Base64InputStream
- 
Empty binary data.
- EMPTY - Static variable in class com.tangosol.util.Binary
- 
An empty Binary.
- EMPTY - Static variable in class com.tangosol.util.SafeSortedMap
- 
An empty, immutable SafeSortedMap instance.
- EMPTY - Static variable in class com.tangosol.util.SegmentedHashMap
- 
An empty, immutable SegmentedHashMap instance.
- EMPTY - Static variable in class com.tangosol.util.SimpleLongArray
- 
Empty array of objects.
- EMPTY_ARRAY - Static variable in class com.tangosol.util.CopyOnWriteLongArray
- 
An empty placeholder array.
- EMPTY_ARRAY - Static variable in class com.tangosol.util.SubSet
- 
An empty immutable array.
- EMPTY_BINARY_ARRAY - Static variable in class com.tangosol.util.ExternalizableHelper
- 
An empty array of Binary objects.
- EMPTY_BYTE_STRING - Static variable in class com.oracle.coherence.grpc.BinaryHelper
- 
Singleton emptyByteString.
- EMPTY_BYTES - Static variable in class com.tangosol.io.MultiByteArrayInputStream
- 
Empty array of bytes.
- EMPTY_SUBJECT - Static variable in class com.tangosol.net.security.SecurityHelper
- 
A subject that represents nobody.
- EmptyChannel(int) - Constructor for class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- EmptyKeyStoreLoader - Class in com.tangosol.net.ssl
- 
AKeyStoreLoaderthat loads an empty, non-password protectedKeyStore.
- EmptyKeyStoreLoader() - Constructor for class com.tangosol.net.ssl.EmptyKeyStoreLoader
- enable(String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Enable an installed token stored under the given name
- enabled() - Static method in class com.tangosol.net.topic.Publisher.FailOnFull
- 
Obtain the Option indicating futures should complete exceptionally if the topic is full.
- enabled() - Static method in class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
- 
Obtain the Option indicating futures should complete if the topic is empty.
- ENABLED - Static variable in class com.tangosol.net.security.Security
- 
Indicates if security is enabled by the operational configuration.
- enableManagement(String, boolean) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- enableReference() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Ensure that reference support (necessary for cyclic dependencies) is enabled.
- enableReference() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Ensure that reference support (necessary for cyclic dependencies) is enabled.
- enableStatistics(String, boolean) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- enableTokenNamed(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Enable the token named by the given string.
- encode(byte[]) - Static method in class com.tangosol.io.Base64OutputStream
- 
Encode the passed binary data using Base64 encoding.
- encode(byte[], boolean) - Static method in class com.tangosol.io.Base64OutputStream
- 
Encode the passed binary data using Base64 encoding.
- encode(byte[], int, int, boolean) - Static method in class com.tangosol.io.Base64OutputStream
- 
Encode the passed binary data using Base64 encoding.
- encode(PofWriter, int, Object) - Method in interface com.tangosol.io.pof.reflect.Codec
- 
Serialize an object using the providedPofWriter.
- encode(PofWriter, int, Object) - Method in class com.tangosol.io.pof.reflect.Codecs.AbstractCodec
- 
Serialize an object using the providedPofWriter.
- encodeAttribute(String, char) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Encode an attribute value so that it can be quoted and made part of a valid and well formed XML document.
- encodeContent(String, boolean) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Encode an element's content value so that it can be made part of a valid and well formed XML document.
- encodeCookie(PartitionSet, int) - Static method in class com.oracle.coherence.grpc.proxy.PagedQueryHelper
- 
Encode the opaque cookie used in a paged request.
- encodeExpiry(ReadBuffer, long) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Return a ReadBuffer whose contents represent the specified buffer with the specified expiry encoded as a DECO_EXPIRY decoration.
- encodeInitParams(XmlElement, XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Encode the supplied xmlConfig XmlElement as a series of init-param elements.
- encodePosition(int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Called for each and every value going into the POF stream, in case the value needs its position to be encoded into the stream.
- encodeString(String) - Static method in class com.tangosol.run.xml.SimpleAdapter
- 
Parse escaped string into a string.
- encodeTinyInt(int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Encode an integer value into one of the reserved single-byte combined type and value indicators.
- encodeUri(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Encode a System Identifier as per the XML 1.0 Specification second edition, section 4.2.2.
- encrypt(Serializable, PrivateKey) - Method in class com.tangosol.net.security.DefaultController
- 
Encrypt the specified object using the specified private key.
- encrypt(Object, Subject) - Method in interface com.tangosol.net.security.AccessController
- 
Encrypt the specified object using the private credentials for the given Subject (encryptor), which is usually associated with the current thread.
- encrypt(Object, Subject) - Method in class com.tangosol.net.security.DefaultController
- 
Encrypt the specified object using the private credentials for the given Subject (encryptor), which is usually associated with the current thread.
- end() - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
End a complex data structure.
- ENDANGERED - com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
Loss of a cluster node that runs a PartitionedService may cause data loss.
- endBulkKeyProcess(Object[], SimpleOverflowMap.Status[]) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Finish the processing of any number of keys.
- endComplexValue() - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Signifies the termination of the current complex value.
- endComplexValue() - Method in interface com.tangosol.io.pof.PofHandler
- 
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Signifies the termination of the current complex value.
- endComplexValue() - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Signifies the termination of the current complex value.
- endKeyProcess(Object, OverflowMap.Status) - Method in class com.tangosol.net.cache.OverflowMap
- 
Finish the processing of a single key.
- endKeyProcess(Object, SimpleOverflowMap.Status) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Finish the processing of a single key.
- endMapProcess() - Method in class com.tangosol.net.cache.OverflowMap
- 
Release exclusive access for the OverflowMap.
- endMapProcess() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Release exclusive access for the OverflowMap.
- EndOfStatementOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
An OPToken representing the end of a CohQL statement.
- EndOfStatementOPToken() - Constructor for class com.tangosol.coherence.dsltools.precedence.EndOfStatementOPToken
- 
Create a new EndOfStatementOPToken
- EndOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
An OPToken representing the end of a token stream.
- EndOPToken() - Constructor for class com.tangosol.coherence.dsltools.precedence.EndOPToken
- 
Create a new EndOPToken
- endProperty(int) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Signifies the termination of the current POF property.
- endProperty(int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Signifies the termination of the current POF property.
- endsWith(Binary) - Method in class com.tangosol.util.Binary
- 
Tests if this Binary object ends with the specified suffix.
- enlist(TransactionMap, Object) - Method in class com.tangosol.run.jca.SimpleValidator
- 
Enlist the resource with the specified transaction.
- enlist(TransactionMap, Object) - Method in interface com.tangosol.util.TransactionMap.Validator
- 
Enlist the resource with the specified transaction.
- enrichEvent(MapEvent, Listeners) - Static method in class com.tangosol.util.MapListenerSupport
- 
Transform the given MapEvent into a FilterEvent if it is not already a FilterEvent and there are matching filters associated with the specified Listeners object.
- ensure(SessionConfiguration) - Static method in interface com.tangosol.net.Session
- 
Obtain aSessionbased on the specified configuration or throw anIllegalStateExceptionif a session could not be obtained.
- ensure(SessionConfiguration, Coherence.Mode) - Static method in interface com.tangosol.net.Session
- 
Obtain aSessionbased on the specified configuration or throw anIllegalStateExceptionif a session could not be obtained.
- ensure(Throwable) - Static method in exception com.tangosol.util.WrapperException
- 
Ensure a WrapperException from a Throwable object.
- ensure(Throwable, String) - Static method in exception com.tangosol.util.WrapperException
- 
Ensure a WrapperException from a Throwable object and an additional description.
- ensureActive() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return control if this PersistenceManager is still active, otherwise throw an exception.
- ensureAdded() - Method in class com.tangosol.util.DeltaSet
- 
Get a mutable set of items that were added to the delta set.
- ensureArgument(Object, String) - Static method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Ensure that the specified object is non-null
- ensureBigDecimal(Number) - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Ensure the specified Number is a BigDecimal value or convert it into a new BigDecimal object.
- ensureBigDecimal(Number) - Static method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Ensure the specified Number is a BigDecimal value or convert it into a new BigDecimal object.
- ensureBigDecimal(Number) - Static method in class com.tangosol.util.Base
- 
Ensure the specified Number is a BigDecimal value or convert it into a new BigDecimal object.
- ensureBuffer(Socket) - Method in class com.tangosol.net.LoadBalancer.SocketHandler
- 
Return the existing buffer, if there is one, or create one to use for reading from the passed socket.
- ensureBufferOutput(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Obtain the internal MultiBufferOutput, creating it if necessary.
- ensureBundles(ParameterResolver, BundlingNamedCache) - Method in class com.tangosol.coherence.config.scheme.BundleManager
- 
Create a BundlingNamedCache using the operation-bundling element.
- ensureBundles(ParameterResolver, ReadWriteBackingMap.StoreWrapper) - Method in class com.tangosol.coherence.config.scheme.BundleManager
- 
Create a BundlingNamedCache using the "operation-bundling" element.
- ensureCache(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Obtain the NamedCache reference for the cache service defined by the specified scheme.
- ensureCache(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
- 
Return the ConfigurableCacheMap that uses this eviction policy.
- ensureCache(String, ClassLoader) - Method in interface com.tangosol.net.CacheProvider
- 
Deprecated.Ensure an Object-based cache for the given name.
- ensureCache(String, ClassLoader) - Method in interface com.tangosol.net.CacheService
- 
Obtain a NamedCache interface that provides a view of resources shared among members of a cluster.
- ensureCache(String, ClassLoader) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Ensure an cache for the given name and classloader (using raw types).
- ensureCache(String, ClassLoader) - Method in class com.tangosol.net.WrapperCacheService
- 
Obtain a NamedCache interface that provides a view of resources shared among members of a cluster.
- ensureCache(String, ClassLoader, NamedMap.Option...) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Ensure an cache for the given name, classloader and options.
- ensureCache(String, ClassLoader, NamedMap.Option...) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Ensure an cache for the given name, classloader and options.
- ensureCache(String, ClassLoader, NamedMap.Option...) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- ensureCapacity(int) - Method in class com.tangosol.util.CircularArrayList
- 
Increase the capacity of this list instance, if necessary, to ensure that it can hold at least the specified number of elements.
- ensureChannelCount(String, int) - Method in interface com.tangosol.net.TopicService
- 
Ensure the specified topic has at least the required number of channels.
- ensureChannelCount(String, int, int) - Method in interface com.tangosol.net.TopicService
- 
Ensure the specified topic has at least the required number of channels.
- ensureClassLoader(ClassLoader) - Static method in class com.oracle.coherence.common.base.Classes
- 
Obtain a non-null ClassLoader.
- ensureClassLoader(ClassLoader) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Ensures we have a non-nullClassLoaderthat we can use for loading classes.
- ensureClassLoader(ClassLoader) - Static method in class com.tangosol.util.Base
- 
Obtain a non-null ClassLoader.
- ensureClient() - Method in class com.tangosol.net.URLMemberIdentityProvider
- ensureCluster() - Static method in class com.tangosol.net.CacheFactory
- 
Obtain a Cluster object running Coherence services.
- ensureCoherence(BeanManager) - Static method in class com.oracle.coherence.cdi.CoherenceExtension
- 
Ensure that aCoherencebean is resolvable and started.
- ensureCollection(Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Return a Collection representation of the specified value, which could be a Collection, Object[], scalar, or NO_VALUE.
- ensureCompactness() - Method in class com.tangosol.util.CircularArrayList
- 
Ensure the representation of this list is appropriatly compact by shrinking if necessary.
- ensureConfigCCFMap(ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Ensure that a map from URI to ConfigurableCacheFactory for the specified loader exists (creating it if necessary).
- ensureConfigMap(ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Ensure that a map from URL to ConfigurableCacheFactory for the specified loader exists (creating it if necessary).
- ensureConfiguredService(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Ensure service and its topic configuration.
- ensureConfiguredService(ParameterResolver, MapBuilder.Dependencies) - Method in interface com.tangosol.coherence.config.scheme.TopicScheme
- 
Obtain a configured topic service.
- ensureConnection(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Obtain a Connection for the specified address.
- ensureConverted(Converter) - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Ensure that the underlying keys are converted using the specified converter.
- ensureConverted(InvocableMap.EntryProcessor) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Wrap anyAsynchronousProcessorinstances with a custom wrapper to perform conversion of result returned by the processor.
- ensureConverterDown() - Method in class com.oracle.coherence.grpc.RequestHolder
- ensureConverterKeyDown() - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- ensureConverters(NamedCache) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Instantiate theconvertersnecessary to support the processing mode that thisContinuousQueryCachewill be operating under.
- ensureConverterUp() - Method in class com.oracle.coherence.grpc.RequestHolder
- ensureDatagramSocketProvider(String, SocketProviderFactory.Dependencies, int) - Method in class com.tangosol.net.SocketProviderFactory
- 
Create aDatagramSocketProvider
- ensureDir(File) - Static method in class com.tangosol.io.FileHelper
- 
Validate that the given File represents a directory, creating it if it doesn't already exist.
- ensureDomain(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Ensure the Canonical name is prefixed with the domain name.
- ensureEffectiveIndex(int) - Method in class com.tangosol.util.CircularArrayList
- 
After range checking Calculate the effective index while taking into account the offsets and the circular nature of the list.
- ensureElement(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Ensure that a child element exists.
- ensureElement(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Ensure that a child element exists.
- ensureElement(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Ensure that a child element exists.
- ensureEraseBundler(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Configure the bundler for the "erase" operations.
- ensureEventQueue() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Obtain the existing event queue or create one if none exists.
- ensureExpired() - Method in class com.tangosol.net.cache.LocalCache.KeyMask
- 
Ensure that the expired operation flag is set.
- ensureExtent(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Ensure that an extent with the given identifier exists in the persistent store, returning true iff the extent was created.
- ensureExtent(long) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Ensure that an extent with the given identifier exists in the persistent store, returning true iff the extent was created.
- ensureExtent(long) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- ensureExtentInternal(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Ensure the provided extent id has been registered and created, thus allowing subsequent load and store operations against the same extent id.
- ensureFactory(BerkeleyDBBinaryStoreManager) - Method in class com.tangosol.io.bdb.DatabaseFactoryManager
- 
Find, or if needed create a DatabaseFactory for the specified manager.
- ensureFilter(ByteString, Serializer) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Obtain aFilterfrom the serialized data in aByteString.
- ensureFilter(ByteString, Serializer) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Obtain aFilterfrom the serialized data in aByteString.
- ensureFilter(NodeTerm, String, String, List, ParameterResolver, ExecutionContext) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Build aFilterfor the given cache using the given where clause, alias and bind environments.
- ensureGetBundler(int) - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Configure the bundler for the "get" operations.
- ensureGlobalName(String) - Method in interface com.tangosol.net.management.Registry
- 
Convert the passed MBean name to a global name if necessary.
- ensureGlobalName(String, Member) - Method in interface com.tangosol.net.management.Registry
- 
Convert the passed MBean name to a global name for a given cluster Member if necessary.
- ensureIndexMap() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Ensure that the map of indexes maintained by this cache exists.
- ensureInflated(Object, Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
If the internal cache value associated with the provided key isBinary, deserialize the value and store it back to the internal cache in its deserialized form.
- ensureInitialized() - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Ensures that this repository is initialized by creating necessary indices on the backing map.
- ensureInitialized() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Fully initialize the ConfigurablePofContext if it has not already been initialized.
- ensureInitialized() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Based on the state of the NamedEventInterceptor populate any uninitialized values based on either an annotation being present or the class file's generic types.
- ensureInitialized() - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Ensure that this aggregator is initialized.
- ensureInitialized() - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Ensure that this aggregator is initialized.
- ensureInitialized() - Method in class com.tangosol.util.aggregator.TopNAggregator
- 
Ensure that this aggregator is initialized.
- ensureInitialized(boolean) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Ensure that this aggregator is initialized.
- ensureInputStream() - Method in class com.tangosol.io.WrapperInputStream
- 
Return the underlying InputStream.
- ensureInstance(ConfigurableCacheFactory) - Static method in class com.tangosol.net.DefaultCacheServer
- 
Returns the DefaultCacheServer singleton, creating it if necessary.
- ensureInternalCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Create and initialize thisContinuousQueryCache's (if not already present) internal cache.
- ensureInternalIterator() - Method in class com.tangosol.net.CompositeAddressProvider
- 
Create (if necessary) and return the default iterator.
- ensureInternalListener() - Method in class com.tangosol.util.WrapperObservableMap
- 
Obtain the internal MapListener, creating one if necessary.
- ensureInvalidationStrategy() - Method in class com.tangosol.net.cache.CachingMap
- 
Ensure that a strategy has been chosen and that any appropriate global listeners have been registered.
- ensureIterator() - Method in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
- 
Return the cache iterator.
- ensureLifecycleListeners() - Method in class com.tangosol.net.DefaultCacheServer
- 
Returns the list ofLifecycleListeners registered for thisDefaultCacheServer.
- ensureListener(MapIndex) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Ensure a MapListener for the given index.
- ensureListenerSupport() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Configure the localMapListenerSupportand register the interceptingMapListenerwith the internalObservableMap.
- ensureLoadBundler(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Configure the bundler for the "load" operations.
- ensureLoadFactor(SegmentedHashMap.Segment) - Method in class com.tangosol.util.SegmentedHashMap
- 
Check whether or not the specified segment is overloaded and if so, grow the bucket array (which suggests with high probability that the per-segment load will decrease).
- ensureMap() - Method in class com.tangosol.util.aggregator.ReducerAggregator
- 
Return a map that can be used to store reduced values, creating it if one has not already been created.
- ensureMapFilters() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Ensure a Map is created to storeFilters to apply against values of the key/value pairs within the ObjectName.
- ensureMapJsonBodyHandler() - Static method in interface com.tangosol.net.management.MapJsonBodyHandler
- 
Load aMapJsonBodyHandlerusing the JVM'sServiceLoadermechanism.
- ensureMapListenerSupport() - Method in class com.tangosol.util.WrapperObservableMap
- 
Obtain the MapListenerSupport, creating it if necessary.
- ensureMutable() - Method in class com.tangosol.run.xml.XmlBean
- 
Make sure that this XML bean is mutable.
- ensureNamespace(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Ensure the existence of the Namespace declaration attribute in a context of the specified XmlElement.
- ensureNamespaceHandler(String, NamespaceHandler) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Ensures that the specifiedNamespaceHandlerfor the specified prefix is defined in thisProcessingContext.
- ensureNamespaceHandler(String, NamespaceHandler) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Ensures that the specifiedNamespaceHandlerfor the specified prefix is defined in thisProcessingContext.
- ensureNamespaceHandler(String, URI) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Ensures that anNamespaceHandlerwith the specifiedURIis available for use in theProcessingContextwith the specified prefix.
- ensureNamespaceHandler(String, URI) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Ensures that anNamespaceHandlerwith the specifiedURIis available for use in theProcessingContextwith the specified prefix.
- ensureOpen() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Ensures that theCoherenceBasedCacheis open (not closed).
- ensureOutputStream() - Method in class com.tangosol.io.WrapperOutputStream
- 
Return the underlying OutputStream.
- ensurePersistenceException(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return a PersistenceException with the given cause.
- ensurePersistenceException(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return a PersistenceException with the given cause.
- ensurePersistenceException(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return a PersistenceException with the given cause.
- ensurePersistenceException(Throwable) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return a PersistenceException with the given cause.
- ensurePersistenceException(Throwable, String) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return a PersistenceException with the given cause and detail message.
- ensurePersistenceException(Throwable, String) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return a PersistenceException with the given cause and detail message.
- ensurePersistenceException(Throwable, String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return a PersistenceException with the given cause and detail message.
- ensurePersistenceException(Throwable, String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return a PersistenceException with the given cause and detail message.
- ensurePrimingListener() - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Return the priming listener, or it not already cached, create it.
- ensurePutBundler(int) - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Configure the bundler for the "put" operations.
- ensureQueueDaemon() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Obtain the QueueDaemon, if one already exists; otherwise, create and start one.
- ensureReadOnly() - Method in class com.tangosol.run.xml.XmlBean
- 
Make sure that this value is read-only (immutable).
- ensureReady() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Block the calling thread until the store is either ready to accept requests or the store has been closed.
- ensureReferenceRegistry() - Method in class com.tangosol.io.pof.PofBufferReader
- 
Obtain the registry for identity-reference pairs, creating it if necessary.
- ensureReferenceRegistry() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Obtain the registry for identity-reference pairs, creating it if necessary.
- ensureRefreshThread() - Method in class com.tangosol.net.RefreshableAddressProvider
- 
Start the refresh thread if not already running.
- ensureRegistration() - Static method in class com.tangosol.net.security.SecurityProvider
- 
Ensure that an instance of this provider has been registered with the system.
- ensureRemoveBundler(int) - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Configure the bundler for the "remove" operations.
- ensureRemoved() - Method in class com.tangosol.util.DeltaSet
- 
Get a mutable set of items that were removed from the delta set.
- ensureRemoved() - Method in class com.tangosol.util.SubSet
- 
Get a mutable set of items that are removed in the subset.
- ensureResults() - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
- 
Obtain results of the bundled requests.
- ensureResults() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Obtain results of the bundled requests.
- ensureResults() - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
- 
Obtain results of the bundled requests.
- ensureResults() - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
- 
Obtain results of the bundled requests.
- ensureResults(boolean) - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Obtain results of the bundled requests or ensure that the results have already been retrieved.
- ensureRetained() - Method in class com.tangosol.util.SubSet
- 
Get a mutable set of items that are retained in the subset.
- ensureRuntimeException(Throwable) - Static method in class com.oracle.coherence.common.base.Exceptions
- 
Convert the passed exception to a RuntimeException if necessary.
- ensureRuntimeException(Throwable) - Static method in class com.tangosol.util.Base
- 
Convert the passed exception to a RuntimeException if necessary.
- ensureRuntimeException(Throwable, String) - Static method in class com.oracle.coherence.common.base.Exceptions
- 
Convert the passed exception to a RuntimeException if necessary.
- ensureRuntimeException(Throwable, String) - Static method in class com.tangosol.util.Base
- 
Convert the passed exception to a RuntimeException if necessary.
- ensureSafe(Comparator<? super V>) - Static method in class com.tangosol.util.comparator.SafeComparator
- 
Ensure that the specified comparator is safe, by wrapping it if it isn't.
- ensureSafeObserver(StreamObserver<T>) - Static method in class com.oracle.coherence.grpc.SafeStreamObserver
- 
Ensure that the specifiedStreamObserveris a safe observer.
- ensureSafeSet(Set) - Static method in class com.tangosol.util.filter.ExtractorFilter
- 
Return a non-null Set.
- ensureSerializer(ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Obtain a Serializer for the specified ClassLoader.
- ensureService(ServiceScheme) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Ensure the service for the specified scheme then start the service if it isn't running.
- ensureService(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Ensure the service for the specified scheme.
- ensureService(String) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Ensure a service for the given name.
- ensureService(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Ensure a service for the given name.
- ensureService(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Ensure a service for the given name.
- ensureService(String, Cluster) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Call theCluster.ensureService(String, String)method to obtain the service.
- ensureService(String, Cluster) - Method in class com.tangosol.coherence.config.scheme.BaseGrpcCacheScheme
- ensureService(String, String) - Method in interface com.tangosol.net.Cluster
- 
Obtains a Service object for the specified service name and type.
- ensureServiceInternal(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Ensure the service for the specified scheme.
- ensureSet() - Method in class com.tangosol.util.aggregator.DistinctValues
- 
Return a set that can be used to store distinct values, creating it if one has not already been created.
- ensureSet(Set) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Return the specified set, or an empty set if null.
- ensureSingletonMBean(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Ensure that there is an instance of a local MBean of the specified type registered with the default MBeansServer.
- ensureSocketException(IOException) - Static method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Convert an IOException into a SocketException.
- ensureSocketProvider(String, SocketProviderFactory.Dependencies, int) - Method in class com.tangosol.net.SocketProviderFactory
- 
Create SocketProvider
- ensureStatusRuntimeException(Throwable) - Static method in class com.oracle.coherence.grpc.ErrorsHelper
- 
Convert aThrowableto aStatusRuntimeException.
- ensureStatusRuntimeException(Throwable, String) - Static method in class com.oracle.coherence.grpc.ErrorsHelper
- 
Convert aThrowableto aStatusRuntimeException.
- ensureStep(Filter) - Method in interface com.tangosol.util.QueryRecord.PartialResult.ExplainStep
- 
Ensure an inner nested explain step for the given filter.
- ensureStep(Filter) - Method in interface com.tangosol.util.QueryRecord.PartialResult.TraceStep
- 
Ensure an inner nested trace step for the given filter.
- ensureStep(Filter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.ExplainStep
- 
Ensure an inner nested explain step for the given filter.
- ensureStep(Filter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.TraceStep
- 
Ensure an inner nested trace step for the given filter.
- ensureStoreBundler(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Configure the bundler for the "store" operations.
- ensureSubscriberGroup(String) - Method in interface com.tangosol.net.topic.NamedTopic
- 
Ensure that the specified subscriber group exists for this topic.
- ensureSubscriberGroup(String, Filter<?>, ValueExtractor<?, ?>) - Method in interface com.tangosol.net.topic.NamedTopic
- 
Ensure that the specified subscriber group exists for this topic.
- ensureSubscriberGroup(String, String) - Method in interface com.tangosol.net.PagedTopicService
- 
Ensure the specified subscriber group is created in a subscription.
- ensureSubscriberGroup(String, String, Filter<?>, ValueExtractor<?, ?>) - Method in interface com.tangosol.net.PagedTopicService
- 
Ensure the specified subscriber group is created in a subscription.
- ensureSubscription(String, long, Subscriber.Id) - Method in interface com.tangosol.net.PagedTopicService
- 
Ensure the specified subscriber is subscribed to a subscription.
- ensureSubscription(String, long, Subscriber.Id, boolean) - Method in interface com.tangosol.net.PagedTopicService
- 
Ensure the specified subscriber is subscribed to a subscription.
- ensureSubscription(String, SubscriberGroupId, Subscriber.Id, Filter<?>, ValueExtractor<?, ?>) - Method in interface com.tangosol.net.PagedTopicService
- 
Ensure the specified subscriber is created in a subscription.
- ensureSynchronized(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Ensure that theContinuousQueryCachelisteners have been registered and its content synchronized with the underlyingNamedCache.
- ensureSynthetic() - Method in class com.tangosol.net.cache.LocalCache.KeyMask
- 
Ensure that the synthetic operation flag is set.
- ensureTarget() - Method in class com.tangosol.util.extractor.ChainedExtractor
- 
Ensure that this target is correct after first extractor manually updated.
- ensureThreadGroup() - Method in class com.tangosol.util.Daemon
- 
Obtain the existing ThreadGroup or create one if none exists or the current one is destroyed.
- ensureTopic(String, NamedCollection.Option...) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Ensure an Object-based topic for the given name.
- ensureTopic(String, ClassLoader) - Method in interface com.tangosol.net.TopicService
- 
Obtain a Topic interface that provides
- ensureTopic(String, ClassLoader, NamedCollection.Option...) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Ensure an Object-based topic for the given name.
- ensureTopic(String, ClassLoader, NamedCollection.Option...) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.This method will throw anUnsupportedOperationExceptionasNamedTopics are not supported by DefaultConfigurableCacheFactory.
- ensureTopic(String, ClassLoader, NamedCollection.Option...) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Ensure an Object-based topic for the given name.
- ensureTracingDaemonPool(DaemonPool) - Static method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- 
Returns aTracingDaemonPoolwrapping the specified pool.
- ensureTrashDir() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Ensure trash directory is created.
- ensureType(int) - Method in class com.tangosol.run.xml.SimpleValue
- 
Change the type of the internal representation of the XmlValue.
- ensureType(Object, int, PofContext) - Static method in class com.tangosol.io.pof.reflect.PofReflectionHelper
- 
Validate that the supplied object is compatible with the specified type.
- ensureTypedCache(String, ClassLoader, TypeAssertion<K, V>) - Method in interface com.tangosol.net.CacheProvider
- 
Deprecated.Ensure a cache for the given name satisfying the specified type assertion.
- ensureTypedCache(String, ClassLoader, TypeAssertion<K, V>) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Ensure a cache for the given name satisfying the specified type assertion.
- ensureUnconverted(Converter) - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Ensure that the underlying keys are un-converted using the specified converter.
- ensureUpdatedPartitions() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Ensure and return the set of updated partitions.
- ensureValid() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- 
Ensure that the cached value/index are valid.
- ensureValue(Object) - Method in class com.tangosol.util.SetMap
- 
Return a value for the specified key.
- ensureValueExtractor(ByteString, Serializer) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Obtain aValueExtractorfrom the serialized data in aByteString.
- enter() - Method in class com.tangosol.util.ThreadGateLite
- enter() - Method in class com.tangosol.util.WrapperReentrantGate
- enter(long) - Method in class com.tangosol.util.ThreadGateLite
- 
Enter the gate.
- enter(long) - Method in class com.tangosol.util.WrapperReentrantGate
- 
Enter the gate.
- entering(Class<?>, String, Object...) - Static method in class com.oracle.coherence.common.base.Logger
- 
Entry logging.
- EntityFactory<ID,T> - Interface in com.oracle.coherence.repository
- 
Provides a way to create entity instances with a known identity.
- Entry() - Constructor for class com.tangosol.net.cache.LocalCache.Entry
- Entry() - Constructor for class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Construct the cacheable entry that holds the cached value.
- Entry() - Constructor for class com.tangosol.util.ObservableHashMap.Entry
- Entry() - Constructor for class com.tangosol.util.SafeHashMap.Entry
- Entry(Binary, Binary) - Constructor for class com.tangosol.io.nio.BinaryMap.Entry
- 
Construct an Entry with a key and a value.
- Entry(Binary, Binary, Binary, long, BackingMapManagerContext) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Construct an Entry with just a key.
- Entry(Object, Object) - Constructor for class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Construct an Entry.
- Entry(Object, Object) - Constructor for class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Construct an Entry.
- Entry(Object, Object) - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap.Entry
- 
Construct an Entry.
- Entry(Object, Object) - Constructor for class com.tangosol.util.OpenHashMap.EntrySet.Entry
- 
Construct an Entry.
- Entry(Object, Object, int) - Constructor for class com.tangosol.util.SegmentedHashMap.Entry
- 
Construct an Entry object with the specified key, value and hash.
- Entry(K, V) - Constructor for class com.tangosol.util.AbstractKeyBasedMap.EntrySet.Entry
- 
Construct an Entry.
- ENTRY - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
State of a block that holds an Entry object's data.
- ENTRY_DELETED - Static variable in class com.tangosol.net.cache.OverflowMap
- 
This event indicates that an entry has been removed from the map.
- ENTRY_DELETED - Static variable in class com.tangosol.net.cache.SimpleOverflowMap
- 
This event indicates that an entry has been removed from the map.
- ENTRY_DELETED - Static variable in class com.tangosol.util.MapEvent
- 
This event indicates that an entry has been removed from the map.
- ENTRY_INSERTED - Static variable in class com.tangosol.net.cache.OverflowMap
- 
This event indicates that an entry has been added to the map.
- ENTRY_INSERTED - Static variable in class com.tangosol.net.cache.SimpleOverflowMap
- 
This event indicates that an entry has been added to the map.
- ENTRY_INSERTED - Static variable in class com.tangosol.util.MapEvent
- 
This event indicates that an entry has been added to the map.
- ENTRY_OVERHEAD - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
The memory cost of creating NullableConcurrentMap.Entry.
- ENTRY_TO_KEY_CONVERTER - Static variable in class com.tangosol.util.InvocableMapHelper
- 
Trivial Entry-to-Key converter.
- ENTRY_TO_VALUE_CONVERTER - Static variable in class com.tangosol.util.InvocableMapHelper
- 
Trivial Entry-to-Value converter.
- ENTRY_UPDATED - Static variable in class com.tangosol.net.cache.OverflowMap
- 
This event indicates that an entry has been updated in the map.
- ENTRY_UPDATED - Static variable in class com.tangosol.net.cache.SimpleOverflowMap
- 
This event indicates that an entry has been updated in the map.
- ENTRY_UPDATED - Static variable in class com.tangosol.util.MapEvent
- 
This event indicates that an entry has been updated in the map.
- EntryActionAdapter() - Constructor for class com.tangosol.util.SegmentedHashMap.EntryActionAdapter
- EntryAttributes(long, long, int) - Constructor for class com.tangosol.net.cache.SerializationCache.EntryAttributes
- 
Construct an attribute holder for an entry.
- EntryAwareComparator<T> - Interface in com.tangosol.util.comparator
- 
EntryAwareComparator is an extension to theComparatorinterface that allows theEntryComparatorto know whether the underlying comparator expects to compare the corresponding Entries' keys or values.
- EntryComparator - Class in com.tangosol.util.comparator
- 
Comparator implementation used to compare map entries.
- EntryComparator() - Constructor for class com.tangosol.util.comparator.EntryComparator
- 
Default constructor (for ExternalizableLite and PortableObject).
- EntryComparator(Comparator) - Constructor for class com.tangosol.util.comparator.EntryComparator
- 
Construct an EntryComparator to compare entries' values using the provided Comparator object.
- EntryComparator(Comparator, int) - Constructor for class com.tangosol.util.comparator.EntryComparator
- 
Construct an EntryComparator to compare entries using the provided Comparator object according to the specified comparison style.
- entryConsumer(StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- entryDeleted(MapEvent) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy.DeactivationListener
- entryDeleted(MapEvent) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
- entryDeleted(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
- entryDeleted(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfigurationMapListener
- 
Remove JCacheContext for JCache identified by evt.getKey().
- entryDeleted(MapEvent) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
- 
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.CachingMap.DeactivationListener
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.CachingMap.FrontMapListener
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.DeactivationListener
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.LocalCache.InternalListener
- 
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
- 
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.SeppukuMapListener
- 
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.net.cache.VersionedNearCache.VersionCacheListener
- 
Deprecated.Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.util.AbstractMapListener
- 
Invoked when a map entry has been removed.
- entryDeleted(MapEvent) - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
- 
Invoked when a map entry has been removed.
- entryDeleted(MapEvent<ID, T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.MapListenerAdapter
- entryDeleted(MapEvent<Object, Object>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- entryDeleted(MapEvent<Object, Object>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy.WrapperPrimingListener
- entryDeleted(MapEvent<K, V>) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- entryDeleted(MapEvent<K, V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- entryDeleted(MapEvent<K, V>) - Method in interface com.tangosol.util.MapListener
- 
Invoked when a map entry has been removed.
- entryDeleted(MapEvent<K, V>) - Method in class com.tangosol.util.MultiplexingMapListener
- 
Invoked when a map entry has been removed.
- EntryEvent<K,V> - Interface in com.tangosol.net.events.partition.cache
- 
An EntryEvent captures information relating to actions performed onentries.
- EntryEvent.Type - Enum in com.tangosol.net.events.partition.cache
- 
TheEntryEventtypes.
- EntryEventHandler(EventObserverSupport.EventObserver<EntryEvent<K, V>>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.EntryEventHandler
- EntryEvents - Annotation Type in com.tangosol.net.events.annotation
- 
EntryEventInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveEntryEvents.
- EntryExtractor - Class in com.tangosol.util.extractor
- 
The EntryExtractor is a base abstract class for special purpose custom ValueExtractor implementations.
- EntryExtractor() - Constructor for class com.tangosol.util.extractor.EntryExtractor
- 
Default constructor (for backward compatibility).
- EntryExtractor(int) - Constructor for class com.tangosol.util.extractor.EntryExtractor
- 
Construct an EntryExtractor based on the entry extraction target.
- EntryFilter<K,V> - Interface in com.tangosol.util.filter
- 
EntryFilter provides an extension to Filter for those cases in which both a key and a value may be necessary to evaluate the conditional inclusion of a particular object.
- entryFromBucket(SegmentedHashMap.Entry[], int) - Static method in class com.tangosol.util.SegmentedHashMap
- 
Return the first non-synthetic Entry object contained by in the specified bucket.
- entryInserted(MapEvent) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
- entryInserted(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
- entryInserted(MapEvent) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
- entryInserted(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
- 
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.net.cache.LocalCache.InternalListener
- 
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
- 
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.net.cache.SeppukuMapListener
- 
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.util.AbstractMapListener
- 
Invoked when a map entry has been inserted.
- entryInserted(MapEvent) - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
- 
Invoked when a map entry has been inserted.
- entryInserted(MapEvent<ID, T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.MapListenerAdapter
- entryInserted(MapEvent<Object, Object>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- entryInserted(MapEvent<Object, Object>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy.WrapperPrimingListener
- entryInserted(MapEvent<K, V>) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- entryInserted(MapEvent<K, V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- entryInserted(MapEvent<K, V>) - Method in interface com.tangosol.util.MapListener
- 
Invoked when a map entry has been inserted.
- entryInserted(MapEvent<K, V>) - Method in class com.tangosol.util.MultiplexingMapListener
- 
Invoked when a map entry has been inserted.
- EntryIterator(Iterator<Map.Entry<K, V>>, LocalCache<K, V>) - Constructor for class com.tangosol.coherence.jcache.localcache.LocalCache.EntryIterator
- 
Construct an EntryIterator backed by the specified iterator.
- EntryIterator(Iterator<Map.Entry<K, V>>, PartitionedCache<K, V>) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache.EntryIterator
- 
Construct anPartitionedCache.EntryIteratorbacked by the specified iterator.
- EntryProcessorEvent - Interface in com.tangosol.net.events.partition.cache
- 
An EntryProcessorEvent captures information relating to the execution ofInvocableMap.EntryProcessors.
- EntryProcessorEvent.Type - Enum in com.tangosol.net.events.partition.cache
- 
TheEntryProcessorEventtypes.
- EntryProcessorEventHandler(EventObserverSupport.EventObserver<EntryProcessorEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.EntryProcessorEventHandler
- EntryProcessorEvents - Annotation Type in com.tangosol.net.events.annotation
- 
EntryProcessorEventInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveEntryProcessorEvents.
- EntryResource - Class in com.tangosol.coherence.rest
- 
REST resource representing a single cache entry.
- EntryResource(NamedCache, Object, Class) - Constructor for class com.tangosol.coherence.rest.EntryResource
- 
Construct EntryResource.
- entrySet() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- entrySet() - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.io.pof.PofHelper.ReadableEntrySetMap
- 
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.io.pof.PofHelper.WriteableEntrySetMap
- 
Returns a set view of the mappings contained in this map.
- entrySet() - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return a set view of all the entries contained in this map.
- entrySet() - Method in class com.tangosol.net.cache.CachingMap
- entrySet() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Returns an set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- entrySet() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.util.ChainedMap
- 
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- entrySet() - Method in class com.tangosol.util.CopyOnWriteMap
- 
Return a set view of the underlying map.
- entrySet() - Method in class com.tangosol.util.EntrySetMap
- entrySet() - Method in class com.tangosol.util.NullImplementation.NullMap
- entrySet() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.util.SafeHashMap
- 
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.util.SafeSortedMap
- entrySet() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- entrySet() - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns a set view of the mappings contained in this map.
- entrySet() - Method in class com.tangosol.util.SetMap
- entrySet() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- entrySet() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- entrySet(CacheRequestHolder<EntrySetRequest, Void>, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theEntrySetRequestrequest and send the results to theStreamObserver.
- entrySet(EntrySetRequest, StreamObserver<Entry>) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Stream a set of cache entries to aStreamObserver.
- entrySet(EntrySetRequest, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- entrySet(EntrySetRequest, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- entrySet(Filter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- entrySet(Filter) - Method in class com.tangosol.net.cache.NearCache
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter) - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter) - Method in interface com.tangosol.util.QueryMap
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter<?>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter<?>, Comparator<?>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter<?>, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream the entries that satisfy the specified filter to the provided callback.
- entrySet(Filter<?>, Consumer<? super Map.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream the entries that satisfy the specified filter to the provided callback.
- entrySet(Filter, Comparator) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- entrySet(Filter, Comparator) - Method in class com.tangosol.net.cache.NearCache
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(Filter, Comparator) - Method in interface com.tangosol.util.QueryMap
- 
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.
- entrySet(InvocableMap<K, V>) - Static method in interface com.tangosol.util.stream.RemoteStream
- 
Create aRemoteStreamof specified map's entries.
- entrySet(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create anEntrySetRequest.
- entrySet(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create anEntrySetRequest.
- entrySet(BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream all the entries contained in this map to the provided callback.
- entrySet(Consumer<? super Map.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream all the entries contained in this map to the provided callback.
- EntrySet() - Constructor for class com.tangosol.io.nio.BinaryMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.net.cache.OldCache.EntrySet
- 
Deprecated.
- EntrySet() - Constructor for class com.tangosol.net.cache.OverflowMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.net.cache.SerializationCache.EntrySet
- EntrySet() - Constructor for class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet
- EntrySet() - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.util.AbstractKeyBasedMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.util.AbstractKeySetBasedMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.util.ChainedMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.util.CopyOnWriteMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.util.OpenHashMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.util.SafeHashMap.EntrySet
- EntrySet() - Constructor for class com.tangosol.util.SegmentedHashMap.EntrySet
- entrySetInternal(Filter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Return multiple values from the back cache based on a filter, transforming them in the process if necessary.
- entrySetInternal(Filter, Comparator) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Return multiple values from the back cache based on a filter, transforming them in the process if necessary.
- EntrySetIterator() - Constructor for class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
- EntrySetIterator() - Constructor for class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet.EntrySetIterator
- EntrySetIterator() - Constructor for class com.tangosol.util.AbstractKeyBasedMap.EntrySet.EntrySetIterator
- EntrySetIterator() - Constructor for class com.tangosol.util.OpenHashMap.EntrySet.EntrySetIterator
- EntrySetIterator() - Constructor for class com.tangosol.util.SafeHashMap.EntrySet.EntrySetIterator
- 
Construct an Iterator over the Entries in the SafeHashMap.
- EntrySetIterator() - Constructor for class com.tangosol.util.SegmentedHashMap.EntrySet.EntrySetIterator
- 
Construct an Iterator over the Entries in the SegmentedHashMap.
- EntrySetMap - Class in com.tangosol.util
- 
A trivial Map implementation that is based on a specified set of entries.
- EntrySetMap(Set) - Constructor for class com.tangosol.util.EntrySetMap
- EntrySetResource - Class in com.tangosol.coherence.rest
- 
REST resource representing a set of cache entries.
- EntrySetResource(NamedCache, Set, Class) - Constructor for class com.tangosol.coherence.rest.EntrySetResource
- 
Construct an EntrySetResource.
- entryTouched(ConfigurableCacheMap.Entry) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.EvictionPolicy
- 
This method is called by the cache to indicate that an entry has been touched.
- entryTouched(ConfigurableCacheMap.Entry) - Method in class com.tangosol.net.cache.OldCache.InternalEvictionPolicy
- 
Deprecated.This method is called by the cache to indicate that an entry has been touched.
- entryTouched(ConfigurableCacheMap.Entry) - Method in class com.tangosol.net.cache.SerializationCache.InternalEvictionPolicy
- 
This method is called by the cache to indicate that an entry has been touched.
- entryUpdated(ConfigurableCacheMap.Entry) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
- 
This method is called to indicate that an entry has been either inserted or updated.
- entryUpdated(MapEvent) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy.DeactivationListener
- entryUpdated(MapEvent) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
- entryUpdated(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
- entryUpdated(MapEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener
- 
These updated mapEvents were decorated with JACHE_SYNTHETIC_EXPIRY or JCACHE_SYNTHETIC_EXPIRY_EVENT_FOR_ORIGINAL_VALUES.
- entryUpdated(MapEvent) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
- 
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.CachingMap.DeactivationListener
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.DeactivationListener
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.LocalCache.InternalListener
- 
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
- 
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.SeppukuMapListener
- 
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.net.cache.VersionedNearCache.VersionCacheListener
- 
Deprecated.Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.util.AbstractMapListener
- 
Invoked when a map entry has been updated.
- entryUpdated(MapEvent) - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
- 
Invoked when a map entry has been updated.
- entryUpdated(MapEvent<ID, T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.MapListenerAdapter
- entryUpdated(MapEvent<Object, Object>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- entryUpdated(MapEvent<Object, Object>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy.WrapperPrimingListener
- entryUpdated(MapEvent<K, V>) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- entryUpdated(MapEvent<K, V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- entryUpdated(MapEvent<K, V>) - Method in interface com.tangosol.util.MapListener
- 
Invoked when a map entry has been updated.
- entryUpdated(MapEvent<K, V>) - Method in class com.tangosol.util.MultiplexingMapListener
- 
Invoked when a map entry has been updated.
- EntryWriter - Class in com.tangosol.coherence.rest.providers
- 
Provider responsible for marshalling map entries.
- EntryWriter() - Constructor for class com.tangosol.coherence.rest.providers.EntryWriter
- 
Default constructor.
- EntryWriter(MarshallerRegistry) - Constructor for class com.tangosol.coherence.rest.providers.EntryWriter
- 
Construct an EntryWriter instance.
- EnumerationIterator<E> - Class in com.tangosol.util
- 
Provide a implementation of an Iterator based on data from an Enumeration.
- EnumerationIterator(Enumeration<E>) - Constructor for class com.tangosol.util.EnumerationIterator
- 
Construct the Iterator based on an Enumeration.
- EnumPofSerializer - Class in com.tangosol.io.pof
- 
PofSerializerimplementation that can be used to serialize all enum values.
- EnumPofSerializer() - Constructor for class com.tangosol.io.pof.EnumPofSerializer
- EnumProcessor<T extends Enum<?>> - Class in com.tangosol.coherence.config.xml.processor
- 
AEnumProcessoris responsible for processing Coherence Enum values and return the corresponding Enum type.
- EnumProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.EnumProcessor
- 
Constructs aEnumProcessor.
- ENVIRONMENT_NAME_PREFIX - Static variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Prefix for temporary environment names.
- EnvironmentHolder(BerkeleyDBBinaryStoreManager) - Constructor for class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Construct a EnvironmentHolder for a given Berkeley DB Environment.
- EnvironmentVariableResolver - Interface in com.tangosol.coherence.config
- 
An abstraction that allows us to make environment variable resolution customizable.
- EnvironmentVariableResolver.Default - Class in com.tangosol.coherence.config
- 
DefaultEnvironmentVariableResolverimplementation.
- equal(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests for equality.
- equal(String, E) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests for equality using aUniversalExtractorinstance to extract the specified field.
- equals(byte[], int, byte[], int, int) - Static method in class com.tangosol.util.Binary
- 
Compare two binary regions, testing for equality.
- equals(Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- equals(Object) - Method in class com.oracle.coherence.cdi.AnnotationInstance
- equals(Object) - Method in class com.oracle.coherence.cdi.AnnotationLiteral
- equals(Object) - Method in class com.oracle.coherence.common.base.IdentityHolder
- equals(Object) - Method in class com.oracle.coherence.common.base.MutableLong
- equals(Object) - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- equals(Object) - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- equals(Object) - Method in class com.oracle.coherence.grpc.proxy.GrpcMetricsInterceptor
- equals(Object) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.MapListenerAdapter
- equals(Object) - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
- equals(Object) - Method in class com.tangosol.coherence.config.SchemeMappingRegistry.SchemeMappingKey
- equals(Object) - Method in class com.tangosol.coherence.config.xml.processor.TopicMappingProcessor
- equals(Object) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- equals(Object) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- equals(Object) - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- equals(Object) - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
- equals(Object) - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- equals(Object) - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Compare the MvelExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Compare the MvelManipulator with another object to determine equality.
- equals(Object) - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Test equality of this object with another.
- equals(Object) - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Test equality of this object with another.
- equals(Object) - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Compare the MvelUpdater with another object to determine equality.
- equals(Object) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Compare two ReadBuffer objects for equality.
- equals(Object) - Method in class com.tangosol.io.AbstractReadBuffer
- 
Compare two ReadBuffer objects for equality.
- equals(Object) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Compares two BerkeleyDBBinaryStoreManagers for equality.
- equals(Object) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Compare two ReadBuffer objects for equality.
- equals(Object) - Method in class com.tangosol.io.pof.PofPrincipal
- 
Compares this Principal to the specified object.
- equals(Object) - Method in class com.tangosol.io.pof.RawDate
- 
Compare this object with another for equality.
- equals(Object) - Method in class com.tangosol.io.pof.RawDateTime
- 
Compare this object with another for equality.
- equals(Object) - Method in class com.tangosol.io.pof.RawDayTimeInterval
- equals(Object) - Method in class com.tangosol.io.pof.RawQuad
- 
Compare this object with another for equality.
- equals(Object) - Method in class com.tangosol.io.pof.RawTime
- 
Compare this object with another for equality.
- equals(Object) - Method in class com.tangosol.io.pof.RawTimeInterval
- equals(Object) - Method in class com.tangosol.io.pof.RawYearMonthInterval
- equals(Object) - Method in class com.tangosol.io.pof.reflect.SimplePofPath
- 
Compare the SimplePofPath with another object to determine equality.
- equals(Object) - Method in interface com.tangosol.io.ReadBuffer
- 
Compare two ReadBuffer objects for equality.
- equals(Object) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
- 
Compare the EventRouter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Compares the specified object with this map for equality.
- equals(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap.HashcodeComparator
- equals(Object) - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
- equals(Object) - Method in class com.tangosol.net.ClusterPermission
- 
Checks two Permission objects for equality.
- equals(Object) - Method in class com.tangosol.net.CompositeAddressProvider
- 
SocketAddressProvider instances are considered equivalent iff they consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
- 
SocketAddressProvider instances are considered equivalent iff they consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Return true iff this ProvidedAddress is equal to the specified Object.
- equals(Object) - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
AddressProvider instances should compare to be equals() iff they should be expected to consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.events.NamedEventInterceptor
- equals(Object) - Method in class com.tangosol.net.management.ObjectNameExcludeFilter
- 
Compare the ObjectNameExcludeFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.net.management.ViewMBeanImpl
- equals(Object) - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- equals(Object) - Method in class com.tangosol.net.partition.Ownership
- 
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.tangosol.net.partition.PartitionSet
- 
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.tangosol.net.partition.SimplePartitionKey
- equals(Object) - Method in class com.tangosol.net.partition.VersionedOwnership
- 
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.tangosol.net.RefreshableAddressProvider
- 
SocketAddressProvider instances are considered equivalent iff they consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.security.SimpleHandler
- 
Compare this principal to the specified object.
- equals(Object) - Method in interface com.tangosol.net.SocketAddressProvider
- 
SocketAddressProvider instances are considered equivalent iff they consistently produce the same resulting set of addresses.
- equals(Object) - Method in class com.tangosol.net.ssl.AbstractCertificateLoader
- equals(Object) - Method in class com.tangosol.net.ssl.AbstractKeyStoreLoader
- equals(Object) - Method in class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- equals(Object) - Method in class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
- equals(Object) - Method in class com.tangosol.run.xml.QualifiedName
- equals(Object) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Compare this XML document and all of its contained information with another XML document for equality.
- equals(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- equals(Object) - Method in class com.tangosol.run.xml.SimpleElement
- 
Compare this XML element and all of its contained information with another XML element for equality.
- equals(Object) - Method in class com.tangosol.run.xml.SimpleValue
- 
Compare this XML value with another XML value for equality.
- equals(Object) - Method in class com.tangosol.run.xml.XmlBean
- 
Determine if this value object is equal to the passed value object.
- equals(Object) - Method in interface com.tangosol.run.xml.XmlDocument
- 
Compare this XML document and all of its contained information with another XML document for equality.
- equals(Object) - Method in interface com.tangosol.run.xml.XmlElement
- 
Compare this XML element and all of its contained information with another XML element for equality.
- equals(Object) - Method in interface com.tangosol.run.xml.XmlValue
- 
Compare this XML value with another XML value for equality.
- equals(Object) - Method in class com.tangosol.util.AbstractByteSequence
- equals(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Compares the specified object with this map for equality.
- equals(Object) - Method in class com.tangosol.util.AbstractLongArray
- 
Test for LongArray equality.
- equals(Object) - Method in class com.tangosol.util.AbstractMapListener
- equals(Object) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Compares this object with another object for equality.
- equals(Object) - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- equals(Object) - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Compare the CompositeAggregator with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Compare the GroupAggregator with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.Binary
- 
Compares this Binary object with another object for equality.
- equals(Object) - Method in class com.tangosol.util.CacheCollator
- 
Compares the equality of two Collators.
- equals(Object) - Method in class com.tangosol.util.ClassFilter
- 
Compare the ClassFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Determine if two ChainedComparator objects are equal.
- equals(Object) - Method in class com.tangosol.util.comparator.EntryComparator
- 
Determine if two EntryComparator objects are equal.
- equals(Object) - Method in class com.tangosol.util.comparator.InverseComparator
- 
Compare the InverseComparator with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.comparator.SafeComparator
- 
Determine if two comparators are equal.
- equals(Object) - Method in class com.tangosol.util.CompositeKey
- 
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class com.tangosol.util.ConditionalIndex
- 
Compares the specified object with this index for equality.
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterHolder
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- 
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
- 
Compare the ConverterMapListener with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterSet
- 
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- equals(Object) - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
Compare the AbstractCompositeExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.AbstractExtractor
- 
Equivalence by canonical name and target.
- equals(Object) - Method in class com.tangosol.util.extractor.CompositeUpdater
- equals(Object) - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Equivalence by canonical name and target.
- equals(Object) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Equivalence by canonical name and target.
- equals(Object) - Method in class com.tangosol.util.extractor.IdentityExtractor
- 
Compare the IdentityExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.KeyExtractor
- equals(Object) - Method in class com.tangosol.util.extractor.PofExtractor
- 
Compare the PofExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.PofUpdater
- 
Compare the PofUpdater with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Compare the ReflectionExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Compare the ReflectionUpdater with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Compare theUniversalExtractorwith another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Compare the UniversalUpdater with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Compare the AlwaysFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Compare the ArrayFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.CacheEventFilter
- 
Compare the CacheEventFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Compare the ComparisonFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.FilterTrigger
- 
Compare the FilterTrigger with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Compare the KeyAssociatedFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.MapEventFilter
- 
Compare the MapEventFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Compare the MapEventTransformerFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.NeverFilter
- 
Compare the NeverFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.NotFilter
- 
Compare the NotFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Compare the PartitionedFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.PresentFilter
- 
Compare the PresentFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- 
Compare the ValueChangeEventFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Compares the specified object with this index for equality.
- equals(Object) - Method in class com.tangosol.util.Fragment
- equals(Object) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent.Discriminator
- equals(Object) - Method in class com.tangosol.util.ImmutableArrayList
- 
Compare this Collection / List / Set / SortedSet with some other Object and determine if the caller would believe this Object to equal that other Object.
- equals(Object) - Method in class com.tangosol.util.ImmutableArrayList.ListView
- equals(Object) - Method in class com.tangosol.util.ImmutableArrayList.SetView
- equals(Object) - Method in class com.tangosol.util.ImmutableArrayList.SortedSetView
- equals(Object) - Method in class com.tangosol.util.ImmutableMultiList
- 
Compare this Collection / List / Set with some other Object and determine if the caller would believe this Object to equal that other Object.
- equals(Object) - Method in class com.tangosol.util.ImmutableMultiList.ListView
- 
Compares the specified object with this list for equality.
- equals(Object) - Method in class com.tangosol.util.ImmutableMultiList.SetView
- 
Compares the specified object with this set for equality.
- equals(Object) - Method in class com.tangosol.util.InflatableCollection
- equals(Object) - Method in class com.tangosol.util.InflatableList
- equals(Object) - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
- 
Compare this IndexMapListener with another object for equality.
- equals(Object) - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Compare this SimpleEntry with another object for equality.
- equals(Object) - Method in interface com.tangosol.util.LongArray
- 
Test for LongArray equality.
- equals(Object) - Method in class com.tangosol.util.MapListenerSupport.WrapperListener
- 
Compare the WrapperListener with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.MultiplexingMapListener
- equals(Object) - Method in class com.tangosol.util.NullFilter
- 
Compare the NullFilter with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- equals(Object) - Method in class com.tangosol.util.NullImplementation.NullSet
- equals(Object) - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Compare the ValueExtractor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.CompositeProcessor
- 
Compare the ConditionalProcessor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Compare the ConditionalProcessor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.ConditionalPut
- 
Compare the ConditionalPut with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Compare the ConditionalPutAll with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Compare the ConditionalRemove with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.ExtractorProcessor
- 
Compare the ExtractorProcessor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.PreloadRequest
- 
Compare the PreloadRequest with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Compare the PropertyManipulator with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Compare the PropertyProcessor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.UpdaterProcessor
- 
Compare the UpdaterProcessor with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.VersionedPut
- 
Compare the VersionedPut with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Compare the VersionedPutAll with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Compares the specified object with this collection for equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
- 
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
- 
Compares the specified object with this Iterator for equality.
- equals(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Compares the specified object with this map for equality.
- equals(Object) - Method in class com.tangosol.util.SafeHashMap.Entry
- 
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.util.SafeLinkedList.Node
- 
Compare this Node with an object for equality.
- equals(Object) - Method in class com.tangosol.util.SafeSortedMap
- equals(Object) - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Compares the specified object with this map for equality.
- equals(Object) - Method in class com.tangosol.util.SimpleHolder
- equals(Object) - Method in class com.tangosol.util.SimpleMapEntry
- 
Compares the specified object with this entry for equality.
- equals(Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Compares the specified object with this index for equality.
- equals(Object) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- equals(Object) - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryKey
- equals(Object) - Method in class com.tangosol.util.StringTable
- 
Test for equality of two string tables.
- equals(Object) - Method in class com.tangosol.util.SubList
- equals(Object) - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Compare the ExtractorEventTransformer with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
- 
Compare the SemiLiteEventTransformer with another object to determine equality.
- equals(Object) - Method in class com.tangosol.util.Tree
- 
Test for tree equality.
- equals(Object) - Method in class com.tangosol.util.UID
- 
Determine if two UIDs are equal.
- equals(Object) - Method in class com.tangosol.util.UUID
- 
Determine if two UUIDs are equal.
- equals(Object) - Method in interface com.tangosol.util.ValueExtractor
- 
This instance is considered equal to parameterowhen both have same non-nullValueExtractor.getCanonicalName().
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- equals(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- equals(Object) - Method in class com.tangosol.util.WrapperObservableMap
- equals(Object, Object) - Static method in class com.oracle.coherence.common.base.Objects
- 
Compare two references for equality.
- equals(Object, Object) - Static method in class com.tangosol.util.Base
- 
Compare two references for equality.
- equals(V, V) - Method in interface com.oracle.coherence.common.base.Hasher
- 
Compare two objects for equality.
- equals(V, V) - Method in class com.oracle.coherence.common.base.IdentityHasher
- 
Compare two objects for equality.
- equals(V, V) - Method in class com.oracle.coherence.common.base.NaturalHasher
- 
Compare two objects for equality.
- equalsDeep(Object, Object) - Static method in class com.oracle.coherence.common.base.Objects
- 
Deeply compare two references for equality.
- equalsDeep(Object, Object) - Static method in class com.tangosol.util.Base
- 
Deeply compare two references for equality.
- equalsElement(XmlElement, XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Compare one XML element with another XML element for equality.
- EqualsFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value for equality.
- EqualsFilter() - Constructor for class com.tangosol.util.filter.EqualsFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- EqualsFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.EqualsFilter
- 
Construct an EqualsFilter for testing equality.
- EqualsFilter(String, E) - Constructor for class com.tangosol.util.filter.EqualsFilter
- 
Construct an EqualsFilter for testing equality.
- equalsMostly(Subject, Subject) - Method in class com.tangosol.net.security.DefaultController
- 
Check whether the specified Subject objects have the same set of principals and public credentials.
- equalsName(String) - Method in enum com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
- EqualsOperator - Class in com.tangosol.coherence.dslquery.operator
- 
An operator implementation representing the equality operator.
- EqualsOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.EqualsOperator
- 
Construct a EqualsOperator.
- equalsValue(XmlValue, XmlValue) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Compare one XML value with another XML value for equality.
- equalsValue(Object) - Method in class com.tangosol.util.SafeLinkedList.Node
- 
Compare this Node's value with another value for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.ArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Compare the two passed objects for equality.
- equalsValue(Object, Object) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Compare the two passed objects for equality.
- erase(long, ReadBuffer) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
Queue an erase operation.
- erase(long, ReadBuffer, Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Remove the specified key from the underlying store if present.
- erase(long, R, Object) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Remove the specified key from the underlying store if present.
- erase(long, R, Object) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- erase(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Remove the specified entry from the underlying store.
- erase(Binary) - Method in class com.tangosol.io.AbstractBinaryStore
- 
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.io.AsyncBinaryStore
- 
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in interface com.tangosol.io.BinaryStore
- 
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.io.nio.BinaryMapStore
- 
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
- 
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Remove the specified key from the underlying store if present.
- erase(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Remove the specified key from the underlying store if present.
- erase(BinaryEntry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
- erase(BinaryEntry<K, V>) - Method in interface com.tangosol.net.cache.BinaryEntryStore
- 
Remove the specified entry from the underlying store.
- erase(BinaryEntry<K, V>) - Method in interface com.tangosol.net.cache.NonBlockingEntryStore
- 
Remove the specified entry from the underlying store.
- erase(Object) - Method in class com.tangosol.util.NullImplementation.NullCacheStore
- 
Remove the specified key from the underlying store if present.
- erase(K) - Method in class com.tangosol.net.cache.AbstractCacheStore
- 
Remove the specified key from the underlying store if present.
- erase(K) - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Remove the specified key from the underlying store if present.
- erase(K) - Method in interface com.tangosol.net.cache.CacheStore
- 
Remove the specified key from the underlying store if present.
- erase(K) - Method in class com.tangosol.net.cache.MapCacheStore
- 
Remove the specified key from the underlying store if present.
- eraseAll() - Method in class com.tangosol.io.AbstractBinaryStore
- 
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Remove all data from the underlying store.
- eraseAll() - Method in interface com.tangosol.io.BinaryStore
- 
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.io.nio.BinaryMapStore
- 
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
- 
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Remove all data from the underlying store.
- eraseAll() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Remove all data from the underlying store.
- eraseAll(Collection) - Method in class com.tangosol.util.NullImplementation.NullCacheStore
- 
Remove the specified keys from the underlying store if present.
- eraseAll(Collection<? extends K>) - Method in interface com.tangosol.net.cache.CacheStore
- 
Remove the specified keys from the underlying store if present.
- eraseAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.MapCacheStore
- 
Remove the specified keys from the underlying store if present.
- eraseAll(Set) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
- eraseAll(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Remove the specified entries from the underlying store.
- eraseAll(Set<? extends BinaryEntry<K, V>>) - Method in interface com.tangosol.net.cache.BinaryEntryStore
- 
Remove the specified entries from the underlying store.
- eraseAll(Set<? extends BinaryEntry<K, V>>) - Method in interface com.tangosol.net.cache.NonBlockingEntryStore
- 
Remove the specified entries from the underlying store.
- eraseAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Remove the specified entries from the underlying store.
- eraseAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Remove the specified entries from the underlying store.
- eraseAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Remove the specified entries from the underlying store.
- eraseAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Remove the specified entries from the underlying store.
- eraseInternal(long, ReadBuffer, Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Remove the specified key from the underlying persistent storage if present.
- eraseInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Remove the specified entry from the underlying store.
- eraseInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Remove the specified entry from the underlying store.
- eraseInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Remove the specified entry from the underlying store.
- eraseInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Remove the specified entry from the underlying store.
- EraseOperation(long, ReadBuffer) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.EraseOperation
- 
Create a new EraseOperation.
- eraseStore() - Method in class com.tangosol.net.cache.SerializationMap
- 
Erase all entries from the underlying store.
- eraseStore() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Erase all entries from the underlying store.
- err() - Static method in class com.tangosol.util.Base
- 
Prints a blank line to the trace Writer.
- err(Class<?>) - Static method in class com.tangosol.util.Base
- 
Prints the passed class information to the trace Writer.
- err(Object) - Static method in class com.tangosol.util.Base
- 
Prints the passed Object to the trace Writer.
- err(String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.ERRORseverity.
- err(String) - Static method in class com.tangosol.util.Base
- 
Prints the passed String value to the trace Writer.
- err(String, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.ERRORseverity.
- err(Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) withLogger.ERRORseverity.
- err(Throwable) - Static method in class com.tangosol.util.Base
- 
Prints the passed exception information to the trace Writer.
- err(Supplier<String>) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.ERRORseverity.
- err(Supplier<String>, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.ERRORseverity.
- error(String, Throwable) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Create aMapListenerErrorResponse.
- error(SAXParseException) - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
- 
Routine called when a error occurs in parser.
- Error - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any ERROR event.
- ERROR - Static variable in class com.oracle.coherence.common.base.Logger
- 
Severity 1 indicates an error.
- Error.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theErrorannotation.
- ErrorHandlingConverter(Converter<F, T>) - Constructor for class com.oracle.coherence.grpc.RequestHolder.ErrorHandlingConverter
- ErrorsHelper - Class in com.oracle.coherence.grpc
- 
Error helper methods.
- escape(char, char[], int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format a char to a printable escape if necessary, putting the result into the passed array.
- escape(char, char[], int) - Static method in class com.tangosol.util.Base
- 
Format a char to a printable escape if necessary, putting the result into the passed array.
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- 
Establishes an appropriateMapListener(provided by theObservableCachingScheme.getListenerBuilder()) on theObservableMapthat was produced by theObservableCachingScheme.
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.NearScheme
- 
Establishes an appropriateMapListener(provided by theObservableCachingScheme.getListenerBuilder()) on theObservableMapthat was produced by theObservableCachingScheme.
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in interface com.tangosol.coherence.config.scheme.ObservableCachingScheme
- 
Establishes an appropriateMapListener(provided by theObservableCachingScheme.getListenerBuilder()) on theObservableMapthat was produced by theObservableCachingScheme.
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
- 
Establishes an appropriateMapListener(provided by theObservableCachingScheme.getListenerBuilder()) on theObservableMapthat was produced by theObservableCachingScheme.
- establishMapListeners(Map, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Establishes an appropriateMapListener(provided by theObservableCachingScheme.getListenerBuilder()) on theObservableMapthat was produced by theObservableCachingScheme.
- etReadLocatorBuilder(ReadLocatorBuilder) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Sets thebuilderthat is capable of building BiFunction's that return the Member reads for a partitioned cache should be targeted against.
- EVAL_COST - Static variable in class com.tangosol.util.filter.ExtractorFilter
- 
The evaluation cost as a factor to the single index access operation.
- evalLine(String) - Method in class com.tangosol.coherence.dslquery.QueryPlus
- 
Evaluate the given CohQL statement.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.ParameterMacroExpression
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CacheRefExpression
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.CollectionRefExpression
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.ResourceRefExpression
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.SchemeRefExpression
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(ParameterResolver) - Method in interface com.tangosol.config.expression.Expression
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.config.expression.LiteralExpression
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.config.expression.Parameter
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(ParameterResolver) - Method in class com.tangosol.config.expression.ValueMacroExpression
- 
Evaluates theExpressionto produce a value of type T.
- evaluate(MapEvent<?, V>) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- 
Apply the test to the input argument.
- evaluate(MapEvent<K, V>) - Method in class com.tangosol.util.filter.CacheEventFilter
- 
Apply the test to the input argument.
- evaluate(MapEvent<K, V>) - Method in class com.tangosol.util.filter.MapEventFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
- evaluate(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap.FrontFilterConverter
- 
Filters keys out that are not in the front map.
- evaluate(Object) - Method in class com.tangosol.net.management.ObjectNameExcludeFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.ClassFilter
- 
Filter interface: evaluate().
- evaluate(Object) - Method in class com.tangosol.util.filter.AllFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.filter.AnyFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.filter.KeyFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.filter.XorFilter
- 
Apply the test to the input argument.
- evaluate(Object) - Method in class com.tangosol.util.NullFilter
- 
Filter interface: evaluate().
- evaluate(Stream<? extends InvocableMap.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.util.stream.RemotePipeline
- 
Evaluate this pipeline against the specified stream of InvocableMap.Entry objects.
- evaluate(T) - Method in interface com.oracle.coherence.common.base.Predicate
- 
Return true iff the specified object satisfies the predicate.
- evaluate(T) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
- evaluate(T) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter
- evaluate(T) - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in interface com.tangosol.util.Filter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.ExtractorFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.LimitFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.NeverFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.NotFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.PresentFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.PriorityFilter
- 
Apply the test to the input argument.
- evaluate(T) - Method in class com.tangosol.util.filter.WrapperQueryRecorderFilter
- 
Apply the test to the input argument.
- evaluate(V) - Method in class com.tangosol.util.filter.ScriptFilter
- evaluateEntry(Filter, Map.Entry<K, V>) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Check if the entry passes the filter evaluation.
- evaluateEntry(Filter, K, V) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Check if an entry, expressed as a key and value, passes the filter evaluation.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
- evaluateEntry(Map.Entry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.ConditionalIndex
- 
Evaluate the given entry using this index's filter.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.KeyFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.LimitFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.NeverFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.NotFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.PresentFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.PriorityFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry) - Method in class com.tangosol.util.filter.WrapperQueryRecorderFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry<?, ? extends T>) - Method in class com.tangosol.util.filter.ExtractorFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry<? extends K, ? extends V>) - Method in interface com.tangosol.util.filter.EntryFilter
- 
Apply the test to a Map Entry.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.AllFilter
- 
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.AnyFilter
- 
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Check if the given entry passes the filter's evaluation.
- evaluateEntry(Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.XorFilter
- 
Check if the given entry passes the filter's evaluation.
- evaluateEvent(Filter, MapEvent) - Method in class com.tangosol.util.MapListenerSupport
- 
Evaluate whether or not the specified event should be delivered to the listener associated with the specified filter.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.ContainsAllFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.ContainsAnyFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.ContainsFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.EqualsFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.ExtractorFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.GreaterEqualsFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.GreaterFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.InFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.LessEqualsFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.LessFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.LikeFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.NotEqualsFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.PredicateFilter
- evaluateExtracted(E) - Method in class com.tangosol.util.filter.RegexFilter
- 
Evaluate the specified extracted value.
- evaluateExtracted(Object) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Evaluate the specified extracted value.
- evaluateFilter(Filter, Map.Entry, QueryContext, QueryRecord.PartialResult.TraceStep) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Check if the given entry passes the given filter's evaluation.
- evaluateGUID(String, String[], Set<String>, int) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Evaluate the provided GUID ensuringasGUIDNewestreferences the latest andsetPrevGUIDsreferences previous GUIDs.
- evaluateName(ParameterResolver, Class<? extends ResourceMapping>, String) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.DataStructureRefExpression
- evaluateOriginalEntry(Filter, MapTrigger.Entry) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Check if the entry, in its "original" form, passes the filter evaluation.
- Event<T extends Enum<T>> - Interface in com.tangosol.net.events
- 
AnEventobject captures the necessary information required to adequately describe some activity that has occurred.
- Event<T extends Enum<T>> - Interface in com.tangosol.net.events.partition.cache
- 
An event dispatched by aPartitionedCacheDispatcher.
- Event<T extends Enum<T>> - Interface in com.tangosol.net.events.partition
- 
A PartitionedServiceEvent captures information concerning an operation on a PartitionedService.
- Event<S extends Enum<S>> - Interface in com.tangosol.util.fsm
- 
AnEventcaptures the information that may trigger aTransitionin aFiniteStateMachinefrom one state to another.
- EventDispatcher - Interface in com.tangosol.net.events
- EventDispatcher.InterceptorRegistrationEvent<E extends Event<? extends Enum>> - Interface in com.tangosol.net.events
- 
An InterceptorRegistrationEvent allowsEventInterceptors to observe other EventInterceptors being added or removed from anEventDispatcherinstance.
- EventDispatcher.InterceptorRegistrationEvent.Type - Enum in com.tangosol.net.events
- 
The InterceptorRegistrationEvent types.
- EventDispatcherAwareInterceptor<E extends Event<?>> - Interface in com.tangosol.net.events
- 
EventDispatcherAwareInterceptor is anEventInterceptorimplementation that takes responsibility for registering itself with theEventDispatcher.
- EventDispatcherRegistry - Interface in com.tangosol.net.events
- 
An EventDispatcherRegistry manages the registration ofEventDispatchers.
- EventHandler(EventObserverSupport.EventObserver<E>, Class<T>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
ConstructEventHandlerinstance.
- EventHelper - Class in com.tangosol.net.events
- 
Helper class providing various functionality related to event handling.
- EventHelper() - Constructor for class com.tangosol.net.events.EventHelper
- EventInterceptor<E extends Event<? extends Enum>> - Interface in com.tangosol.net.events
- 
An EventInterceptor provides an implementation that is capable of intercepting and processingEvents.
- EventObserverSupport - Class in com.oracle.coherence.cdi.events
- 
Manages registration of CDI observers withInterceptorRegistryuponConfigurableCacheFactoryactivation, and their subsequent un-registration on deactivation.
- EventObserverSupport() - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport
- EventObserverSupport.CacheLifecycleEventHandler - Class in com.oracle.coherence.cdi.events
- 
Handler forCacheLifecycleEvents.
- EventObserverSupport.CoherenceLifecycleEventHandler - Class in com.oracle.coherence.cdi.events
- 
Handler forCoherenceLifecycleEvents.
- EventObserverSupport.EntryEventHandler<K,V> - Class in com.oracle.coherence.cdi.events
- 
Handler forEntryEvents.
- EventObserverSupport.EntryProcessorEventHandler - Class in com.oracle.coherence.cdi.events
- 
Handler forEntryProcessorEvents.
- EventObserverSupport.EventHandler<E extends Event<T>,T extends Enum<T>> - Class in com.oracle.coherence.cdi.events
- 
Abstract base class for all observer-based interceptors.
- EventObserverSupport.EventObserver<E extends Event> - Interface in com.oracle.coherence.cdi.events
- 
An observer of a specific event type.
- EventObserverSupport.LifecycleEventHandler - Class in com.oracle.coherence.cdi.events
- 
Handler forLifecycleEvents.
- EventObserverSupport.ServiceEventHandler<E extends Event<T>,T extends Enum<T>> - Class in com.oracle.coherence.cdi.events
- 
Abstract base class for all observer-based service interceptors.
- EventObserverSupport.SessionLifecycleEventHandler - Class in com.oracle.coherence.cdi.events
- 
Handler forSessionLifecycleEvents.
- EventObserverSupport.TransactionEventHandler - Class in com.oracle.coherence.cdi.events
- 
Handler forTransactionEvents.
- EventObserverSupport.TransferEventHandler - Class in com.oracle.coherence.cdi.events
- 
Handler forTransactionEvents.
- EventObserverSupport.UnsolicitedCommitEventHandler - Class in com.oracle.coherence.cdi.events
- 
Handler forUnsolicitedCommitEvents.
- eventOccurred(AnyEvent) - Method in interface com.tangosol.util.AnyListener
- EventRouter(MapListener<? super K, ? super V>, boolean) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
- 
Construct an EventRouter to route events from the internal cache of theContinuousQueryCacheto the client listeners.
- events(StreamObserver<MapListenerResponse>) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Add aMapListenerto a cache and stream the events received to theStreamObserver.
- events(StreamObserver<MapListenerResponse>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- events(StreamObserver<MapListenerResponse>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- Events - Annotation Type in com.tangosol.net.events.annotation
- 
Meta annotation that must be applied to all event interceptor annotations, in order to make them discoverable.
- eventTypes() - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
Create a final set of event types to register this interceptor for.
- evict() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- evict() - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Flush items that have expired.
- evict() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Evict all entries from the cache that are no longer valid, and potentially prune the cache size if the cache is size-limited and its size is above the caching low water mark.
- evict() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Evict all entries from the cache that are no longer valid, and potentially prune the cache size if the cache is size-limited and its size is above the caching low water mark.
- evict() - Method in class com.tangosol.net.cache.OverflowMap
- 
Flush items that have expired.
- evict() - Method in class com.tangosol.net.cache.SerializationCache
- 
Flush items that have expired.
- evict() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Flush items that have expired.
- evict() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Evict all entries from the cache that are no longer valid, and potentially prune the cache size if the cache is size-limited and its size is above the caching low water mark.
- evict(Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- evict(Object) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Evict a specified key from the cache, as if it had expired from the cache.
- evict(Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Evict a specified key from the cache, as if it had expired from the cache.
- evict(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Evict a specified key from the cache, as if it had expired from the cache.
- evict(Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Evict a specified key from the cache, as if it had expired from the cache.
- evict(Map) - Static method in class com.tangosol.net.cache.OverflowMap
- 
If the passed Map supports it, evict its expired data.
- evictAll(Collection) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- evictAll(Collection) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Evict the specified keys from the cache, as if they had each expired from the cache.
- evictAll(Collection) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Evict the specified keys from the cache, as if they had each expired from the cache.
- evictAll(Collection) - Method in class com.tangosol.net.cache.SerializationCache
- 
Evict the specified keys from the cache, as if they had each expired from the cache.
- evictAll(Collection) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Evict the specified keys from the cache, as if they had each expired from the cache.
- EvictingBackupMap() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.EvictingBackupMap
- 
Default constructor.
- EVICTION_POLICY_EXTERNAL - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The cache can prune using an external eviction policy.
- EVICTION_POLICY_HYBRID - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.By default, the cache prunes based on a hybrid LRU+LFU algorithm.
- EVICTION_POLICY_LFU - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The cache can prune based on a pure Least Frequently Used (LFU) algorithm.
- EVICTION_POLICY_LRU - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The cache can prune based on a pure Least Recently Used (LRU) algorithm.
- EvictionPolicyBuilder - Class in com.tangosol.coherence.config.builder
- 
TheEvictionPolicyBuilderbuilds aConfigurableCacheMap.EvictionPolicy.
- EvictionPolicyBuilder() - Constructor for class com.tangosol.coherence.config.builder.EvictionPolicyBuilder
- EvictionPolicyProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AEvictionPolicyProcessoris responsible for processing an eviction-policyXmlElementto produce anEvictionPolicyBuilder.
- EvictionPolicyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.EvictionPolicyProcessor
- Evolvable - Interface in com.tangosol.io
- 
The Evolvable interface is implemented by classes that require forwards- and backwards-compatibility of their serialized form.
- EvolvableHolder - Class in com.tangosol.io.pof
- 
Storage for evolvable classes.
- EvolvableHolder() - Constructor for class com.tangosol.io.pof.EvolvableHolder
- EvolvableObject - Interface in com.tangosol.io.pof
- 
Defines an interface that should be implemented by the classes that want to support evolution.
- EvolvablePortableObject - Interface in com.tangosol.io.pof
- 
Extension of thePortableObjectinterface that supports forwards- and backwards-compatibility of POF data streams.
- exact() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Ensure the generated query does not include a wild card (exact).
- exact(boolean) - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Ensure the generated query does not include a wild card (exact).
- Exceptions - Class in com.oracle.coherence.common.base
- 
Class for providing exception support.
- Exceptions() - Constructor for class com.oracle.coherence.common.base.Exceptions
- EXCESSIVE - com.oracle.coherence.cdi.events.Backlog.Type
- 
Indicates that a participant is backlogged; if the participant is remote it indicates the remote participant has more work than it can handle; if the participant is local it indicates this participant has more work than it can handle.
- exclusiveLocksMap() - Static method in class com.oracle.coherence.concurrent.locks.Locks
- 
Return CoherenceNamedMapcontaining the exclusive locks state.
- exclusively() - Method in interface com.oracle.coherence.common.base.Lockable
- 
Suggest to this Lockable that the caller requires exclusive access untilcloseis called on the returnedAutoCloseable.
- exclusively() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- exclusively() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Suggest to this PersistentStore that the caller requires exclusive access to this store untilcloseis called on the returnedAutoCloseable.
- execute() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
Execute all queued operations and commit changes.
- execute() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTask
- execute() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.OpenTask
- execute() - Method in class com.tangosol.persistence.AbstractPersistenceManager.Task
- 
Execute the task.
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder.CommandsQueryPlusStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageQueryPlusStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder.HelpQueryPlusStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder.SanityCheckQueryPlusStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder.ServicesQueryPlusStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder.SetTimeoutStatement
- 
Set the current timeout to be used by the CohQL session.
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder.TraceQueryPlusStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder.WheneverQueryPlusStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder.BackupStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder.CreateCacheStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder.CreateIndexStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder.DeleteStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder.DropCacheStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder.DropIndexStatement
- execute(ExecutionContext) - Method in interface com.tangosol.coherence.dslquery.Statement
- 
Execute a CohQL query or command and return the relevantresult.
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder.CreateSnapshotStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder.ForceRecoveryStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder.ListArchiverStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder.ListServicesStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder.ListSnapshotsStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder.RecoverSnapshotStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder.RemoveSnapshotStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder.ResumeServiceStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder.RetrieveSnapshotStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder.SuspendServiceStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder.ValidateSnapshotStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder.QueryRecorderStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder.RestoreStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.AsyncSelectStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder.TruncateCacheStatement
- execute(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
- execute(Invocable, Set, InvocationObserver) - Method in interface com.tangosol.net.InvocationService
- 
Asynchronously invoke the specified task on each of the specified members.
- execute(Invocable, Set, InvocationObserver) - Method in class com.tangosol.net.WrapperInvocationService
- 
Asynchronously invoke the specified task on each of the specified members.
- execute(NamedCache, ValueExtractor<Map.Entry, ? extends E>, String, int, int) - Method in interface com.tangosol.coherence.rest.query.Query
- 
Return the values that satisfy this query.
- execute(Remote.Function<MBeanServer, R>) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Afunctionexecuted on the management node.
- execute(Remote.Function<MBeanServer, R>) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- execute(Remote.Runnable) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Executes the given command at some time in the future.
- execute(Reader, ExecutionContext) - Method in class com.tangosol.coherence.dslquery.StatementExecutor
- 
Parse and execute all of the CohQL statements read from the specifiedReader.
- execute(Runnable) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theRunnableand return anEmptyinstance.
- execute(Runnable) - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- execute(Runnable) - Method in class com.tangosol.util.TaskDaemon
- execute(Callable<T>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theCallableand return the result.
- executeAsync(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder.DeleteStatement
- executeAsync(ExecutionContext) - Method in interface com.tangosol.coherence.dslquery.Statement
- 
Execute a CohQL query or command asynchronously and return theCompletableFuturewith the relevantresult.
- executeAsync(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
- executeAsync(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- executeAsync(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
- Executed - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any EXECUTED event.
- EXECUTED - com.tangosol.net.events.partition.cache.EntryProcessorEvent.Type
- 
ThisEntryProcessorEventis dispatched after anInvocableMap.EntryProcessorhas been executed.
- Executed.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theExecutedannotation.
- executeExpression(Object, Object) - Static method in class com.tangosol.coherence.rest.util.MvelHelper
- 
Executes a compiledExpression against target.
- executePeriodicTask(Runnable, long) - Method in class com.tangosol.util.TaskDaemon
- 
Schedule a periodic task to be run "as soon as possible", and to repeat at the specified interval.
- executeQuery(String, ValueExtractor<Map.Entry, ?>, int, int, String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Returns a collection of extracted values for cache entries that satisfy the criteria expressed by the query.
- executeQuery(UriInfo, ValueExtractor<Map.Entry, ?>, int, int, String) - Method in class com.tangosol.coherence.rest.NamedQueryResource
- 
Returns a collection of extracted values for cache entries that satisfy the criteria expressed by the query.
- executeSetExpression(Serializable, Object, Object) - Static method in class com.tangosol.coherence.rest.util.MvelHelper
- 
Set property referenced bycompiledSetexpression inoTargettoOvalue..
- executeStatement(String) - Static method in class com.tangosol.util.QueryHelper
- 
Execute a CohQL statement.
- executeStatement(String, ExecutionContext) - Static method in class com.tangosol.util.QueryHelper
- 
Execute a CohQL statement.
- executeTask(AbstractPersistenceManager.Task) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Execute the specified task with the calling thread.
- executeTask(Runnable) - Method in class com.tangosol.util.TaskDaemon
- 
Schedule a task to be run by the daemon "as soon as possible".
- executeTaskExclusive(AbstractPersistenceManager.Task) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Execute the specified task with the calling thread.
- Executing - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any EXECUTING event.
- EXECUTING - com.tangosol.net.events.partition.cache.EntryProcessorEvent.Type
- 
ThisEntryProcessorEventis raised prior to executing anInvocableMap.EntryProcessoron a set of entries.
- Executing.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theExecutingannotation.
- ExecutionContext - Class in com.tangosol.coherence.dslquery
- 
Instances of this context are passed toStatements to allow commands to discern execution conditions, altering their behavior / result as needed.
- ExecutionContext - Interface in com.tangosol.util.fsm
- 
Provides contextual information about aFiniteStateMachine, typically to aid in runtime decision making for actions (eg:TransitionActions,StateEntryActions and/orStateExitActions) andEvents.
- ExecutionContext() - Constructor for class com.tangosol.coherence.dslquery.ExecutionContext
- 
Construct an ExecutionContext.
- EXECUTOR_NAME - Static variable in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
A string representing the "name" part ofObjectNamefor the ExecutorMBean.
- EXECUTOR_TYPE - Static variable in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
A string representing the "type" part ofObjectNamefor the ExecutorMBean.
- EXECUTOR_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the ExecutorMBean.
- ExecutorMBean - Interface in com.oracle.coherence.concurrent.executor.management
- 
ExecutorMBean provides a monitor interface for theExecutorstatistics.
- ExecutorProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse and produce a Executor based on an ssl/executor configuration element.
- ExecutorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ExecutorProcessor
- exists() - Method in class com.tangosol.coherence.rest.EntryResource
- 
Return true if the referenced entry exists in the cache.
- exists(long) - Method in class com.tangosol.util.AbstractLongArray
- 
Determine if the specified index is in use.
- exists(long) - Method in class com.tangosol.util.AbstractSafeLongArray
- exists(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Determine if the specified index is in use.
- exists(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- exists(long) - Method in interface com.tangosol.util.LongArray
- 
Determine if the specified index is in use.
- exists(long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- exists(long) - Method in class com.tangosol.util.SimpleLongArray
- 
Determine if the specified index is in use.
- exists(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- exists(ID) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Returns true if this repository contains the entity with the specified identifier.
- exists(ID) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Returns true if this repository contains the entity with the specified identifier.
- exit() - Method in class com.tangosol.util.ThreadGateLite
- 
Exit the gate.
- exit() - Method in class com.tangosol.util.WrapperReentrantGate
- 
Exit the gate.
- exiting(Class<?>, String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Exit logging.
- exiting(Class<?>, String, Object, Object...) - Static method in class com.oracle.coherence.common.base.Logger
- 
Exit logging.
- ExpirableStatus() - Constructor for class com.tangosol.net.cache.OverflowMap.ExpirableStatus
- 
Construct a Status object for a specific key.
- expire(long) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Update the entry with the specified expiry delay.
- expire(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Update the entry with the specified expiry delay.
- expire(long) - Method in interface com.tangosol.util.BinaryEntry
- 
Update the entry with the specified expiry delay.
- expire(long) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Update the entry with the specified expiry delay.
- expire(long) - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- EXPIRED - Static variable in class com.tangosol.net.cache.CacheEvent
- 
Flag indicating whether the deletion event is a result of time expiration.
- EXPIRY_DEFAULT - Static variable in interface com.tangosol.net.cache.CacheMap
- 
A special time-to-live value that can be passed to the extendedputmethod to indicate that the cache's default expiry should be used.
- EXPIRY_NEVER - Static variable in interface com.tangosol.net.cache.CacheMap
- 
A special time-to-live value that can be passed to the extendedputmethod to indicate that the cache entry should never expire.
- explain(Filter<T>, Map, Set, QueryRecord.PartialResult.ExplainStep) - Static method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
- 
Record an estimated cost of query execution for a given filter.
- explain(Filter<T>, Map, Set, QueryRecord.PartialResult.ExplainStep, ValueExtractor) - Static method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
- 
Record an estimated cost of query execution for a given filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
- 
Record the projected query execution cost by this filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Record the projected query execution cost by this filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Record the projected query execution cost by this filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in interface com.tangosol.util.filter.QueryRecorderFilter
- 
Record the projected query execution cost by this filter.
- explain(QueryContext, QueryRecord.PartialResult.ExplainStep, Set) - Method in class com.tangosol.util.filter.WrapperQueryRecorderFilter
- 
Record the projected query execution cost by this filter.
- EXPLAIN - com.tangosol.util.aggregator.QueryRecorder.RecordType
- 
Produce aQueryRecordobject that contains an estimated cost of the query execution.
- EXPLAIN_INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
- 
An instance of a QueryRecorderStatementBuilder that builds EXPLAIN PLAN queries.
- ExplainStep(Filter) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.ExplainStep
- 
Construct an ExplainStep
- expression(int) - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Parse the next expression into an Abstract Syntax Tree using the given right binding power.
- Expression<T> - Interface in com.tangosol.config.expression
- 
AExpressionrepresents a calculation to be evaluated at runtime, during which, one or moreParameters may be required.
- ExpressionParser - Interface in com.tangosol.config.expression
- 
AnExpressionParserparses aStringrepresentation of some calculation to produce anExpression, that of which when evaluated will return an expected type of value.
- extend(CacheConfigNamespaceHandler) - Method in interface com.tangosol.coherence.config.xml.CacheConfigNamespaceHandler.Extension
- 
Add any extensions to the specifiedCacheConfigNamespaceHandler.
- extend(OperationalConfigNamespaceHandler) - Method in interface com.tangosol.coherence.config.xml.OperationalConfigNamespaceHandler.Extension
- 
Add extensions to theOperationalConfigNamespaceHandler.
- ExtendedLanguageCommandOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageCommandOPToken
- 
Construct a ExtendedLanguageCommandOPToken.
- ExtendedLanguageQueryPlusStatement(boolean) - Constructor for class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageQueryPlusStatement
- 
Construct a ExtendedLanguageQueryPlusStatement to turn on or off extended CohQL.
- ExtendedLanguageStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
- 
A class that builds the QueryPlus "EXTENDED LANGUAGE" command.
- ExtendedLanguageStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
- ExtendedLanguageStatementBuilder.ExtendedLanguageCommandOPToken - Class in com.tangosol.coherence.dslquery.queryplus
- 
A CohQL OPToken representing the QueryPlus "extended language" command.
- ExtendedLanguageStatementBuilder.ExtendedLanguageQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
- 
The command to turn on or off extended CohQL.
- extendedSqlTokenTable() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return an initialized TokenTable for the full CoherenceQueryLanguage.
- ExtendPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
AnExtendPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat will inject an "acceptor-config"XmlElementinto a "proxy-scheme"XmlElementif one does not exist.
- ExtendPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.ExtendPreprocessor
- ExtensibleConfigurableCacheFactory - Class in com.tangosol.net
- 
ExtensibleConfigurableCacheFactory provides a facility to access caches declared in a "coherence-cache-config.xsd" compliant configuration file.
- ExtensibleConfigurableCacheFactory(ExtensibleConfigurableCacheFactory.Dependencies) - Constructor for class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Constructs anExtensibleConfigurableCacheFactoryusing the specifiedExtensibleConfigurableCacheFactory.Dependencies.
- ExtensibleConfigurableCacheFactory.DefaultDependencies - Class in com.tangosol.net
- 
TheExtensibleConfigurableCacheFactory.DefaultDependenciesis a simple implementation of theExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinterface.
- ExtensibleConfigurableCacheFactory.Dependencies - Interface in com.tangosol.net
- ExtensibleConfigurableCacheFactory.DependenciesHelper - Class in com.tangosol.net
- 
TheExtensibleConfigurableCacheFactory.DependenciesHelperprovides helper method for constructingExtensibleConfigurableCacheFactory.Dependenciesimplementations forExtensibleConfigurableCacheFactorys.
- ExtensibleConfigurableCacheFactory.Manager - Class in com.tangosol.net
- 
The Manager class uses builders to create the required backing maps and provides client access to those maps.
- ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager - Class in com.tangosol.net
- 
The PartitionedBackingMapManager is used by PartitionAwareBackingMap(s) to lazily configure the enclosing PABM based on the configuration settings of the enclosed maps.
- extents() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return a list of the extent identifiers in the underlying store.
- extents() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Return a list of the extent identifiers in the underlying store.
- extents() - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- ExternalizableHelper - Class in com.tangosol.util
- 
Helpers for the Serializable, Externalizable and the ExternalizableLite interface.
- ExternalizableHelper() - Constructor for class com.tangosol.util.ExternalizableHelper
- ExternalizableHelper.DecoratedMultiBufferReadBuffer - Class in com.tangosol.util
- 
DecoratedMultiBufferReadBuffer is a MultiBufferWriteBuffer that represents a binary "decorated" value, and allows a more optimizedExternalizableHelper.getUndecorated(ReadBuffer)operation.
- ExternalizableHelper.DefaultObjectStreamFactory - Class in com.tangosol.util
- 
Default ObjectStreamFactory implementation.
- ExternalizableHelper.FormatAwareCompressor - Class in com.tangosol.util
- 
A DeltaCompressor wrapper implementation that removes/replaces the serialization format byte (FMT_EXT) before/after delegating to the underlying compressor.
- ExternalizableHelper.IntDecoratedObject - Class in com.tangosol.util
- 
Integer decorated object.
- ExternalizableHelper.Shielded - Interface in com.tangosol.util
- 
Marker interface.
- ExternalizableHelper.ShieldedDataOutputStream - Class in com.tangosol.util
- 
An OutputStream that implements DataOutput that delegates all operations other than flush and close to an underlying object that implements DataOutput.
- ExternalizableHelper.ShieldedInputStream - Class in com.tangosol.util
- 
An InputStream that delegates all operations other than close to an underlying InputStream.
- ExternalizableHelper.ShieldedObjectOutputStream - Class in com.tangosol.util
- 
An OutputStream that implements ObjectOutput that delegates all operations other than flush and close to an underlying object that implements ObjectOutput.
- ExternalizableHelper.ShieldedOutputStream - Class in com.tangosol.util
- 
An OutputStream that delegates all operations other than flush and close to an underlying OutputStream.
- ExternalizableHelper.SimpleXmlBeanClassCache - Class in com.tangosol.util
- 
An implementation XmlBeanClassCache that uses a pre-defined list of XmlBean implementations.
- ExternalizableHelper.Stats - Class in com.tangosol.util
- 
Serialization statistics for a given user type.
- ExternalizableHelper.XmlBeanClassCache - Interface in com.tangosol.util
- 
An interface for caching class reference by integer ID values.
- ExternalizableLite - Interface in com.tangosol.io
- 
Optimized serialization.
- ExternalizableLitePofSerializer - Class in com.tangosol.io.pof
- 
PofSerializerimplementation that supports the serialization and deserialization of any class that implementsExternalizableLiteto and from a POF stream.
- ExternalizableLitePofSerializer(int) - Constructor for class com.tangosol.io.pof.ExternalizableLitePofSerializer
- 
Create a new ExternalizableLitePofSerializer for the user type with the given type identifier.
- ExternalizablePofSerializer - Class in com.tangosol.io.pof
- 
PofSerializerimplementation that supports the serialization and deserialization of any class that implementsExternalizableto and from a POF stream.
- ExternalizablePofSerializer(int) - Constructor for class com.tangosol.io.pof.ExternalizablePofSerializer
- 
Create a new ExternalizablePofSerializer for the user type with the given type identifier.
- ExternalScheme - Class in com.tangosol.coherence.config.scheme
- 
TheExternalSchemeclass is responsible for building a fully configured instance of a ExternalCache.
- ExternalScheme() - Constructor for class com.tangosol.coherence.config.scheme.ExternalScheme
- ExternalSerializer(Serializer, boolean) - Constructor for class com.tangosol.io.pof.SafeConfigurablePofContext.ExternalSerializer
- 
ConstructSafeConfigurablePofContext.ExternalSerializerwith specified non-POF serializer.
- extract(ValueExtractor) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Extract a value out of the Entry's key or value.
- extract(ValueExtractor) - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- 
Extract a value out of the Entry's key or value.
- extract(ValueExtractor<? super T, ? extends R>) - Static method in class com.tangosol.util.Processors
- 
Construct an extract processor based on the specifiedValueExtractor.
- extract(ValueExtractor<T, E>) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Depending upon the type of the ValueExtractor route the call to the appropriate extract method.
- extract(ValueExtractor<T, E>) - Method in interface com.tangosol.util.QueryMap.Entry
- 
Extract a value out of the Entry's key or value.
- extract(ValueExtractor<T, E>) - Method in class com.tangosol.util.SimpleMapEntry
- 
Extract a value out of the Entry's key or value.
- extract(ValueExtractor<V, T>) - Method in interface com.tangosol.coherence.federation.ChangeRecord.Entry
- 
Extract a value from the entry value using theValueExtractor.
- extract(Object) - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Extract the value from the passed object.
- extract(Object) - Method in class com.tangosol.util.extractor.ChainedExtractor
- 
Extract the value from the passed object.
- extract(Object) - Method in class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Extract the value from the passed object.
- extract(Object) - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Using a ConditionalExtractor to extract values in not supported.
- extract(Object) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Using a DeserializationAccelerator to extract values in not supported.
- extract(Object) - Method in class com.tangosol.util.extractor.MultiExtractor
- 
Extract a collection of values from the passed object using the underlying array of ValueExtractor objects.
- extract(Object) - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Extract the value from the passed object.
- extract(Object[]) - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Extract an array of partial objects.
- extract(String) - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that extracts the value of the specified field.
- extract(String) - Static method in class com.tangosol.util.Processors
- 
Construct an extract processor for a given property or method name.
- extract(String, Object...) - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that extracts the value of the specified field.
- extract(Collection<? extends T>) - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Extract a collection of partial objects.
- extract(T) - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Extract a partial object from a source object.
- extract(T) - Method in class com.tangosol.util.extractor.AbstractExtractor
- extract(T) - Method in class com.tangosol.util.extractor.ChainedFragmentExtractor
- extract(T) - Method in class com.tangosol.util.extractor.FragmentExtractor
- extract(T) - Method in class com.tangosol.util.extractor.IdentityExtractor
- 
Simply return the passed object.
- extract(T) - Method in class com.tangosol.util.extractor.KeyExtractor
- 
Extract the value from the passed object.
- extract(T) - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Extract from target using reflection.
- extract(T) - Method in class com.tangosol.util.extractor.ScriptValueExtractor
- extract(T) - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Extract from target using reflection or map access.
- extract(T) - Method in class com.tangosol.util.filter.ExtractorFilter
- 
Get the result of ValueExtractor invocation.
- extract(T) - Method in interface com.tangosol.util.ValueExtractor
- 
Extract the value from the passed object.
- extract(V) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- 
Extract value from a target object.
- extractCertificates(Set) - Method in class com.tangosol.net.security.DefaultController
- 
Extract a set of Certificate objects from the set of public credentials.
- extractChild(ReadBuffer, int, int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Extract child PofValue from a buffer.
- extractComplex(T) - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Extract from target using reflection or map access.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.BinaryDeltaCompressor
- 
Compare an old value to a new value and generate a delta that represents the changes that must be made to the old value in order to transform it into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.DecoratedBinaryDeltaCompressor
- 
Compare an old value to a new value and generate a delta that represents the changes that must be made to the old value in order to transform it into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.io.DecorationOnlyDeltaCompressor
- 
Compare an old value to a new value and generate a delta that represents the changes that must be made to the old value in order to transform it into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in interface com.tangosol.io.DeltaCompressor
- 
Compare an old value to a new value and generate a delta that represents the changes that must be made to the old value in order to transform it into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.util.ExternalizableHelper.FormatAwareCompressor
- 
Compare an old value to a new value and generate a delta that represents the changes that must be made to the old value in order to transform it into the new value.
- extractDelta(ReadBuffer, ReadBuffer) - Method in class com.tangosol.util.NullImplementation.NullDeltaCompressor
- 
Compare an old value to a new value and generate a delta that represents the changes that must be made to the old value in order to transform it into the new value.
- extractExpiry(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the expiration value for the given entry.
- extractFlag(int) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Extract a particular masked flag from the state of the Status object.
- extractFlag(int) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Extract a particular masked flag from the state of the Status object.
- extractFromEntry(ValueExtractor<? super T, ? extends E>, Map.Entry<? extends K, ? extends V>) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Extract a value from the specified entry using the specified extractor.
- extractFromEntry(Map.Entry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
- extractFromEntry(Map.Entry) - Method in class com.tangosol.util.extractor.AbstractExtractor
- 
Extract the value from the passed Entry object.
- extractFromEntry(Map.Entry) - Method in class com.tangosol.util.extractor.ChainedExtractor
- 
Extract the value from the passed entry.
- extractFromEntry(Map.Entry) - Method in class com.tangosol.util.extractor.MultiExtractor
- 
Extract a collection of values from the passed entry using the underlying array of ValueExtractor objects.
- extractFromEntry(Map.Entry) - Method in class com.tangosol.util.extractor.PofExtractor
- 
Extracts the value from the passed Entry object.
- extractFromKey(ValueExtractor<? super K, E>) - Method in interface com.tangosol.util.QueryMap.Entry
- 
Extract a value out of the Entry's key.
- extractFromValue(ValueExtractor<? super V, E>) - Method in interface com.tangosol.util.QueryMap.Entry
- 
Extract a value out of the Entry's value.
- extractIntDecoration(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Extract a decoration value from the specified ReadBuffer that contains a representation of an IntDecoratedObject.
- extractNewValue(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
- 
Extract the "new" value from the specified entry.
- extractOldValue(MapTrigger.Entry) - Method in class com.tangosol.util.SimpleMapIndex
- 
Extract the "old" value from the specified entry.
- EXTRACTOR_BUILDER - Static variable in class com.tangosol.coherence.rest.query.CoherenceQueryLanguageEngine
- 
ExtractorBuilder to use.
- ExtractorBinding - Annotation Type in com.oracle.coherence.cdi
- 
Specifies that an annotation type is aValueExtractorbinding type.
- ExtractorBuilder - Interface in com.tangosol.coherence.dslquery
- 
ExtractorBuilders provide a mechanism to construct aValueExtractorfor a provided cache name, target and property chain (ExtractorBuilder.realize(String, int, String)).
- ExtractorComparator<T> - Class in com.tangosol.util.comparator
- 
Comparator implementation that uses specifiedValueExtractorto extract value(s) to be used for comparison.
- ExtractorComparator() - Constructor for class com.tangosol.util.comparator.ExtractorComparator
- 
Default constructor (for PortableObject).
- ExtractorComparator(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.comparator.ExtractorComparator
- 
Construct a ExtractorComparator with the specified extractor.
- ExtractorEventTransformer<K,V,E> - Class in com.tangosol.util.transformer
- 
ExtractorEventTransformer is a special purposeMapEventTransformerimplementation that transforms emitted events, extracting one or more properties from either the OldValue or the NewValue.
- ExtractorEventTransformer() - Constructor for class com.tangosol.util.transformer.ExtractorEventTransformer
- 
No-argument constructor for lite deserialization.
- ExtractorEventTransformer(ValueExtractor<? super V, ? extends E>) - Constructor for class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Construct a ExtractorEventTransformer that transforms MapEvent values based on the specified extractor.
- ExtractorEventTransformer(ValueExtractor<? super V, ? extends E>, ValueExtractor<? super V, ? extends E>) - Constructor for class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Construct a ExtractorEventTransformer that transforms MapEvent values based on the specified extractors.
- ExtractorEventTransformer(String) - Constructor for class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Construct a ExtractorEventTransformer that transforms MapEvent's values based on the specified method name.
- ExtractorFactory<A extends Annotation,T,E> - Interface in com.oracle.coherence.cdi
- 
A factory that produces instances ofValueExtractorfor a givenAnnotation.
- ExtractorFilter<T,E> - Class in com.tangosol.util.filter
- 
Base Filter implementation for doing extractor-based processing.
- ExtractorFilter() - Constructor for class com.tangosol.util.filter.ExtractorFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- ExtractorFilter(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.filter.ExtractorFilter
- 
Construct a ExtractorFilter for a given ValueExtractor.
- ExtractorFilter(String) - Constructor for class com.tangosol.util.filter.ExtractorFilter
- 
Construct an ExtractorFilter for a given method name.
- extractOriginalFromEntry(MapTrigger.Entry) - Method in class com.tangosol.util.extractor.AbstractExtractor
- 
Extract the value from the "original value" of the passed Entry object or the key (if targeted).
- extractOriginalFromEntry(MapTrigger.Entry) - Method in class com.tangosol.util.extractor.ChainedExtractor
- extractOriginalFromEntry(MapTrigger.Entry) - Method in class com.tangosol.util.extractor.MultiExtractor
- extractOriginalFromEntry(MapTrigger.Entry) - Method in class com.tangosol.util.extractor.PofExtractor
- extractOriginalFromEntry(ValueExtractor, MapTrigger.Entry) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Extract a value from the "original value" of the specified entry using the specified extractor.
- ExtractorProcessor<K,V,T,E> - Class in com.tangosol.util.processor
- 
ExtractorProcessor is an EntryProcessor implementations that extracts a value from an object cached in an InvocableMap.
- ExtractorProcessor() - Constructor for class com.tangosol.util.processor.ExtractorProcessor
- 
Default constructor (necessary for the ExternalizableLite interface).
- ExtractorProcessor(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.processor.ExtractorProcessor
- 
Construct an ExtractorProcessor based on the specified ValueExtractor.
- ExtractorProcessor(String) - Constructor for class com.tangosol.util.processor.ExtractorProcessor
- 
Construct an ExtractorProcessor for a given method name.
- ExtractorProducer - Class in com.oracle.coherence.cdi
- 
A CDI bean that producesValueExtractorinstances usingExtractorFactorybeans annotated withExtractorBindingannotations.
- ExtractorProducer.ChainedExtractorsSupplier - Class in com.oracle.coherence.cdi
- 
A {ExtractorFactorythat producesMultiExtractorcontainingValueExtractorinstances produced from the annotations contained in aChainedExtractor.Extractorsannotation.
- ExtractorProducer.ChainedExtractorSupplier - Class in com.oracle.coherence.cdi
- 
A {ExtractorFactorythat produces chainedValueExtractorinstances for an array of property or method names.
- ExtractorProducer.PofExtractorsSupplier - Class in com.oracle.coherence.cdi
- 
A {ExtractorFactorythat producesMultiExtractorcontainingValueExtractorinstances produced from the annotations contained in aPofExtractor.Extractorsannotation.
- ExtractorProducer.PofExtractorSupplier - Class in com.oracle.coherence.cdi
- 
A {ExtractorFactorythat producesValueExtractorinstances for a given POF index or property path.
- ExtractorProducer.UniversalExtractorsSupplier - Class in com.oracle.coherence.cdi
- 
A {ExtractorFactorythat producesMultiExtractorcontainingValueExtractorinstances produced from the annotations contained in aPropertyExtractor.Extractorsannotation.
- ExtractorProducer.UniversalExtractorSupplier - Class in com.oracle.coherence.cdi
- 
A {ExtractorFactorythat producesValueExtractorinstances for a given property or method name.
- Extractors - Class in com.tangosol.util
- 
Simple Extractor DSL.
- Extractors() - Constructor for class com.tangosol.util.Extractors
- extractPage(Object[]) - Method in class com.tangosol.util.filter.LimitFilter
- 
Extract a subset of the specified array to fit the filter's parameters (i.e. page size and page number).
- extractPage(Iterator) - Method in class com.tangosol.util.filter.LimitFilter
- 
Extract a subset of the specified iterator to fit the filter's parameters (i.e. page size and page number).
- extractPage(Set) - Method in class com.tangosol.util.filter.LimitFilter
- 
Extract a subset of the specified set to fit the filter's parameters (i.e. page size and page number).
- extractPublicKeys(Set) - Method in class com.tangosol.net.security.DefaultController
- 
Extract a set of PublicKeys from the set of public credentials.
- extractState(int) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Extract a particular masked value from the state of the Status object.
- extractState(int) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Extract a particular masked value from the state of the Status object.
F
- f_aCol - Variable in class com.tangosol.util.ChainedCollection
- 
An array of Collections to enumerate.
- f_activeSpan - Variable in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- 
TheSupplierthat will provide active spans.
- f_aFilter - Variable in class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Filters that caused the event.
- f_aggregator - Variable in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder.QueryRecorderStatement
- 
The type of query recorder to run.
- f_aggregator - Variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.AsyncSelectStatement
- 
TheInvocableMap.EntryAggregatorto use in the query.
- f_aggregator - Variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- 
TheInvocableMap.EntryAggregatorto use in the query.
- f_asAlias - Variable in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
An array of optional aliases for this operator.
- f_aSets - Variable in class com.tangosol.util.ChainedSet
- 
An array of Sets to enumerate.
- f_asyncNamedCache - Variable in class com.oracle.coherence.grpc.CacheRequestHolder
- 
TheAsyncNamedCachethat the request executes against.
- f_atomicRemovesCounter - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
An atomic counter counter used duringsnapshot removal.
- f_bufKey - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.Operation
- 
The target key of the operation.
- f_bufValue - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.StoreOperation
- 
The value to store.
- f_cache - Variable in class com.tangosol.net.management.ViewMBeanImpl
- 
The cache instance.
- f_cacheFactorySupplier - Variable in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
The function used to obtain ConfigurableCacheFactory instances for a given scope name.
- f_cacheSupplier - Variable in class com.oracle.coherence.grpc.CacheRequestHolder
- 
TheSupplierto use to obtain a non-pass-through cache.
- f_canceled - Variable in class com.tangosol.persistence.AbstractPersistenceManager.Task
- 
Canceled flag.
- f_cLoadFailures - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The number of Load failures.
- f_cLoadMillis - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The cumulative time spent on Load operations.
- f_cLoadOps - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The number of Load operations.
- f_clzCol - Variable in class com.tangosol.io.pof.reflect.Codecs.CollectionCodec
- 
Class that represents the Collection implementation that will be serialized and deserialized into.
- f_clzComponent - Variable in class com.tangosol.io.pof.reflect.Codecs.ArrayCodec
- 
Class that represents the type for each element in the array that will be serialized and deserialized into.
- f_clzLa - Variable in class com.tangosol.io.pof.reflect.Codecs.LongArrayCodec
- 
Class that represents the LongArray implementation that will be serialized and deserialized into.
- f_clzMap - Variable in class com.tangosol.io.pof.reflect.Codecs.MapCodec
- 
Class that represents the Map implementation that will be serialized and deserialized into.
- f_clzMBean - Variable in class com.tangosol.net.management.AnnotatedStandardEmitterMBean.SilentEmitter
- 
The MBean interface class this emitter provides notification info for.
- f_cMillisTimeout - Variable in class com.oracle.coherence.common.base.Timeout
- 
This Timeout's timeout.
- f_collector - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
An optional Collector to add notifications to.
- f_collector - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.OpenTask
- 
TheCollectorto notify upon completion of opening the store.
- f_command - Variable in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
- 
An instance of theCommandsStatementBuilder.CommandsQueryPlusStatement.
- f_command - Variable in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
- 
AHelpStatementBuilder.HelpQueryPlusStatementinstance.
- f_comparator - Variable in class com.oracle.coherence.common.base.InverseComparator
- 
The comparator to invert.
- f_comparator - Variable in class com.tangosol.util.SortedBag.WrapperComparator
- 
The underlying "logical" comparator.
- f_context - Variable in class com.tangosol.coherence.dslquery.QueryPlus
- 
TheExecutionContextthat will be passed toStatements.
- f_contFailure - Variable in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
The failure continuation for this environment.
- f_contFailure - Variable in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
The failure continuation for this manager.
- f_contFailure - Variable in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
The failure continuation for this store.
- f_convDown - Variable in class com.tangosol.util.ConverterCollections.ConverterLongArray
- 
The Converter to use to convert from type T to type F.
- f_converter - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy.KeyConverter
- 
Converter to handle the conversion casesMapListenerProxy.KeyConverter.f_holderdoesn't cover.
- f_converter - Variable in class com.oracle.coherence.grpc.RequestHolder.DownConverter
- f_convKey - Variable in class com.tangosol.net.cache.ContinuousQueryCache.InternalMapListener
- 
TheConverterto be applied to keys.
- f_convUp - Variable in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- 
Converter to deserializeBinaryvalues.
- f_convUp - Variable in class com.tangosol.util.ConverterCollections.ConverterLongArray
- 
The Converter to use to convert from type F to type T.
- f_convValue - Variable in class com.tangosol.net.cache.ContinuousQueryCache.InternalMapListener
- 
TheConverterto be applied to values.
- f_cPendingAsyncStoreOps - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The number of pending non-blocking store operations.
- f_cStoreEntries - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The total number of entries written in Store operations.
- f_cStoreFailures - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The number of Store failures.
- f_cStoreMillis - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The cumulative time spent on Store operations.
- f_cStoreOps - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The number of Store operations.
- f_ctx - Variable in class com.tangosol.util.ForwardOnlyMapIndex
- 
Thecontextassociated with this index.
- f_daemonRefresh - Variable in class com.tangosol.net.RefreshableAddressProvider
- 
The refresh daemon.
- f_defaultNamedBindVars - Variable in class com.tangosol.coherence.dslquery.FilterBuilder
- 
The default named bind variables.
- f_delegate - Variable in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- 
TheDaemonPoolto delegate to.
- f_delegate - Variable in class com.oracle.coherence.grpc.proxy.TracingDaemonPool.TracingRunnable
- 
TheRunnable.
- f_delegate - Variable in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- 
The delegate iterator.
- f_dependencies - Variable in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
The serviceBaseGrpcServiceImpl.Dependencies.
- f_dependencies - Variable in class com.tangosol.coherence.dslquery.QueryPlus
- 
TheQueryPlus.Dependenciesconfiguring this query session.
- f_dirData - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The directory used to store persisted data.
- f_dirLock - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The directory used to store lock files (to protect against multi-process file system clean up).
- f_dirSnapshot - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistenceSnapshotTools
- 
The snapshot directory.
- f_dirStore - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The directory used to store persisted data.
- f_dirTrash - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The directory used to store "safe-deleted" data.
- f_dispatcher - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
ConfigurableCacheFactoryDispatcher linked to this cache factory.
- f_durationTimeout - Variable in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder.SetTimeoutStatement
- 
The name of the timeout to set as the current timeout.
- f_elem - Variable in class com.tangosol.util.SortedBag.UniqueElement
- 
The "actual" element.
- f_env - Variable in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
The underlying PersistenceEnvironment.
- f_event - Variable in class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Optional wrapped MapEvent.
- f_executor - Variable in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
TheExecutorto use to hand off asynchronous tasks.
- f_executor - Variable in class com.oracle.coherence.grpc.RequestHolder
- 
TheExecutorto use to hand off asynchronous tasks.
- f_executor - Variable in class com.tangosol.coherence.dslquery.QueryPlus
- 
TheStatementExecutorto use to execute statements.
- f_exitSentry - Variable in class com.tangosol.util.ThreadGateLite
- 
Sentry to return fromThreadGateLite.enter()that willThreadGateLite.exit()when the sentry is closed.
- f_exitSentry - Variable in class com.tangosol.util.WrapperReentrantGate
- 
Sentry to return fromWrapperReentrantGate.enter(long)that willWrapperReentrantGate.exit()when the sentry is closed.
- f_extractor - Variable in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder.CreateIndexStatement
- 
TheValueExtractorto be used to create the index.
- f_extractor - Variable in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder.DropIndexStatement
- 
TheValueExtractorto be used to create the index.
- f_extractor - Variable in class com.tangosol.util.ForwardOnlyMapIndex
- 
ValueExtractor object that this MapIndex uses to extract an indexable property value from a [converted] value stored in the resource map.
- f_factoryCont - Variable in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
The FailureContinuationFactory.
- f_factoryCont - Variable in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
The FailureContinuationFactory.
- f_fConditional - Variable in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
Flag indicating whether this operator can be used as a conditional operator, for example ==, >=, etc, as opposed to a non-conditional operator such as +, -, etc.
- f_fileActive - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
The data directory of the active persistence manager.
- f_fileBackup - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
The data directory of the backup persistence manager.
- f_fileEvents - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
The events directory of the events persistence manager.
- f_fileLock - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The file used to prevent concurrent access to the data directory underlying this persistent store.
- f_fileSnapshot - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
The snapshot directory.
- f_fileTrash - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
An optional trash directory.
- f_filter - Variable in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder.DeleteStatement
- 
TheFilterto be used in the CohQL "delete" command.
- f_filter - Variable in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder.QueryRecorderStatement
- 
TheFilterto be explained or traced.
- f_filter - Variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.AsyncSelectStatement
- 
TheFilterto use in the query.
- f_filter - Variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- 
TheFilterto use in the query.
- f_filter - Variable in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
- 
TheFilterthat will be used to select entries to be updated.
- f_fLazy - Variable in class com.tangosol.util.ForwardOnlyMapIndex
- 
The "lazy" flag.
- f_fLite - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy.FilterInfo
- 
A flag indicating whether the filter was registered for lite events.
- f_fLite - Variable in class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
- 
Flag indicatingMapEventobjects do not have to include the OldValue and NewValue property values in order to allow optimizations.
- f_fReduction - Variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.AsyncSelectStatement
- 
Flag to denote whether this query is an aggregation to select specific fields from the values of a cache; e.g. select x, y, z from foo.
- f_fReduction - Variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- 
Flag to denote whether this query is an aggregation to select specific fields from the values of a cache; e.g. select x, y, z from foo.
- f_fSanity - Variable in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder.SanityCheckQueryPlusStatement
- 
Flag indicating whether this command turns sanity checking on or off.
- f_fShowKeys - Variable in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
A flag to determine whether to print keys in theDefaultStatementResult.print(java.io.PrintWriter, String)method if the value inDefaultStatementResult.f_oResultis aMap.
- f_fTloCreator - Variable in class com.oracle.coherence.common.base.Timeout
- 
True iff this Timeout created (and thus must ultimately destroy) the TLO.
- f_functionValue - Variable in class com.tangosol.util.SetMap
- 
A function to load a value for a provided key.
- f_fValue - Variable in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
- 
Wrapped atomic boolean value.
- f_guardable - Variable in class com.tangosol.net.GuardSupport.Context
- 
The Guardable represented by this GuardContext
- f_holder - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy.KeyConverter
- 
Cache request holder to handle conversion ofBinaryandByteStringobjects.
- f_idToSerializer - Variable in class com.tangosol.io.MultiplexingSerializer
- 
The mapping ofSerializers keyed by their name.
- f_info - Variable in class com.tangosol.persistence.AbstractPersistenceTools
- 
Information about the snapshot or archived snapshot.
- f_iterator - Variable in class com.tangosol.net.RefreshableAddressProvider
- 
An Iterator over the cached set of addresses.
- f_laDelegate - Variable in class com.tangosol.util.ConverterCollections.ConverterLongArray
- 
The LongArray to delegate to.
- f_language - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
TheCoherenceQueryLanguageto use.
- f_language - Static variable in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
The defaultCoherenceQueryLanguageused by this QueryHelper when no language is provided to methods.
- f_language - Variable in class com.tangosol.coherence.rest.query.CoherenceQueryLanguageEngine
- f_language - Static variable in class com.tangosol.util.QueryHelper
- 
The defaultCoherenceQueryLanguageused by this QueryHelper when no language is provided to methods.
- f_lExtentId - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.Operation
- 
The extent identifier for the target key.
- f_LExtentId - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTask
- 
The extent to delete.
- f_lHash - Variable in class com.oracle.coherence.grpc.proxy.TracingDaemonPool.TracingRunnable
- 
TheRunnable's hash.
- f_lId - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy.FilterInfo
- 
The filter identifier.
- f_listBuilders - Variable in class com.tangosol.coherence.dslquery.ChainedExtractorBuilder
- 
The chain ofExtractorBuilders to delegate to.
- f_listDefaultBindVars - Variable in class com.tangosol.coherence.dslquery.FilterBuilder
- 
The default indexed bind variables.
- f_listener - Variable in class com.tangosol.util.MapListenerSupport.WrapperListener
- 
Wrapped MapListener.
- f_listenerBackService - Variable in class com.tangosol.net.cache.NearCache
- 
The back cache service MemberListener.
- f_listenerDeactivation - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
The listener used to detect cache deactivation.
- f_listenerSupport - Variable in class com.tangosol.net.cache.ContinuousQueryCache.InternalMapListener
- 
TheMapListenerSupportto dispatch events to.
- f_listenerWrapped - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy.WrapperPrimingListener
- 
The wrappedMapListener.
- f_listOps - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
The sequence of operations to commit atomically.
- f_listTasks - Variable in class com.tangosol.persistence.AbstractPersistenceManager.BatchTasks
- 
List of tasks to execute.
- f_lock - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The ReadWriteLock used to protect against concurrent read/write operations.
- f_lock - Variable in class com.tangosol.util.SafeLongArray
- 
The lock to hold during read and write operations.
- f_lockReadRaw - Variable in class com.tangosol.util.ReadHeavyLongArray
- 
The raw read lock.
- f_lockWrite - Variable in class com.tangosol.util.ReadHeavyLongArray
- 
The write lock, delegating to the one in the super class.
- f_lRefresh - Variable in class com.tangosol.net.RefreshableAddressProvider
- 
The interval with which to attempt to refresh the address list.
- f_lRefresh - Variable in class com.tangosol.net.RefreshableAddressProvider.RefreshThread
- 
The interval with which to attempt to refresh the address list.
- f_lTimeoutOrig - Variable in class com.oracle.coherence.common.base.Timeout
- 
The original timeout before this instance changed it.
- f_manager - Variable in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
The underlying PersistenceManager.
- f_map - Variable in class com.tangosol.util.SetMap
- 
The underlying map.
- f_mapFilter - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
The map ofFiltersthat thisMapListenerProxywas registered with.
- f_mapForward - Variable in class com.tangosol.util.ForwardOnlyMapIndex
- 
Map that contains the index values (forward index).
- f_mapGUID - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
The Map of registered GUIDs, keyed by member.
- f_mapKeys - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
The map of keys that thisMapListenerProxywas registered with.
- f_mapSnapshots - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
The map of snapshots, keyed by snapshot name.
- f_mapStores - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
Map of open AbstractPersistentStore instances.
- f_mapTokens - Variable in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- f_mapTypeToSerializer - Variable in class com.tangosol.io.MultiplexingSerializer
- 
The mapping of types referenced by their String name and a workingSerializerfor that type.
- f_mbeanServerProxy - Variable in class com.tangosol.net.management.MBeanAccessor
- 
TheMBeanServerProxyto be used for MBean operations.
- f_message - Variable in class com.tangosol.io.WrapperBufferInput.VersionAwareBufferInput
- 
The associated message received by this recipient.
- f_message - Variable in class com.tangosol.io.WrapperBufferOutput.VersionAwareBufferOutput
- 
The associated message being sent.
- f_metrics - Variable in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
The proxy service metrics.
- f_mlTimeout - Variable in class com.oracle.coherence.common.base.Timeout
- 
Cached reference to the thread's MutableLong holding it's current timeout.
- f_nLength - Variable in class com.tangosol.io.MultiplexingSerializer.SerializationHeader
- 
The length, in bytes, of the serialized data.
- f_nUniqueId - Variable in class com.tangosol.util.SortedBag.UniqueElement
- 
The unique "id" for this element.
- f_oAssociation - Variable in class com.tangosol.persistence.AbstractPersistenceManager.BatchTasks
- 
Association for this BatchTasks.
- f_observer - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
TheStreamObserverto streamMapEventinstances to.
- f_oFrom - Variable in class com.tangosol.util.SortedBag.ViewBag
- 
The (inclusive) lower bound of this view.
- f_oKey - Variable in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
- 
The key to use to put the value into the cache.
- f_onPartial - Variable in class com.tangosol.util.processor.StreamingAsynchronousProcessor
- 
The user-provided callback that will be invoked for each partial result.
- f_openSentry - Variable in class com.tangosol.util.ThreadGateLite
- 
Sentry to return fromThreadGateLite.close()that willThreadGateLite.open()when the sentry is closed.
- f_oReceipt - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
The receipt to add to the Collector after the unit is committed.
- f_oResult - Variable in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
The actual result of executing a CohQLStatement.
- f_oTo - Variable in class com.tangosol.util.SortedBag.ViewBag
- 
The (exclusive) upper bound of this view.
- f_oToken - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
A token representing the atomic unit that will be committed asynchronously.
- f_oValue - Variable in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
- 
The value being inserted into the cache.
- f_policyPrimary - Variable in class com.tangosol.net.CompositeActionPolicy
- 
The primary ActionPolicy.
- f_policySecondary - Variable in class com.tangosol.net.CompositeActionPolicy
- 
The secondary ActionPolicy.
- f_pool - Variable in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- 
TheDaemonPoolassociated with this MBean.
- f_pool - Variable in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- 
TheDaemonPoolthat will be used to execute tasks.
- f_processor - Variable in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
- 
TheInvocableMap.EntryProcessorthat will perform the "update" command.
- f_processor - Variable in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- 
The delegateAsynchronousProcessor.
- f_processor - Variable in class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
The underlying entry processor.
- f_proxy - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy.DeactivationListener
- 
TheMapListenerProxy.
- f_request - Variable in class com.oracle.coherence.grpc.RequestHolder
- 
The request.
- f_resourceRegistry - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
TheResourceRegistryused to store various resources used by queries managed by this context.
- f_sAction - Variable in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder.ServicesQueryPlusStatement
- 
Flag indicating whether this command turns sanity checking on or off.
- f_sCache - Variable in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder.BackupStatement
- 
The name of the cache to be backed up.
- f_sCache - Variable in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder.CreateCacheStatement
- 
The name of the cache to be created by this command.
- f_sCache - Variable in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder.CreateIndexStatement
- 
The name of the cache the index will be added to.
- f_sCache - Variable in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder.DeleteStatement
- 
The cache name containing the entries to be deleted
- f_sCache - Variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.AsyncSelectStatement
- 
The name of the cache to query.
- f_sCache - Variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- 
The name of the cache to query.
- f_sCache - Variable in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
- 
The name of the cache to be updated.
- f_sCacheName - Variable in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder.DropCacheStatement
- 
The name of the cache to be destroyed.
- f_sCacheName - Variable in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder.DropIndexStatement
- 
The name of the cache the index will be added to.
- f_sCacheName - Variable in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
- 
The cache name to be used in the CohQL "insert" command.
- f_sCacheName - Variable in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder.QueryRecorderStatement
- 
The name of the cache to query.
- f_sCacheName - Variable in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder.RestoreStatement
- 
The cache name to be used in the CohQL "backup" command.
- f_sCacheName - Variable in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder.TruncateCacheStatement
- 
The name of the cache to be truncated.
- f_sClusterName - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
The cluster name.
- f_scopeResolver - Variable in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Scope resolver used to resolve scope name upon CCF construction.
- f_sDescription - Variable in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
- 
Handler description.
- f_sDescription - Variable in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
- f_serializer - Variable in class com.oracle.coherence.grpc.RequestHolder.DownConverter
- 
TheSerializerused to convert the originalBinaryinto object form.
- f_serializer - Variable in class com.oracle.coherence.grpc.RequestHolder
- 
TheSerializerused by the request.
- f_serializerFrom - Variable in class com.oracle.coherence.grpc.RequestHolder.UpConverter
- 
TheSerializerused to convert theBinaryto object form.
- f_serializerName - Variable in class com.tangosol.io.MultiplexingSerializer.SerializationHeader
- 
The name of the serializer that should be used to deserialize the payload.
- f_serializerProducer - Variable in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
The factory to use to lookup namedSerializerinstances.
- f_serializers - Variable in class com.tangosol.io.MultiplexingSerializer
- f_serializerTo - Variable in class com.oracle.coherence.grpc.RequestHolder.UpConverter
- 
TheSerializerused to convert the object to aBinary.
- f_service - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
The owningNamedCacheService.
- f_service - Variable in class com.oracle.coherence.grpc.RequestHolder
- 
TheServicemanaging the resource.
- f_service - Variable in class com.tangosol.net.cache.NearCache
- 
The back cache service.
- f_setDeletedIds - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The set of extent identifiers that are in the process of being deleted.
- f_setExtentIds - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The set of valid extent identifiers known to this persistent store.
- f_setKeys - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
The set of keys that thisMapListenerProxywas registered with.
- f_setTasks - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
Set of outstanding tasks.
- f_sFeature - Variable in class com.tangosol.coherence.config.xml.processor.UnsupportedFeatureProcessor
- 
The feature that is not supported
- f_sFile - Variable in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder.BackupStatement
- 
The file name to write the cache contents to.
- f_sFile - Variable in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder.RestoreStatement
- 
The file name to be used in the CohQL "backup" command.
- f_sFileName - Variable in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
- 
The file name to be used in the CohQL "source" command.
- f_sFormat - Variable in class com.oracle.coherence.grpc.RequestHolder
- 
The name of the serializer used to serialize the request payloads.
- f_sFunctor - Variable in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractOPToken
- 
The Functor string used by the parser for this token.
- f_sId - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The identifier of this persistent store.
- f_sName - Variable in class com.tangosol.net.cache.NearCache
- 
The cache name.
- f_sName - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The name of this AbstractPersistenceManager.
- f_span - Variable in class com.oracle.coherence.grpc.proxy.TracingDaemonPool.TracingRunnable
- 
TheSpan.
- f_spanParent - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
The parent tracing span.
- f_sServiceName - Variable in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Service name to carry out operations for.
- f_sServiceName - Variable in class com.tangosol.net.cache.NearCache
- 
The back cache service name.
- f_sServiceName - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
The service name.
- f_sSnapshotName - Variable in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Snapshot name to utilize.
- f_sSymbol - Variable in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
The symbol for this operator.
- f_store - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Store that holds cache references scoped by class loader and optionally, if configured, Subject.
- f_store - Variable in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
The underlying PersistentStore.
- f_storeFrom - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.OpenTask
- 
ThePersistentStoreto open with.
- f_storeTopics - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Store that holdsNamedTopicreferences scoped by class loader and optionally, if configured, Subject.
- f_supplierNamedCache - Variable in class com.tangosol.net.MapViewBuilder
- 
TheSupplierreturning aNamedCachefrom which the view will be created.
- f_thread - Variable in class com.tangosol.util.ThreadGateLite.Bar
- f_tokenDelegate - Variable in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
- 
TheIdentifierOPTokento delegate to if we cannot process the token.
- f_writer - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
ThePrintWriterto use to display output.
- f_xmlConfig - Variable in class com.tangosol.coherence.config.builder.ServiceLoadBalancerBuilder
- 
Xml Configuration Element to use to report ConfigurationException.
- Factory<T> - Interface in com.oracle.coherence.common.base
- 
The Factory interface provides a means of producing objects of a given type.
- FactoryBasedAddressProviderBuilder - Class in com.tangosol.coherence.config.builder
- 
This class builds an AddressProviderBuilder from a AddressProviderFactory.
- FactoryBasedAddressProviderBuilder(AddressProviderFactory) - Constructor for class com.tangosol.coherence.config.builder.FactoryBasedAddressProviderBuilder
- 
ConstructsFactoryBasedAddressProviderBuilder
- FAIL - com.tangosol.util.RegistrationBehavior
- 
Specifies that registration should fail (by raising an exception) if the identified artifact is already registered.
- FailOnFull() - Constructor for class com.tangosol.net.topic.Publisher.FailOnFull
- 
Default constructor for serialization.
- FailoverAccessPolicy - Class in com.tangosol.net.partition
- 
FailoverAccessPolicy is used to moderate the client request load during a failover event in order to allow cache servers adequate opportunity to re-establish partition backups.
- FailoverAccessPolicy() - Constructor for class com.tangosol.net.partition.FailoverAccessPolicy
- 
Default constructor.
- FailoverAccessPolicy(long, long, long) - Constructor for class com.tangosol.net.partition.FailoverAccessPolicy
- 
Construct a FailoverAccessPolicy according to the specified parameters.
- FailoverAccessPolicy.MembershipListener - Class in com.tangosol.net.partition
- 
The MemberListener is used to listen to service membership events to monitor the endangered status of the service.
- FakeBinaryStore() - Constructor for class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
- FALSE - Static variable in class com.tangosol.util.Binary
- 
A Binary representation ofBoolean.FALSEvalue.
- fatalError(SAXParseException) - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
- 
Routine called when a fatal error occurs in parser.
- fContend - Variable in class com.tangosol.util.SegmentedHashMap.Segment
- 
Are any threads contending to lock this segment?
- FederatedChangeEvents - Annotation Type in com.tangosol.net.events.annotation
- 
EntryEventInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveFederatedChangeEvents.
- FederatedConnectionEvents - Annotation Type in com.tangosol.net.events.annotation
- 
EntryEventInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveFederatedConnectionEvents.
- FederatedPartitionEvents - Annotation Type in com.tangosol.net.events.annotation
- 
EntryEventInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveFederatedPartitionEvents.
- FEDERATION_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the FederationMBean.
- FederationEventHandlers - Class in com.oracle.coherence.cdi.server
- 
Federation event handlers that allow CDI observers to handle any federation event.
- FederationEventHandlers() - Constructor for class com.oracle.coherence.cdi.server.FederationEventHandlers
- fForward - Variable in class com.tangosol.util.AbstractSparseArray.Crawler
- FIELD_LIST - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The AST node name for a Field List Node.
- FILE_CFG_CACHE - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The default configuration file name.
- FILE_CFG_CACHE - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The default configuration file name.
- FILE_MAPPED - Static variable in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
A file mapped backup storage.
- FileHelper - Class in com.tangosol.io
- 
A Collection of helper methods for files.
- FileHelper() - Constructor for class com.tangosol.io.FileHelper
- fill() - Method in class com.tangosol.net.partition.PartitionSet
- 
Fill the set to contain all the partitions.
- FILL_BUFFER - Static variable in class com.tangosol.io.nio.BinaryMap
- 
Byte array used for wiping the buffer.
- FILL_BYTE - Static variable in class com.tangosol.io.nio.BinaryMap
- 
Byte used as a fill byte.
- filter(Filter<?>) - Method in class com.tangosol.net.MapViewBuilder
- 
TheFilterthat will be used to define the entries maintained in this view.
- filter(Filter<?>) - Method in class com.tangosol.net.ViewBuilder
- 
TheFilterthat will be used to define the entries maintained in this view.
- filter(Remote.DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the elements of this stream that match the given predicate.
- filter(Remote.IntPredicate) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the elements of this stream that match the given predicate.
- filter(Remote.LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the elements of this stream that match the given predicate.
- filter(Remote.Predicate<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream that match the given predicate.
- filter(DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the elements of this stream that match the given predicate.
- filter(IntPredicate) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the elements of this stream that match the given predicate.
- filter(LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the elements of this stream that match the given predicate.
- filter(Predicate<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream that match the given predicate.
- filter(ContainerRequestContext) - Method in class com.tangosol.coherence.rest.providers.SecurityFilter
- Filter<T> - Interface in com.tangosol.util
- 
Provide for "pluggable" conditional behavior.
- filterArray(Object[], int, Filter) - Static method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Apply the specified filter to the specified array elements.
- filterArray(Object[], Filter) - Static method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Apply the specified filter to the elements of the specified array.
- FilterBinding - Annotation Type in com.oracle.coherence.cdi
- 
Specifies that an annotation type is aFilterbinding type.
- FilterBuilder - Class in com.tangosol.coherence.dslquery
- 
FilterBuilder is a visitor class that converts a given Abstract Syntax Tree into a Filter.
- FilterBuilder() - Constructor for class com.tangosol.coherence.dslquery.FilterBuilder
- 
Construct a new FilterBuilder.
- FilterBuilder(CoherenceQueryLanguage) - Constructor for class com.tangosol.coherence.dslquery.FilterBuilder
- 
Construct a new FilterBuilder.
- FilterBuilder(Term) - Constructor for class com.tangosol.coherence.dslquery.FilterBuilder
- 
Construct a new FilterBuilder that can construct a Filter from the given Term.
- FilterBuilder(Object[]) - Constructor for class com.tangosol.coherence.dslquery.FilterBuilder
- 
Construct a new FilterBuilder with given binding environment.
- FilterBuilder(Object[], Map) - Constructor for class com.tangosol.coherence.dslquery.FilterBuilder
- 
Construct a new FilterBuilder with given binding environment.
- FilterBuilder(List, ParameterResolver, CoherenceQueryLanguage) - Constructor for class com.tangosol.coherence.dslquery.FilterBuilder
- 
Construct a new FilterBuilder with given default bind variables.
- FilterBuildingException - Exception in com.tangosol.util
- 
FilterBuildingException is the RuntimeException thrown by theQueryHelperwhen building aFilter.
- FilterBuildingException() - Constructor for exception com.tangosol.util.FilterBuildingException
- 
Construct a new FilterBuildingException.
- FilterBuildingException(String, String) - Constructor for exception com.tangosol.util.FilterBuildingException
- 
Construct a new FilterBuildingException with the given error string along with the string that was being parsed.
- FilterBuildingException(String, String, Throwable) - Constructor for exception com.tangosol.util.FilterBuildingException
- 
Construct a new FilterBuildingException with the given error string, the string that was being parsed and a base exception.
- Filtered() - Constructor for class com.tangosol.net.topic.Subscriber.Filtered
- 
Default constructor for serialization.
- Filtered(Filter<? super V>) - Constructor for class com.tangosol.net.topic.Subscriber.Filtered
- FilterEnumerator - Class in com.tangosol.util
- 
Provide a generic implementation of an enumerator which can enumerate items based on an inclusion test.
- FilterEnumerator(Object[], Filter) - Constructor for class com.tangosol.util.FilterEnumerator
- 
Construct the Filter enumerator based on an array of objects.
- FilterEnumerator(Enumeration, Filter) - Constructor for class com.tangosol.util.FilterEnumerator
- 
Construct the Filter enumerator based on an Enumeration.
- FilterEnumerator(Iterator, Filter) - Constructor for class com.tangosol.util.FilterEnumerator
- 
Construct the Filter enumerator based on an Iterator.
- FilterEvent(MapEvent, Filter[]) - Constructor for class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Constructs a new FilterEvent that wraps the given MapEvent.
- FilterEvent(ObservableMap, int, Object, boolean, boolean, Filter[]) - Constructor for class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Constructs a new lite (no values are specified) FilterEvent.
- FilterEvent(ObservableMap, int, Object, boolean, Filter[]) - Constructor for class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Constructs a new lite (no values are specified) FilterEvent.
- FilterEvent(ObservableMap, int, Object, Object, Object, boolean, boolean, Filter[]) - Constructor for class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Constructs a new FilterEvent.
- FilterEvent(ObservableMap, int, Object, Object, Object, boolean, CacheEvent.TransformationState, boolean, boolean, Filter[]) - Constructor for class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Constructs a new FilterEvent.
- FilterEvent(ObservableMap, int, Object, Object, Object, boolean, CacheEvent.TransformationState, boolean, Filter[]) - Constructor for class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Constructs a new FilterEvent.
- FilterEvent(ObservableMap, int, Object, Object, Object, boolean, CacheEvent.TransformationState, Filter[]) - Constructor for class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Constructs a new FilterEvent.
- FilterFactory<A extends Annotation,T> - Interface in com.oracle.coherence.cdi
- 
A factory that produces instances ofFilterfor a givenAnnotation.
- FilterInfo(long, boolean) - Constructor for class com.oracle.coherence.grpc.proxy.MapListenerProxy.FilterInfo
- 
Constructs a new FilterInfo instance.
- FilterProducer - Class in com.oracle.coherence.cdi
- 
A CDI bean that producesFilterinstances usingFilterFactorybeans annotated withFilterBindingannotations.
- FilterProducer.AlwaysFilterSupplier - Class in com.oracle.coherence.cdi
- 
AFilterFactorythat producesAlwaysFilterinstances.
- FilterProducer.WhereFilterSupplier - Class in com.oracle.coherence.cdi
- 
AFilterFactorythat producesFilterinstances from a CohQL where clause.
- Filters - Class in com.tangosol.util
- 
Simple Filter DSL.
- Filters() - Constructor for class com.tangosol.util.Filters
- filterSort(Object[], int, Comparator, Filter) - Static method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Filter the specified array elements and sort any matching elements using the specified comparator.
- filterSort(Object[], Comparator, Filter) - Static method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Filter the elements in the specified array and sort any matching elements using the specified comparator.
- filtersTokenTable() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return an initialized standardTokenTableknown by this CoherenceQueryLanguage.
- FilterTrigger - Class in com.tangosol.util.filter
- 
A generic Filter-based MapTrigger implementation.
- FilterTrigger() - Constructor for class com.tangosol.util.filter.FilterTrigger
- 
Default constructor (necessary for the ExternalizableLite interface).
- FilterTrigger(Filter<T>) - Constructor for class com.tangosol.util.filter.FilterTrigger
- 
Construct a FilterTrigger based on the specified Filter object and ACTION_ROLLBACK.
- FilterTrigger(Filter<T>, int) - Constructor for class com.tangosol.util.filter.FilterTrigger
- 
Construct a FilterTrigger based on the specified Filter object and the action constant.
- finalize() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Perform cleanup during garbage collection.
- finalize() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
Finalize the holder, deleting the database if it is temporary.
- finalize() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
Automatically release the lock on finalization.
- finalize() - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Finalize for the DatabaseFactory.
- finalize() - Method in class com.tangosol.io.nio.MappedBufferManager
- 
Perform cleanup during garbage collection.
- finalizeResult() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- finalizeResult() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- finalizeResult() - Method in class com.tangosol.util.aggregator.AbstractAggregator
- finalizeResult() - Method in class com.tangosol.util.aggregator.CompositeAggregator
- finalizeResult() - Method in class com.tangosol.util.aggregator.Count
- finalizeResult() - Method in class com.tangosol.util.aggregator.GroupAggregator
- finalizeResult() - Method in class com.tangosol.util.aggregator.PriorityAggregator
- finalizeResult() - Method in class com.tangosol.util.aggregator.QueryRecorder
- finalizeResult() - Method in class com.tangosol.util.aggregator.ScriptAggregator
- finalizeResult() - Method in class com.tangosol.util.aggregator.TopNAggregator
- finalizeResult() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
Return the final result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Obtain the result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Obtain the result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
Obtain the result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.AbstractDoubleAggregator
- 
Obtain the result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.AbstractLongAggregator
- 
Obtain the result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.BigDecimalAverage
- 
Obtain the result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.DistinctValues
- 
Obtain the result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.DoubleAverage
- 
Obtain the result of the aggregation.
- finalizeResult(boolean) - Method in class com.tangosol.util.aggregator.ReducerAggregator
- 
Obtain the result of the aggregation.
- find(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Find the specified key and return its node.
- findAdapter(XmlBean.BeanInfo, XmlElement) - Method in class com.tangosol.run.xml.IterableAdapter
- 
Obtain a PropertyAdapapter for a map entry key or value
- findAdapter(String) - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Find a property adapter instance for the specified property.
- findAny() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns anOptionalDoubledescribing some element of the stream, or an emptyOptionalDoubleif the stream is empty.
- findAny() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns anOptionalIntdescribing some element of the stream, or an emptyOptionalIntif the stream is empty.
- findAny() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns anOptionalLongdescribing some element of the stream, or an emptyOptionalLongif the stream is empty.
- findAny() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anOptionaldescribing some element of the stream, or an emptyOptionalif the stream is empty.
- findAttribute(XmlElement) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Find an attribute of the specified XmlElement that represents a value for a property represented by this adapter.
- findAttribute(String) - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Find the Term amoungst the children whose functor equals the given functor that has a singleton child.
- findCacheMapping(String) - Method in class com.tangosol.coherence.config.CacheMappingRegistry
- 
Deprecated.Attempts to find theCacheMappingthat matches the specified cache name.
- findCacheMapping(String) - Method in interface com.tangosol.coherence.config.ResourceMappingRegistry
- 
Attempts to find theCacheMappingthat matches the specified name and type.
- findCachingScheme(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Return theCachingSchemefor a given cache name.
- findCachingScheme(String, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.SchemeRefPreprocessor
- 
Obtains theXmlElementthat contains a <scheme-name> definition for the specified sSchemeName with in the providedXmlElement, ornullif not found.
- findChild(int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Find the child value with the specified index.
- findChild(String) - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Find the Term amoungst the children whose functor equals the given functor.
- findChild(String) - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Find the Term amoungst the children whose functor equals the given functor.
- findChildInternal(int, int, int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Find the child value with the specified index.
- findChildInternal(int, int, int) - Method in class com.tangosol.io.pof.reflect.PofArray
- 
Find the child value with the specified index.
- findChildInternal(int, int, int) - Method in class com.tangosol.io.pof.reflect.PofSparseArray
- 
Find the child value with the specified index.
- findConstructor() - Method in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Find a key class constructor that accepts a single String argument.
- findDistributedScheme(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Return theDistributedSchemefor a given cache name.
- findElement(XmlElement) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Find a child element of the specified XmlElement that represents a value for a property represented by this adapter.
- findElement(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Find a child element of the specified element with the specified '/'-delimited path.
- findElement(XmlElement, String, Object) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Find a child element of the specified element with the specified '/'-delimited path and specified value.
- findElement(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Find a child element with the specified '/'-delimited path.
- findElement(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Find a child element with the specified '/'-delimited path.
- findEntry(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- 
Find an entry with the specified key.
- findEntryBlock(Binary) - Method in class com.tangosol.io.nio.BinaryMap
- 
Find the Entry block with the specified key.
- findFileOrResource(String, ClassLoader) - Static method in class com.oracle.coherence.common.base.Resources
- 
Return a URL to the specified file or resource, using the specified class loader or acontext ClassLoader.
- findFirst() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns anOptionalDoubledescribing the first element of this stream, or an emptyOptionalDoubleif the stream is empty.
- findFirst() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns anOptionalIntdescribing the first element of this stream, or an emptyOptionalIntif the stream is empty.
- findFirst() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns anOptionalLongdescribing the first element of this stream, or an emptyOptionalLongif the stream is empty.
- findFirst() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anOptionaldescribing the first element of this stream, or an emptyOptionalif the stream is empty.
- findInsertionPoint(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Find the point at which a Node with the specified index would be inserted.
- findJMXServiceUrl(String) - Method in class com.tangosol.net.management.JmxmpServer
- findJMXServiceUrl(String) - Method in interface com.tangosol.net.management.MBeanServerFinder
- 
Find the JMXServiceURL for the MBeanConnector used by the Coherence JMX framework.
- findJMXServiceUrl(String, GatewayDependencies) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Find the JMXServiceURL for the MBeanConnector used by the Coherence JMX framework.
- findMapping(String, Class<M>) - Method in interface com.tangosol.coherence.config.ResourceMappingRegistry
- 
Attempts to find theResourceMappingthat matches the specified name and type.
- findMapping(String, Class<M>) - Method in class com.tangosol.coherence.config.SchemeMappingRegistry
- findMatchingOPToken(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- findMBeanServer() - Static method in class com.tangosol.net.management.MBeanHelper
- 
Find an MBeanServer that Coherence MBeans are registered with.
- findMBeanServer(String) - Method in class com.tangosol.net.management.JmxmpServer
- findMBeanServer(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Find an MBeanServer that has the specified default domain name.
- findMBeanServer(String) - Method in interface com.tangosol.net.management.MBeanServerFinder
- 
Find an MBeanServer that should be used by the Coherence JMX framework to register new or locate existing MBeans.
- findMBeanServer(String, GatewayDependencies) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Find an MBeanServer that has the specified default domain name.
- findMethod(Class, String, Class[], boolean) - Static method in class com.oracle.coherence.common.base.Classes
- 
Find a Method that matches the specified name and parameter types.
- findMethod(Class, String, Class[], boolean) - Static method in class com.tangosol.util.ClassHelper
- 
Find a Method that matches the specified name and parameter types.
- findMethod(Class, String, String...) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Find aMethodwith the specified name and parameter types in the specified class.
- findMethod(Class, MBeanOperationInfo) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Find aMethodfor the specifiedMBeanOperationInfoin the specified MBean class or interface.
- findMethod(String) - Method in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Find a static method with a specified name that accepts a single String argument.
- findProperty(List<ClassNode>, String) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Attempt to find a property with a given name in one of the specified class definitions.
- findProperty(ClassNode, String) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Attempt to find a property getter with a given name in the specified class definitions.
- findPublicKeys(Subject) - Method in class com.tangosol.net.security.DefaultController
- 
Find a set of public keys for the specified Subject.
- findRelativeOrAbsoluteResource(String, ClassLoader) - Static method in class com.oracle.coherence.common.base.Resources
- 
Find the URL of the resource with the given name using the specifiedClassLoader.
- findResource(String, ClassLoader) - Static method in class com.oracle.coherence.common.base.Resources
- 
Find the URL of the resource with the given name using the specified ClassLoader or the following Classes: The Thread ContextClassLoaderTheClassLoaderused to loadClasses, which represents the Coherence Class Loader The SystemClassLoader
- findScheme(XmlElement, String) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.In the specified configuration XML, find a "scheme" element associated with the specified scheme name.
- findScheme(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.In the configuration XML find a "scheme" element associated with a given scheme name.
- findSchemeByCacheName(String) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Find theCachingSchemefor the specified cache name.
- findSchemeBySchemeName(String) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Find theServiceSchemegiven the scheme name.
- findSchemeBySchemeName(String) - Method in class com.tangosol.coherence.config.ServiceSchemeRegistry
- 
Attempts to locate aServiceSchemeregistered with the specifiedScheme.getSchemeName().
- findSchemeByServiceName(String) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Find theServiceSchemegiven the service name.
- findSchemeByServiceName(String) - Method in class com.tangosol.coherence.config.ServiceSchemeRegistry
- 
Attempts to locate aServiceSchemeregistered with the specifiedServiceScheme.getServiceName()giving preference to "autostart" schemes.
- findSchemeByTopicName(String) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Find theCachingSchemefor the specified topic name.
- findSchemeMapping(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.In the configuration XML find a "cache-mapping" element associated with a given cache name.
- findServiceScheme(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.In the configuration XML find a "scheme" element associated with a given service name.
- findSession(String) - Static method in class com.tangosol.net.Coherence
- findSessionsByScope(String) - Static method in class com.tangosol.net.Coherence
- findSpan() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- 
Return the current active span, or try to find the span in the currentContext.
- findTopicScheme(String) - Method in class com.tangosol.net.topic.TopicBackingMapManager
- 
Find theNamedTopicSchemethat defines a topic.
- fine(String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.FINEseverity.
- fine(String, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.FINEseverity.
- fine(Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) withLogger.FINEseverity.
- fine(Supplier<String>) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.FINEseverity.
- fine(Supplier<String>, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.FINEseverity.
- FINE - Static variable in class com.oracle.coherence.common.base.Logger
- 
Severity 5 indicates an essential debug message.
- finer(String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.FINERseverity.
- finer(String, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.FINERseverity.
- finer(Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) withLogger.FINERseverity.
- finer(Supplier<String>) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.FINERseverity.
- finer(Supplier<String>, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.FINERseverity.
- FINER - Static variable in class com.oracle.coherence.common.base.Logger
- 
Severity 6 indicates a non-essential debug message.
- finest(String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.FINESTseverity.
- finest(String, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.FINESTseverity.
- finest(Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) withLogger.FINESTseverity.
- finest(Supplier<String>) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.FINESTseverity.
- finest(Supplier<String>, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.FINESTseverity.
- FINEST - Static variable in class com.oracle.coherence.common.base.Logger
- 
Severity 7 indicates a very low-level, non-essential debug message or a tracing message.
- finishStarting(Daemon.DaemonWorker) - Method in class com.tangosol.util.Daemon
- 
Wait for the specified worker to finish starting.
- finishStopping(Daemon.DaemonWorker, long) - Method in class com.tangosol.util.Daemon
- 
Wait for the specified worker to finish stopping.
- finishUse() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Decrement the use count for this block and check if it is now zero.
- FiniteStateMachine<S extends Enum<S>> - Interface in com.tangosol.util.fsm
- 
AFiniteStateMachineimplements a general purpose finite-state-machine.
- FiniteStateMachineListener<S extends Enum<S>> - Interface in com.tangosol.util.fsm
- 
A FiniteStateMachineListener listens for state related events on aFiniteStateMachine.
- fireEvent(MapEvent, boolean) - Method in class com.tangosol.util.MapListenerSupport
- 
Fire the specified map event.
- first() - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Return the first property in this PropertySet.
- first() - Method in class com.tangosol.net.partition.PartitionSet
- 
Return an index of the first marked partition.
- first() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- first() - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns the first element currently in this sorted set.
- first() - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedSet
- 
Returns the first (lowest) element currently in this sorted set.
- first() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- first() - Method in class com.tangosol.util.SortedBag
- 
Returns the first (lowest) element currently in this bag.
- first() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
- FIRST - com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent.Process
- 
FIRST indicates that the first submittedEventfor a specific discriminator will be the one which is processed.
- firstEntry() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- firstKey() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- firstKey() - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedMap
- 
Returns the first (lowest) key currently in this sorted map.
- firstKey() - Method in class com.tangosol.util.SafeSortedMap
- firstKey() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- firstKey() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- fixed(ConfigurableCacheFactory...) - Static method in interface com.oracle.coherence.grpc.proxy.ConfigurableCacheFactorySuppliers
- 
Returns an instance of a fixed supplier that only returns one of the specified set ofConfigurableCacheFactoryinstances.
- FIXED - com.tangosol.util.SimpleMapIndex.IndexCalculator.CalculatorState
- FixedCacheFactorySupplier(ConfigurableCacheFactory...) - Constructor for class com.oracle.coherence.grpc.proxy.ConfigurableCacheFactorySuppliers.FixedCacheFactorySupplier
- fixedClient() - Static method in class com.tangosol.net.Coherence
- 
Create a defaultCoherenceclient instance, creating it if it does not already exist.
- fixedClient(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
- 
Create a clientCoherenceinstance from the specifiedCoherenceConfiguration.
- fixedClientBuilder(CoherenceConfiguration) - Static method in class com.tangosol.net.Coherence
- 
Returns aCoherence.Builderinstance that can build aCoherenceinstance using the specifiedCoherenceConfiguration.
- FixedElementCalculator - Class in com.tangosol.net.topic
- 
A fixed implementation of aNamedTopic.ElementCalculatorthat gives all elements a size of 1.
- FixedElementCalculator() - Constructor for class com.tangosol.net.topic.FixedElementCalculator
- fixNanos(Date) - Static method in class com.tangosol.io.pof.PofBufferWriter
- 
Return aDatewhich is suitable for POF serialization
- FLASHJOURNAL - Static variable in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
A Flash Journal backup storage.
- FlashJournalScheme - Class in com.tangosol.coherence.config.scheme
- 
TheFlashJournalSchemeis used to create an instance of a Flash Journal map.
- FlashJournalScheme() - Constructor for class com.tangosol.coherence.config.scheme.FlashJournalScheme
- flatMap(Remote.DoubleFunction<? extends DoubleStream>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMap(Remote.Function<? super T, ? extends Stream<? extends R>>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMap(Remote.IntFunction<? extends IntStream>) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMap(Remote.LongFunction<? extends LongStream>) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMap(DoubleFunction<? extends DoubleStream>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMap(Function<? super T, ? extends Stream<? extends R>>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMap(IntFunction<? extends IntStream>) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMap(LongFunction<? extends LongStream>) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMapToDouble(Remote.Function<? super T, ? extends DoubleStream>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anDoubleStreamconsisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMapToDouble(Function<? super T, ? extends DoubleStream>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anDoubleStreamconsisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMapToInt(Remote.Function<? super T, ? extends IntStream>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anIntStreamconsisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMapToInt(Function<? super T, ? extends IntStream>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anIntStreamconsisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMapToLong(Remote.Function<? super T, ? extends LongStream>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anLongStreamconsisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatMapToLong(Function<? super T, ? extends LongStream>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anLongStreamconsisting of the results of replacing each element of this stream with the contents of a mapped stream produced by applying the provided mapping function to each element.
- flatten(Object[][], int, Object[]) - Static method in class com.tangosol.util.ImmutableMultiList
- 
Create a single dimensional array containing all elements of the specified array of arrays.
- flip() - Method in class com.tangosol.coherence.dslquery.operator.ComparisonOperator
- 
Return the operator to use if this operation needs to be flipped due to the CohQL statement having the literal on the left hand side.
- flip() - Method in class com.tangosol.coherence.dslquery.operator.EqualsOperator
- flip() - Method in class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
- flip() - Method in class com.tangosol.coherence.dslquery.operator.GreaterOperator
- flip() - Method in class com.tangosol.coherence.dslquery.operator.LessEqualsOperator
- flip() - Method in class com.tangosol.coherence.dslquery.operator.LessOperator
- flip() - Method in class com.tangosol.coherence.dslquery.operator.NotEqualsOperator
- FLOAT_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
- 
An empty array of floats.
- FloatAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.FloatAdapter
- 
Construct a SimpleAdapter.
- FloatArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Construct a FloatArrayAdapter.
- floatingPointFormatError() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
A problem has been detected in a floating point number.
- FLOATLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
The numberic code for a float literal
- FLOATLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
The numberic code for a float literal
- floatValue() - Method in class com.oracle.coherence.common.base.MutableLong
- floatValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Returns the current value of thisAsyncAtomicIntegeras afloatafter a widening primitive conversion.
- floatValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Returns the current value of thisDistributedAtomicLongas afloatafter a widening primitive conversion.
- floatValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- floatValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- floatValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- floatValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- floatValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Returns the current value of thisAtomicIntegeras afloatafter a widening primitive conversion.
- floatValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Returns the current value of thisAtomicLongas afloatafter a widening primitive conversion.
- floatValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- floatValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- floatValue() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- floatValue() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- floatValue() - Method in class com.tangosol.io.pof.RawQuad
- 
Returns the value of the specified number as afloat.
- floor(long) - Method in class com.tangosol.util.AbstractSafeLongArray
- floor(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Return the "first" value with an index which is less than or equal to the specified index.
- floor(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- floor(long) - Method in interface com.tangosol.util.LongArray
- 
Return the "first" value with an index which is less than or equal to the specified index.
- floor(long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- floor(long) - Method in class com.tangosol.util.SimpleLongArray
- floor(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- floor(Object) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- floorEntry(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- floorIndex(long) - Method in class com.tangosol.util.AbstractSafeLongArray
- floorIndex(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Return the "first" index which is less than or equal to the specified index.
- floorIndex(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- floorIndex(long) - Method in interface com.tangosol.util.LongArray
- 
Return the "first" index which is less than or equal to the specified index.
- floorIndex(long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- floorIndex(long) - Method in class com.tangosol.util.SimpleLongArray
- floorIndex(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- floorKey(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- FlowControl - Interface in com.tangosol.net
- 
Communication facilities that provide an asynchronous (non-blocking) way of submitting data exchange requests commonly implement mechanisms of modulating the control flow for underlying data transfer units (e.g. messages or packets).
- flush() - Method in interface com.oracle.coherence.common.base.Collector
- 
Request processing of any added values.
- flush() - Static method in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- 
Ensure that any deferred signals will be processed.
- flush() - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Flushes this OutputStream and forces any buffered output bytes to be written.
- flush() - Method in class com.tangosol.io.Base64OutputStream
- 
Close the stream, flushing any accumulated bytes.
- flush() - Method in class com.tangosol.io.DebugDataOutputStream
- 
Flushes this OutputStream and forces any buffered output bytes to be written.
- flush() - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Flush any accumulated bytes.
- flush() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Close the Block object by resetting its contents and recycling the object.
- flush() - Method in class com.tangosol.io.nio.ByteBufferOutputStream
- 
Flush any accumulated bytes.
- flush() - Method in class com.tangosol.io.pof.PofOutputStream
- 
Flushes this OutputStream and forces any buffered output bytes to be written.
- flush() - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- flush() - Method in class com.tangosol.io.Utf8Writer
- 
Flush the stream.
- flush() - Method in class com.tangosol.io.WrapperBufferOutput
- 
Flushes this OutputStream and forces any buffered output bytes to be written.
- flush() - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Flushes this OutputStream and forces any buffered output bytes to be written.
- flush() - Method in class com.tangosol.io.WrapperOutputStream
- 
Flushes this OutputStream and forces any buffered output bytes to be written.
- flush() - Method in class com.tangosol.io.WriterPrintStream
- 
Flush the stream.
- flush() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- flush() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Flush the write-behind queue, writing everything immediately.
- flush() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Asynchronous flush, i.e. effectively mark all currently queue'd entries as ripe.
- flush() - Method in class com.tangosol.net.cache.SerializationCache
- 
Deprecated.
- flush() - Method in class com.tangosol.net.DatagramPacketOutputStream
- 
Flushes this output stream and forces any buffered output bytes to be written out.
- flush() - Method in interface com.tangosol.net.FlowControl
- 
Ensure that any buffered asynchronous operations are dispatched to the underlying tier.
- flush() - Method in interface com.tangosol.net.topic.Publisher
- 
Obtain aCompletableFuturethat will be complete when all of the currently outstanding publish operations complete.
- flush() - Method in class com.tangosol.util.AsynchronousAgent
- flush() - Method in class com.tangosol.util.ExternalizableHelper.ShieldedDataOutputStream
- flush() - Method in class com.tangosol.util.ExternalizableHelper.ShieldedObjectOutputStream
- flush() - Method in class com.tangosol.util.ExternalizableHelper.ShieldedOutputStream
- flush() - Method in class com.tangosol.util.NullImplementation.NullCollector
- 
Request processing of any added values.
- flush() - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- 
Flushes this OutputStream and forces any buffered output bytes to be written.
- flush() - Method in class com.tangosol.util.NullImplementation.NullWriter
- flush(int, SingleWaiterCooperativeNotifier) - Static method in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- 
Ensure that any deferred signals will be processed.
- flush(ReadWriteBackingMap.WriteQueue, ReadWriteBackingMap.StoreWrapper) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Flush the write-behind queue, writing everything immediately.
- flushAccumulator() - Method in class com.tangosol.io.Base64OutputStream
- 
Flushes the bytes accumulated by the write(int) method.
- FMT_B_ARRAY - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Byte array value.
- FMT_BIN_DECO - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Decorated Binary value.
- FMT_BIN_EXT_DECO - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Extended-range Decorated Binary value.
- FMT_BINARY - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Binary value.
- FMT_BINDIFF - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
A format indicator (the first byte of the binary delta) that indicates that the new value is formed by applying a series of modifications to the old value.
- FMT_BOOLEAN - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Boolean value.
- FMT_BYTE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Byte value.
- FMT_DECIMAL - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: BigDecimal value.
- FMT_DOUBLE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Double value.
- FMT_EMPTY - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
A format indicator (the first byte of the binary delta) that indicates that the new value is a zero-length binary value.
- FMT_EXT - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: A DefaultSerializer is NOT used.
- FMT_FLOAT - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Float value.
- FMT_IDO - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Integer-decorated value.
- FMT_INT - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Integer value.
- FMT_INTEGER - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: BigInteger value.
- FMT_LONG - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Long value.
- FMT_NONE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Unknown value (alias to FMT_UNKNOWN).
- FMT_NULL - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Null value.
- FMT_OBJ_EXT - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: ExternalizableLite value.
- FMT_OBJ_SER - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Serializable value.
- FMT_OPT - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Optional value.
- FMT_OPT_DOUBLE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: OptionalDouble value.
- FMT_OPT_INT - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: OptionalInt value.
- FMT_OPT_LONG - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: OptionalLong value.
- FMT_REPLACE - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
A format indicator (the first byte of the binary delta) that indicates that the new value is found in its entirety in the delta value.
- FMT_SHORT - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Short value.
- FMT_STRING - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: String value.
- FMT_UNKNOWN - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: Unknown value.
- FMT_XML_BEAN - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: XmlBean value.
- FMT_XML_SER - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Serialization format: XmlSerializable value.
- FORCE_RESOLVING_STREAMS - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Option: Always use a ResolvingObjectInputStream, even if a regular ObjectInputStream is available.
- forceRecovery() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Proceed with recovery despite the dynamic quorum policy objections.
- ForceRecoveryStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder.ForceRecoveryStatement
- 
Create a ForceRecoveryStatement that will force recovery.
- ForceRecoveryStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aForceRecoveryStatementBuilder.ForceRecoveryStatement.
- ForceRecoveryStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder
- ForceRecoveryStatementBuilder.ForceRecoveryStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "FORCE RECOVERY" command.
- forceSync() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Indicate the future write operations must be synchronous.
- forEach(Filter, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.util.QueryMap
- 
Perform the given action for each entry selected by the specified filter until all entries have been processed or the action throws an exception.
- forEach(Collection<? extends K>, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.cache.CacheMap
- 
Perform the given action for each entry selected by the specified key set until all entries have been processed or the action throws an exception.
- forEach(Collection<? extends K>, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.NamedCache
- 
Perform the given action for each entry selected by the specified key set until all entries have been processed or the action throws an exception.
- forEach(Collection<? extends K>, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.NamedMap
- 
Perform the given action for each entry selected by the specified key set until all entries have been processed or the action throws an exception.
- forEach(BiConsumer) - Method in class com.tangosol.util.SafeSortedMap
- forEach(BiConsumer) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- forEach(BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.util.QueryMap
- 
Perform the given action for each entry in this map until all entries have been processed or the action throws an exception.
- forEach(BiConsumer<? super K, ? super V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- forEach(BiConsumer<? super K, ? super V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- forEach(Consumer<? super E>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- forEach(Consumer<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs an action for each element of this stream.
- forEach(DoubleConsumer) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Performs an action for each element of this stream.
- forEach(IntConsumer) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Performs an action for each element of this stream.
- forEach(LongConsumer) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Performs an action for each element of this stream.
- forEachOrdered(Consumer<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs an action for each element of this stream, in the encounter order of the stream if the stream has a defined encounter order.
- forEachOrdered(DoubleConsumer) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Performs an action for each element of this stream, guaranteeing that each element is processed in encounter order for streams that have a defined encounter order.
- forEachOrdered(IntConsumer) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Performs an action for each element of this stream, guaranteeing that each element is processed in encounter order for streams that have a defined encounter order.
- forEachOrdered(LongConsumer) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Performs an action for each element of this stream, guaranteeing that each element is processed in encounter order for streams that have a defined encounter order.
- forgetDatabase(Database) - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Remove a database handle from the cleanup list.
- forgetDatabase(Database) - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Remove a database handle from the cleanup list.
- forKeys(Set<K>) - Method in interface com.tangosol.util.Filter
- 
Return a filter that will only be evaluated within specified key set.
- format(Date) - Static method in class com.tangosol.run.xml.DateTimeAdapter
- 
Return an ISO8601 string for the date/time represented by this Calendar.
- FORMAT_OUTPUT - Static variable in interface com.tangosol.coherence.rest.io.Marshaller
- 
The name of the system property that is used to determine whether the marshaller output should be formatted for human readability.
- formatAction(int) - Static method in class com.tangosol.net.ClusterPermission
- 
Format the action string.
- FormatAwareCompressor(DeltaCompressor) - Constructor for class com.tangosol.util.ExternalizableHelper.FormatAwareCompressor
- 
Construct a FormatAwareCompressor.
- formatDate(int, int, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Format a date in the form YYYY-MM-DD.
- formatDateTime(long) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format a long value into a human readable date/time string.
- formatDateTime(long) - Static method in class com.tangosol.util.Base
- 
Format a long value into a human readable date/time string.
- formatIndex(int) - Static method in class com.tangosol.io.nio.BinaryMap
- 
Format an index to a String.
- formatKeys(Set, String) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Generate a log message containing the keys from the specified set of entries.
- formatOffset(int) - Static method in class com.tangosol.io.nio.BinaryMap
- 
Format an offset to a String.
- formatOffsetArray(int[]) - Static method in class com.tangosol.io.nio.BinaryMap
- 
Format an array of offsets to be readable in a dump.
- formatStatusName(int) - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Return a human readable name for the specified status value.
- FormattedMapStatementResult - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementResultwhich assumes the result is aMapwith value being aObjectorObject[].
- FormattedMapStatementResult(Object) - Constructor for class com.tangosol.coherence.dslquery.statement.FormattedMapStatementResult
- 
Construct an instance with the given result which will should be aMap.
- formatTime(int, int, int, int, boolean) - Static method in class com.tangosol.io.pof.PofHelper
- 
Format a time using the simplest applicable of the following formats: HH:MM HH:MM:SS HH:MM:SS.MMM HH:MM:SS.NNNNNNNNN
- formatTime(int, int, int, int, int, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Format a time using the simplest applicable of the following formats: HH:MM(+|-)HH:MM HH:MM:SS(+|-)HH:MM HH:MM:SS.MMM(+|-)HH:MM HH:MM:SS.NNNNNNNNN(+|-)HH:MM
- Formatting - Class in com.oracle.coherence.common.base
- 
Class for providing formatting functionality for various types.
- Formatting() - Constructor for class com.oracle.coherence.common.base.Formatting
- formatUTF(byte[], int, char[], int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Format the passed characters as UTF into the passed byte array.
- formatUTF(byte[], int, int, String) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Format the passed String as UTF into the passed byte array.
- forMethod(Method) - Static method in interface com.tangosol.util.ValueExtractor
- 
Return aValueExtractorfor the specifiedMethod.
- forPartitions(PartitionSet) - Method in interface com.tangosol.util.Filter
- 
Return a partitioned filter for a specified partition set.
- forServiceLoader() - Static method in class com.tangosol.util.comparator.PriorityComparator
- 
Returns aComparatorthat can sortServiceLoader.Providerinstances based on whether the class they provide is annotated with thePriorityannotation.
- ForwardOnlyMapIndex - Class in com.tangosol.util
- 
ForwardOnlyMapIndex is aMapIndeximplementation that unlike theSimpleMapIndexmaintains only a forward index and not the inverse index.
- ForwardOnlyMapIndex(ValueExtractor, BackingMapContext, boolean) - Constructor for class com.tangosol.util.ForwardOnlyMapIndex
- 
Construct an index for the given map.
- FOUND - Static variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
- fragment(ValueExtractor<? super T, ?>...) - Static method in class com.tangosol.util.Extractors
- 
Return aValueExtractorthat extracts aFragmentfrom a target object.
- fragment(ValueExtractor<? super T, E>, ValueExtractor<? super E, ?>...) - Static method in class com.tangosol.util.Extractors
- 
Return aValueExtractorthat extracts a nestedFragmentfrom a property of the target object.
- Fragment<T> - Class in com.tangosol.util
- 
An object that represents a fragment of another object.
- Fragment() - Constructor for class com.tangosol.util.Fragment
- 
Deserialization constructor.
- Fragment(Map<String, Object>) - Constructor for class com.tangosol.util.Fragment
- 
ConstructFragmentinstance.
- FragmentExtractor<T> - Class in com.tangosol.util.extractor
- 
AValueExtractorthat is used to extract aFragmentfrom an object.
- FragmentExtractor() - Constructor for class com.tangosol.util.extractor.FragmentExtractor
- 
Deserialization constructor.
- FragmentExtractor(ValueExtractor<? super T, ?>[]) - Constructor for class com.tangosol.util.extractor.FragmentExtractor
- 
ConstructFragmentExtractorinstance.
- free() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Free this Entry block.
- FREE - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
State of a block that is available for use.
- from(MapEvent) - Static method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
- 
Creates aPassThroughCacheEntryEventbased on aMapEvent
- from(Object) - Static method in class com.tangosol.io.pof.RawDate
- 
Create RawDate from the specified object.
- from(Object) - Static method in class com.tangosol.io.pof.RawDateTime
- 
Create RawDateTime from the specified object.
- from(Object) - Static method in class com.tangosol.io.pof.RawTime
- 
Create RawTime from the specified object.
- from(Date) - Static method in class com.tangosol.io.pof.RawDate
- 
Create a RawDate from the JDBC Date.
- from(Time) - Static method in class com.tangosol.io.pof.RawTime
- 
Create a RawTime from the JDBC Time.
- from(Timestamp) - Static method in class com.tangosol.io.pof.RawDateTime
- 
Create RawDateTime from the specified Timestamp.
- from(LocalDate) - Static method in class com.tangosol.io.pof.RawDate
- 
Create a RawDate from the LocalDate.
- from(LocalDateTime) - Static method in class com.tangosol.io.pof.RawDateTime
- 
Create RawDateTime from the specified LocalDateTime.
- from(LocalTime) - Static method in class com.tangosol.io.pof.RawTime
- 
Create RawTime from LocalTime.
- from(OffsetDateTime) - Static method in class com.tangosol.io.pof.RawDateTime
- 
Create RawDateTime from the specified OffsetDateTime.
- from(OffsetTime) - Static method in class com.tangosol.io.pof.RawTime
- 
Create RawTime from OffsetTime.
- from(Date) - Static method in class com.tangosol.io.pof.RawDate
- 
Create a RawDate from the Java Date.
- from(Date) - Static method in class com.tangosol.io.pof.RawDateTime
- 
Create RawDateTime from the specified Date.
- from(Date) - Static method in class com.tangosol.io.pof.RawTime
- 
Create a RawTime from the Java Date.
- fromBinary(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Obtain the value deserialized from the specifiedBinaryusing the cache's serializer.
- fromBinary(Binary) - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Translate the passed Binary object into an Object object.
- fromBinary(Binary) - Method in class com.tangosol.net.cache.SerializationMap
- 
Translate the passed Binary object into an Object object.
- fromBinary(Binary) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Translate the passed Binary object into an Object object.
- fromBinary(Binary) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a Binary object.
- fromBinary(Binary, Serializer) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Deserialize a serializedBinary.
- fromBinary(Binary, Serializer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a Binary object using the specified Serializer.
- fromBinary(Binary, Serializer, Remote.Function<ReadBuffer.BufferInput, ReadBuffer.BufferInput>) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a Binary object using the specified Serializer.
- fromBinary(Binary, Serializer, Remote.Function<ReadBuffer.BufferInput, ReadBuffer.BufferInput>, Class<T>) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a Binary object using the specified Serializer and expected class.
- fromBinary(Binary, Serializer, Class<T>) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a Binary object using the specified Serializer and expected class.
- fromBinary(Binary, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a Binary object.
- fromBoxedTypeField(String) - Static method in class com.oracle.coherence.common.base.Classes
- 
Provide a boxed version of the given primitive in binary format.
- fromByteArray(byte[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a byte array.
- fromByteArray(byte[], ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a byte array.
- fromByteString(ByteString, Serializer) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
A utility method to deserialize aByteStringto an Object.
- fromBytesValue(BytesValue, Serializer) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
A utility method to deserialize aBytesValueto an Object.
- fromClientName(String) - Static method in enum com.tangosol.net.Coherence.Mode
- 
Return theCoherence.Modefor the given client name.
- fromdir - Variable in class com.tangosol.util.AbstractSparseArray.Crawler
- fromInt(int) - Static method in enum com.tangosol.util.aggregator.QueryRecorder.RecordType
- 
Convert an integer value to an RecordType
- fromInternal(Object) - Method in class com.tangosol.coherence.jcache.common.CoherenceConverterAdapter
- fromInternal(Object) - Method in interface com.tangosol.coherence.jcache.common.InternalConverter
- 
Converts an internal representation of a value to a value.
- fromInternal(Object) - Method in class com.tangosol.coherence.jcache.common.ReferenceInternalConverter
- fromInternal(Object) - Method in class com.tangosol.coherence.jcache.common.SerializingInternalConverter
- fromInternal(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Deserialize the providedBinaryvalue.
- fromKey() - Method in interface com.tangosol.util.ValueExtractor
- 
Obtain a version of thisValueExtractorthat targets an entry's key.
- fromPof(int...) - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that extracts the value of the specified index(es) from a POF encoded binary value.
- fromPof(Class<E>, int...) - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that extracts the value of the specified index(es) from a POF encoded binary value.
- fromPof(Class<E>, PofNavigator) - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that extracts the value of the specified index(es) from a POF encoded binary value.
- fromPof(Class<E>, String) - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that extracts the value of the specified index(es) from a POF encoded@PortableType.
- fromString(String) - Method in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Convert a string representation of a key into its object form.
- fromString(String) - Method in interface com.tangosol.coherence.rest.KeyConverter
- 
Convert a string representation of a key into its object form.
- fromString(String) - Static method in class com.tangosol.coherence.rest.util.PropertySet
- 
Create a PropertySet from its textual representation.
- fromString(String) - Static method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Create a PropertySpec from its textual representation.
- fromUri(String) - Method in class com.tangosol.run.xml.DateTimeAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.RestrictedStringAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SerializableAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.BigDecimalAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.BigIntegerAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.BooleanAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.ByteAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.CharAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.DoubleAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.FloatAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.IntAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.LongAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.ShortAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.StringAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.SystemTimeAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.TimeAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- 
Deserialize an object from a URI element.
- fromUri(String) - Method in interface com.tangosol.run.xml.UriSerializable
- 
Deserialize the object from a URI String.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.DateFormatAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.DateTimeAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.IterableAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.QNameAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.RestrictedStringAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SerializableAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.BigDecimalAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.BigIntegerAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.BooleanAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.ByteAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.CharAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.DateAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.DoubleAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.FloatAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.IntAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.LongAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.ShortAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.SystemTimeAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.TimeAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Deserialize the object from an XmlElement.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.SimpleElement
- 
Deserialize the object from an XmlElement.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.XmlBean
- 
Deserialize the object from an XmlElement.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.XmlElementAdapter
- 
Deserialize an object from an XML element.
- fromXml(XmlElement) - Method in interface com.tangosol.run.xml.XmlSerializable
- 
Deserialize the object from an XmlElement.
- fromXml(XmlElement) - Method in class com.tangosol.run.xml.XmlSerializableAdapter
- 
Deserialize an object from an XML element.
- fromXmlString(XmlElement) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Deserialize a primitive array from a single XML element.
- fromXmlString(XmlElement) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Deserialize a primitive array from a single XML element.
- fromXmlString(XmlElement) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Deserialize a primitive array from a single XML element.
- fromXmlString(XmlElement) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Deserialize a primitive array from a single XML element.
- FrontFilterConverter() - Constructor for class com.tangosol.net.cache.SimpleOverflowMap.FrontFilterConverter
- FrontMapListener() - Constructor for class com.tangosol.net.cache.CachingMap.FrontMapListener
- FrontMapListener() - Constructor for class com.tangosol.net.cache.OverflowMap.FrontMapListener
- FrontMapListener() - Constructor for class com.tangosol.net.cache.SimpleOverflowMap.FrontMapListener
- fullFormString() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Answer a String representation of the Term that is allowed to show more internal details than toString() which does not compress information.
- fullFormString() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Answer a String representation of the Term that is allowed to show more internal details than toString() which does not compress information.
- fullFormString() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Answer a String representation of the Term that is allowed to show more internal details than toString() which does not compress information.
- function(Remote.Function<T, R>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable Function.
- FunctionBuilders - Class in com.tangosol.coherence.dslquery.function
- 
This class contains a number ofParameterizedBuilderimplementations for the standard built-in CohQL functions.
- FunctionBuilders() - Constructor for class com.tangosol.coherence.dslquery.function.FunctionBuilders
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLArchiveSnapshotOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLCreateSnapshotOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLForceRecoveryOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLListArchivedSnapshotsOPToken
- 
The functor name used to represent this node in an AST.
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLListArchiverOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLListServicesOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLListSnapshotsOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLRecoverSnapshotOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLRemoveSnapshotOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLResumeServiceOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLRetrieveSnapshotOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLSuspendServiceOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.persistence.SQLValidateSnapshotOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLBackupOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLCreateCacheOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLCreateIndexOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLDeleteOPToken
- 
The functor name used to represent this node in an AST.
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLDropCacheOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLDropIndexOPToken
- 
The functor name used to represent this node in an AST.
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLExplainOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLInsertOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLRestoreOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLSelectOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLSourceOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLTraceOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLTruncateCacheOPToken
- 
The functor name used to represent this node in an AST
- FUNCTOR - Static variable in class com.tangosol.coherence.dslquery.token.SQLUpdateOPToken
- 
The functor name used to represent this node in an AST
G
- Gar - com.tangosol.net.Coherence.Mode
- 
TheCoherenceinstance has been created from a gar.
- Gate<R> - Interface in com.tangosol.util
- 
A thin extension ofGate.
- generateEnvironmentName() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Generate a potentially unique Environment name.
- generateGUID(int, long, long, Member) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Generate and return a new GUID for the specified partition.
- generateName() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Generates a unique name for the interceptor.
- get() - Method in interface com.oracle.coherence.common.base.Holder
- 
Return the held object.
- get() - Method in class com.oracle.coherence.common.base.MutableLong
- 
Return the current value.
- get() - Method in interface com.oracle.coherence.common.base.Nullable
- 
Return the raw value of thisNullable.
- get() - Method in class com.oracle.coherence.common.base.SimpleHolder
- 
Return the held object.
- get() - Method in class com.oracle.coherence.common.base.VolatileHolder
- 
Return the held object.
- get() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicBoolean
- 
Returns the current value.
- get() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Returns the current value.
- get() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Returns the current value.
- get() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Returns the current value.
- get() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
- get() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- get() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- get() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- get() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- get() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- get() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- get() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- get() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicBoolean
- 
Returns the current value.
- get() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Returns the current value.
- get() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Returns the current value.
- get() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Returns the current value.
- get() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- get() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- get() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- get() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- get() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- get() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- get() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- get() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- get() - Method in class com.tangosol.coherence.config.unit.Bytes
- 
Obtain theMemorySizein bytes.
- get() - Method in class com.tangosol.coherence.config.unit.Megabytes
- 
Obtain theMemorySizein megabytes.
- get() - Method in class com.tangosol.coherence.config.unit.Millis
- 
Obtain theDurationin units of milliseconds.
- get() - Method in class com.tangosol.coherence.config.unit.Seconds
- 
Obtain theDurationin units of seconds.
- get() - Method in class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor.DefaultPasswordProvider
- 
Returns the password.
- get() - Method in class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
- get() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Gets the internal value (without updating the access time).
- get() - Method in class com.tangosol.config.expression.Value
- get() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- get() - Method in class com.tangosol.net.InputStreamPasswordProvider
- get() - Method in interface com.tangosol.net.PasswordProvider
- 
Returns the password to be used in clear format.
- get() - Static method in interface com.tangosol.net.SessionProvider
- 
Acquire theSessionProviderto use to create sessions.
- get() - Method in class com.tangosol.util.AsynchronousAgent
- get() - Method in class com.tangosol.util.ConverterCollections.ConverterHolder
- get() - Method in class com.tangosol.util.ThreadLocalObject
- 
Get the value of the ThreadLocalObject for the current thread.
- get(boolean[]) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicMarkableReference
- 
Returns the current values of both the reference and the mark.
- get(boolean[]) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
- get(boolean[]) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- get(boolean[]) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicMarkableReference
- 
Returns the current values of both the reference and the mark.
- get(boolean[]) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- get(boolean[]) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- get(int) - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
- 
Return the BaseToken at the given index
- get(int) - Method in class com.tangosol.util.CircularArrayList
- get(int) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- get(int) - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns the element at the specified position in this List.
- get(int) - Method in class com.tangosol.util.ImmutableMultiList
- 
Returns the element at the specified position in this List.
- get(int) - Method in class com.tangosol.util.InflatableList
- get(int) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Returns the element at the specified position in this list.
- get(int) - Method in class com.tangosol.util.SafeLinkedList
- 
Returns the element at the specified position in this List.
- get(int) - Method in class com.tangosol.util.SubList
- get(int) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- get(int[]) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicStampedReference
- 
Returns the current values of both the reference and the stamp.
- get(int[]) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
- get(int[]) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- get(int[]) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicStampedReference
- 
Returns the current values of both the reference and the stamp.
- get(int[]) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- get(int[]) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- get(long) - Method in class com.tangosol.util.AbstractLongArray
- 
Return the value stored at the specified index.
- get(long) - Method in class com.tangosol.util.AbstractSafeLongArray
- get(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Return the value stored at the specified index.
- get(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- get(long) - Method in interface com.tangosol.util.LongArray
- 
Return the value stored at the specified index.
- get(long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- get(long) - Method in class com.tangosol.util.SimpleLongArray
- 
Return the value stored at the specified index.
- get(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- get(long, TimeUnit) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- get(long, TimeUnit) - Method in class com.tangosol.util.AsynchronousAgent
- get(Nullable<? extends T>) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Return the value of the specifiedNullable.
- get(CacheRequestHolder<GetRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theGetRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of theGetRequestrequest as a serialized Boolean.
- get(GetRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Get a value for a given key from a cache.
- get(GetRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- get(GetRequest, StreamObserver<OptionalValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- get(PropertySet, Request) - Method in class com.tangosol.coherence.rest.EntryResource
- 
Return the entry value or a subset of its properties.
- get(SessionProvider.Option...) - Static method in interface com.tangosol.net.SessionProvider
- 
Deprecated.since 20.12SessionProvider.Optionis deprecated useSessionProvider.get()
- get(XmlBean) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Extract the property value from the passed bean reference.
- get(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Get the property value from the passed Entry object.
- get(ValueExtractor<? super T, ? extends E>) - Method in class com.tangosol.util.Fragment
- 
Get the value of the attribute extracted by the specified extractor.
- get(ID) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return an entity with a given identifier.
- get(ID) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return an entity with a given identifier.
- get(ID, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the value extracted from an entity with a given identifier.
- get(ID, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the value extracted from an entity with a given identifier.
- get(Comparable) - Method in class com.tangosol.util.Tree
- 
Find the specified key and return its value.
- get(Integer) - Method in class com.tangosol.io.pof.EvolvableHolder
- 
Return anEvolvablefor the specified type id.
- get(Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- get(Object) - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.CachingMap
- get(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- get(Object) - Method in class com.tangosol.net.cache.LocalCache
- 
If the specified item is in the cache, return it.
- get(Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.OverflowMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EvictingBackupMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SerializationMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- get(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.ChainedMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in interface com.tangosol.util.ConcurrentMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.ConditionalIndex
- 
Using the index information if possible, get the value associated with the specified key.
- get(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- get(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- get(Object) - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Using the index information if possible, get the value associated with the specified key.
- get(Object) - Method in class com.tangosol.util.KeyValueArrayMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- get(Object) - Method in class com.tangosol.util.OpenHashMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.SafeHashMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.SafeSortedMap
- get(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- get(Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns the value to which this map maps the specified key.
- get(Object) - Method in class com.tangosol.util.SetMap
- get(Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Using the index information if possible, get the value associated with the specified key.
- get(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- get(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- get(Object) - Method in class com.tangosol.util.WrapperObservableMap
- 
Returns the value to which this map maps the specified key.
- get(String) - Static method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Return theRemoteExecutorfor the given name.
- get(String) - Method in class com.tangosol.coherence.rest.util.PartialObject
- 
Get a property value.
- get(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- get(String) - Method in interface com.tangosol.persistence.SnapshotArchiver
- 
Return aSnapshotwhich represents the archived snapshot with the given identifier.
- get(String) - Method in class com.tangosol.util.Fragment
- 
Get the value of the attribute with the specified name or positional index.
- get(String) - Method in class com.tangosol.util.StringTable
- 
Find the specified string in the table and return its value.
- get(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aGetRequest.
- get(K) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- get(K) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- get(K) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- get(K) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- get(K) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Returns the value to which the specified key is mapped, ornullif this map contains no mapping for the key.
- get(K) - Method in interface com.tangosol.util.MapIndex
- 
Using the index information if possible, get the value associated with the specified key.
- getAbandonedCount() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getAbandonedThreadCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getAbandonedThreadCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the total number of abandoned Daemon threads.
- getAbsolutePath() - Method in class com.tangosol.run.xml.SimpleElement
- 
Get the '/'-delimited path of the element starting from the root element.
- getAbsolutePath() - Method in interface com.tangosol.run.xml.XmlElement
- 
Get the '/'-delimited path of the element starting from the root element.
- getAbsolutePath(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Get the '/'-delimited path of the passed element starting from the root element.
- getAcceptAddress() - Method in interface com.tangosol.net.NameService.RequestContext
- 
Get theInetAddressthat the NameService received the request on.
- getAccessCount() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Gets the number of times the internal value has been accessed.
- getAccessCount() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Gets the number of times the internal value has been accessed.
- getAccessor() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Obtain the Method object that is used to call the property accessor.
- getAccessTime() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Gets the time (since the Epoc) in milliseconds since the internal value was last accessed.
- getAccessTime() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Gets the time (since the Epoc) in milliseconds since the internal value was last accessed.
- getAction() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.HostnameVerifierBuilder
- 
The action to take on a name mismatch.
- getAction() - Method in class com.tangosol.util.filter.FilterTrigger
- 
Obtain the action code for this FilterTrigger.
- getAction() - Method in class com.tangosol.util.fsm.Transition
- 
Obtains theTransitionActionto be performed for theTransition.
- getActionName(int) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Return the string description of the given rule mask.
- getActionPolicy() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of an ActionPolicy.
- getActions() - Method in class com.tangosol.net.ClusterPermission
- 
Return the actions as a String in a canonical form.
- getActivatedCount() - Method in class com.tangosol.coherence.jcache.common.ContainerHelper.JCacheLifecycleInterceptor
- 
Added for Coherence JCache functional testing.
- getActiveMillis() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getActivePageArray() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Get the array of BinaryStore objects, one for each active page.
- getActivePageCount() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Determine the number of pages that the PagedBinaryStore is currently managing.
- getActualBackupCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the number of backups to maintain, given the actual set of ownership-enabled and leaving members.
- getAdapters() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Obtain the PropertyAdapter objects for the properties of this XML bean.
- getAdapters() - Method in class com.tangosol.run.xml.XmlBean
- 
Obtain the PropertyAdapter objects for this XmlBean.
- getAdded() - Method in class com.tangosol.util.DeltaSet
- 
Determine what items were added to the delta set.
- getAddress() - Method in interface com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics.ConnectionMetricsMBean
- 
Returns the remote address of the connection.
- getAddress() - Method in interface com.tangosol.net.Member
- 
Return the IP address of the Member's DatagramSocket for point-to-point communication.
- getAddress() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the IP address of the Member's DatagramSocket for point-to-point communication.
- getAddress() - Method in class com.tangosol.util.UID
- 
Determine the internet address of the host that generated the UID instance (or a random number if no internet address was available)
- getAddress() - Method in class com.tangosol.util.UUID
- 
Determine the internet address of the host that generated the UUID instance.
- getAddressDescriptions() - Method in class com.tangosol.net.CompositeAddressProvider
- 
Retrieve a human readable description of underlying addresses.
- getAddressDescriptions() - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Retrieve a human readable description of underlying addresses.
- getAddressDescriptions() - Method in interface com.tangosol.net.DescribableAddressProvider
- 
Retrieve a human readable description of underlying addresses.
- getAddressDescriptions() - Method in class com.tangosol.net.RefreshableAddressProvider
- 
Retrieve a human readable description of underlying addresses.
- getAddressDescriptions(Collection) - Static method in class com.tangosol.net.InetAddressHelper
- 
Return an array of strings representing addresses in the specified collection.
- getAddressProvider() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of anAddressProvider.
- getAddressProviderMap() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the address provider map.
- getAddressProviderMap() - Method in interface com.tangosol.net.OperationalContext
- 
Return a Map of address provider factories.
- getAdvanceFrequency() - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Get the frequency at which the DatagramSocket will advance over the sub-sockets during receive
- getAdvanceFrequency() - Method in interface com.tangosol.net.TcpDatagramSocketProvider.Dependencies
- 
Get the frequency at which the DatagramSocket will advance over the sub-sockets during receive
- getAdvice() - Method in exception com.tangosol.config.ConfigurationException
- 
Returns advice to resolve the issue.
- getAggregator() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.AsyncSelectStatement
- 
Return theInvocableMap.EntryAggregatorto use to execute this query.
- getAggregator() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- 
Return theInvocableMap.EntryAggregatorto use to execute this query.
- getAggregator() - Method in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
- 
Return the underlying streaming aggregator.
- getAggregator() - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Obtain the underlying EntryAggregator.
- getAggregator() - Method in class com.tangosol.util.aggregator.PriorityAggregator
- 
Obtain the underlying aggregator.
- getAggregator(String) - Method in class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
- 
Returns a configured aggregator.
- getAggregator(String...) - Method in interface com.tangosol.coherence.rest.util.aggregator.AggregatorFactory
- 
Returns an aggregator instance.
- getAggregator(String...) - Method in class com.tangosol.coherence.rest.util.aggregator.DefaultAggregatorFactory
- 
Return an aggregator instantiated by calling an aggregator class constructor.
- getAggregatorClass() - Method in class com.tangosol.coherence.rest.config.AggregatorConfig
- 
Determine the class of the aggregator or aggregator factory.
- getAggregatorName() - Method in class com.tangosol.coherence.rest.config.AggregatorConfig
- 
Determine the name of the aggregator.
- getAggregatorRegistry() - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Return the configured aggregator registry.
- getAggregators() - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Obtain the EntryAggregator array.
- getAlias(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the String that represents the cache name alias from the given AST node by looking for the "alias" term in the AST.
- getAliases() - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
Return the alternative symbols to use in CohQL that represent this operator.
- getAll() - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return all entities in this repository.
- getAll() - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return all entities in this repository.
- getAll(CacheRequestHolder<GetAllRequest, Void>, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theGetAllRequestrequest and send the results to theStreamObserver.
- getAll(GetAllRequest, StreamObserver<Entry>) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Obtain a stream of mappings of keys to values for all of the specified keys.
- getAll(GetAllRequest, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- getAll(GetAllRequest, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- getAll(Filter<?>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return all entities that satisfy the specified criteria.
- getAll(Filter<?>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return all entities that satisfy the specified criteria.
- getAll(Filter<?>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Get all the entries that satisfy the specified filter.
- getAll(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return a map of values extracted from a set of entities based on the specified criteria.
- getAll(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return a map of values extracted from a set of entities based on the specified criteria.
- getAll(Filter<?>, ValueExtractor<? super T, ? extends R>, BiConsumer<? super ID, ? super R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Streams the id and the associated extracted value from a set of entities based on the specified criteria.
- getAll(Filter<?>, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Get all the entries that satisfy the specified filter.
- getAll(Filter<?>, Consumer<? super Map.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Get all the entries that satisfy the specified filter.
- getAll(Filter<?>, Consumer<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Stream all entities that satisfy the specified criteria.
- getAll(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return a map of values extracted from all entities in the repository.
- getAll(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return a map of values extracted from all entities in the repository.
- getAll(ValueExtractor<? super T, ? extends R>, BiConsumer<? super ID, ? super R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Streams the id and the associated extracted value from all entities in the repository.
- getAll(String, String, String, Iterable<ByteString>) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aGetAllRequest.
- getAll(Collection) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getAll(Collection) - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Get all the specified keys, if they are in the Map.
- getAll(Collection) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Get all the specified keys, if they are in the Map.
- getAll(Collection) - Method in class com.tangosol.net.cache.LocalCache
- 
Get all the specified keys, if they are in the cache.
- getAll(Collection) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Get all the specified keys, if they are in the cache.
- getAll(Collection) - Method in class com.tangosol.net.cache.OverflowMap
- 
Get all the specified keys, if they are in the Map.
- getAll(Collection) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Retrieve values for all the specified keys.
- getAll(Collection) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Get all the specified keys, if they are in the cache.
- getAll(Collection<? extends ID>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the entities with the specified identifiers.
- getAll(Collection<? extends ID>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the entities with the specified identifiers.
- getAll(Collection<? extends ID>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return a map of values extracted from a set of entities with the given identifiers.
- getAll(Collection<? extends ID>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return a map of values extracted from a set of entities with the given identifiers.
- getAll(Collection<? extends ID>, ValueExtractor<? super T, ? extends R>, BiConsumer<? super ID, ? super R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Stream the entities associated with the specified ids to the provided callback.
- getAll(Collection<? extends ID>, Consumer<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Stream the entities associated with the specified ids to the provided callback.
- getAll(Collection<? extends K>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Get all the specified keys, if they are in the map.
- getAll(Collection<? extends K>) - Method in interface com.tangosol.net.cache.CacheMap
- 
Get all the specified keys, if they are in the cache.
- getAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.CachingMap
- 
Get all the specified keys, if they are in the cache.
- getAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- getAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Get all the specified keys, if they are in the Map.
- getAll(Collection<? extends K>) - Method in interface com.tangosol.net.NamedMap
- 
Get all the specified keys, if they are in the map.
- getAll(Collection<? extends K>) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Get all the specified keys, if they are in the Map.
- getAll(Collection<? extends K>, BiConsumer<? super K, ? super V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream the entries associated with the specified keys to the provided callback.
- getAll(Collection<? extends K>, Consumer<? super Map.Entry<? extends K, ? extends V>>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream the entries associated with the specified keys to the provided callback.
- getAll(Collection<? extends TK>) - Method in class com.tangosol.util.ConverterCollections.ConverterCacheMap
- 
Get all the specified keys, if they are in the cache.
- getAll(Consumer<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Stream all entities all entities in this repository.
- getAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- getAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- getAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- getAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- getAllFromFrontMap(Collection<? extends K>) - Method in class com.tangosol.net.cache.CachingMap
- 
Retrieve entries from the front map.
- getAllInternal(Collection<? extends K>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Return multiple values from the back cache, transforming them in the process if necessary.
- getAllOrderedBy(Filter<?>, Remote.Comparator<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return all entities that satisfy the specified criteria, sorted using specifiedRemote.Comparator.
- getAllOrderedBy(Filter<?>, Remote.Comparator<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return all entities that satisfy the specified criteria, sorted using specifiedRemote.Comparator.
- getAllOrderedBy(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return all entities that satisfy the specified criteria, sorted using specifiedComparableattribute.
- getAllOrderedBy(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return all entities that satisfy the specified criteria, sorted using specifiedComparableattribute.
- getAllOrderedBy(Remote.Comparator<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return all entities in this repository, sorted using specifiedRemote.Comparator.
- getAllOrderedBy(Remote.Comparator<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return all entities in this repository, sorted using specifiedRemote.Comparator.
- getAllOrderedBy(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return all entities in this repository, sorted using specifiedComparableattribute.
- getAllOrderedBy(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return all entities in this repository, sorted using specifiedComparableattribute.
- getAnalysisDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the number of milliseconds the analysis should be delayed;0Lsuggests immediate analysis.
- getAndAccumulate(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 previous value.
- getAndAccumulate(int, Remote.IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- getAndAccumulate(int, Remote.IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- getAndAccumulate(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 previous value.
- getAndAccumulate(int, Remote.IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- getAndAccumulate(int, Remote.IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- getAndAccumulate(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 previous value.
- getAndAccumulate(int, IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- getAndAccumulate(int, IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- getAndAccumulate(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 previous value.
- getAndAccumulate(int, IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- getAndAccumulate(int, IntBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- getAndAccumulate(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 previous value.
- getAndAccumulate(long, Remote.LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- getAndAccumulate(long, Remote.LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- getAndAccumulate(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 previous value.
- getAndAccumulate(long, Remote.LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- getAndAccumulate(long, Remote.LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- getAndAccumulate(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 previous value.
- getAndAccumulate(long, LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- getAndAccumulate(long, LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- getAndAccumulate(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 previous value.
- getAndAccumulate(long, LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- getAndAccumulate(long, LongBinaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- getAndAccumulate(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 previous value.
- getAndAccumulate(V, Remote.BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- getAndAccumulate(V, Remote.BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- getAndAccumulate(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 previous value.
- getAndAccumulate(V, Remote.BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- getAndAccumulate(V, Remote.BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- getAndAccumulate(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 previous value.
- getAndAccumulate(V, BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- getAndAccumulate(V, BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- getAndAccumulate(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 previous value.
- getAndAccumulate(V, BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- getAndAccumulate(V, BinaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- getAndAdd(int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically adds the given value to the current value.
- getAndAdd(int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- getAndAdd(int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- getAndAdd(int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically adds the given value to the current value.
- getAndAdd(int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- getAndAdd(int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- getAndAdd(long) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- getAndAdd(long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- getAndAdd(long) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- getAndAdd(long) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- getAndDecrement() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically decrements the current value.
- getAndDecrement() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically decrements the current value.
- getAndDecrement() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- getAndDecrement() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- getAndDecrement() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- getAndDecrement() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- getAndDecrement() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically decrements the current value.
- getAndDecrement() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically decrements the current value.
- getAndDecrement() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- getAndDecrement() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- getAndDecrement() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- getAndDecrement() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- getAndIncrement() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically increments the current value.
- getAndIncrement() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically increments the current value.
- getAndIncrement() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- getAndIncrement() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- getAndIncrement() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- getAndIncrement() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- getAndIncrement() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically increments the current value.
- getAndIncrement() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically increments the current value.
- getAndIncrement() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- getAndIncrement() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- getAndIncrement() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- getAndIncrement() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- getAndPut(K, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- getAndPut(K, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- getAndPut(K, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- getAndPut(K, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- getAndRemove(K) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- getAndRemove(K) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- getAndRemove(K) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- getAndRemove(K) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- getAndReplace(K, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- getAndReplace(K, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- getAndReplace(K, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- getAndReplace(K, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- getAndSet(boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicBoolean
- 
Atomically sets the value tonewValueand returns the old value.
- getAndSet(boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
- getAndSet(boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- getAndSet(boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicBoolean
- 
Atomically sets the value tonewValueand returns the old value.
- getAndSet(boolean) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- getAndSet(boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- getAndSet(int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically sets the value tonewValueand returns the old value.
- getAndSet(int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- getAndSet(int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- getAndSet(int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically sets the value tonewValueand returns the old value.
- getAndSet(int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- getAndSet(int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- getAndSet(long) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically sets the value tonewValueand returns the old value.
- getAndSet(long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- getAndSet(long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- getAndSet(long) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically sets the value tonewValueand returns the old value.
- getAndSet(long) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- getAndSet(long) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- getAndSet(V) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Atomically sets the value tonewValueand returns the old value.
- getAndSet(V) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- getAndSet(V) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- getAndSet(V) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Atomically sets the value tonewValueand returns the old value.
- getAndSet(V) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- getAndSet(V) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- getAndUpdate(Remote.IntUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(Remote.IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- getAndUpdate(Remote.IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- getAndUpdate(Remote.IntUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(Remote.IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- getAndUpdate(Remote.IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- getAndUpdate(Remote.LongUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(Remote.LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- getAndUpdate(Remote.LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- getAndUpdate(Remote.LongUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(Remote.LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- getAndUpdate(Remote.LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- getAndUpdate(Remote.UnaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(Remote.UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- getAndUpdate(Remote.UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- getAndUpdate(Remote.UnaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(Remote.UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- getAndUpdate(Remote.UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- getAndUpdate(IntUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- getAndUpdate(IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- getAndUpdate(IntUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- getAndUpdate(IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- getAndUpdate(LongUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- getAndUpdate(LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- getAndUpdate(LongUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- getAndUpdate(LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- getAndUpdate(UnaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- getAndUpdate(UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- getAndUpdate(UnaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Atomically updates the current value with the results of applying the given function, returning the previous value.
- getAndUpdate(UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- getAndUpdate(UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- getAnnouncingMemberSet() - Method in interface com.tangosol.net.Cluster.MemberTimeoutAction
- 
Return the set of Members who are "announcing".
- getAppendingBufferOutput() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Get a BufferOutput object to write data to this buffer.
- getAppendingBufferOutput() - Method in interface com.tangosol.io.WriteBuffer
- 
Get a BufferOutput object to write data to this buffer.
- getApplicationContext() - Method in interface com.tangosol.net.CoherenceConfiguration
- 
Return the optional applicationContextassociated to thisCoherenceinstance.
- getApplicationContext() - Method in class com.tangosol.net.CoherenceConfiguration.SimpleConfig
- getApplicationName() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getApplicationName() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return the optional application name to use if loading a GAR file.
- getApplicationName() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- getArchiverPersistenceTools(ExtensibleConfigurableCacheFactory, String, String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return an implementation specific instance of PersistenceTools for the given archived snapshot.
- getArgs() - Method in class com.tangosol.util.AbstractScript
- 
Return the arguments to be passed to the script during evaluation.
- getArgs() - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- 
Return the method arguments.
- getArrayOffset(Binary) - Method in class com.tangosol.util.Unsafe
- 
Return the offset into theunderlying byte arrayfor the specified Binary.
- getAssignableValue(Class<?>, Parameter, ParameterResolver, ClassLoader) - Static method in class com.tangosol.coherence.config.builder.ParameterizedBuilderHelper
- 
Obtains an assignment compatible value of the required type given an actualParameter.
- getAssociatedEntry(String, K1) - Method in interface com.tangosol.util.BinaryEntry
- 
Return an associated entry from the specified map, obtaining exclusive access to that map entry.
- getAssociatedEntry(String, K1, boolean) - Method in interface com.tangosol.util.BinaryEntry
- 
Return an associated entry from the specified map, obtaining either an exclusive or shared (read-only) access to that map entry.
- getAssociatedKey() - Method in interface com.oracle.coherence.common.base.Associated
- 
Determine the host key (or base) object to which this object is associated.
- getAssociatedKey() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
Determine the host key (or base) object to which this object is associated.
- getAssociatedKey() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTask
- getAssociatedKey() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.OpenTask
- getAssociatedKey() - Method in class com.tangosol.persistence.AbstractPersistenceManager.BatchTasks
- getAssociatedKey() - Method in class com.tangosol.util.CompositeKey
- 
Determine the host key (or base) object to which this object is associated.
- getAssociatedKey() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DefaultTaskDependencies
- 
Return the associated key for the task.
- getAssociatedKey() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
- 
Determine the host key (or base) object to which this object is associated.
- getAssociatedKey() - Method in interface com.tangosol.util.fsm.NonBlockingFiniteStateMachine.TaskDependencies
- 
Return the associated key for the task.
- getAssociatedKey(Object) - Method in interface com.oracle.coherence.common.base.Associator
- 
Determine the host key (or base) object to which the specified object is associated.
- getAssociatedKey(Object) - Method in class com.oracle.coherence.common.base.NaturalAssociator
- 
Determine the host key (or base) object to which the specified object is associated.
- getAssociatedKey(Object) - Method in interface com.tangosol.net.partition.KeyAssociator
- 
Determine the key object to which the specified key object is associated.
- getAssociatedPartitions(Object) - Method in class com.tangosol.net.partition.BroadKeyPartitioningStrategy
- 
Determine the set of partitions that all keys associated with the specified key are assigned to.
- getAssociatedPartitions(Object) - Method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
- 
Determine the set of partitions that all keys associated with the specified key are assigned to.
- getAssociatedPartitions(Object) - Method in interface com.tangosol.net.partition.KeyPartitioningStrategy
- 
Determine the set of partitions that all keys associated with the specified key are assigned to.
- getAssociatedService() - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Return the associated service.
- getAsyncCache() - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- 
Obtain theAsyncNamedCachethat the request executes on.
- getAsyncCache(String, String) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Obtain anAsyncNamedCache.
- getAsynchronousListeners() - Method in class com.tangosol.util.Listeners
- 
Get the array of asynchronous event listeners.
- getAsyncLimit(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
- 
Return the maximum number of bytes that are queued to be written asynchronously.
- getAttribute(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Get an attribute of the specified XmlElement that matches to the specified local name and the specified Namespace URI.
- getAttribute(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Get an attribute value.
- getAttribute(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Get an attribute value.
- getAttribute(String, String) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Obtain the value of the specified MBean attribute.
- getAttribute(String, String) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- getAttributeList(Map<String, Object>) - Method in class com.tangosol.net.management.MBeanAccessor.SetAttributes
- 
Convert the entity map to anAttributeList
- getAttributeMap() - Method in class com.tangosol.run.xml.SimpleElement
- 
Get the map of all attributes.
- getAttributeMap() - Method in interface com.tangosol.run.xml.XmlElement
- 
Get the map of all attributes.
- getAttributeProcessor(XmlAttribute) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Obtains theAttributeProcessorthat is suitable for processing the specifiedXmlAttributein the xml namespace associated with thisNamespaceHandler.
- getAttributeProcessor(XmlAttribute) - Method in interface com.tangosol.config.xml.NamespaceHandler
- 
Obtains theAttributeProcessorthat is suitable for processing the specifiedXmlAttributein the xml namespace associated with thisNamespaceHandler.
- getAttributeProcessor(String) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Obtains theAttributeProcessorregistered with the specified localName (in the namespace).
- getAttributes() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Obtain the cache attributes for this entry.
- getAttributes() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.Obtain the attribute map.
- getAttributes(MBeanAccessor.QueryBuilder.ParsedQuery) - Method in class com.tangosol.net.management.MBeanAccessor
- 
Return all the attributes that match the query expressed by the providedMBeanAccessor.QueryBuilder.
- getAttributes(MBeanAccessor.QueryBuilder.ParsedQuery, Filter<MBeanAttributeInfo>, boolean) - Method in class com.tangosol.net.management.MBeanAccessor
- 
Return all the attributes that match the query expressed by the providedMBeanAccessor.QueryBuilder.
- getAttributes(String, Filter<String>) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Return a Map of attribute name to attribute value for a given MBean name.
- getAttributes(String, Filter<String>) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- GetAttributes() - Constructor for class com.tangosol.net.management.MBeanAccessor.GetAttributes
- 
Default constructor.
- GetAttributes(MBeanAccessor.QueryBuilder.ParsedQuery) - Constructor for class com.tangosol.net.management.MBeanAccessor.GetAttributes
- 
Create a GetAttributes object.
- GetAttributes(MBeanAccessor.QueryBuilder.ParsedQuery, Filter<MBeanAttributeInfo>, boolean) - Constructor for class com.tangosol.net.management.MBeanAccessor.GetAttributes
- 
Create a GetAttributes object.
- getAuthenticationScheme() - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
- getAuthorizedHostFilter() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the filter that is used by the cluster to determine whether to accept a new Cluster member.
- getAutoCloseable() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of anAutoCloseable.
- getAverageBatchSize() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the average number of entries stored per store() operation.
- getAverageEraseMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the average time spent per erase() operation.
- getAverageGetMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the average number of milliseconds per get() invocation since the cache statistics were last reset.
- getAverageGetMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the average number of milliseconds per get() invocation since the cache statistics were last reset.
- getAverageGetMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the average number of milliseconds per get() invocation since the cache statistics were last reset.
- getAverageGetTime() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getAverageGetTime() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getAverageGetTime() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getAverageHitMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the average number of milliseconds per get() invocation that is a hit.
- getAverageHitMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the average number of milliseconds per get() invocation that is a hit.
- getAverageHitMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the average number of milliseconds per get() invocation that is a hit.
- getAverageLoadMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the average time spent per load() operation.
- getAverageMissMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the average number of milliseconds per get() invocation that is a miss.
- getAverageMissMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the average number of milliseconds per get() invocation that is a miss.
- getAverageMissMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the average number of milliseconds per get() invocation that is a miss.
- getAveragePartitionSize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
Return average partition storage size.
- getAveragePartitionSizeKB() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the average partition storage size.
- getAveragePartitionSizeKB() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the average partition storage size.
- getAveragePruneMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Calculate the average number of milliseconds that a prune takes.
- getAveragePutMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the average number of milliseconds per put() invocation since the cache statistics were last reset.
- getAveragePutMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the average number of milliseconds per put() invocation since the cache statistics were last reset.
- getAveragePutMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the average number of milliseconds per put() invocation since the cache statistics were last reset.
- getAveragePutTime() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getAveragePutTime() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getAveragePutTime() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getAverageRemoveTime() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getAverageRemoveTime() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getAverageRemoveTime() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getAverageStorageSize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
Return average node storage size.
- getAverageStorageSizeKB() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the average node storage size.
- getAverageStorageSizeKB() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the average node storage size.
- getAverageStoreMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the average time spent per store() operation.
- getBackCache() - Method in class com.tangosol.net.cache.NearCache
- 
Obtain the NamedCache object that sits behind this NearCache.
- getBackEvent() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
For internal use only, return the current event from the back Map.
- getBackingMap() - Method in interface com.tangosol.net.BackingMapContext
- 
Deprecated.As of Coherence 12.1.3, replaced withBackingMapContext.getBackingMapEntry(java.lang.Object)
- getBackingMap() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Obtain a reference to the backing map that this Entry corresponds to.
- getBackingMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Obtain a reference to the backing map that this Entry corresponds to.
- getBackingMap() - Method in interface com.tangosol.util.BinaryEntry
- 
Deprecated.As of Coherence 12.1.3, replaced withBackingMapContext.getBackingMapEntry(java.lang.Object)BackingMapContext.getBackingMapEntry(java.lang.Object)
- getBackingMap() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Obtain a reference to the backing map that this Entry corresponds to.
- getBackingMap() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- getBackingMap(int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
- 
Obtain the backing map that corresponds to a specified partition.
- getBackingMap(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Obtain a backing map for the specified key.
- getBackingMap(String) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Deprecated.As of Coherence 3.7, use of this method is discouraged. Instead, useBackingMapContext.getBackingMapEntry(java.lang.Object).
- getBackingMap(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Get the backing Map associated with a given cache.
- getBackingMap(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Get the backing Map associated with a given cache.
- getBackingMap(String) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Obtain a reference to the backing map that corresponds to the specified cache name.
- getBackingMapContext() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Obtain a reference to thebacking map contextfor the cache that this Entry corresponds to.
- getBackingMapContext() - Method in interface com.tangosol.net.events.partition.cache.Event
- 
Return theBackingMapContextthis event was raised from.
- getBackingMapContext() - Method in interface com.tangosol.net.events.partition.cache.PartitionedCacheDispatcher
- 
Return theBackingMapContextfor this dispatcher.
- getBackingMapContext() - Method in interface com.tangosol.util.BinaryEntry
- 
Obtain a reference to thebacking map contextfor the cache that this Entry corresponds to.
- getBackingMapContext() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Obtain a reference to thebacking map contextfor the cache that this Entry corresponds to.
- getBackingMapContext() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- getBackingMapContext() - Method in interface com.tangosol.util.QueryContext
- 
Return the correspondingBackingMapContext.
- getBackingMapContext(String) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Obtain a reference to theBackingMapContextthat corresponds to the specified cache name.
- getBackingMapContext(String) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Obtain a reference to theBackingMapContextthat corresponds to the specified cache name.
- getBackingMapEntry(Object) - Method in interface com.tangosol.net.BackingMapContext
- 
Return an InvocableMap.Entry for the specified key (in its internal format) from the associated cache, obtaining exclusive access to that cache entry.
- getBackingMapManager() - Method in interface com.tangosol.net.CacheService
- 
Return a backing map manager used by this CacheService.
- getBackingMapManager() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Obtain the BackingMapManager that this PartitionAwareBackingMap uses to instantiate and release backing maps.
- getBackingMapManager() - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
- 
Obtain the BackingMapManager that this PartitionAwareBackingMap uses to instantiate and release backing maps.
- getBackingMapManager() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Obtain the BackingMapManager that this PartitionAwareBackingMap uses to instantiate and release backing maps.
- getBackingMapManager() - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Obtain the BackingMapManager that this PartitionAwareBackingMap uses to instantiate and release backing maps.
- getBackingMapManager() - Method in class com.tangosol.net.WrapperCacheService
- 
Return a backing map manager used by this CacheService.
- getBackingMapManagerContext() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Return theBackingMapManagerContext.
- getBackingMapManagerContext() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a BackingMapManagerContext.
- getBackingMaps() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
- 
Obtain an array of all of the current backing maps, one for each partition.
- getBackingMaps(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
- 
Obtain an array of the current backing maps for the partitions specified in the passed PartitionSet.
- getBackingMapScheme() - Method in interface com.tangosol.coherence.config.scheme.ClusteredCachingScheme
- 
Return theBackingMapSchemeused to create a backing map.
- getBackingMapScheme() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Return theBackingMapSchemewhich builds the backing map for the clustered scheme.
- getBackingMapScheme() - Method in class com.tangosol.coherence.config.scheme.ReplicatedScheme
- 
Return theBackingMapSchemewhich builds the backing map for the clustered scheme.
- getBacklog() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getBacklog() - Method in interface com.tangosol.net.ThreadPoolManager
- 
Return the backlog of the thread pool.
- getBackMap() - Method in class com.tangosol.net.cache.CachingMap
- 
Obtain the back map reference.
- getBackMap() - Method in class com.tangosol.net.cache.OverflowMap
- 
Returns the back Map.
- getBackMap() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Returns the back Map.
- getBackMapListener() - Method in class com.tangosol.net.cache.OverflowMap
- 
Get the MapListener for the back map.
- getBackPaddingSize() - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Determine the number of extra bytes of padding that will be allocated and left blank at the end of each block after the data portion.
- getBackScheme() - Method in class com.tangosol.coherence.config.scheme.AbstractCompositeScheme
- 
Return the back scheme.
- getBackupCount() - Method in class com.tangosol.net.partition.Ownership
- 
Return the backup count for this Ownership object.
- getBackupCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the configured number of backups.
- getBackupCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the configured number of backups.
- getBackupCount() - Method in interface com.tangosol.net.PartitionedService
- 
Determine the configured redundancy count that this service has been configured to maintain.
- getBackupLoadCalculator() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the LoadCalculator used to calculate the backup partition load.
- getBackupMapConfig() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Return theBackupMapConfigwhich is used to configure the backup map.
- getBackupOwner(int, int) - Method in interface com.tangosol.net.PartitionedService
- 
Determine the backup owner of the specified partition.
- getBackupSchemeName(ParameterResolver) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
- 
Return the name of the caching scheme to use as a backup map.
- getBackupSchemeName(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Return the name of the caching scheme to use as a backup map.
- getBackupStrength() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the BackupStrength for this analysis context.
- getBackupStrength() - Method in interface com.tangosol.net.PartitionedService
- 
Return the current backup strength of the partitioned service.
- getBackupStrengthName() - Method in interface com.tangosol.net.PartitionedService
- 
Return the string representing current backup strength.
- getBaseMap() - Method in interface com.tangosol.util.TransactionMap
- 
Return the base map, which contains this TransactionMap's committed data.
- getBaseName(String) - Static method in class com.tangosol.io.FileHelper
- 
Gets the base name, minus the full path and extension, from a full filename.
- getBatchSize() - Method in class com.tangosol.util.filter.LimitFilter
- 
Return the number of members query concurrently.
- getBeanId() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Get the serialization ID for the specific XML bean implementation.
- getBeanInfo() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Obtain the containing BeanInfo object.
- getBeanInfo() - Method in class com.tangosol.run.xml.XmlBean
- 
Obtain the BeanInfo for this XmlBean object, or create and configure a BeanInfo if one does not exist.
- getBehavior() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Return theRegistrationBehaviorassociated with this interceptor.
- getBigDecimal() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the BigDecimal which this PofValue represents.
- getBigDecimal() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the BigDecimal which this PofValue represents.
- getBigInteger() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the BigInteger which this PofValue represents.
- getBigInteger() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the BigInteger which this PofValue represents.
- getBinary() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as binary.
- getBinary() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as binary.
- getBinary(Binary) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as binary.
- getBinary(Binary) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as binary.
- getBinaryChangeRecord() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- getBinaryEntryStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
The wrapped BinaryEntryStore.
- getBinaryKey() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return a raw binary key for this entry.
- getBinaryKey() - Method in interface com.tangosol.util.BinaryEntry
- 
Return a raw binary key for this entry.
- getBinaryKey() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- 
Return a raw binary key for this entry.
- getBinaryKey() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- 
Return a raw binary key for this entry.
- getBinaryMap() - Method in class com.tangosol.io.nio.BinaryMapStore
- 
Obtain the underlying BinaryMap.
- getBinaryMap() - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
- 
Obtain the map that stores the binary values held by this BinaryStore.
- getBinaryStore() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Obtain the BinaryStore that this AsyncBinaryStore wraps.
- getBinaryStore() - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Returns the BinaryStore that this CacheStore uses for its storage.
- getBinaryStore() - Method in class com.tangosol.net.cache.SerializationMap
- 
Returns the BinaryStore that this map uses for its storage.
- getBinaryStore() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- getBinaryStore() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns the BinaryStore that this map uses for its storage.
- getBinaryStoreKeyMap() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- getBinaryStoreList() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Get the list of registered BinaryStore objects.
- getBinaryStoreManager() - Method in class com.tangosol.io.AsyncBinaryStoreManager
- getBinaryStoreManager() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Returns the BinaryStoreManager that provides BinaryStore objects this cache uses for its storage.
- getBinaryStoreManagerBuilder() - Method in class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
- 
Obtains theBinaryStoreManagerBuilderfor theBinaryStoreManager.
- getBinaryStoreManagerBuilder() - Method in interface com.tangosol.coherence.config.builder.storemanager.BinaryStoreManagerBuilderCustomization
- 
Obtains theBinaryStoreManagerBuilderfor theBinaryStoreManager.
- getBinaryStoreManagerBuilder() - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Obtains theBinaryStoreManagerBuilderfor theBinaryStoreManager.
- getBinaryStoreManagerBuilder() - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Obtains theBinaryStoreManagerBuilderfor theBinaryStoreManager.
- getBinaryStoreMap() - Method in class com.tangosol.io.AsyncBinaryStoreManager
- getBinaryValue() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return a raw binary value for this entry.
- getBinaryValue() - Method in interface com.tangosol.net.topic.Subscriber.Element
- 
Returns the element's value in serialized form.
- getBinaryValue() - Method in exception com.tangosol.net.topic.TopicPublisherException
- 
Returns the value that failed to be published in serializedBinaryformat.
- getBinaryValue() - Method in interface com.tangosol.util.BinaryEntry
- 
Return a raw binary value for this entry.
- getBinaryValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- 
Return a raw binary value for this entry.
- getBinaryValue() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- 
Return an OriginalBinaryValue from the underlying entry.
- getBindableServices() - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- 
Return the list of services this controller is serving.
- getBindingPower() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Get The binding precedence of this token.
- getBits() - Method in class com.tangosol.io.pof.RawQuad
- 
Obtain the raw binary form of the 128-bit float.
- getBlock(int) - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Obtain the specified block of data.
- getBlockCount() - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Determine the number of blocks that have been written thus far.
- getBlockCount() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Return the blocked threads count.
- getBlockDataSize() - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Determine the maximum number of bytes of data that will be stored in each block.
- getBlockDataSize(int) - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Determine the specific number of bytes of data stored in the specified block.
- getBoolean() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the boolean which this PofValue represents.
- getBoolean() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the boolean which this PofValue represents.
- getBoolean() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a boolean.
- getBoolean() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a boolean.
- getBoolean(boolean) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a boolean.
- getBoolean(boolean) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a boolean.
- getBoolean(String) - Static method in class com.tangosol.coherence.config.Config
- 
Returns true if coherence system propertysNameexists and value is equal to string true.
- getBoolean(String, boolean) - Static method in class com.tangosol.coherence.config.Config
- 
Return true if propertysNameexists and its value is string true.
- getBooleanArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the boolean[] which this PofValue represents.
- getBooleanArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the boolean[] which this PofValue represents.
- getBottomAnchor() - Method in class com.tangosol.util.filter.LimitFilter
- 
Obtain the bottom anchor object, which is the last value object on the current page.
- getBucketCount() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the number of hash buckets.
- getBucketIndex(int, int) - Method in class com.tangosol.util.SafeHashMap
- 
Calculate the bucket number for a particular hash code.
- getBucketIndex(int, int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Calculate the bucket number for a particular hash code.
- getBucketLevel() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the hash bucket level.
- getBucketOffset(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Get the first Entry block in the linked list of Entry blocks that fall into a certain hash bucket.
- getBuffer() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Get the ReadBuffer object that this BufferInput is reading from.
- getBuffer() - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Get the WriteBuffer object that this BufferOutput is writing to.
- getBuffer() - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Get the current ByteBuffer reference.
- getBuffer() - Method in class com.tangosol.io.nio.BinaryMap
- 
Obtain the ByteBuffer that the BinaryMap is backed by.
- getBuffer() - Method in interface com.tangosol.io.nio.ByteBufferManager
- 
Get the current ByteBuffer reference.
- getBuffer() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Get the ReadBuffer object that this BufferInput is reading from.
- getBuffer() - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- getBuffer() - Method in class com.tangosol.io.WrapperBufferInput
- 
Get the ReadBuffer object that this BufferInput is reading from.
- getBuffer() - Method in class com.tangosol.io.WrapperBufferOutput
- 
Get the WriteBuffer object that this BufferOutput is writing to.
- getBuffer() - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Get the WriteBuffer object that this BufferOutput is writing to.
- getBuffer(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Obtain the specified buffer.
- getBuffer(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Obtain the specified buffer.
- getBufferCount() - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Determine the number of ReadBuffer objects that contain the data presented by this MultiBufferReadBuffer.
- getBufferCount() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Determine the number of WriteBuffer objects allocated by this MultiBufferWriteBuffer from the WriteBufferPool.
- getBufferIndexByOffset(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Determine which underlying ReadBuffer contains the specified offset.
- getBufferIndexByOffset(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Determine which underlying WriteBuffer contains the specified offset.
- getBufferInput() - Method in class com.tangosol.io.AbstractReadBuffer
- 
Get a BufferInput object to read data from this buffer.
- getBufferInput() - Method in class com.tangosol.io.nio.BinaryMap
- 
Get the DataInputStream that maps to the underlying ByteBuffer.
- getBufferInput() - Method in interface com.tangosol.io.ReadBuffer
- 
Get a BufferInput object to read data from this buffer.
- getBufferManager() - Method in class com.tangosol.io.nio.BinaryMap
- 
Obtain the ByteBufferManager that provides the ByteBuffer objects.
- getBufferOffset(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Determine the offset of the specified buffer.
- getBufferOffset(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Determine the offset of the specified buffer.
- getBufferOutput() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Get a BufferOutput object to write data to this buffer, starting at the beginning of the WriteBuffer.
- getBufferOutput() - Method in class com.tangosol.io.nio.BinaryMap
- 
Get the DataOutputStream that maps to the underlying ByteBuffer.
- getBufferOutput() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Return the BufferOutput that this PofBufferWriter writes to.
- getBufferOutput() - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Obtain the DataOutput object that this Writing POF Handler is writing to.
- getBufferOutput() - Method in interface com.tangosol.io.WriteBuffer
- 
Get a BufferOutput object to write data to this buffer, starting at the beginning of the WriteBuffer.
- getBufferOutput(int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Get a BufferOutput object to write data to this buffer starting at a particular offset.
- getBufferOutput(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Get a BufferOutput object to write data to this buffer starting at a particular offset.
- getBufferOutput(int) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Get a BufferOutput object to write data to this buffer starting at a particular offset.
- getBufferOutput(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Get a BufferOutput object to write data to this buffer starting at a particular offset.
- getBufferOutput(int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Get a BufferOutput object to write data to this buffer starting at a particular offset.
- getBufferOutput(int) - Method in interface com.tangosol.io.WriteBuffer
- 
Get a BufferOutput object to write data to this buffer starting at a particular offset.
- getBufferPool() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Obtain the factory used to create WriteBuffer objects.
- getBuilder() - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry.Registration
- 
Obtains theParameterizedBuilder.
- getBuilder() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.BuilderRegistration
- getBuilder() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryValue
- 
Return the registered builder.
- getBuilder(Class<T>) - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry
- 
Attempts to retrieve the builder that was registered with the specified class.
- getBuilder(Class<T>) - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- getBuilder(Class<T>, String) - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry
- 
Attempts to retrieve the builder that was registered with the specified class and name.
- getBuilder(Class<T>, String) - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- getBuilderRegistry() - Method in interface com.tangosol.net.ClusterDependencies
- 
The registry for all builders associated with the cluster.
- getBuilderRegistry() - Method in interface com.tangosol.net.OperationalContext
- 
The registry for all builders associated with the cluster.
- getBundleManager() - Method in interface com.tangosol.coherence.config.scheme.BundlingScheme
- 
Obtains theBundleManager.
- getBundleManager() - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Obtains theBundleManager.
- getBundleManager() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Obtains theBundleManager.
- getBundleManager() - Method in class com.tangosol.coherence.config.scheme.RemoteCacheScheme
- 
Obtains theBundleManager.
- GetBundler() - Constructor for class com.tangosol.net.cache.BundlingNamedCache.GetBundler
- getBundleSize() - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
- 
Obtain this bundle size.
- getBundleSize() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Obtain this bundle size.
- getBundleSize() - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
- 
Obtain this bundle size.
- getBundleSize() - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
- 
Obtain this bundle size.
- getByte() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the byte which this PofValue represents.
- getByte() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the byte which this PofValue represents.
- getByteArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the byte[] which this PofValue represents.
- getByteArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the byte[] which this PofValue represents.
- getByteArray(Binary) - Method in class com.tangosol.util.Unsafe
- 
Return the underlying byte[] for the specified Binary.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferInputStream
- 
Obtain the ByteBuffer that this InputStream is based on.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferOutputStream
- 
Obtain the ByteBuffer that this OutputStream is based on.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Obtain the NIO ByteBuffer that this BufferInput is based on.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Obtain the ByteBuffer that this ReadBuffer is based on.
- getByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Obtain the ByteBuffer that this WriteBuffer is based on.
- getBytesWritten() - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Return the total number of bytes written to the wrapped DataOutput object.
- getBytesWritten() - Method in class com.tangosol.io.WrapperObjectOutputStream
- 
Return the total number of bytes written to the wrapped DataOutput object.
- getCache() - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- 
Obtain theNamedCachethat the request executes on.
- getCache() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Return the cache name.
- getCache() - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
- 
Return the ConfigurableCacheMap that uses this eviction policy.
- getCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Obtain theNamedCachethat thisContinuousQueryCacheis based on.
- getCache() - Method in class com.tangosol.util.CacheCollator
- getCache(String) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- getCache(String) - Static method in class com.tangosol.net.CacheFactory
- 
Return an instance of an cache configured by the current ConfigurableCacheFactory
- getCache(String, NamedMap.Option...) - Static method in class com.tangosol.net.CacheFactory
- 
Return an instance of an cache configured by the current ConfigurableCacheFactory, using the specifiedNamedMap.Options.
- getCache(String, NamedMap.Option...) - Method in class com.tangosol.net.CoherenceSession
- getCache(String, NamedMap.Option...) - Method in interface com.tangosol.net.Session
- getCache(String, Class<K>, Class<V>) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- getCache(String, ClassLoader) - Static method in class com.tangosol.net.CacheFactory
- 
Return an instance of a cache configured by the current ConfigurableCacheFactory with a specificClassLoaderno options.
- getCache(String, ClassLoader, NamedMap.Option...) - Static method in class com.tangosol.net.CacheFactory
- 
Return an instance of a cache configured by the current ConfigurableCacheFactory with a specificClassLoaderandNamedMap.Options
- getCache(String, String, boolean) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Obtain anNamedCache.
- getCacheConfig() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DefaultDependencies
- 
ObtainsCacheConfigfor anExtensibleConfigurableCacheFactory.
- getCacheConfig() - Method in interface com.tangosol.net.ExtensibleConfigurableCacheFactory.Dependencies
- 
ObtainsCacheConfigfor anExtensibleConfigurableCacheFactory.
- getCacheConfig() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return theCacheConfigthat contains the configuration used by this factory.
- getCacheConfigURI() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- getCachedOrPending(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get a value from the internal cache in a way that respects a potentially pending write-behind operation.
- getCacheEntry() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Obtain the actual cache entry from the partition-specific backing map.
- getCacheEntry(Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getCacheEntry(Object) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Locate a cache Entry in the cache based on its key.
- getCacheEntry(Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Locate a cache Entry in the cache based on its key.
- getCacheEntry(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Locate a cache Entry in the cache based on its key.
- getCacheEntry(Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Locate a cache Entry in the cache based on its key.
- getCacheEntryEventFilter() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
- 
Obtains theCacheEntryEventFilterto which to delegateCacheEntryEvents.
- getCacheEntryFilter() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
- 
Obtains an instance of theCacheEntryEventFilterfor the registration.
- getCacheEntryListener() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
- 
Obtains an instance of theCacheEntryListenerfor the registration.
- getCacheEntryListener() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
- 
Obtains theCacheEntryListenerto whichMapEvents will be delegated.
- getCacheEntryListenerConfiguration() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughListenerRegistration
- 
Obtains theCacheEntryListenerConfigurationfor the registration.
- getCacheEntryListenerConfigurations() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- getCacheEvent() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEvent
- 
Return the underlying CacheEvent.
- getCacheEvictions() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheEvictions() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getCacheEvictions() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheFactory() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Deprecated.
- getCacheFactory() - Method in interface com.tangosol.net.BackingMapManager
- 
Obtain the "container" ConfigurableCacheFactory that created this manager and which this manager is bound to.
- getCacheFactory() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Obtain the "container" DefaultConfigurableCacheFactory that created this manager and which this manager is bound to.
- getCacheFactory() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.Obtain the "container" DefaultConfigurableCacheFactory that created this manager and which this manager is bound to.
- getCacheFactory() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Obtain the "container" ConfigurableCacheFactory that created this manager and which this manager is bound to.
- getCacheFactory() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
- 
Obtain the "container" ConfigurableCacheFactory that created this manager and which this manager is bound to.
- getCacheFactoryBuilder() - Static method in class com.tangosol.net.CacheFactory
- 
Obtain the CacheFactoryBuilder singleton using the configuration info from the "cache-factory-builder-config" element.
- getCacheFactoryBuilder() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- getCacheFactoryBuilderConfig() - Static method in class com.tangosol.net.CacheFactory
- 
Return the cache factory builder configuration as defined by the "cache-factory-builder-config" element in the tangosol-coherence.xml configuration file.
- getCacheFactorySupplier() - Method in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl.DefaultDependencies
- getCacheFactorySupplier() - Method in interface com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl.Dependencies
- 
Return the function to use to obtain namedConfigurableCacheFactoryinstances.
- getCacheFormat(Service) - Static method in class com.oracle.coherence.grpc.RequestHolder
- 
Returns the serializer format name for the specifiedService's serializer.
- getCacheGets() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheGets() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getCacheGets() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheHitPercentage() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheHitPercentage() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getCacheHitPercentage() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheHits() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheHits() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getCacheHits() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheHits() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the rough number of cache hits since the cache statistics were last reset.
- getCacheHits() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the rough number of cache hits since the cache statistics were last reset.
- getCacheHits() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the rough number of cache hits since the cache statistics were last reset.
- getCacheHits() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the rough number of cache hits since the cache statistics were last reset.
- getCacheHitsMillis() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheHitsMillis() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
get time elapsed in milliseconds performing operations resulting in a hit
- getCacheHitsMillis() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheHitsMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) for the get() operations for which an entry existed in this map.
- getCacheHitsMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) for the get() operations for which an entry existed in this map.
- getCacheHitsMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) for the get() operations for which an entry existed in this map.
- getCacheLoader() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
- 
Return the configured CacheLoader independent if read-through is enabled or not.
- getCacheLoader() - Method in class com.tangosol.net.cache.LocalCache
- 
Determine the loader used by this LocalCache, if any.
- getCacheLoader() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheLoaderCacheStore
- 
The wrapped CacheLoader.
- getCacheLoaderFactory() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- getCacheManager() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- getCacheManager() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- getCacheManager(URI, ClassLoader) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- 
Return a CacheManager.
- getCacheManagerURI() - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- 
Get the JCache CacheManager URI, a unique identifier for the JCache CacheManager
- getCacheMap() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheMap
- 
Return the underlying CacheMap.
- getCacheMap(CacheMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of CacheMap.
- getCacheMappingRegistry() - Method in class com.tangosol.coherence.config.CacheConfig
- 
Deprecated.As of Coherence 14.1.1, replaced byCacheConfig.getMappingRegistry().
- getCacheMisses() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheMisses() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getCacheMisses() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheMisses() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the rough number of cache misses since the cache statistics were last reset.
- getCacheMisses() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the rough number of cache misses since the cache statistics were last reset.
- getCacheMisses() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the rough number of cache misses since the cache statistics were last reset.
- getCacheMisses() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the rough number of cache misses since the cache statistics were last reset.
- getCacheMissesMillis() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheMissesMillis() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
get time elapsed in milliseconds performing operations resulting in a miss
- getCacheMissesMillis() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheMissesMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) for the get() operations for which no entry existed in this map.
- getCacheMissesMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) for the get() operations for which no entry existed in this map.
- getCacheMissesMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) for the get() operations for which no entry existed in this map.
- getCacheMissPercentage() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheMissPercentage() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getCacheMissPercentage() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheName() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Return the name of the cache this listener is for, or'*'if it should be registered regardless of the cache name.
- getCacheName() - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- 
Obtain the cache name.
- getCacheName() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Return the cache name.
- getCacheName() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Determine the name of the cache.
- getCacheName() - Method in interface com.tangosol.net.BackingMapContext
- 
Return the name of thecachethat this BackingMapContext is associated with.
- getCacheName() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- getCacheName() - Method in class com.tangosol.net.cache.NearCache
- 
Return the cache name.
- getCacheName() - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Return the cache name.
- getCacheName() - Method in class com.tangosol.net.ClusterPermission
- 
Return the cache name for this permission object or null if the permission applies to any cache.
- getCacheName() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.Obtain the cache name.
- getCacheName() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Return the name of the cache this interceptor should receive events from.
- getCacheName() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEvent
- 
The name of the cache that the event is associated with.
- getCacheName() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEventDispatcher
- 
Return the name of thecachethat this dispatcher is associated with.
- getCacheName() - Method in interface com.tangosol.net.events.partition.cache.Event
- 
Return the name of the cache this event was raised from.
- getCacheName() - Method in interface com.tangosol.net.events.partition.cache.PartitionedCacheDispatcher
- 
Return the name of thecachethat this PartitionedCacheDispatcher is associated with.
- getCacheName() - Method in interface com.tangosol.net.NamedCache
- 
Return the cache name.
- getCacheName() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Return the cache name.
- getCacheName(long) - Method in class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
- 
Return the cache name based upon the old cache id.
- getCacheName(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the String that represents the cache name from the given AST node by looking for the "from" term AST.
- getCacheNamePattern() - Method in class com.tangosol.coherence.config.CacheMapping
- 
Deprecated.As of Coherence 14.1.1, useResourceMapping.getNamePattern().
- getCacheNames() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- getCacheNames() - Method in interface com.tangosol.net.CacheService
- 
Returns an Enumeration of String objects, one for each cache name that has been previously registered with this CacheService.
- getCacheNames() - Method in class com.tangosol.net.WrapperCacheService
- 
Returns an Enumeration of String objects, one for each cache name that has been previously registered with this CacheService.
- getCacheNames(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return the cache names that have beenstoredin the specified store.
- getCachePrunes() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the rough number of cache pruning cycles since the cache statistics were last reset.
- getCachePrunes() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the rough number of cache pruning cycles since the cache statistics were last reset.
- getCachePrunes() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the rough number of cache pruning cycles since the cache statistics were last reset.
- getCachePrunesMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) spent on cache pruning.
- getCachePrunesMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) spent on cache pruning.
- getCachePrunesMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the total number of milliseconds (since the last statistics reset) spent on cache pruning.
- getCachePuts() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCachePuts() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getCachePuts() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCachePutsMillis() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCachePutsMillis() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
get time elapsed in milliseconds performing operations resulting in a put
- getCachePutsMillis() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheRemovals() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheRemovals() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- getCacheRemovals() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheRemoveMillis() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getCacheRemoveMillis() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
get time elapsed in milliseconds performing operations resulting in a remove
- getCacheRemoveMillis() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getCacheResource(String) - Method in class com.tangosol.coherence.rest.DefaultRootResource
- 
Returns a resource representing single named cache.
- getCacheResource(String) - Method in class com.tangosol.coherence.rest.PassThroughRootResource
- 
Returns a resource representing a single named cache.
- getCacheSerializer() - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- 
Obtain the cache'sSerializer.
- getCacheService() - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Return the CacheService associated with this context.
- getCacheService() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- getCacheService() - Method in class com.tangosol.net.cache.NearCache
- 
Return the CacheService that this NamedCache is a part of.
- getCacheService() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the CacheService.
- getCacheService() - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Return the CacheService that this NamedCache is a part of.
- getCacheService() - Method in interface com.tangosol.net.NamedCache
- 
Return the CacheService that this NamedCache is a part of.
- getCacheService() - Method in class com.tangosol.net.WrapperCacheService
- 
Return the wrapped CacheService.
- getCacheService() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Return the CacheService that this NamedCache is a part of.
- getCacheService() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Return the CacheService associated with this context.
- getCacheStatistics() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- 
Returns the statistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.CachingMap
- 
Obtain the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.OverflowMap
- 
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.SerializationMap
- 
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Return the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Returns the CacheStatistics for this cache.
- getCacheStatistics() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
- 
Obtain an array of all of the CacheStatistics objects for the current backing maps, one for each partition.
- getCacheStatistics() - Method in class com.tangosol.util.WrapperObservableMap
- 
Return the CacheStatistics for this cache.
- getCacheStore() - Method in class com.tangosol.net.cache.LocalCache
- 
Determine the store used by this LocalCache, if any.
- getCacheStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
The wrapped CacheStore.
- getCacheStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the representative of the "persistent" storage for this backing map.
- getCacheStore() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a CacheStore.
- getCacheStoreScheme() - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Return theCacheStoreSchemewhich builds a CacheStore or CacheLoader.
- getCacheStoreScheme() - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return theCacheStoreSchemeused to create a CacheStore or CacheLoader.
- getCacheStoreTimeout(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return the timeout interval to use for CacheStore read and write operations.
- getCacheStoreTimeoutMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the timeout used for CacheStore operations, or 0 if no timeout is specified.
- getCacheToConfigurationMapping(JCacheIdentifier) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- 
Provide access to meta cache that maps JCache cache names to JCache configuration.
- getCacheWriter() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
- 
If write-through is enabled, return the CacheWriter.
- getCacheWriterFactory() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- getCachingProvider() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- getCachingScheme() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- 
Obtain the wrappedCachingScheme.
- getCachingSchemeName() - Method in class com.tangosol.coherence.config.CacheMapping
- 
Deprecated.As of Coherence 14.1.1, useResourceMapping.getSchemeName().
- getCalculator() - Method in class com.tangosol.util.SimpleMapIndex
- 
Return the UnitCalculator used to size this index's contents.
- getCalculatorState(Class) - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
Determine which method to use to count the size of an instance of the specified class.
- getCalibratedHighUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the high units adjusted based on thepartition unit factor.
- getCalibratedLowUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the low units adjusted based on thepartition unit factor.
- getCallerStackFrame() - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Get the StackFrame information for the caller of the current method.
- getCallerStackFrame() - Static method in class com.tangosol.util.Base
- 
Get the StackFrame information for the caller of the current method.
- getCanonicalCacheName() - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- 
Get the JCache Adapter internal name for thisJCacheIdentifier
- getCanonicalName() - Method in interface com.oracle.coherence.common.base.CanonicallyNamed
- 
Return a canonical name for the entity ornull.
- getCanonicalName() - Method in class com.tangosol.util.extractor.AbstractExtractor
- getCanonicalName() - Method in class com.tangosol.util.extractor.ChainedExtractor
- 
Compute a canonical name as a dot-separated concatenation of the canonical name of eachValueExtractorarray element, starting from lowest index array element.
- getCanonicalName() - Method in class com.tangosol.util.extractor.ChainedFragmentExtractor
- getCanonicalName() - Method in class com.tangosol.util.extractor.IdentityExtractor
- getCanonicalName() - Method in class com.tangosol.util.extractor.KeyExtractor
- getCanonicalName() - Method in class com.tangosol.util.extractor.ReflectionExtractor
- getCanonicalName() - Method in class com.tangosol.util.extractor.UniversalExtractor
- getCanonicalName() - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Return the canonical name for this updater.
- getCanonicalName() - Method in interface com.tangosol.util.ValueExtractor
- 
Return the canonical name for this extractor.
- getCapacity() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Determine the number of bytes that the buffer can hold without resizing itself.
- getCapacity() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Determine the number of bytes that the buffer can hold without resizing itself.
- getCapacity() - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Determine the number of bytes that the buffer can hold without resizing itself.
- getCapacity() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Determine the number of bytes that the buffer can hold without resizing itself.
- getCapacity() - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Get the capacity of the current ByteBuffer.
- getCapacity() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the capacity of the map in bytes.
- getCapacity() - Method in interface com.tangosol.io.nio.ByteBufferManager
- 
Get the capacity of the current ByteBuffer.
- getCapacity() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Determine the number of bytes that the buffer can hold without resizing itself.
- getCapacity() - Method in interface com.tangosol.io.WriteBuffer
- 
Determine the number of bytes that the buffer can hold without resizing itself.
- getCCF(String) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- getChangedBinaryValue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Return the Binary value changed by the BinaryEntryStore.
- getChanges() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return a buffer containing changes made to this PofValue in the format defined by theBinaryDeltaCompressor.
- getChanges() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return a buffer containing changes made to this PofValue in the format defined by theBinaryDeltaCompressor.
- getChannel() - Method in interface com.tangosol.net.topic.Publisher.Status
- 
Returns the channel that the element was published to.
- getChannel() - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- 
Returns the channel that thePositionwas committed in.
- getChannel() - Method in interface com.tangosol.net.topic.Subscriber.Element
- 
Return the channel that the element was received from.
- getChannelCount() - Method in interface com.tangosol.net.topic.NamedTopic
- 
Returns the number of channels that this topic has.
- getChannelCount() - Method in interface com.tangosol.net.topic.Publisher
- 
Returns the number of channels in the underlyingNamedTopicthat can be published to.
- getChannelCount() - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns the number of channels in the underlyingNamedTopic.
- getChannelCount(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Returns the number of channels in the topic, or thePagedTopic.DEFAULT_CHANNEL_COUNTvalue to indicate the topic uses the default channel count.
- getChannelCount(String) - Method in interface com.tangosol.net.TopicService
- 
Return the number of channels the topic has.
- getChannels() - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns the current set of channels that thisSubscriberowns.
- getChar() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the char which this PofValue represents.
- getChar() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the char which this PofValue represents.
- getCharArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the char[] which this PofValue represents.
- getCharArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the char[] which this PofValue represents.
- getCharBuf() - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Obtain a temp buffer used to avoid allocations fromString.toCharArray()and repeated calls toString.charAt(int).
- getCharBuf(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Obtain a temp buffer used to avoid allocations when building Strings from UTF binary data.
- getChild(int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Locate a child PofValue contained within this PofValue.
- getChild(int) - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Locate a child PofValue contained within this PofValue.
- getChild(int) - Method in class com.tangosol.io.pof.reflect.SimplePofValue
- 
Locate a child PofValue contained within this PofValue.
- getChildrenIterator() - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Return an iterator over all parsed child values.
- getClass(int) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine the class associated with the given user type identifier.
- getClass(int) - Method in interface com.tangosol.io.pof.PofContext
- 
Determine the class associated with the given user type identifier.
- getClass(int) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Determine the class associated with the given user type identifier.
- getClass(int) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine the class associated with the given user type identifier.
- getClass(int) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Determine the class associated with the given user type identifier.
- getClass(int, PofContext) - Static method in class com.tangosol.io.pof.reflect.PofReflectionHelper
- 
Determine the class associated with the given type identifier.
- getClass(int, ClassLoader) - Method in class com.tangosol.util.ExternalizableHelper.SimpleXmlBeanClassCache
- 
Look up the class for the specified ID.
- getClass(int, ClassLoader) - Method in interface com.tangosol.util.ExternalizableHelper.XmlBeanClassCache
- 
Look up the class for the specified ID.
- getClass(Type) - Static method in class com.tangosol.util.ClassHelper
- getClass(String) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Return class for the specified class name; null if not found.
- getClassArray(Object[]) - Static method in class com.oracle.coherence.common.base.Classes
- 
Calculate the class array based on the parameter array.
- getClassArray(Object[]) - Static method in class com.tangosol.util.ClassHelper
- 
Calculate the class array based on the parameter array.
- getClassArrayFromObjectArray(Object[]) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Returns an array of Class objects representing the class of the objects in the parameter.
- getClassExtracted() - Method in class com.tangosol.util.extractor.PofExtractor
- 
Obtain the Class of the extracted value.
- getClassForTypeId(PofContext, int) - Method in class com.tangosol.io.pof.PortableTypeSerializer
- 
Return the class associated with a specified type identifier, or null if the identifier is not defined in the current POF context.
- getClassId(Class) - Method in class com.tangosol.util.ExternalizableHelper.SimpleXmlBeanClassCache
- 
Look up the class ID for the specified class.
- getClassId(Class) - Method in interface com.tangosol.util.ExternalizableHelper.XmlBeanClassCache
- 
Look up the class ID for the specified class.
- getClassLoader() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Returns theClassLoaderto use in the context of realizingMaps and other associated infrastructure.
- getClassLoader() - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.DataStructureRefExpression
- getClassLoader() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Determine theClassLoaderto use for theCoherenceBasedCache.
- getClassLoader() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- getClassLoader() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
get class loader for this Cache
- getClassLoader() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Returns aClassLoaderassociated with this stream.
- getClassLoader() - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Return the ClassLoader associated with this context.
- getClassLoader() - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Returns the ClassLoader that this CacheStore uses for deserialization, if it has one.
- getClassLoader() - Method in class com.tangosol.net.cache.SerializationMap
- 
Returns the ClassLoader that this map uses for deserialization, if it has one.
- getClassLoader() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns the ClassLoader that this map uses for deserialization, if it has one.
- getClassLoader() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- getClassLoader() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- getClassLoader() - Method in interface com.tangosol.net.SessionConfiguration
- 
Return the optionalClassLoaderto use for the session.
- getClassLoader() - Method in class com.tangosol.net.WrapperSessionConfiguration
- getClassLoader() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a ClassLoader.
- getClassLoader() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Return the ClassLoader associated with this context.
- getClassName() - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- getClassName() - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Return the expression representing the name of the class this builder will attempt to instantiate.
- getClassName(int) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine the name of the class associated with the given user type identifier.
- getClassName(int) - Method in interface com.tangosol.io.pof.PofContext
- 
Determine the name of the class associated with the given user type identifier.
- getClassName(int) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine the name of the class associated with the given user type identifier.
- getClassName(int) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Determine the name of the class associated with the given user type identifier.
- getClassNode(Class) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Return a class definition for the specified class.
- getClient() - Method in enum com.tangosol.net.Coherence.Mode
- 
Returns the defaultcoherence.clientproperty.
- getCloner() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Obtain the Method object that is used to deep-clone the property value.
- getCluster() - Method in class com.oracle.coherence.cdi.server.ClusterProducer
- 
Produces the singleton CoherenceClusterinstance.
- getCluster() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return the currentClusterto be used by commands executed under this context.
- getCluster() - Static method in class com.tangosol.net.CacheFactory
- 
Return a Cluster object for Coherence services.
- getCluster() - Method in class com.tangosol.net.Coherence
- 
Return aClusterobject for Coherence services.
- getCluster() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
The Coherence cluster name to be used for the query.
- getCluster() - Method in interface com.tangosol.net.Service
- 
Return the Cluster object that this Service is a part of.
- getCluster() - Method in class com.tangosol.net.WrapperService
- 
Return the Cluster object that this Service is a part of.
- getClusterActionPolicyBuilder() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the action policy builder used by the cluster to control cluster membership actions.
- getClusterAnnounceTimeoutMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the maximum amount of time that the cluster service will announce itself without receiving a response before deciding that a cluster does not exist and a new cluster should be formed.
- getClusterConfig() - Static method in class com.tangosol.net.CacheFactory
- 
Return the default cluster configuration as defined by the "cluster-config" element in the tangosol-coherence.xml configuration file.
- getClusterHeartbeatDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the amount of time between heartbeat messages.
- getClusterName() - Method in interface com.tangosol.net.Cluster
- 
Determine the configured name for the Cluster.
- getClusterName() - Method in class com.tangosol.net.ClusterPermission
- 
Return the cluster name.
- getClusterName() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the name of the cluster with which this member is associated.
- getClusterName() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the name of the cluster with which this member is associated.
- getClusterName() - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return the cluster name without starting the cluster service.
- getClusterPermissions(Principal) - Method in class com.tangosol.net.security.DefaultController
- 
Obtain the permissions for the specified principal.
- getClusterQuorumMap() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Return the cluster quorum map, keyed by role name.
- getClusterTimestampMaxVarianceMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the maximum variance between sending and receiving broadcast messages when trying to determine the difference between a new cluster Member's wall time and the cluster time.
- getCode() - Method in enum com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
Return the integer representation of the HAStatus.
- getCodec(Class<?>) - Static method in class com.tangosol.io.pof.reflect.Codecs
- 
Return aCodecbased on the provided Class.
- getCoherence() - Method in class com.oracle.coherence.cdi.AbstractCacheInterceptor
- getCoherence() - Method in class com.oracle.coherence.cdi.CoherenceExtension
- 
Returns theCoherenceinstance started by the extension.
- getCoherence() - Method in interface com.tangosol.net.events.CoherenceLifecycleEvent
- 
TheCoherenceinstance that this event is associated with.
- getCoherenceQueryLanguage() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return an instance ofCoherenceQueryLanguageto be used by commands.
- getCoherenceQueryLanguage() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getCoherenceQueryLanguage() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return an instance ofCoherenceQueryLanguageto be used by the QueryPlus session.
- getCollationKey(String) - Method in class com.tangosol.util.CacheCollator
- 
Transforms the String into a series of bits that can be compared bitwise to other CollationKeys.
- getCollection() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Return the underlying Collection.
- getCollection(Collection) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the Collection which this PofValue represents.
- getCollection(Collection) - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the Collection which this PofValue represents.
- getCollection(Collection<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns an instance of Collection that uses a Converter to view an underlying Collection.
- getCollection(Collection, Class) - Static method in class com.tangosol.util.RestrictedCollections
- 
Returns a restricted instance of Collection.
- getCollector() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aCollector.
- getComment() - Method in class com.tangosol.run.xml.SimpleElement
- 
Get the text of any comments that are in the XML element.
- getComment() - Method in interface com.tangosol.run.xml.XmlElement
- 
Get the text of any comments that are in the XML element.
- getCommitCount() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getCommitCount() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Return the number of completed commit requests.
- getCommonDaemonPool() - Method in interface com.tangosol.net.OperationalContext
- 
Return the commonDaemonPool.
- getCommonMonitor(int) - Static method in class com.tangosol.util.Base
- 
Return the common monitor associated with the specified integer value.
- getCommonMonitor(long) - Static method in class com.tangosol.util.Base
- 
Return the common monitor associated with the specified long value.
- getCommonMonitor(Object) - Static method in class com.tangosol.util.Base
- 
Return the common monitor associated with the specified object based on its identity hashCode.
- getComparator() - Method in class com.tangosol.util.comparator.SafeComparator
- 
Obtain the wrapped Comparator.
- getComparator() - Method in class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Return a Comparator used by this extractor.
- getComparator() - Method in class com.tangosol.util.filter.LimitFilter
- 
Obtain the Comparator used to partition the entry values into pages.
- getComparator() - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Get the Comparator used to sort the index.
- getComparator() - Method in interface com.tangosol.util.MapIndex
- 
Get the Comparator used to sort the index.
- getComparator() - Method in class com.tangosol.util.SimpleMapIndex
- 
Get the Comparator used to sort the index.
- getComparator() - Method in class com.tangosol.util.SortedBag
- 
Return the Comparator used to order the bag contents.
- getComparators() - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Obtain the underlying Comparator array.
- getComparisonStyle() - Method in class com.tangosol.util.comparator.EntryComparator
- 
Obtain the comparison style value utilized by this EntryComparator.
- getCompatibleConstructor(Class<?>, Class<?>[]) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Get a compatible constructor to the supplied parameter types.
- getCompatibleMethod(Class<?>, String, Object...) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Obtains theMethodthat is compatible to the supplied parameter types.
- getCompiledExpression() - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Return a compiled MVEL expression.
- getCompiledExpression() - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Return a compiled MVEL expression.
- getCompletableFuture() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- getCompletableFuture() - Method in class com.tangosol.util.AsynchronousAgent
- 
Get the CompletableFuture.
- getCompletedTime() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the time at which the analysis associated with this context was completed, or 0 if it has not been completed.
- getComplex() - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Obtain the current Complex object, if any.
- getComplex() - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Obtain the current Complex object that represents the complex type that is being written to the POF stream.
- getComponentType(Type) - Static method in class com.tangosol.util.ClassHelper
- 
Obtains the component type of a collection or array (taking generic declarations into account).
- getCompositeName(Class, String) - Static method in class com.tangosol.util.ClassHelper
- 
Build the composite name of a class based on an existing class and a second class name.
- getCompositeName(String, String) - Static method in class com.tangosol.util.ClassHelper
- 
Build the composite name of a class based on an existing class name and a second class name.
- getCompositePackage(String, String) - Static method in class com.tangosol.util.ClassHelper
- 
Build the composite name of a package based on two package names.
- getConcreteType(Type) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Obtains the concrete (non-parameterized)Classgiven a specified (possibly parameterized) type.
- getConcurrency() - Method in interface com.tangosol.util.TransactionMap
- 
Retrieve this TransactionMap's current concurrency mode.
- getConcurrentMap() - Method in class com.tangosol.util.ConverterCollections.ConverterConcurrentMap
- 
Return the underlying ConcurrentMap.
- getConcurrentMap(ConcurrentMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of ConcurrentMap.
- getConditionalRemoveAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Return the registered action for conditional remove.
- getConfig() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Retrieve the manager's configuration.
- getConfig() - Method in class com.tangosol.io.ConfigurableSerializerFactory
- 
Deprecated.Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine the current configuration of the object.
- getConfig() - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Determine the current configuration of the associated BackingMapManager.
- getConfig() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.net.CompressionFilter
- 
Deprecated.Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.net.ConfigurableAddressProviderFactory
- 
Deprecated.Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Obtain the factory configuration XML.
- getConfig() - Method in class com.tangosol.net.SocketOptions
- 
Deprecated.
- getConfig() - Method in class com.tangosol.persistence.ConfigurableSnapshotArchiverFactory
- 
Determine the current configuration of the object.
- getConfig() - Method in interface com.tangosol.run.xml.XmlConfigurable
- 
Deprecated.Determine the current configuration of the object.
- getConfig() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Determine the current configuration of the associated BackingMapManager.
- getConfigClassLoader() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Return the class loader used to load the configuration for this factory.
- getConfigClassLoader() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return the class loader used to load the configuration for this factory.
- getConfigElementName() - Method in class com.tangosol.coherence.config.CacheMapping
- getConfigElementName() - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Obtain the xml element name of this mapping.
- getConfigElementName() - Method in class com.tangosol.coherence.config.TopicMapping
- getConfigLocation() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Obtain the location of the configuration that the ConfigurablePofContext used to configure itself.
- getConfigMap() - Method in class com.oracle.coherence.mp.config.CoherenceConfigSource
- 
For testing.
- getConfigSerialFilter() - Static method in class com.tangosol.util.ExternalizableHelper
- 
Return the static JVM-wide serial filter ornullif not configured.
- getConfigSerialFilterFactory() - Static method in class com.tangosol.util.ExternalizableHelper
- 
Return the static JVM-wide serial filter factory.
- getConfigSources(ClassLoader) - Method in class com.oracle.coherence.mp.config.CdiConfigSourceProvider
- getConfigUnsafe() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Obtain a mutable reference to the factory configuration XML.
- getConfigurableCacheFactory() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Return theConfigurableCacheFactoryneeded to create nested caches.
- getConfigurableCacheFactory() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- 
Get ConfigurableCacheFactory context.
- getConfigurableCacheFactory() - Static method in class com.tangosol.net.CacheFactory
- 
Obtain the ConfigurableCacheFactory singleton using the configuration info from the "configurable-cache-factory-config" element located in the tangosol-coherence.xml configuration file.
- getConfigurableCacheFactory() - Static method in class com.tangosol.net.DefaultCacheServer
- 
Gets a ConfigurableCacheFactory based on the default configuration.
- getConfigurableCacheFactory() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- getConfigurableCacheFactory() - Method in interface com.tangosol.net.events.application.LifecycleEvent
- 
Returns theConfigurableCacheFactoryinstance that was activated or about to be disposed.
- getConfigurableCacheFactory(PartitionedService) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.ServiceEventHandler
- getConfigurableCacheFactory(ClassLoader) - Static method in class com.tangosol.net.CacheFactory
- 
Obtain the ConfigurableCacheFactory associated with the specified class loader.
- getConfigurableCacheFactory(ClassLoader) - Method in interface com.tangosol.net.CacheFactoryBuilder
- 
Return the default ConfigurableCacheFactory for a given class loader.
- getConfigurableCacheFactory(ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Return the default ConfigurableCacheFactory for a given class loader.
- getConfigurableCacheFactory(String, ClassLoader) - Method in interface com.tangosol.net.CacheFactoryBuilder
- 
Return the ConfigurableCacheFactory for a given URI and class loader.
- getConfigurableCacheFactory(String, ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Return the ConfigurableCacheFactory for a given URI and class loader.
- getConfigurableCacheFactory(String, ClassLoader, ParameterResolver) - Method in interface com.tangosol.net.CacheFactoryBuilder
- 
Return the ConfigurableCacheFactory for a given URI and class loader.
- getConfigurableCacheFactory(String, ClassLoader, ParameterResolver) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Return the ConfigurableCacheFactory for a given URI and class loader.
- getConfigurableCacheFactoryConfig() - Static method in class com.tangosol.net.CacheFactory
- 
Return the configurable cache factory configuration as defined by the "configurable-cache-factory-config" element in the tangosol-coherence.xml configuration file.
- getConfigurableCacheFactoryConfig() - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Return the XML configuration used for the construction of aConfigurableCacheFactory.
- getConfiguration() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
- 
Obtains the underlyingCacheEntryListenerConfigurationused to create the registration
- getConfiguration() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
- 
Return the JCache cache configuration
- getConfiguration() - Method in class com.tangosol.net.Coherence
- 
Returns the configuration used by thisCoherenceinstance.
- getConfiguration(Class<T>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- getConfiguration(Class<T>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- getConfiguredAddresses(AddressProvider) - Method in class com.tangosol.net.CompositeAddressProvider
- 
Return a list of configured addresses in the specified AddressProvider.
- getConfiguredChannelCount() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Returns the number of channels configured for the topic, orPagedTopic.DEFAULT_CHANNEL_COUNTto indicate that the topic uses the default number of channels.
- getConfiguredName() - Method in class com.tangosol.util.Daemon
- 
Determine the configured name for the daemon.
- getConfiguredPriority() - Method in class com.tangosol.util.Daemon
- 
Determine the configured priority for the daemon.
- getConfigUri() - Method in interface com.oracle.coherence.cdi.SessionInitializer
- getConfigUri() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- getConfigUri() - Method in interface com.tangosol.net.SessionConfiguration
- 
Return the optional configuration file URI for a session that wraps aConfigurableCacheFactory.
- getConfigUri() - Method in class com.tangosol.net.WrapperSessionConfiguration
- getConfigURI() - Method in interface com.tangosol.io.pof.PofConfigProvider
- 
Provide a POF configuration files to load.
- getConfigURIs() - Method in interface com.tangosol.io.pof.PofConfigProvider
- 
Provide a set of POF configuration files to load.
- getConfirmationMessage(String) - Method in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Return a confirmation message.
- getConnectionCount() - Method in interface com.tangosol.net.ServiceLoad
- 
Return the connection count.
- getConnectionLimit() - Method in interface com.tangosol.net.ServiceLoad
- 
Return the maximum number of simultaneous connections allowed.
- getConnectionPendingCount() - Method in interface com.tangosol.net.ServiceLoad
- 
Return the number of connections that are pending.
- getConnectionPort() - Static method in class com.tangosol.net.management.MBeanConnector
- 
Get the configured connection port for the RMI Connector Server.
- getConnectionPortMax() - Static method in class com.tangosol.net.management.MBeanConnector
- 
Get the max configured connection port for the RMI Connector Server.
- getConstructor(Constructor[]) - Method in class com.tangosol.coherence.rest.util.aggregator.DefaultAggregatorFactory
- 
Search the given constructors for a constructor that accepts a singleValueExtractorparameter.
- getConstructor(Constructor[]) - Method in class com.tangosol.coherence.rest.util.processor.DefaultProcessorFactory
- 
Search the given constructors for a constructor that accepts aStringparameter.
- getConstructorParameterList() - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Return theParameterListto be used for constructor parameters when realizing the class.
- getContainerContext() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- getContainsValueAction() - Method in class com.tangosol.util.SegmentedHashMap
- 
Return the registered action for containsValue().
- getContent() - Method in class com.tangosol.coherence.rest.util.StaticContent
- 
Return content as Binary.
- getContentionObserver() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Return the ContentionObserver for this SegmentedConcurrentMap.
- getContext() - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- getContext() - Method in interface com.oracle.coherence.grpc.proxy.GrpcServiceDependencies
- 
Return the optional applicationContext.
- getContext() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Get the JCache context for this JCache's operations
- getContext() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Return currentJCacheContext
- getContext() - Method in class com.tangosol.net.AbstractBackingMapManager
- 
Determine the current BackingMapManagerContext for this BackingMapManager.
- getContext() - Method in interface com.tangosol.net.BackingMapManager
- 
Determine the current BackingMapManagerContext for this BackingMapManager.
- getContext() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return the context this entry operates within.
- getContext() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the context information provided by the CacheService.
- getContext() - Method in interface com.tangosol.net.Guardable
- 
Return the guard context monitoring this guardable, or null if this Guardable is no longer being monitored.
- getContext() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Obtain the BackingMapManagerContext that provides the partition information for keys that are stored in the backing map.
- getContext() - Method in interface com.tangosol.util.BinaryEntry
- 
Return the context this entry operates within.
- getContext() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Return the context this entry operates within.
- getContext() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Get the BackingMapManagerContext if one was provided.
- getContext() - Method in class com.tangosol.util.Daemon
- 
Return the guard context monitoring this guardable, or null if this Guardable is no longer being monitored.
- getContext() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- getContext(ResourceRegistry, JCacheIdentifier) - Static method in class com.tangosol.coherence.jcache.common.JCacheContext
- 
Get a JCacheContext forcacheIdinResourceRegistry
- getContext(ResourceRegistry, JCacheIdentifier, CompleteConfiguration) - Static method in class com.tangosol.coherence.jcache.common.JCacheContext
- 
Get or Create a JCacheContext forcacheIdinResourceRegistry
- getContext(Class<?>) - Method in class com.tangosol.coherence.rest.providers.JacksonMapperProvider
- getContextClassLoader() - Static method in class com.oracle.coherence.common.base.Classes
- 
Try to determine the ClassLoader that supports the current context.
- getContextClassLoader() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- getContextClassLoader() - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- getContextClassLoader() - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Return the context class loader to use.
- getContextClassLoader() - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains theClassLoaderto use for loading classes in theProcessingContext.
- getContextClassLoader() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Obtains theClassLoaderto use for dynamically loading classes during processing.
- getContextClassLoader() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
- 
Obtains theClassLoaderto use for dynamically loading classes during processing.
- getContextClassLoader() - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains theClassLoaderto use for loading classes in theProcessingContext.
- getContextClassLoader() - Method in interface com.tangosol.io.ClassLoaderAware
- 
Retrieve the context ClassLoader for this object.
- getContextClassLoader() - Method in class com.tangosol.io.DefaultSerializer
- getContextClassLoader() - Method in class com.tangosol.io.MultiplexingSerializer
- getContextClassLoader() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Retrieve the context ClassLoader for this object.
- getContextClassLoader() - Method in class com.tangosol.net.cache.NearCache
- 
Retrieve the context ClassLoader for this object.
- getContextClassLoader() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DefaultDependencies
- 
Obtains theClassLoaderthan anExtensibleConfigurableCacheFactoryshould use for loading classes.
- getContextClassLoader() - Method in interface com.tangosol.net.ExtensibleConfigurableCacheFactory.Dependencies
- 
Obtains theClassLoaderthan anExtensibleConfigurableCacheFactoryshould use for loading classes.
- getContextClassLoader() - Method in class com.tangosol.net.WrapperService
- 
Retrieve the context ClassLoader for this object.
- getContextClassLoader() - Static method in class com.tangosol.util.Base
- 
Try to determine the ClassLoader that supports the current context.
- getContextClassLoader(Object) - Static method in class com.oracle.coherence.common.base.Classes
- 
Try to determine the ClassLoader that supports the current context.
- getContextClassLoader(Object) - Static method in class com.tangosol.util.Base
- 
Try to determine the ClassLoader that supports the current context.
- getContextSerializer() - Method in interface com.tangosol.io.SerializerAware
- 
Retrieve the context Serializer for this object.
- getContinuation() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aContinuation.
- getControlMap() - Method in class com.tangosol.net.cache.CachingMap
- 
Obtain the ConcurrentMap that should be used to synchronize the front map modification access.
- getControlMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the concurrency control map for this backing map.
- getConverter() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a Converter.
- getConverter() - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
Return the converter used by this IndexCalculator, or null.
- getConverterDown() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Return the Converter used to pass values down to the underlying Collection.
- getConverterDown() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- 
Return the Converter used to pass values down to the underlying ListIterator.
- getConverterHolder(F, Converter<F, T>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of Holder..
- getConverterKeyDown() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Return the Converter used to pass keys down to the underlying Entry Set.
- getConverterKeyDown() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Return the Converter used to pass keys down to the underlying Map.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- 
Return the Converter to view the underlying Entry's key through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntry
- 
Return the Converter to view the underlying Entry's key through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterEntry
- 
Return the Converter to view the underlying Entry's key through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Return the Converter used to view the underlying Entry Set's keys through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Return the Converter used to view the underlying Map's keys through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Return the Converter used to view the underlying MapEvent's key through.
- getConverterKeyUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
- 
Return the Converter used to view an underlying CacheEvent's key through.
- getConverterListener(MapListener<? super TK, ? super TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
- 
Create a converter listener for the specified listener.
- getConverterUp() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Return the Converter used to view the underlying Collection's values through.
- getConverterUp() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- 
Return the Converter used to view the underlying ListIterator's values through.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- 
Return the Converter used to change value in the underlying Entry.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.ConverterEntry
- 
Return the Converter used to change value in the underlying Entry.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterEntry
- 
Return the Converter used to change value in the underlying Entry.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Return the Converter used to pass values down to the underlying Entry Set.
- getConverterValueDown() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Return the Converter used to pass values down to the underlying Map.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- 
Return the Converter to view the underlying Entry's value through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntry
- 
Return the Converter to view the underlying Entry's value through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterEntry
- 
Return the Converter to view the underlying Entry's value through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Return the Converter used to view the underlying Entry Set's values through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Return the Converter used to view the underlying Map's values through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Return the Converter used to view the underlying MapEvent's value through.
- getConverterValueUp() - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
- 
Return the Converter used to view an underlying CacheEvent's value through.
- getCookie() - Method in class com.tangosol.util.filter.LimitFilter
- 
Obtain the cookie object.
- getCookie(Class<T>) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Locates and returns the cookie with the specified type.
- getCookie(Class<T>) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Locates and returns the cookie with the specified type.
- getCookie(Class<T>, String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Locates and returns the cookie with the specified type and name.
- getCookie(Class<T>, String) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Locates and returns the cookie with the specified type and name.
- getCoordinatorId() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the node id of the ownership distribution coordinator.
- getCoordinatorId() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the node id of the ownership distribution coordinator.
- getCoordinatorId() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Return the node id of the persistence coordinator.
- getCount() - Method in interface com.oracle.coherence.concurrent.CountDownLatch
- 
Returns the current count.
- getCount() - Method in class com.oracle.coherence.concurrent.LocalCountDownLatch
- getCount() - Method in class com.oracle.coherence.concurrent.RemoteCountDownLatch
- 
Returns the current count.
- getCount() - Method in class com.tangosol.util.UID
- 
Determine the "counter" portion of the UID that ensures that two UIDs generated at the same exact time by the same process are unique.
- getCount() - Method in class com.tangosol.util.UUID
- 
Determine the "counter" portion of the UUID that ensures that two UUIDs generated at the same exact time by the same process are unique.
- getCreatedMillis() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Determine when the cache entry was created.
- getCreationTime() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Gets the time (since the Epoc) in milliseconds since the internal value was created.
- getCreationTime() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Gets the time (since the Epoc) in milliseconds since the internal value was created.
- getCurrent() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Answer the current OPToken.
- getCurrentAsString() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Answer the string representation of the current BaseToken.
- getCurrentAsStringWithAdvance() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Answer the string representation of the current BaseToken and advance.
- getCurrentBaseToken() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Answer the current BaseToken.
- getCurrentBuffer() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Obtain the current buffer.
- getCurrentBufferAbsoluteOffset() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Determine the offset of the first byte of the current buffer.
- getCurrentBufferRemaining() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Determine the maximum number of bytes that can still be written to the current underlying WriteBuffer.
- getCurrentChar() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Answer the current char of the underlying Reader
- getCurrentPage() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Obtain the page to which current updates are being performed.
- getCurrentPageNumber() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Determine the number of pages that the PagedBinaryStore has managed in total, including those it is currently managing.
- getCurrentPageTime() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine the time that the current page was created.
- getCurrentProvider() - Method in class com.tangosol.net.CompositeAddressProvider.AddressIterator
- 
Return the current AddressProvider.
- getCurrentRule() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Return the current quorum rule used by the policy.
- getCurrentSubject() - Static method in class com.tangosol.net.security.SecurityHelper
- 
Return the Subject from the current security context.
- getCurrentTimeMillis() - Static method in class com.tangosol.coherence.jcache.common.Helper
- 
Common method for getting current time to make it easy to change time lookup.
- getCurrentTimeMillis() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Return the currentsafe timeorlast safe timedepending on the optimization flag.
- getCurrentToken() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
- 
Answer a current BaseToken base on the position of streaming
- getCurrentVersion() - Method in interface com.tangosol.net.partition.VersionAwareMapListener
- 
A convenience method that returns a single version with the same rules as describedhere.
- getCustomBuilder() - Method in interface com.tangosol.coherence.config.builder.BuilderCustomization
- 
Obtains the customParameterizedBuilder.
- getCustomBuilder() - Method in class com.tangosol.coherence.config.builder.DefaultBuilderCustomization
- 
Obtains the customParameterizedBuilder.
- getCustomBuilder() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Obtains the customParameterizedBuilder.
- getCustomBuilder() - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractStoreManagerBuilder
- 
Obtains the customParameterizedBuilder.
- getCustomBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
- 
Obtains the customParameterizedBuilder.
- getCustomBuilder() - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Obtains the customParameterizedBuilder.
- getCustomBuilder() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Obtains the customParameterizedBuilder.
- getDaemon() - Method in class com.tangosol.util.Daemon.DaemonWorker
- getDaemonActiveCount() - Method in interface com.tangosol.net.ServiceLoad
- 
Return the number of daemon threads that are currently processing messages.
- getDaemonCount() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getDaemonCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getDaemonCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the number of Daemon threads that exist, if the pool has been started, or the number of Daemon threads that will be created, if the pool has not yet been started.
- getDaemonCount() - Method in interface com.tangosol.net.ServiceLoad
- 
Return number of daemon threads that are used to process messages.
- getDaemonCountMax() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getDaemonCountMax() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getDaemonCountMax() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Returns the maximum number of daemon threads that the pool can create.
- getDaemonCountMin() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getDaemonCountMin() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getDaemonCountMin() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Returns the minimum number of daemon threads that the pool should have.
- getDaemonPool() - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- getDaemonPool() - Method in interface com.oracle.coherence.grpc.proxy.GrpcServiceDependencies
- 
Return theDaemonPool.
- getDaemonPool() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the optional DaemonPool used to execute tasks.
- getDaemonPool() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the optional DaemonPool used to execute tasks.
- getDataDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The directory used to store persisted data.
- getDataDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the directory used to store persisted data.
- getDatagramSocketProvider(int) - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
- 
Return an instance of the specified DatagramSocketProvider, creating it if necessary.
- getDatagramSocketProvider(XmlElement, int) - Method in class com.tangosol.net.SocketProviderFactory
- 
Deprecated.
- getDatagramSocketProvider(String, SocketProviderFactory.Dependencies, int, boolean) - Method in class com.tangosol.net.SocketProviderFactory
- 
Return an instance of the specified DatagramSocketProvider, creating it if necessary.
- getDataInput() - Method in class com.tangosol.io.WrapperBufferInput
- 
Obtain the underlying object providing the DataInput interface that this object is delegating to.
- getDataInput() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Obtain the underlying object providing the DataInput interface that this object is delegating to.
- getDataOutput() - Method in class com.tangosol.io.WrapperBufferOutput
- 
Obtain the underlying object providing the DataOutput interface that this object is delegating to.
- getDataOutput() - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Obtain the underlying object providing the DataOutput interface that this object is delegating to.
- getDataOutput() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a DataOutput.
- getDataVersion() - Method in class com.tangosol.io.AbstractEvolvable
- 
Obtain the version associated with the data stream from which this object was deserialized.
- getDataVersion() - Method in interface com.tangosol.io.Evolvable
- 
Obtain the version associated with the data stream from which this object was deserialized.
- getDataVersion() - Method in class com.tangosol.io.SimpleEvolvable
- 
Obtain the version associated with the data stream from which this object was deserialized.
- getDate() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the Date which this PofValue represents.
- getDate() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the Date which this PofValue represents.
- getDate() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a Date.
- getDate() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a Date.
- getDate(Date) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a Date.
- getDate(Date) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a Date.
- getDateTime() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a Timestamp.
- getDateTime() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a Timestamp.
- getDateTime(Timestamp) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a Timestamp.
- getDateTime(Timestamp) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a Timestamp.
- getDay() - Method in class com.tangosol.io.pof.RawDate
- 
Determine the date's day value.
- getDays() - Method in class com.tangosol.io.pof.RawDayTimeInterval
- 
Determine the number of days in the day-time interval.
- getDb() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
Get the underlying Database handle.
- getDbConfig() - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Get the DatabaseConfiguration used to create Databases.
- getDbHolder() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Get the DatabaseHolder.
- getDbIdCounter() - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Get the DB ID Counter value.
- getDeactivationListener() - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Return theMapListenerProxy.DeactivationListenerfor this proxy.
- getDecimal() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a decimal.
- getDecimal() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a decimal.
- getDecimal(BigDecimal) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a decimal.
- getDecimal(BigDecimal) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a decimal.
- getDecomposition() - Method in class com.tangosol.util.CacheCollator
- 
Get the decomposition mode of this Collator.
- getDecoration() - Method in class com.tangosol.util.ExternalizableHelper.IntDecoratedObject
- 
Return the int decoration.
- getDecoration(ReadBuffer, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Extract and return the specified decoration from the passed ReadBuffer.
- getDecoration(Binary, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Deprecated.as of Coherence 3.7.2
- getDecorations(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Return an array containing all of the decorations from the passed ReadBuffer.
- getDeepMessage(Throwable, String) - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Extract a throwable's message, and all causal messages.
- getDeepMessage(Throwable, String) - Static method in class com.tangosol.util.Base
- 
Extract a throwable's message, and all causal messages.
- getDefault() - Static method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Return the default executor.
- getDefaultClassLoader() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- 
Returns a non-null ClassLoader.
- getDefaultCoherenceBasedConfigurationClassName() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- 
Determines the fully-qualified-class-name of the defaultCoherenceBasedConfigurationclass to use when provided with a JCacheConfiguration.
- getDefaultDatagramSocketProvider(SocketProviderBuilder, int) - Method in class com.tangosol.net.SocketProviderFactory
- 
Return an instance of the specified DatagramSocketProvider, creating it if necessary.
- getDefaultDirectory() - Static method in class com.tangosol.io.AbstractBinaryStore
- 
Obtain a File object for the default directory to use for file storage.
- getDefaultDomain() - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return the default domain name as configured in the Coherence operational configuration descriptor ("default-domain-name" element).
- getDefaultGuardRecovery() - Method in interface com.tangosol.net.Guardian
- 
Default recovery percentage for Guardables monitored by this Guardian.
- getDefaultGuardTimeout() - Method in interface com.tangosol.net.Guardian
- 
Default timeout interval (in milliseconds) for Guardables monitored by this Guardian.
- getDefaultLoadBalancer() - Method in class com.tangosol.coherence.config.builder.InvalidConfigServiceLoadBalancerBuilder
- 
Use thisServiceLoadBalancerwhen a customized ServiceLoadBalancer is not provided.
- getDefaultLoadBalancer() - Method in class com.tangosol.coherence.config.builder.ProxyServiceLoadBalancerBuilder
- 
Use thisServiceLoadBalancerwhen a customized ServiceLoadBalancer is not provided.
- getDefaultLoadBalancer() - Method in class com.tangosol.coherence.config.builder.ServiceLoadBalancerBuilder
- 
Use thisServiceLoadBalancerwhen a customized ServiceLoadBalancer is not provided.
- getDefaultName(String, Filter, ValueExtractor) - Static method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Return the default name used by the CQC.
- getDefaultNamespaceHandler() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
TheNamespaceHandlerfor the default (ie: unspecified) xml namespace.
- getDefaultNamespaceHandler() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
- 
TheNamespaceHandlerfor the default (ie: unspecified) xml namespace.
- getDefaultParameterResolver() - Method in class com.tangosol.coherence.config.CacheConfig
- 
Obtain theParameterResolverto use for theCacheConfigwhen no other is available or in context.
- getDefaultParameterResolver() - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- 
Obtains the ParameterResolver to use when resolving parameters without one being available in a context.
- getDefaultParameterResolver() - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains theParameterResolverto use for resolving parameters defined externally to the document being processed (ie: the operating system or container)
- getDefaultParameterResolver() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Obtains the defaultParameterResolverthat may be used for resolving externally defined configuration parameters, like those from the operating system or container.
- getDefaultParameterResolver() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
- 
Obtains the defaultParameterResolverthat may be used for resolving externally defined configuration parameters, like those from the operating system or container.
- getDefaultParameterResolver() - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains theParameterResolverto use for resolving parameters defined externally to the document being processed (ie: the operating system or container)
- getDefaultPersistenceEnvironmentHomeDirectory() - Static method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Return the default 'base' persistence directory.
- getDefaultProperties() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- getDefaultSerializer(InjectionPoint) - Method in class com.oracle.coherence.cdi.SerializerProducer
- 
Produces an instance of the defaultSerializer.
- getDefaultServiceName() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
DefaultServiceName to use if none configured.
- getDefaultSession(InjectionPoint) - Method in class com.oracle.coherence.cdi.SessionProducer
- 
Produces the defaultSession.
- getDefaultSessionName() - Method in interface com.tangosol.net.CoherenceConfiguration
- 
Return the name of the default session.
- getDefaultSessionName() - Method in class com.tangosol.net.CoherenceConfiguration.SimpleConfig
- getDefaultSocketProviderBuilder() - Method in class com.tangosol.net.SocketProviderFactory
- 
Return the defaultSocketProviderBuilder.
- getDefaultURI() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- getDeferredList() - Method in class com.tangosol.net.cache.OverflowMap
- 
Obtain the List of keys that may have deferred events.
- getDeferredList() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Obtain the List of keys that may have deferred events.
- getDelayMillis() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Obtain the timeout delay value.
- getDelayMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- getDelayMillis(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Specifies the maximum amount of time that individual execution requests are allowed to be deferred for a purpose of "bundling" them and passing into a corresponding bulk operation.
- getDelaySeconds() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- getDelegate() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- 
Returns theDaemonPoolto delegate to.
- getDelegate() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool.TracingRunnable
- 
Returns theRunnabledelegate.
- getDelegate() - Method in class com.tangosol.coherence.config.builder.NamedResourceBuilder
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- 
Return the Collection to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- 
Return the Map to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- 
Return the Iterator to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- 
Return the List to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
- 
Return the Iterator to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- 
Return the Map to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSet
- 
Return the Set to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- 
Return the Map to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
- 
Return the SortedSet to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- 
Return the Collection to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- 
Return the Collection to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
Return the Map to which all operations should be delegated to.
- getDelegate() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperSet
- 
Return the Set to which all operations should be delegated to.
- getDelegateSocketProvider() - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Return the SocketProvider to use in producing the underling sockets which will be wrapped with DatagramSocket.
- getDelegateSocketProvider() - Method in interface com.tangosol.net.TcpDatagramSocketProvider.Dependencies
- 
Return the SocketProvider to use in producing the underling sockets which will be wrapped with DatagramSocket.
- getDelimiter() - Method in class com.tangosol.config.expression.ValueMacroExpression.DefaultDelimiterExpansionProcessor
- getDelimiter() - Method in class com.tangosol.config.expression.ValueMacroExpression.MacroExpansionProcessor
- 
Return delimiter being used by the processor.
- getDelimiter() - Method in class com.tangosol.config.expression.ValueMacroExpression.OffsetLengthSubstringExpansionProcessor
- getDelta() - Method in class com.tangosol.io.pof.PofDeltaCompressor.ChangeTracker
- 
Obtain the final delta result as a Binary value.
- getDeltaCompressor() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a DeltaCompressor.
- getDeltaCompressor(Serializer, DeltaCompressor) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Return a DeltaCompressor suitable for compressing/extracting binaries produced by ExternalizableHelper using the specified serializer.
- getDemultiplexedSocketProvider(int) - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
- 
Return a Demultiplexed Socket provider
- getDemultiplexedSocketProvider(SocketProviderBuilder, int) - Method in class com.tangosol.net.SocketProviderFactory
- 
Return a Demultiplexed Socket provider
- getDemultiplexedSocketProvider(XmlElement, int) - Method in class com.tangosol.net.SocketProviderFactory
- 
Deprecated.
- getDemultiplexedSocketProvider(String, SocketProviderFactory.Dependencies, int, boolean) - Method in class com.tangosol.net.SocketProviderFactory
- 
Return a Demultiplexed Socket provider
- getDependencies() - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- getDependencies() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- getDependencies() - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
- 
Return either an anonymous SocketProviderFactory dependencies for an inlined socket-provider or the global SocketProviderFactory dependencies initialized from cluster socket-providers definitions.
- getDependencies() - Method in class com.tangosol.config.xml.DefaultProcessingContext
- getDependencies() - Method in interface com.tangosol.net.Cluster
- 
Retrieve the Cluster configuration.
- getDependencies() - Method in interface com.tangosol.net.Service
- 
Return the service's dependencies.
- getDependencies() - Method in class com.tangosol.net.SocketProviderFactory
- 
Get SocketProviderDependencies object
- getDependencies() - Method in class com.tangosol.net.WrapperService
- 
Return the service's dependencies.
- getDepth() - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Determine the current nested data structure depth within the POF stream.
- getDerivedName(Class, String) - Static method in class com.tangosol.util.ClassHelper
- 
Build the name of a "derived" class based on an existing class and a "derived" class prefix.
- getDerivedName(String, String) - Static method in class com.tangosol.util.ClassHelper
- 
Build the name of a "derived" class based on the name of an existing class and a "derived" class prefix.
- getDescription() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Return the description of the registeredExecutorService.
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder
- getDescription() - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
- getDescription() - Method in interface com.tangosol.coherence.dslquery.StatementBuilder
- 
Return a description of the CohQL command suitable for displaying as help text.
- getDescription() - Method in class com.tangosol.config.expression.ChainedParameterResolver
- 
Return a human-readable String representation of this class.
- getDescription() - Method in class com.tangosol.config.expression.ScopedParameterResolver
- 
Return a human-readable String representation of this class.
- getDescription() - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.CacheEvent
- 
Get the event's description.
- getDescription() - Method in class com.tangosol.net.cache.OverflowMap.ExpirableStatus
- 
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.SerializationCache
- 
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.SerializationMap
- 
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Return a human-readable description of the state of the partition assignment.
- getDescription() - Method in class com.tangosol.net.partition.Ownership
- 
Return a human-readable description of this Ownership.
- getDescription() - Method in interface com.tangosol.net.partition.PartitionAssignmentStrategy
- 
Return a human-readable description of the state of the partition assignment.
- getDescription() - Method in class com.tangosol.net.partition.PartitionEvent
- 
Get the event's description.
- getDescription() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return a human-readable description of this statistics object.
- getDescription() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Return a human-readable description string of this backup-strength.
- getDescription() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return a human-readable description of the state of the partition assignment.
- getDescription() - Method in class com.tangosol.net.partition.VersionedOwnership
- 
Return a human-readable description of this Ownership.
- getDescription() - Method in interface com.tangosol.net.ThreadPoolSizingStrategy
- 
Return a human-readable description of the state of the ThreadPoolSizingStrategy.
- getDescription() - Method in class com.tangosol.util.Daemon
- 
Format the Daemon attributes into a String for inclusion in the String returned from theDaemon.toString()method.
- getDescription() - Method in class com.tangosol.util.filter.CacheEventFilter
- 
Get the filter's description.
- getDescription() - Method in class com.tangosol.util.filter.MapEventFilter
- 
Get the filter's description.
- getDescription() - Method in class com.tangosol.util.MapEvent
- 
Get the event's description.
- getDescription() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Get the event's description.
- getDescription() - Method in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
- 
Return a human-readable description of the state of the partition assignment.
- getDescription() - Method in class com.tangosol.util.processor.NumberIncrementor
- 
Returns this PropertyProcessor's description.
- getDescription() - Method in class com.tangosol.util.processor.NumberMultiplier
- 
Returns this PropertyProcessor's description.
- getDescription() - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Returns this PropertyProcessor's description.
- getDescription() - Method in class com.tangosol.util.TaskDaemon
- 
Format the Daemon attributes into a String for inclusion in the String returned from theDaemon.toString()method.
- getDescription() - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Assemble a human-readable description.
- getDescription() - Method in class com.tangosol.util.WrapperObservableMap
- 
Assemble a human-readable description.
- getDescription(int) - Static method in class com.tangosol.net.partition.PartitionEvent
- 
Convert an event ID into a human-readable string.
- getDescription(int) - Static method in class com.tangosol.util.MapEvent
- 
Convert an event ID into a human-readable string.
- getDescription(Class<?>, MBeanInfo) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Retrieve the description for the MBean from the MBean interface annotation.
- getDescription(Class, MBeanAttributeInfo) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Retrieve a description for a particular attribute by finding aDescriptionannotation on the getter method for the attribute.
- getDescription(Class, MBeanOperationInfo) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Retrieve a description for the particularMBeanOperationInfoby finding aDescriptionannotation on the corresponding method.
- getDescription(MBeanAttributeInfo) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
- 
Retrieve a description for a particular attribute by finding aDescriptionannotation on the getter method for the attribute.
- getDescription(MBeanAttributeInfo) - Method in class com.tangosol.net.management.AnnotatedStandardMBean
- 
Retrieve a description for a particular attribute by finding aDescriptionannotation on the getter method for the attribute.
- getDescription(MBeanInfo) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
- 
Retrieve the description for the MBean from the MBean interface annotation.
- getDescription(MBeanInfo) - Method in class com.tangosol.net.management.AnnotatedStandardMBean
- 
Retrieve the description for the MBean from the MBean interface annotation.
- getDescription(MBeanOperationInfo) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
- 
Retrieve a description for the particularMBeanOperationInfoby finding aDescriptionannotation on the corresponding operation.
- getDescription(MBeanOperationInfo) - Method in class com.tangosol.net.management.AnnotatedStandardMBean
- 
Retrieve a description for the particularMBeanOperationInfoby finding aDescriptionannotation on the corresponding operation.
- getDeserializedResult() - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Obtain the holder's deserialized result value, assuming that the result value is a serializedBinary.
- getDesiredState(S, ExecutionContext) - Method in interface com.tangosol.util.fsm.Event
- 
Determines the desired state of theFiniteStateMachinefor theEventgiven the current state of theFiniteStateMachine.
- getDesiredState(S, ExecutionContext) - Method in class com.tangosol.util.fsm.Instruction.TransitionTo
- 
Determines the desired state of theFiniteStateMachinefor theEventgiven the current state of theFiniteStateMachine.
- getDesiredState(S, ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
- 
Determines the desired state of theFiniteStateMachinefor theEventgiven the current state of theFiniteStateMachine.
- getDesiredState(S, ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DelayedTransitionTo
- 
Determines the desired state of theFiniteStateMachinefor theEventgiven the current state of theFiniteStateMachine.
- getDesiredState(S, ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.SubsequentEvent
- 
Determines the desired state of theFiniteStateMachinefor theEventgiven the current state of theFiniteStateMachine.
- getDestination(int) - Method in class com.tangosol.net.LoadBalancer
- 
Determine one of the AddressPort combinations that the load balancer balances requests to.
- getDestinationCount() - Method in class com.tangosol.net.LoadBalancer
- 
Determine the number of AddressPort combinations that the load balancer balances requests to.
- getDestructiveBufferInput() - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Return a self-destructing BufferInput over this Buffer.
- getDirectory() - Method in class com.tangosol.io.nio.MappedStoreManager
- 
Obtain the directory to use for MappedBufferManager(s).
- getDirectory(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Return the path name for the root directory that the BDB file manager uses to store files in.
- getDirectory(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.NioFileManagerBuilder
- 
Return the path name for the root directory that the manager uses to store files in.
- getDirectory(ParameterResolver) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
- 
Return the root directory where the disk persistence manager stores files.
- getDirectory(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Return the root directory where the disk persistence manager stores files.
- getDirectQuery() - Method in class com.tangosol.coherence.rest.config.QueryConfig
- 
Return the direct query.
- getDirectStorageSize() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the partition size from partitioned maps.
- getDirEnv() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Get the Environment Directory.
- getDirLock() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Get the DirectoryLock held on a temporary Environment.
- getDirParent() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Get the Parent Directory.
- getDirtyBytesCount() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Get the estimated number of dirty bytes in this POF value hierarchy.
- getDiscoveryInterface() - Method in interface com.tangosol.net.OperationalContext
- 
Return the IP associated with the network interface to use for multicast based discovery.
- getDiscoveryTimeToLive() - Method in interface com.tangosol.net.OperationalContext
- 
Return the TTL for multicast based discovery.
- getDispatcher() - Method in interface com.tangosol.net.events.CoherenceLifecycleEvent
- getDispatcher() - Method in interface com.tangosol.net.events.Event
- 
Return theEventDispatcherthis event was raised by.
- getDispatcher() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEvent
- 
Deprecated.
- getDispatcher() - Method in interface com.tangosol.net.events.partition.cache.Event
- 
Return thePartitionedCacheDispatcherthis event was raised by.
- getDispatcher() - Method in interface com.tangosol.net.events.partition.Event
- 
Return thePartitionedServiceDispatcherthis event was raised by.
- getDispatcher() - Method in interface com.tangosol.net.events.SessionLifecycleEvent
- getDistance(Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
- 
Return the "distance" of the specified member from the reference ownership.
- getDistance(Member, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
- 
Return the "distance" between the specified members.
- getDistributedCacheConfig() - Static method in class com.tangosol.net.CacheFactory
- 
Return the default distributed (partitioned) cache configuration.
- getDocumentComment() - Method in class com.tangosol.run.xml.SimpleDocument
- 
Get the XML comment that appears outside of the root element.
- getDocumentComment() - Method in interface com.tangosol.run.xml.XmlDocument
- 
Get the XML comment that appears outside of the root element.
- getDocumentPreprocessor() - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Obtains theDocumentPreprocessorthat must be applied to theXmlElement(ie: document) in which theNamespaceHandleris defined, prior toXmlElements andXmlAttributes being processed defined by thisNamespaceHandler.
- getDocumentPreprocessor() - Method in interface com.tangosol.config.xml.NamespaceHandler
- 
Obtains theDocumentPreprocessorthat must be applied to theXmlElement(ie: document) in which theNamespaceHandleris defined, prior toXmlElements andXmlAttributes being processed defined by thisNamespaceHandler.
- getDomainName() - Method in interface com.tangosol.net.management.Registry
- 
Domain name for managed beans registered by Coherence clustered services.
- getDomainPartitions() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getDomainPartitions() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return the optional array of domain partition names to use if loading a GAR file.
- getDouble() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the double which this PofValue represents.
- getDouble() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the double which this PofValue represents.
- getDouble() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a double.
- getDouble() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a double.
- getDouble(double) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a double.
- getDouble(double) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a double.
- getDouble(String) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as a Double.
- getDouble(String, double) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as a double.
- getDoubleArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the double[] which this PofValue represents.
- getDoubleArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the double[] which this PofValue represents.
- getDtdName() - Method in class com.tangosol.run.xml.SimpleDocument
- 
Get the public identifier of the DTD (DOCTYPE) for the document.
- getDtdName() - Method in interface com.tangosol.run.xml.XmlDocument
- 
Get the public identifier of the DTD (DOCTYPE) for the document.
- getDtdUri() - Method in class com.tangosol.run.xml.SimpleDocument
- 
Get the URI of the DTD (DOCTYPE) for the document.
- getDtdUri() - Method in interface com.tangosol.run.xml.XmlDocument
- 
Get the URI of the DTD (DOCTYPE) for the document.
- getDuration() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DelayedTransitionTo
- 
Obtains the amount of time to wait before the transition to the desired state should occur
- getDuration() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.ProcessEventLater
- 
Obtains the amount of time to wait before the transition to the desired state should occur.
- getDuration() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
- 
Get the amount of time (in ms) spent evaluating the filter or applying an index for this query plan step.
- getDuration() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Get the amount of time (in ms) spent evaluating the filter or applying an index for this query plan step.
- getDuration(String) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as aDuration.
- getDuration(String, Duration) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as aDuration.
- getEdition() - Static method in class com.tangosol.net.CacheFactory
- 
Returns the edition currently loaded based on the operational configuration.
- getEdition() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the Coherence product edition.
- getEdition() - Method in interface com.tangosol.net.OperationalContext
- 
Get the product edition.
- getEditionName() - Method in interface com.tangosol.net.OperationalContext
- 
Get the product edition in a formatted string.
- getEfficiency() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
- 
Get the calculated cost of applying the filter as defined bycalculateEffectiveness
- getEfficiency() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Get the calculated cost of applying the filter as defined bycalculateEffectiveness
- getElement(int) - Method in class com.tangosol.util.OpenHashSet
- 
Expose the indexed element storage to sub-classes in a range-unsafe manner.
- getElement(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Get a child element for the specified element.
- getElement(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Get a child element of the specified XmlElement that matches to the specified local name and the specified Namespace URI.
- getElement(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Get a child element.
- getElement(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Get a child element.
- getElementAdapter() - Method in class com.tangosol.run.xml.CollectionAdapter
- getElementCalculator() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Return the calculator used to calculate element sizes.
- getElementCalculatorBuilder() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return the ElementCalculatorBuilder used to build a ElementCalculator.
- getElementCalculatorType(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.ElementCalculatorBuilder
- 
Returns theNamedTopic.ElementCalculatortype.
- getElementCount() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
Obtain the total element count.
- getElementExpiryMillis() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Obtain the expiry delay to apply to elements in ths topic.
- getElementList() - Method in class com.tangosol.run.xml.SimpleElement
- 
Get the list of all child elements.
- getElementList() - Method in interface com.tangosol.run.xml.XmlElement
- 
Get the list of all child elements.
- getElementName() - Method in enum com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- 
Get the configuration element name for thisConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule.
- getElementName() - Method in class com.tangosol.run.xml.IterableAdapter
- getElementProcessor(XmlElement) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Obtains theElementProcessorthat is suitable for processing the specifiedXmlElementin the xml namespace associated with thisNamespaceHandler.
- getElementProcessor(XmlElement) - Method in interface com.tangosol.config.xml.NamespaceHandler
- 
Obtains theElementProcessorthat is suitable for processing the specifiedXmlElementin the xml namespace associated with thisNamespaceHandler.
- getElementProcessor(String) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Obtains theElementProcessorregistered with the specified localName (in the namespace).
- getElements(XmlElement) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Get an iterator of child elements of the specified XmlElement that represent values for a property represented by this adapter.
- getElements(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Get an iterator of child elements of the specified XmlElement that match to the specified local name and the specified Namespace URI.
- getElements(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Get an iterator of child elements that have a specific name.
- getElements(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Get an iterator of child elements that have a specific name.
- getEncodedHash() - Method in class com.tangosol.io.AbstractReadBuffer
- 
Return the encoded hash value orHashEncoded.UNENCODEDif absent.
- getEncodedHash() - Method in interface com.tangosol.util.HashEncoded
- 
Return the encoded hash value orHashEncoded.UNENCODEDif absent.
- getEncoding() - Method in class com.tangosol.run.xml.SimpleDocument
- 
Get the encoding string for the XML document.
- getEncoding() - Method in interface com.tangosol.run.xml.XmlDocument
- 
Get the encoding string for the XML document.
- getEndingState() - Method in class com.tangosol.util.fsm.Transition
- 
Obtains the state to which theFiniteStateMachinewill be in once thisTransitionhas occurred.
- getEntityType() - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Return the type of entities in this repository.
- getEntries() - Method in interface com.tangosol.net.events.partition.TransferEvent
- 
Return a map of cache names and associated set of read-onlyentriesencapsulated in thisTransferEvent.
- getEntries(int, int, String, PropertySet, String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Return the cache entries that satisfy the given query criteria.
- getEntries(PropertySet) - Method in class com.tangosol.coherence.rest.EntrySetResource
- getEntries(UriInfo, int, int, String, PropertySet) - Method in class com.tangosol.coherence.rest.NamedQueryResource
- 
Return the cache entries that satisfy criteria defined by this resource.
- getEntry() - Method in interface com.tangosol.net.events.partition.cache.EntryEvent
- 
Return theentryon which the action represented by thisEntryEventoccurred.
- getEntry() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- 
Return the underlying Map.Entry.
- getEntry() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- 
Return the underlying Map.Entry.
- getEntry(MapEvent) - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
- 
Return the map entry associated with the given map event.
- getEntry(Object) - Method in class com.tangosol.net.cache.LocalCache
- 
Locate an Entry in the hash map based on its key.
- getEntry(Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Locate an Entry in the hash map based on its key.
- getEntry(Object) - Method in class com.tangosol.util.SafeHashMap
- 
Locate an Entry in the hash map based on its key.
- getEntry(Object) - Method in class com.tangosol.util.SafeSortedMap
- 
Locate a Map.Entry in this map based on its key.
- getEntry(Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Locate an Entry in the this map based on its key.
- getEntry(Map.Entry<FK, FV>, Converter<FK, TK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns an instance of a MapEntry that uses Converters to retrieve the Entry's data.
- GetEntryAction() - Constructor for class com.tangosol.util.SegmentedHashMap.GetEntryAction
- getEntryBlockCount() - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns the number of entry blocks.
- getEntryEventsMap(TransactionEvent) - Static method in class com.tangosol.net.events.EventHelper
- 
Converts the providedTransactionEventinto a map keyed byEntryEventand with a value of a Set ofentries.
- getEntryEventsMap(UnsolicitedCommitEvent) - Static method in class com.tangosol.net.events.EventHelper
- 
Converts the providedUnsolicitedCommitEventinto a map keyed byEntryEventand with a value of a Set ofentries.
- getEntryEventsMap(Set<BinaryEntry>, boolean) - Static method in class com.tangosol.net.events.EventHelper
- 
Converts the provided set ofentriesinto a map keyed byEntryEventand with a value of a Set of entries.
- getEntryInternal(Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Locate an Entry in the hash map based on its key.
- getEntryInternal(Object) - Method in class com.tangosol.util.SafeHashMap
- 
Locate an Entry in the hash map based on its key.
- getEntryInternal(Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Locate an Entry in the hash map based on its key.
- getEntryInternal(Object, boolean) - Method in class com.tangosol.util.SegmentedHashMap
- 
Locate an Entry in the hash map based on its key.
- getEntryMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Return a map of items queued to be written.
- getEntryOrQueryResource(String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Return a REST sub-resource representing either a configured named query or a single cache entry.
- getEntryProcessor() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of an EntryProcessor.
- getEntrySet() - Method in interface com.tangosol.net.events.partition.cache.EntryEvent
- 
Deprecated.since 14.1.2; useEntryEvent.getEntry()and related methods instead
- getEntrySet() - Method in interface com.tangosol.net.events.partition.cache.EntryProcessorEvent
- 
Return a Set ofentriesbeing processed by the entry processor.
- getEntrySet() - Method in interface com.tangosol.net.events.partition.TransactionEvent
- 
A set ofentriesenlisted within this transaction.
- getEntrySet() - Method in interface com.tangosol.net.events.partition.UnsolicitedCommitEvent
- 
A set ofentriesobserved to have been modified without being caused by the partitioned service.
- getEntrySet() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Return the underlying Entry Set.
- getEntrySet(Collection<Map.Entry<FK, FV>>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of a Set that holds Entry objects for a ConverterMap.
- getEntrySet(Set, Class, Class) - Static method in class com.tangosol.util.RestrictedCollections
- 
Returns a restricted instance of Set that holds Entry objects for a RestrictedMap.
- getEntrySetResource(String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Return a REST sub-resource representing a set of cache entries.
- getEntrySize() - Method in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
Return the size of a map entry.
- getEntrySize() - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
Return the size of a map entry.
- getEnumeration() - Static method in class com.tangosol.util.NullImplementation
- 
Returns an instance of the null enumerator.
- getenv(String) - Static method in class com.tangosol.coherence.config.Config
- 
Coherence enhanced system environment getter Use instead ofSystem.getenv(String).
- getEnv(String) - Method in class com.oracle.coherence.mp.config.ConfigPropertyResolver
- getEnv(String) - Method in class com.tangosol.coherence.config.EnvironmentVariableResolver.Default
- getEnv(String) - Method in interface com.tangosol.coherence.config.EnvironmentVariableResolver
- 
Return the value of the specified environment variable.
- getEnv(String, String) - Method in interface com.tangosol.coherence.config.EnvironmentVariableResolver
- 
Return the value of the specified environment variable, or the specified default value if the variable doesn't exist.
- getEnvConfig() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Get the Environment Configuration.
- getEnvHolder() - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Get the EnvironmentHolder.
- getEnvironment() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Get underlying Berkeley DB Environment.
- getEnvironment() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Return the underlying PersistenceEnvironment.
- getEnvironmentContinuation(PersistenceEnvironment<R>) - Method in interface com.tangosol.persistence.SafePersistenceWrappers.FailureContinuationFactory
- 
Return a failure continuation to handle unexpected exceptions thrown by operations against the specified PersistenceEnvironment.
- getEnvironmentInfo(ExtensibleConfigurableCacheFactory, String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return thePersistenceEnvironmentInfofor a given cluster and service name using the currentConfigurableCacheFactorywithout starting the services.
- getEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Obtain the bundler for the "erase" operations.
- getEraseFailures() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the number of erase() failures.
- getEraseMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the cumulative time spent on erase() operations.
- getEraseOps() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the number of erase() operations.
- getErr() - Static method in class com.tangosol.util.Base
- 
Obtains the current writer used for tracing.
- getError() - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- 
Returns an optional error that caused a commit to fail.
- getErrorCount() - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
- 
Returns the number of Errors encountered.
- getErrorRequestCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getErrorRequestCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the count of requests that responded with an error.
- getErrorRequestFifteenMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getErrorRequestFifteenMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the fifteen minute rate of requests that responded with an error.
- getErrorRequestFiveMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getErrorRequestFiveMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the five minute rate of requests that responded with an error.
- getErrorRequestMeanRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getErrorRequestMeanRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the mean rate of requests that responded with an error.
- getErrorRequestOneMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getErrorRequestOneMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the one minute rate of requests that responded with an error.
- getEscapeChar() - Method in class com.tangosol.util.filter.LikeFilter
- 
Obtain the escape character that is used for escaping '%' and '_' in the pattern or zero if there is no escape.
- getEvent() - Method in class com.tangosol.util.fsm.Instruction.ProcessEvent
- 
Obtain theEventto process.
- getEvent() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.ProcessEventLater
- 
Obtain theEventto process later.
- getEventDispatcher() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEvent
- 
Return theCacheLifecycleEventDispatcherthis event was raised by.
- getEventDispatcherThreadPriority() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain the priority of the event dispatcher thread.
- getEventInterceptor(String) - Method in interface com.tangosol.net.events.InterceptorRegistry
- 
Return a registeredEventInterceptor.
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.CacheConfig
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.ResourceMapping
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.ClassScheme
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- getEventInterceptorBuilders() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
- getEventInterceptorBuilders() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- getEventListeners() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
- 
Iterable over asynchronous CacheEntryListenerRegistrations
- getEventListeners() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheSynchronousMapListener
- getEventListeners() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
- 
get JCache registered CacheEntryListenerRegistrations.
- getEventListeners() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSynchronousMapListener
- 
Iterate over synchronous JCache CacheEntry Listener Registrations.
- getEventMask() - Method in class com.tangosol.util.filter.MapEventFilter
- 
Obtain the event mask.
- getEventQueue() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Obtain thisContinuousQueryCache's event queue.
- getEventScope(LifecycleEvent) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.LifecycleEventHandler
- getEventScope(E) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
Return the scope name of theConfigurableCacheFactorythe specified event was raised from.
- getEventType() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
The type of the FederatedChangeEvent.
- getEventTypes() - Method in interface com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent
- 
Return the Event Types theEventInterceptorbeing registered will intercept.
- getEventTypes() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Return the set of event types this interceptor is concerned with.
- getEvictionApprover() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getEvictionApprover() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Obtain the registered EvictionApprover.
- getEvictionApprover() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Obtain the registered EvictionApprover.
- getEvictionApprover() - Method in class com.tangosol.net.cache.SerializationCache
- 
Obtain the registered EvictionApprover.
- getEvictionApprover() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Obtain the registered EvictionApprover.
- getEvictionPolicy() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getEvictionPolicy() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Obtain the current EvictionPolicy used by the cache.
- getEvictionPolicy() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Obtain the current EvictionPolicy used by the cache.
- getEvictionPolicy() - Method in class com.tangosol.net.cache.SerializationCache
- 
Obtain the current EvictionPolicy used by the cache.
- getEvictionPolicy() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Obtain the current EvictionPolicy used by the cache.
- getEvictionPolicyBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Return the EvictionPolicyBuilder used to build an EvictionPolicy.
- getEvictionPolicyBuilder() - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Return the EvictionPolicyBuilder used to build an EvictionPolicy.
- getEvictionType() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the current eviction type.
- getEvictionType() - Method in class com.tangosol.net.cache.OldCache.InternalEvictionPolicy
- 
Deprecated.Determine the OldCache eviction type represented by this InternalEvictionPolicy.
- getEvictionType(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.EvictionPolicyBuilder
- 
Obtains the EvictionPolicy type.
- getEvolvable(int) - Method in interface com.tangosol.io.pof.EvolvableObject
- 
ReturnEvolvableobject for the specified type id.
- getEvolvableHolder() - Method in interface com.tangosol.io.pof.EvolvableObject
- 
ReturnEvolvableHolderthat should be used to store information about evolvable objects that are not known during deserialization.
- getException() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- getException() - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
- 
Returns a saved parser exception.
- getException() - Method in class com.tangosol.util.AsynchronousAgent
- 
Helper method that returns an exception (if completed exceptionally).
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractStatement
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.AbstractStatement
- getExecutionConfirmation(ExecutionContext) - Method in interface com.tangosol.coherence.dslquery.Statement
- 
Return a string that will be used as a question to confirm execution of a statement.
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder.ArchiveSnapshotStatement
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder.CreateSnapshotStatement
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder.ForceRecoveryStatement
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder.RecoverSnapshotStatement
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder.RemoveSnapshotStatement
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder.ResumeServiceStatement
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder.RetrieveSnapshotStatement
- getExecutionConfirmation(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder.SuspendServiceStatement
- getExecutionContext() - Method in class com.tangosol.coherence.dslquery.QueryPlus
- 
Return the currentExecutionContextpassed toStatements.
- getExecutionTimeoutMillis() - Method in class com.tangosol.net.AbstractInvocable
- 
Obtain the maximum amount of time this task is allowed to run before the corresponding service will attempt to stop it.
- getExecutionTimeoutMillis() - Method in class com.tangosol.net.AbstractPriorityTask
- 
Obtain the maximum amount of time this task is allowed to run before the corresponding service will attempt to stop it.
- getExecutionTimeoutMillis() - Method in interface com.tangosol.net.PriorityTask
- 
Obtain the maximum amount of time this task is allowed to run before the corresponding service will attempt to stop it.
- getExecutionTimeoutMillis() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DefaultTaskDependencies
- 
Return the execution timeout for the task in millisecond.
- getExecutionTimeoutMillis() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
- 
Obtain the maximum amount of time this task is allowed to run before the corresponding service will attempt to stop it.
- getExecutionTimeoutMillis() - Method in interface com.tangosol.util.fsm.NonBlockingFiniteStateMachine.TaskDependencies
- 
Return the execution timeout for the task in millisecond.
- getExecutor() - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- getExecutor() - Method in interface com.oracle.coherence.grpc.proxy.GrpcServiceDependencies
- 
Return theExecutor.
- getExecutor() - Method in class com.tangosol.net.AsyncNamedMap.Complete
- 
Return theExecutorto use to complete theCompletableFuturereturned from async methods.
- getExpiry() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return the number of milliseconds remaining before the specified entry is scheduled to expire.
- getExpiry() - Method in class com.tangosol.net.cache.OverflowMap.ExpirableStatus
- 
Determine the expiry for the entry represented by this Status.
- getExpiry() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine the expiry for the entry represented by this Status.
- getExpiry() - Method in interface com.tangosol.util.BinaryEntry
- 
Return the number of milliseconds remaining before the specified entry is scheduled to expire.
- getExpiry() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Return the number of milliseconds remaining before the specified entry is scheduled to expire.
- getExpiry() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- getExpiryArray() - Method in class com.tangosol.net.cache.OverflowMap
- 
Obtain the array of keys that have an expiration, indexed by expiration times.
- getExpiryArray() - Method in class com.tangosol.net.cache.SerializationCache
- 
Get the Expiry data structure.
- getExpiryDelay() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getExpiryDelay() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Determine the default "time to live" for each individual cache entry.
- getExpiryDelay() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the default "time to live" for each individual cache entry.
- getExpiryDelay() - Method in class com.tangosol.net.cache.OverflowMap
- 
Determine the "time to live" for each individual cache entry.
- getExpiryDelay() - Method in class com.tangosol.net.cache.SerializationCache
- 
Determine the default "time to live" for each individual cache entry.
- getExpiryDelay() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the default "time to live" for each individual cache entry.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Return the amount of time since the last update that entries are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Return the amount of time since the last update that entries are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Return the amount of time since the last update that entries are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Return the amount of time since the last update that entries are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
- 
Return the amount of time since the last update that entries are kept by the cache before being expired.
- getExpiryDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return the amount of time that elements offered to the queue remain visible to consumers.
- getExpiryMillis() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
- 
Determine when the cache entry will expire, if ever.
- getExpiryMillis() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Determine when the cache entry will expire, if ever.
- getExpiryMillis() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Determine when the cache entry will expire, if ever.
- getExpiryMillis() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Determine when the cache entry will expire, if ever.
- getExpiryMillis() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- 
Determine when the cache entry will expire, if ever.
- getExpiryPolicy() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
- 
Get ExpiryPolicy
- getExpiryPolicyFactory() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- getExpiryTime() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Gets the time (since the Epoc) in milliseconds when the Cache Entry associated with this value should be considered expired.
- getExpiryTime() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Gets the time (since the Epoc) in milliseconds when the Cache Entry associated with this value should be considered expired.
- getExpiryTime() - Method in class com.tangosol.net.cache.SerializationCache.EntryAttributes
- 
Determine the date/time at which the entry expires.
- getExplicitType() - Method in class com.tangosol.config.expression.Parameter
- 
Obtains the explicitly specified type of theParameter.
- getExpression() - Method in class com.tangosol.coherence.rest.config.NamedQuery
- 
Return the query expression.
- getExpression() - Method in class com.tangosol.config.expression.Parameter
- 
Obtains theExpressionfor theParameter.
- getExpression(String) - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Get the source code expression from the method that called the specified method.
- getExpressionParser() - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains the configuredExpressionParserfor thisProcessingContext.
- getExpressionParser() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Obtains theExpressionParserto use for parsingExpressions during document processing.
- getExpressionParser() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
- 
Obtains theExpressionParserto use for parsingExpressions during document processing.
- getExpressionParser() - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains the configuredExpressionParserfor thisProcessingContext.
- getExtendedContext() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- 
Deprecated.
- getExtension() - Method in class com.oracle.coherence.cdi.AbstractCacheInterceptor
- getExtension(String) - Static method in class com.tangosol.io.FileHelper
- 
Gets the extension of a filename.
- getExtensionsMap() - Static method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Construct a map with URL suffix to media type mappings.
- getExternalMap() - Method in class com.tangosol.util.SetMap
- 
Return an external map allowing type safe access.
- getExtractor() - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Retrieve the underlying ValueExtractor reference.
- getExtractor() - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Return extractor for this property.
- getExtractor() - Method in class com.tangosol.net.topic.Subscriber.Convert
- 
Return the option's converter function.
- getExtractor() - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Obtain the underlying ValueExtractor.
- getExtractor() - Method in class com.tangosol.util.comparator.ExtractorComparator
- 
Returns theValueExtractorto extract value(s) to be used in comparison.
- getExtractor() - Method in class com.tangosol.util.extractor.CompositeUpdater
- 
Retrieve the ValueExtractor part.
- getExtractor() - Method in class com.tangosol.util.extractor.ConditionalExtractor
- getExtractor() - Method in class com.tangosol.util.extractor.KeyExtractor
- 
Obtain the underlying ValueExtractor.
- getExtractor() - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Retrieve the underlying ValueExtractor reference.
- getExtractor() - Method in interface com.tangosol.util.ValueManipulator
- 
Retrieve the underlying ValueExtractor reference.
- getExtractor(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the AST node that represents the extractor for an index from the given AST node.
- getExtractor(Map<ValueExtractor<T, E>, MapIndex>, MapIndex) - Method in interface com.tangosol.util.extractor.IndexAwareExtractor
- 
Obtain the underlying ValueExtractor that was added to the index map during theindex creation.
- getExtractorBuilder() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return theExtractorBuilderto use to buildValueExtractors.
- getExtractorDescription() - Method in interface com.tangosol.util.QueryRecord.PartialResult.IndexLookupRecord
- 
Get a description of the extractor that was used for the index lookup.
- getExtractorDescription() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Get a description of the extractor that was used for the index lookup.
- getExtractors() - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
Obtain the ValueExtractor array.
- getFactory() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Get the DatabaseFactory used to create the underlying Database.
- getFactory() - Method in interface com.tangosol.net.SocketProvider
- 
Return the factory associated with this provider.
- getFactory(String, ClassLoader, ParameterResolver) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Helper method to return aConfigurableCacheFactoryinstance for the specified URI and class loader.
- getFactory(String, ClassLoader, ParameterResolver) - Method in class com.tangosol.net.SingletonCacheFactoryBuilder
- 
Helper method to return aConfigurableCacheFactoryinstance for the specified URI and class loader.
- getFactoryClassName() - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Return theExpressionthat when evaluated will produce the name of the class containing a static factory method that will realize instances for thisParameterizedBuilder.
- getFactoryManager() - Static method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Get the DatabaseFactoryManager.
- getFactoryMethodName() - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Return theExpressionthat when evaluated will produce the name of the factory class static method that will realize instances for thisParameterizedBuilder.
- getFactoryMethodParameters() - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Returns theParameterListto use to resolve factory method parameters when realizing the class.
- getFairShare() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
- 
Return the fair-share partition load.
- getFairShare(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the (primary or backup) fair-share partition load.
- getFairShareBackup() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the number of backup partitions per storage-enabled service member that this strategy will currently attempt to maintain.
- getFairShareBackup() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the number of backup partitions per storage-enabled service member that this strategy will currently attempt to maintain.
- getFairSharePrimary() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the number of primary partitions per storage-enabled service member that this strategy will currently attempt to maintain.
- getFairSharePrimary() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the number of primary partitions per storage-enabled service member that this strategy will currently attempt to maintain.
- getFields(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the AST node that represents the fields to select from the given AST node.
- getFile() - Method in class com.tangosol.io.nio.MappedBufferManager
- 
Obtain the RandomAccessFile that the buffer is constructed on.
- getFile(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the String that represents the filename from the given AST node by looking for the "file" term in the AST.
- getFileName() - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- getFiles() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getFiles() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return the list of statement script files that should be executed prior to the start of the CohQL session.
- getFileURL(String) - Static method in class com.oracle.coherence.common.base.Resources
- 
Obtain a URL for an existing file with the specified name.
- getFillLength() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Get the size of the fill in the block.
- getFilter() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Obtain theFilterthat should be used when registering this listener.
- getFilter() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.AsyncSelectStatement
- 
Return theFilterto use to execute this query.
- getFilter() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- 
Return theFilterto use to execute this query.
- getFilter() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- getFilter() - Method in interface com.tangosol.net.management.ViewMBean
- getFilter() - Method in class com.tangosol.net.management.ViewMBeanImpl
- getFilter() - Method in class com.tangosol.net.topic.Subscriber.Filtered
- 
Return the option's filter.
- getFilter() - Method in class com.tangosol.util.ConditionalIndex
- 
Get the associated filter.
- getFilter() - Method in class com.tangosol.util.filter.ArrayFilter.WeightedFilter
- 
Get the wrapped filter.
- getFilter() - Method in class com.tangosol.util.filter.FilterTrigger
- 
Obtain the underlying Filter.
- getFilter() - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Obtain the underlying Filter.
- getFilter() - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Obtain the wrapped Filter.
- getFilter() - Method in class com.tangosol.util.filter.LimitFilter
- 
Obtain the Filter whose results are truncated by this filter.
- getFilter() - Method in class com.tangosol.util.filter.MapEventFilter
- 
Obtain the Filter object used to evaluate the event value(s).
- getFilter() - Method in class com.tangosol.util.filter.NotFilter
- 
Obtain the Filter whose results are negated by this filter.
- getFilter() - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Obtain the wrapped Filter.
- getFilter() - Method in class com.tangosol.util.filter.PriorityFilter
- 
Obtain the underlying filter.
- getFilter() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Return an array of filters that are the cause of this event.
- getFilter(ByteString, Serializer) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Obtain aFilterfrom the serialized data in aByteString.
- getFilter(ByteString, Serializer) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Obtain aFilterfrom the serialized data in aByteString.
- getFilter(InjectionPoint) - Method in class com.oracle.coherence.cdi.FilterProducer
- 
ProducesFilterbased on injection point metadata.
- getFilterBuilder() - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- 
Return theParameterizedBuilderused to construct theFilterto be used by theContinuousQueryCache.
- getFilterDescription() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
- 
Get a description of the filter that was associated with this step during its creation.
- getFilterDescription() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Get a description of the filter that was associated with this step during its creation.
- getFilterList() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the list of all filters for the cluster.
- getFilterMap() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the map of filter name to WrapperStreamFactory.
- getFilterMap() - Method in interface com.tangosol.net.OperationalContext
- 
Return a Map of network filter factories.
- getFilters() - Method in class com.tangosol.util.filter.ArrayFilter
- 
Obtain the Filter array.
- getFilters() - Method in class com.tangosol.util.Listeners
- 
Return the array of filters associated with this Listeners object.
- getFilterSet() - Method in class com.tangosol.util.MapListenerSupport
- 
Obtain a set of all filters that have associated global listeners.
- getFirst() - Method in class com.tangosol.util.SafeLinkedList
- 
Returns the first element in the list, or null if empty.
- getFirstEntry() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- 
Return the first entry in the list..
- getFirstIndex() - Method in class com.tangosol.util.AbstractLongArray
- 
Determine the first index that exists in the LongArray.
- getFirstIndex() - Method in class com.tangosol.util.AbstractSafeLongArray
- getFirstIndex() - Method in class com.tangosol.util.AbstractSparseArray
- 
Determine the first index that exists in the LongArray.
- getFirstIndex() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- getFirstIndex() - Method in interface com.tangosol.util.LongArray
- 
Determine the first index that exists in the LongArray.
- getFirstIndex() - Method in class com.tangosol.util.NullImplementation.NullLongArray
- getFirstIndex() - Method in class com.tangosol.util.SimpleLongArray
- 
Determine the first index that exists in the LongArray.
- getFirstIndex() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- getFirstMap() - Method in class com.tangosol.util.ChainedMap
- 
Get the first (front) map.
- getFirstParameter(ParameterResolver, ParameterList, Class<V>) - Static method in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
Extract the first parameter from the listParameters argument.
- getFirstPolled() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getFirstPolled() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the first position polled by this subscriber.
- getFirstPolledTimestamp() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getFirstPolledTimestamp() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the timestamp when the first element was polled by this subscriber.
- getFloat() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the float which this PofValue represents.
- getFloat() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the float which this PofValue represents.
- getFloat(String) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as a Float.
- getFloat(String, float) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as a float.
- getFloatArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the float[] which this PofValue represents.
- getFloatArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the float[] which this PofValue represents.
- getFlowControl() - Method in interface com.tangosol.net.topic.Publisher
- 
Return theFlowControlobject governing this publisher.
- getFlowControl() - Method in interface com.tangosol.net.topic.Subscriber
- 
Return theFlowControlobject governing this subscriber.
- getFlushTime() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.as of Coherence 3.5
- getForwardEntry(Object) - Method in class com.tangosol.util.ConditionalIndex
- 
Get the forward index entry associated with the specified key.
- getForwardEntry(Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Get the forward index entry associated with the specified key.
- getFragment(ValueExtractor<? super T, ? extends E>) - Method in class com.tangosol.util.Fragment
- 
Get the nested fragment extracted from the specified attribute.
- getFragment(String) - Method in class com.tangosol.util.Fragment
- 
Get the nested fragment extracted from the specified attribute.
- getFreeBlockOffset(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Get the first free block in the linked list of free blocks that have a certain size code.
- getFreeCapacity() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the free capacity of the map in bytes.
- getFreeListCount() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the number of free lists (ie the number of size codes).
- getFromInternalCache(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the the value for a given key.
- getFromMember() - Method in class com.tangosol.net.partition.PartitionEvent
- 
Determine the member that held the partitions prior to the action represented by this event.
- getFrontEvent() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
For internal use only, return the current event from the front Map.
- getFrontEvent() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
For internal use only, return the current event from the front Map.
- getFrontMap() - Method in class com.tangosol.net.cache.CachingMap
- 
Obtain the front map reference.
- getFrontMap() - Method in class com.tangosol.net.cache.OverflowMap
- 
Returns the front Map.
- getFrontMap() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Returns the front Map.
- getFrontMapListener() - Method in class com.tangosol.net.cache.OverflowMap
- 
Get the MapListener for the front map.
- getFrontMapListener() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Get the MapListener for the front map.
- getFrontPaddingSize() - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Determine the number of extra bytes of padding that will be allocated and left blank at the start of each block in front of the data portion.
- getFrontScheme() - Method in class com.tangosol.coherence.config.scheme.AbstractCompositeScheme
- 
Return the front scheme.
- getFullStackTrace() - Method in exception com.tangosol.io.pof.PortableException
- 
Return an array of Strings containing the full representation of the stack trace.
- getFullyQualifiedClassNameOf(String) - Static method in class com.tangosol.util.ClassHelper
- 
Determines the fully qualified class name of the Coherence-style abbreviated class name.
- getFunction(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return the function mapped to the given function name or null if no function mapping exists.
- getFunctionKey(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Returns a key value based on case-insensitivity of the token table.
- getFunctor() - Method in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractOPToken
- 
Return the functor for this OPToken.
- getFunctor() - Method in class com.tangosol.coherence.dslquery.token.SQLExplainOPToken
- 
Get the functor for the new term.
- getFunctor() - Method in class com.tangosol.coherence.dslquery.token.SQLTraceOPToken
- getFunctor() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Obtain the functor representation of the Term.
- getFunctor() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Obtain the functor representation of the Term.
- getFunctor() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Obtain the functor representation of the Term.
- getFutureData() - Method in class com.tangosol.io.AbstractEvolvable
- 
Return all the unknown remainder of the data stream from which this object was deserialized.
- getFutureData() - Method in interface com.tangosol.io.Evolvable
- 
Return all the unknown remainder of the data stream from which this object was deserialized.
- getFutureData() - Method in class com.tangosol.io.SimpleEvolvable
- 
Return all the unknown remainder of the data stream from which this object was deserialized.
- getGarFileName() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getGarFileName() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return the name of the optional GAR file to load before running QueryPlus.
- getGate() - Method in class com.tangosol.net.cache.OverflowMap
- 
Obtain the Gate for managing key-level and Collection-level operations against the Map, versus Map-level operations themselves.
- getGate() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Obtain the Gate for managing key-level and Collection-level operations against the Map, versus Map-level operations themselves.
- getGenericTypeId(Class) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
For user types that are not registered in the POF configuration used by this PofContext, determine if the user type can be serialized using POF, otherwise determine if the user type can be serialized using the traditional (pre-POF) Coherence Java Serialization format that supports Java Serializable and ExternalizableLite objects.
- getGetBundler() - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Obtain the bundler for the "get" operations.
- getGetEntryAction() - Method in class com.tangosol.util.SegmentedHashMap
- 
Return the registered action for getEntryInternal.
- getGlobalPartitions(PartitionedService) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return a PartitionSet that contains partitions to be used to persist (meta-)data that is logically "global".
- getGlobalSocketProviderBuilder() - Static method in class com.tangosol.net.SocketProviderFactory
- 
Returns the globalSocketProviderBuilderornullif no global provider has been set.
- getGroupAddress() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the multicast group address to listen/publish on.
- getGroupBufferSize() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the preferred size for the multicast datagram socket input buffer (SO_RCVBUF).
- getGroupBy(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the AST node that represents the group by fields from the given AST node.
- getGroupInterface() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the IP address of the interface (e.g. the NIC) that the MulticastSocket will open a socket on.
- getGroupListenerPriority() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the priority of the PacketListener daemon thread.
- getGroupPort() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the multicast port number that the cluster will listen/publish on.
- getGroupTimeToLive() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the multicast time-to-live setting for the cluster.
- getGrowthCount() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the level at which the modulo will increase.
- getGrowthThreshold() - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Determine the level (what number of bytes used) above which the current ByteBuffer will need to be "resized" upwards.
- getGrowthThreshold() - Method in interface com.tangosol.io.nio.ByteBufferManager
- 
Determine the level (what number of bytes used) above which the current ByteBuffer will need to be "resized" upwards.
- getGuardable() - Method in interface com.tangosol.net.Guardian.GuardContext
- 
Return the Guardable for this context.
- getGuardable() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the Guardable for this context.
- getGuardableCount() - Method in class com.tangosol.net.GuardSupport
- 
Return the number of Guardables that are registered with this GuardSupport.
- getGuardContexts() - Method in class com.tangosol.net.GuardSupport
- 
Return the array of GuardContext objects for the Guardables managed by this GuardSupport.
- getGuardian() - Method in interface com.tangosol.net.Guardian.GuardContext
- 
Return the Guardian for this context.
- getGuardian() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the Guardian for this context.
- getGuardian() - Method in class com.tangosol.net.GuardSupport
- 
Return the Guardian that manages this GuardSupport.
- getGuardRegisterAction() - Method in class com.tangosol.util.Daemon
- 
Return the Guardian registration action.
- getGuardTimeoutMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the default Guard timeout.
- getGUID(List<String>, int) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Return GUID in the specified list of GUIDs for the specified partition.
- getHashCode() - Method in class com.tangosol.run.xml.XmlBean
- 
Get the cached hash code.
- getHAStatus() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The High Availability status for the service.
- getHAStatus() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
The High Availability status for the service.
- getHAStatusCode() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The High Availability status for the service as an integer.
- getHAStatusCode() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
The High Availability status for the service as an integer.
- getHATarget() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The High Availability status that this strategy attempts to achieve.
- getHATarget() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
The High Availability status that this strategy attempts to achieve.
- getHead() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getHead() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the current head position for the channel.
- getHead(int) - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns thePositionthat is currently the tail for the specified channel, orOptional.empty()if the channel is not owned by thisSubscriber.
- getHeads() - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns aMapof thePositionsthat are currently the head for each channel owned by thisSubscriber.
- getHealthCheck(String) - Method in interface com.tangosol.net.management.Registry
- 
Return anOptionalcontaining theHealthCheckwith the specified name, or an emptyOptionalif noHealthCheckhas been registered with the specified name.
- getHealthCheckDependencies() - Method in interface com.tangosol.net.ServiceDependencies
- 
Returns the service'sHealthCheckDependencies.
- getHealthChecks() - Method in interface com.tangosol.net.management.Registry
- 
Returns an immutable collection of the currently registeredhealth checks.
- getHighUnitFairShare() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Return the fair share of high-units per partition map.
- getHighUnits() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getHighUnits() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Determine the limit of the cache size in units.
- getHighUnits() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the limit of the cache size in units.
- getHighUnits() - Method in class com.tangosol.net.cache.SerializationCache
- 
Determine the limit of the cache size in units.
- getHighUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the limit of the cache size in units.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Return the limit of cache size.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Return the limit of cache size.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Return the limit of cache size.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Return the limit of cache size.
- getHighUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return the high-units
- getHitProbability() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the rough probability (0 <= p <= 1) that the next invocation will be a hit, based on the statistics collected since the last reset of the cache statistics.
- getHitProbability() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the rough probability (0 <= p <= 1) that any particularOldCache.get(java.lang.Object)invocation will be satisfied by an existing entry in the cache, based on the statistics collected since the last reset of the cache statistics.
- getHitProbability() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the rough probability (0 <= p <= 1) that the next invocation will be a hit, based on the statistics collected since the last reset of the cache statistics.
- getHitProbability() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the rough probability (0 <= p <= 1) that the next invocation will be a hit, based on the statistics collected since the last reset of the cache statistics.
- getHoldCount() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Queries the number of holds on this lock by the current thread.
- getHoldCount() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Queries the number of holds on this write lock by the current thread.
- getHost() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Return the host name.
- getHost() - Method in class com.tangosol.net.LoadBalancer
- 
Determine the AddressPort that the load balancer listens on.
- getHostKey() - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Obtain the host key that serves as an associated key for all keys that the wrapped filter will be applied to.
- getHostName() - Static method in class com.tangosol.net.management.MBeanConnector
- 
Get the configured host name for the RMI Connector Server.
- getHostnameVerifierBuilder() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Get customized HostnameVerifierBuilder
- getHour() - Method in class com.tangosol.io.pof.RawTime
- 
Determine the time's hour value.
- getHourOffset() - Method in class com.tangosol.io.pof.RawTime
- 
Determine the timezone's hour offset value.
- getHours() - Method in class com.tangosol.io.pof.RawDayTimeInterval
- 
Determine the number of hours in the day-time interval.
- getHours() - Method in class com.tangosol.io.pof.RawTimeInterval
- 
Determine the number of hours in the time interval.
- getHungCount() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getHungDuration() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getHungTaskCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getHungTaskCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the total number of currently executing hung tasks.
- getHungTaskDuration() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getHungTaskDuration() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the longest currently executing hung task duration (in milliseconds).
- getId() - Method in class com.oracle.coherence.cdi.CdiEventObserver
- getId() - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
Return a unique identifier for this interceptor.
- getId() - Method in interface com.oracle.coherence.cdi.events.EventObserverSupport.EventObserver
- 
Return the unique identifier for this observer.
- getId() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Return the unique ID of the registeredExecutorService.
- getId() - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy.FilterInfo
- 
Return the filter identifier.
- getId() - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
- 
Return the identifier for SocketProvider built by this builder.
- getId() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Obtain the string representation of this token.
- getId() - Method in interface com.tangosol.net.Member
- 
Return a small number that uniquely identifies the Member at this point in time and does not change for the life of this Member.
- getId() - Method in class com.tangosol.net.MemberEvent
- 
Return this event's id.
- getId() - Method in class com.tangosol.net.partition.PartitionEvent
- 
Return this event's id.
- getId() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return a small number that uniquely identifies the Member at this point in time and does not change for the life of this Member.
- getId() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getId() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the identifier for this channel.
- getId() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return the identifier of this store.
- getId() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Return the identifier of this store.
- getId() - Method in class com.tangosol.util.MapEvent
- 
Return this event's id.
- getId() - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- getId() - Method in class com.tangosol.util.ServiceEvent
- 
Return this event's ID.
- getId(T) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Return the identifier of the specified entity instance.
- getIdentifier() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- getIdentifier() - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
Obtain the internal identifier used for JCache caches.
- getIdentifier() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- getIdentifier() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
Get unique JCacheIdentifier for cache that these statistics are for.
- getIdentifier() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- getIdentifier() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- getIdentifier() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getIdentifier() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- getIdentifier() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- getIdentifier() - Method in interface com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent
- 
Return the identifier theEventInterceptorwas registered with.
- getIdentity(Object) - Method in class com.tangosol.io.pof.PofBufferWriter.ReferenceLibrary
- 
Look up an identity for an object.
- getIdentityAsserter() - Method in interface com.tangosol.net.OperationalContext
- 
Return an IdentityAsserter that can be used to establish a user's identity.
- getIdentityManager() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Get the SSL identity manager dependencies
- getIdentityTransformer() - Method in interface com.tangosol.net.OperationalContext
- 
Return an IdentityTransformer that can be used to transform a Subject into an identity assertion.
- getIdleThreadCount() - Method in interface com.tangosol.net.ThreadPoolManager
- 
Return the idle thread count of the thread pool.
- getIdleTimeout() - Method in class com.tangosol.util.TaskDaemon
- 
Determine the length of time that the daemon will live without any activity before it stops itself.
- getIgnoredAdvice() - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return a set of partitions from the previous suggestions that were ignored or rejected.
- getImplVersion() - Method in class com.tangosol.io.AbstractEvolvable
- 
Determine the serialization version supported by the implementing class.
- getImplVersion() - Method in interface com.tangosol.io.Evolvable
- 
Determine the serialization version supported by the implementing class.
- getImplVersion() - Method in class com.tangosol.io.SimpleEvolvable
- 
Determine the serialization version supported by the implementing class.
- getImplVersion() - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- getImplVersion() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the implementation version of this manager.
- getIn() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Obtain the underlying BufferOutput.
- getIncidentStartTime() - Method in interface com.tangosol.net.Cluster.MemberTimeoutAction
- 
Return the time at which the current outage "incident" was first detected.
- getIndent() - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Determine the current textual indent for logging, which is based on the nested data structure depth within the POF stream.
- getIndex() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- getIndex() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Returns the index of the current value, which is the value returned by the most recent call to the next method.
- getIndex() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray.ConverterLongArrayIterator
- getIndex() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
Returns the index of the current value, which is the value returned by the most recent call to the next method.
- getIndex() - Method in interface com.tangosol.util.LongArray.Iterator
- 
Returns the index of the current value, which is the value returned by the most recent call to the next method.
- getIndex() - Method in class com.tangosol.util.SimpleLongArray.Iterator
- 
Returns the index of the current value, which is the value returned by the most recent call to the next method.
- getIndexContents() - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Get the Map that contains the index contents.
- getIndexContents() - Method in interface com.tangosol.util.MapIndex
- 
Get the Map that contains the index contents.
- getIndexContents() - Method in class com.tangosol.util.SimpleMapIndex
- 
Get the Map that contains the index contents.
- getIndexDef() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Returns the index definition.
- getIndexDescription() - Method in interface com.tangosol.util.QueryRecord.PartialResult.IndexLookupRecord
- 
Get a description of the associated index.
- getIndexDescription() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Get a description of the associated index.
- getIndexExtentId(long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return the extent identifier that contains index registration information for the cache with the given identifier.
- getIndexFileName() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Return the Jandex index file name to use to discover portable types.
- getIndexLookupRecords() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
- 
Get the recorded information about the index lookups performed during filter evaluation as part of a query record.
- getIndexLookupRecords() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Get the recorded information about the index lookups performed during filter evaluation as part of a query record.
- getIndexMap() - Method in interface com.tangosol.net.BackingMapContext
- 
Return a map of indexes defined for all partitions of thecachethat this BackingMapContext is associated with.
- getIndexMap() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Get the map of indexes maintained by this cache.
- getIndexMap() - Method in interface com.tangosol.util.BinaryEntry
- 
Return a map of indexes defined for the partition of thecachethat this BinaryEntry belongs to.
- getIndexMap(int) - Method in interface com.tangosol.net.BackingMapContext
- 
Return a map of indexes defined for the specified partition of thecachethat this BackingMapContext is associated with.
- getIndexMap(PartitionSet) - Method in interface com.tangosol.net.BackingMapContext
- 
Return a map of indexes defined for the specified partitions of thecachethat this BackingMapContext is associated with.
- getIndirectStorageSize() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the partition size from non-PartitionAwareBackingMaps.
- getInfo() - Method in interface com.tangosol.net.Service
- 
Return the ServiceInfo object for this Service.
- getInfo() - Method in class com.tangosol.net.WrapperService
- 
Return the ServiceInfo object for this Service.
- getInheritedUserTypeIdentifier(Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Helper method for determining the user type identifier associated with a given class that does not have a direct configured association.
- getInitialCount() - Method in class com.oracle.coherence.concurrent.RemoteCountDownLatch
- 
Returns the initial count of the latch.
- getInitialPermits() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Returns number of permits that were used to initialise this semaphore.
- getInitialSize(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractNioManagerBuilder
- 
Return the initial buffer size in bytes.
- getInitialSize(ParameterResolver) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
- 
Return the initial buffer size in bytes for off-heap and file-mapped backup maps.
- getInitialSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Return the initial buffer size in bytes for off-heap and file-mapped backup maps.
- getInitParams() - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Return the BDB init params needed to construct a BerkeleyDBBinaryStoreManager.
- getInnerScheme() - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Return the inner scheme.
- getInProcessName() - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- getInProcessName() - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Returns the name of the in-process gRPC server.
- getInProcessServerBuilder(String) - Method in interface com.oracle.coherence.grpc.proxy.GrpcServerBuilderProvider
- 
Deprecated.Returns aInProcessServerBuilderthat may be used to build an in-process gRPC server.
- getInputStream() - Method in class com.tangosol.io.WrapperInputStream
- 
Obtain the underlying InputStream.
- getInputStream() - Method in class com.tangosol.net.InputStreamPasswordProvider
- 
Returns theInputStreamto read the password from.
- getInputStream() - Method in class com.tangosol.net.ssl.AbstractCertificateLoader
- 
Open anInputStreamfor the specified named resource, which should be the contents of a JavaCertificatein the format required by thisCertificateLoaderimplementation.
- getInputStream() - Method in class com.tangosol.net.ssl.AbstractKeyStoreLoader
- 
Open anInputStreamfor the specified named resource, which should be the contents of a JavaKeyStorein the format required by thisKeyStoreLoaderimplementation.
- getInputStream() - Method in class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- 
Open anInputStreamfor the specified named resource, which should be the contents of a JavaPrivateKeyin the format required by thisPrivateKeyLoaderimplementation.
- getInputStream() - Method in class com.tangosol.net.ssl.URLCertificateLoader
- getInputStream() - Method in class com.tangosol.net.ssl.URLKeyStoreLoader
- getInputStream() - Method in class com.tangosol.net.ssl.URLPrivateKeyLoader
- getInputStream() - Method in class com.tangosol.net.URLPasswordProvider
- getInputStream() - Method in class com.tangosol.util.Binary
- 
Get an InputStream to read the Binary object's contents from.
- getInputStream(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Get an InputStream for the passed DataInput object.
- getInputStream(InputStream) - Method in interface com.tangosol.io.WrapperStreamFactory
- 
Deprecated.Requests an InputStream that wraps the passed InputStream.
- getInputStream(InputStream) - Method in class com.tangosol.net.CompressionFilter
- 
Deprecated.Requests an InputStream that wraps the passed InputStream.
- getInsertAction() - Method in class com.tangosol.util.SegmentedHashMap
- 
Return the registered action for insert.
- getInsertKey(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the AST node that represents the key to insert from the given AST node.
- getInsertValue(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the AST node that represents the value to insert from the given AST node.
- getInstance() - Static method in class com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics
- 
Returns the singleton instance ofGrpcConnectionMetrics.
- getInstance() - Static method in interface com.tangosol.coherence.config.EnvironmentVariableResolver
- 
Return an instance of aEnvironmentVariableResolverdiscovered by theServiceLoader, or a default instance if none are discovered.
- getInstance() - Static method in interface com.tangosol.coherence.config.SystemPropertyResolver
- 
Return an instance of aSystemPropertyResolverdiscovered by theServiceLoader, or a default instance if none are discovered.
- getInstance() - Static method in class com.tangosol.net.Coherence
- getInstance() - Static method in class com.tangosol.net.DefaultCacheServer
- 
Returns the DefaultCacheServer created by a previous invocation ofDefaultCacheServer.ensureInstance(ConfigurableCacheFactory).
- getInstance() - Static method in class com.tangosol.util.NullFilter
- 
Returns an instance of the null enumerator.
- getInstance(ClassLoader) - Static method in class com.tangosol.net.Coherence
- getInstance(String) - Static method in class com.tangosol.net.Coherence
- getInstance(String, ClassLoader) - Static method in class com.tangosol.net.Coherence
- getInstanceClass() - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry.Registration
- 
Obtains the class of instance produced by the builder.
- getInstanceClass() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.BuilderRegistration
- getInstanceClass() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
- 
Return the class of the instance produced by the builder.
- getInstances() - Static method in class com.tangosol.net.Coherence
- 
Returns all of theCoherenceinstances.
- getInstances(ClassLoader) - Static method in class com.tangosol.net.Coherence
- 
Returns all of theCoherenceinstances.
- getInt() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the int which this PofValue represents.
- getInt() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the int which this PofValue represents.
- getInt() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as an int.
- getInt() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as an int.
- getInt() - Method in class com.tangosol.util.AnyEvent
- 
Gets the associated value as a java int.
- getInt(int) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as an int.
- getInt(int) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as an int.
- getIntArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the int[] which this PofValue represents.
- getIntArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the int[] which this PofValue represents.
- getInteger(String) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as an Integer.
- getInteger(String, int) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as an Integer.
- getInterceptor() - Method in interface com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent
- 
Return theEventInterceptorthat is either: in the process ofregisteringhas beenregisteredhas beenremoved
- getInterceptor() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Return the wrapped interceptor.
- getInterceptorClass(EventInterceptor) - Method in class com.oracle.coherence.cdi.CdiInterceptorMetadataResolver
- getInterceptorClass(EventInterceptor) - Method in interface com.tangosol.net.events.InterceptorMetadataResolver
- 
Return the actual interceptor class that the generic type arguments can be reified from.
- getInterceptorRegistry() - Method in class com.tangosol.net.Coherence
- 
Return theInterceptorRegistryfor thisCoherenceinstance.
- getInterceptorRegistry() - Method in class com.tangosol.net.CoherenceSession
- getInterceptorRegistry() - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Return theInterceptorRegistryfor this factory.
- getInterceptorRegistry() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Return theInterceptorRegistryused to register event interceptors for this factory.
- getInterceptorRegistry() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return theInterceptorRegistryfor this factory.
- getInterceptorRegistry() - Method in interface com.tangosol.net.Session
- 
Return theInterceptorRegistryfor this session.
- getInterceptors() - Method in interface com.oracle.coherence.cdi.CoherenceExtension.InterceptorProvider
- 
Returns theNamedEventInterceptorinstances.
- getInterceptors() - Method in class com.oracle.coherence.cdi.server.CoherenceServerExtension
- getInterceptors() - Method in interface com.tangosol.net.CoherenceConfiguration
- 
Return an immutableIterableofinterceptorsthat will be added to all sessions created by theCoherenceinstance.
- getInterceptors() - Method in class com.tangosol.net.CoherenceConfiguration.SimpleConfig
- getInterceptors() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- getInterceptors() - Method in interface com.tangosol.net.SessionConfiguration
- 
Return the interceptors to add to the session.
- getInterceptors() - Method in interface com.tangosol.net.SessionProvider.Context
- 
Returns zero or moreEventInterceptorinstances to add to the session.
- getInterceptors() - Method in class com.tangosol.net.SessionProvider.DefaultContext
- getInterceptors() - Method in class com.tangosol.net.WrapperSessionConfiguration
- getInternal(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Return the value from the back cache, transforming it in the process if necessary.
- getInternal(Object, boolean, Map) - Method in class com.tangosol.net.cache.OverflowMap
- 
A combined implementation ofOverflowMap.get(java.lang.Object)andOverflowMap.getAll(java.util.Collection)that eliminates duplicate (and very complex) code.
- getInternalCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Obtain a reference to the internal cache.
- getInternalCache() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the representative of the "in-memory" storage for this backing map.
- getInternalConfigurableCache() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the map that provides internal storage for this backing map.
- getInternalIterator() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
Return the internal Iterator.
- getInternalKeySet() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- getInternalKeySet() - Method in class com.tangosol.net.cache.OverflowMap
- 
Obtain a set of keys that are represented by this Map.
- getInternalKeySet() - Method in class com.tangosol.net.cache.SerializationMap
- 
Obtain a set of keys that are represented by this Map.
- getInternalKeySet() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Obtain a set of keys that are represented by this Map.
- getInternalKeySet() - Method in class com.tangosol.util.WrapperObservableMap
- 
Obtain a set of keys that are represented by this Map.
- getInternalListener() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Obtain the MapListener that listens to the internal cache and routes those events to anyone listening to this ReadWriteBackingMap, creating such a listener if one does not already exist.
- getInternalMap() - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return the internal map which is set by the backing map manager when the partitioned flag is true.
- getInternalMap() - Method in class com.tangosol.util.CopyOnWriteMap
- 
Return the internal map.
- getInternalMap() - Method in class com.tangosol.util.SetMap
- 
Return the internal map allowing any object to be stored.
- getInternalMap() - Method in class com.tangosol.util.SortedBag
- 
Return the internal sorted-map holding the bag contents.
- getInternalScheme() - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return the scheme which the specifies the map used to cache entries.
- getInternalValue() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Access internal value without updating access expiry.
- getInternalValue() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the internal value of this XmlValue.
- getInternalValue(long) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Gets the internal value with the side-effect of updating the access time to that which is specified and incrementing the access count.
- getInternalValueDecoration(Object, int) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Obtain a decoration from the specified value in the internal form.
- getInternalValueDecoration(Object, int) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Obtain a decoration from the specified value in the internal form.
- getInvalidationHits() - Method in class com.tangosol.net.cache.CachingMap
- 
Determine the rough number of front map invalidation hits since the cache statistics were last reset.
- getInvalidationMisses() - Method in class com.tangosol.net.cache.CachingMap
- 
Determine the rough number of front map invalidation misses since the cache statistics were last reset.
- getInvalidationStrategy() - Method in class com.tangosol.net.cache.CachingMap
- 
Obtain the invalidation strategy used by this CachingMap.
- getInvalidationStrategy(int) - Method in class com.tangosol.net.cache.CachingMap
- 
Return string representation for invalidation strategyvalue.
- getInvalidationStrategy(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.NearScheme
- 
Return the invalidation strategy.
- getInvocableMap() - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- 
Return the underlying InvocableMap.
- getInvocableMap(InvocableMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of InvocableMap.
- getInvocationService() - Method in class com.tangosol.net.WrapperInvocationService
- 
Return the wrapped InvocationService.
- getIpMonitorAttempts() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the number of connection attempts that the IpMonitor will use in determining if IP connectivity exists to other hosts.
- getIpMonitorPriority() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the priority of the IpMonitor daemon thread.
- getIpMonitorTimeoutMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the timeout that the IpMonitor will use in determining if IP connectivity exists to other hosts.
- getIsDistinct(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the boolean that indicates whether distinctness in indicated in the given AST node.
- getIterable() - Static method in class com.tangosol.util.NullImplementation
- 
Returns an instance of the null iterable.
- getIterator() - Method in class com.tangosol.util.ChainedEnumerator
- 
Get the current or next enumeration in the list
- getIterator() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
- 
Return the underlying Iterator.
- getIterator() - Static method in class com.tangosol.util.NullImplementation
- 
Returns an instance of the null iterator.
- getIterator(Iterator<F>, Converter<F, T>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns an instance of Iterator that uses a Converter to view an underlying Iterator.
- getJavaTypeId(Object, PofContext) - Static method in class com.tangosol.io.pof.PofHelper
- 
Return an identifier that represents the Java type of the specified object.
- getJlineReader(OutputStream, InputStream, boolean) - Static method in class com.tangosol.coherence.dslquery.QueryPlus
- 
Return an instance of BufferedReader if JLine is present.
- getJoiningMember() - Method in interface com.tangosol.net.Service.MemberJoinAction
- 
Return the Member that is attempting to join the service.
- getKey() - Method in class com.oracle.coherence.mp.config.ConfigPropertyChanged
- 
The key of the configuration property that was modified.
- getKey() - Method in interface com.tangosol.coherence.federation.ChangeRecord.Entry
- 
Obtain the key corresponding to this entry.
- getKey() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Obtain the key of the changedChangeRecord.Entry.
- getKey() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- getKey() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
- getKey() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
- getKey() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Return the key associated with this event.
- getKey() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Get the Entry key in the block, lazy loading it if necessary.
- getKey() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return the key corresponding to this entry.
- getKey() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
- 
Return the key that is being loaded by the refresh-ahead thread.
- getKey() - Method in interface com.tangosol.net.events.partition.cache.EntryEvent
- 
Return the key of the entry on which the action represented by thisEntryEventoccurred.
- getKey() - Method in interface com.tangosol.run.xml.Identifiable
- 
Determine the key for this value object
- getKey() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- getKey() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- getKey() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Return a key associated with this event.
- getKey() - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Return the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- 
Return the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.MapEvent
- 
Return a key associated with this event.
- getKey() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Return a key associated with this event.
- getKey() - Method in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
- 
Return the key
- getKey() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
- 
Returns the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.SafeHashMap.Entry
- 
Returns the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.SafeSortedMap.NullableEntry
- getKey() - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Returns the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.SimpleMapEntry
- 
Return the key corresponding to this entry.
- getKey() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- getKey() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- getKeyAdapter() - Method in class com.tangosol.run.xml.MapAdapter
- getKeyAssociator() - Method in interface com.tangosol.net.PartitionedService
- 
Determine the key associator that this service has been configured to use.
- getKeyClass() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Determine the class of the cache key.
- getKeyClassName() - Method in class com.tangosol.coherence.config.CacheMapping
- 
Obtains the name of the key class forNamedCaches using thisCacheMapping.
- getKeyClassName() - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
- 
Get Key ClassName
- getKeyConverter() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Get key converter for this.
- getKeyConverter() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Return a KeyConverter instance for this resource.
- getKeyFromInternalConverter() - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Return a converter that allows the manager (or a backing map managed thereby) to convert a key object from its internal form (as managed by the CacheService) into its "normal" (Object) form.
- getKeyFromInternalConverter() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Return a converter that allows the manager (or a backing map managed thereby) to convert a key object from its internal form (as managed by the CacheService) into its "normal" (Object) form.
- getKeyHash() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Get the hash code for the Entry block.
- getKeyLength() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Get the length of the Entry key in the block.
- getKeyList() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Return a list of keys in the queue.
- getKeyMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Return a map of keys in the queue.
- getKeyMap() - Method in class com.tangosol.net.cache.SerializationMap
- 
Returns the cache of keys that are in the SerializationMap.
- getKeyMask() - Method in class com.tangosol.net.cache.LocalCache
- 
ThreadLocal: Get the current key mask for the current thread.
- getKeyOwner(Object) - Method in interface com.tangosol.net.PartitionedService
- 
Determine the primary owner of the specified key, as determined by the combination of the KeyPartitioningStrategy and the PartitionAssignmentStrategy.
- getKeyPartition() - Method in interface com.tangosol.util.BinaryEntry
- 
Return the key partition for this BinaryEntry.
- getKeyPartition(Object) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Determine the partition to which the specified key belongs.
- getKeyPartition(Object) - Method in class com.tangosol.net.partition.BroadKeyPartitioningStrategy
- 
Determine the partition to which a particular key should be assigned.
- getKeyPartition(Object) - Method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
- 
Determine the partition to which a particular key should be assigned.
- getKeyPartition(Object) - Method in interface com.tangosol.net.partition.KeyPartitioningStrategy
- 
Determine the partition to which a particular key should be assigned.
- getKeyPartition(Object) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Determine the partition to which the specified key belongs.
- getKeyPartitioningStrategy() - Method in interface com.tangosol.net.PartitionedService
- 
Determine the strategy for key partitioning that this service has been configured to use.
- getKeys() - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Obtain the underlying key set.
- getKeys() - Method in class com.tangosol.util.filter.KeyFilter
- 
Get the set of keys that are evaluated to true by this filter.
- getKeys(String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Return the keys of cache entries that satisfy the given query criteria.
- getKeys(UriInfo) - Method in class com.tangosol.coherence.rest.NamedQueryResource
- 
Return the keys for cache entries that satisfy criteria defined by this resource.
- getKeySet() - Method in class com.tangosol.util.MapListenerSupport
- 
Obtain a set of all keys that have associated key listeners.
- getKeyToInternalConverter() - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Return a converter that allows the manager (or a backing map managed thereby) to convert a key object into its internal form as managed by the CacheService.
- getKeyToInternalConverter() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Return a converter that allows the manager (or a backing map managed thereby) to convert a key object into its internal form as managed by the CacheService.
- getKeyType() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- getKeyType() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
- getKeyType() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- getLambdasSerializationMode() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the lambdas serialization mode, i.e. static, dynamic or empty string, if not set.
- getLanguage() - Method in class com.tangosol.util.AbstractScript
- 
Return the language the script is written.
- getLastAnalysisContext() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return the last AnalysisContext.
- getLastAnalysisTime() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the last time a partition distribution analysis was performed.
- getLastAnalysisTime() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the last time a partition distribution analysis was performed.
- getLastBlockOffset() - Method in class com.tangosol.io.nio.BinaryMap
- 
Get the offset of the last block in the buffer.
- getLastChildIndex(int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Return index of the last parsed child with an index lower than the specified one.
- getLastCommit() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getLastCommit() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the last position committed by this subscriber.
- getLastCommitted() - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns aMapof channels to the latestPositioncommitted for that channel; the map will only contain channels owned by thisSubscriber.
- getLastCommitted(int) - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns anOptionalcontaining the latest position committed for a channel, orOptional.empty()if the channel is not owned by thisSubscriber
- getLastIndex() - Method in class com.tangosol.util.AbstractLongArray
- 
Determine the last index that exists in the LongArray.
- getLastIndex() - Method in class com.tangosol.util.AbstractSafeLongArray
- getLastIndex() - Method in class com.tangosol.util.AbstractSparseArray
- 
Determine the last index that exists in the LongArray.
- getLastIndex() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- getLastIndex() - Method in interface com.tangosol.util.LongArray
- 
Determine the last index that exists in the LongArray.
- getLastIndex() - Method in class com.tangosol.util.NullImplementation.NullLongArray
- getLastIndex() - Method in class com.tangosol.util.SimpleLongArray
- 
Determine the last index that exists in the LongArray.
- getLastIndex() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- getLastOwnershipMembers() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return the set of ownership-enabled members present when the analysis was last considered.
- getLastPolled() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getLastPolled() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the last position polled by this subscriber.
- getLastPolledTimestamp() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getLastPolledTimestamp() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the timestamp when the last element was polled by this subscriber.
- getLastPosition() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
Obtain the last known position, which is the index (or property number) of the most recent value.
- getLastReceived() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getLastReceived() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the last position received by this subscriber.
- getLastResetMillis() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getLastResetMillis() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getLastResetMillis() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the last time stats were reset.
- getLastResizeMillis() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getLastResizeMillis() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getLastResizeMillis() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the last time the daemon pool was resized.
- getLastSafeTimeMillis() - Static method in class com.oracle.coherence.common.base.TimeHelper
- 
Returns the last "safe" time as computed by a previous call to theTimeHelper.getSafeTimeMillis()method.
- getLastSafeTimeMillis() - Static method in class com.tangosol.util.Base
- 
Returns the last "safe" time as computed by a previous call to theBase.getSafeTimeMillis()method.
- getLastTouchMillis() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
- 
Determine when the cache entry was last touched.
- getLastTouchMillis() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Determine when the cache entry was last touched.
- getLastTouchMillis() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Determine when the cache entry was last touched.
- getLastTouchMillis() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Determine when the cache entry was last touched.
- getLastTouchMillis() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- 
Determine when the cache entry was last touched.
- getLastTransferTime() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the time (on the primary owner) at which the partition was last transferred or restored.
- getLatestOldValue() - Method in class com.tangosol.net.cache.OverflowMap.HistoricCacheEvent
- 
Obtain the value that needs to be saved if this event represents a merged sequence of events ending with the eviction of data.
- getLatestOldValue(MapEvent) - Static method in class com.tangosol.net.cache.OverflowMap
- 
Obtain the latest old value from the passed event.
- getLeavingMembers() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Return the set of members that are leaving the associated service
- getLeavingOwners() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the set of ownership members that are leaving.
- getLedASTName() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Get led AST Name for this token
- getLegacySocketProvider(XmlElement) - Method in class com.tangosol.net.SocketProviderFactory
- 
Deprecated.
- getLength() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the length of the block.
- getLength() - Method in class com.tangosol.io.pof.reflect.PofArray
- 
Return the length of this array.
- getLicenseMode() - Static method in class com.tangosol.net.CacheFactory
- 
Returns the value oflicense-modechild element oflicense-configelement in the operational configuration.
- getLine() - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- getLineNumber() - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- getLink() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
- 
Answer a BaseTokenStream that can become the target of streaming
- getList() - Method in class com.tangosol.util.ConverterCollections.ConverterList
- 
Return the underlying List.
- getList() - Method in class com.tangosol.util.ImmutableArrayList
- 
Return a java.util.List view of this ImmutableArrayList.
- getList() - Method in class com.tangosol.util.ImmutableMultiList
- 
Return a java.util.List view of this ImmutableMultiList.
- getList(List<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of List.
- getList(List, Class) - Static method in class com.tangosol.util.RestrictedCollections
- 
Returns a restricted instance of List.
- getListenerBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- 
Obtains aParameterizedBuilderfor aMapListenerthat can be used for buildingMapListeners those of which may be later added to theMaps orNamedCaches realized by theCachingScheme.
- getListenerBuilder() - Method in interface com.tangosol.coherence.config.scheme.ObservableCachingScheme
- 
Obtains aParameterizedBuilderfor aMapListenerthat can be used for buildingMapListeners those of which may be later added to theMaps orNamedCaches realized by theCachingScheme.
- getListenerClassNames() - Method in class com.tangosol.util.Listeners
- 
Return a comma separated list of the listener class names.
- getListenerCount() - Method in class com.tangosol.util.Listeners
- 
Returns the number of listeners.
- getListenerCount() - Method in class com.tangosol.util.MapListenerSupport
- 
Return the number of listeners registered.
- getListenerExtentId(long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return the extent identifier that contains listener registration information for the cache with the given identifier.
- getListeners() - Method in class com.tangosol.net.topic.Subscriber.ChannelOwnershipListeners
- 
Returns the list oflistenersto add to the subscriber.
- getListeners(Filter) - Method in class com.tangosol.util.MapListenerSupport
- 
Obtain the Listeners object for a given filter.
- getListeners(Object) - Method in class com.tangosol.util.MapListenerSupport
- 
Obtain the Listeners object for a given key.
- getListIterator() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- 
Return the underlying ListIterator.
- getListIterator(ListIterator<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of ListIterator.
- getListIterator(ListIterator, Class) - Static method in class com.tangosol.util.RestrictedCollections
- 
Returns a restricted instance of ListIterator.
- getLoad(int) - Method in interface com.tangosol.net.partition.SimpleAssignmentStrategy.LoadCalculator
- 
Return the load for the specified partition.
- getLoad(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.SimpleLoadCalculator
- 
Return the load for the specified partition.
- getLoad(PartitionSet) - Method in interface com.tangosol.net.partition.SimpleAssignmentStrategy.LoadCalculator
- 
Return the load for the specified set of partitions.
- getLoad(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.SimpleLoadCalculator
- 
Return the load for the specified set of partitions.
- getLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Obtain the bundler for the "load" operations.
- getLoadFailures() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the number of load() failures.
- getLoadMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the cumulative time spent on load() operations.
- getLoadOps() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the number of load() operations.
- getLocalAddress() - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- getLocalAddress() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the unicast IP address that the cluster member will listen/publish on or null for default.
- getLocalAddress() - Method in interface com.tangosol.net.NameService
- 
Retrieve the running or configured listening address.
- getLocalAddress(Filter) - Static method in class com.tangosol.net.InetAddressHelper
- 
Obtain the "best" local host address which matches the supplied filter.
- getLocalBufferSize() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the preferred size for the unicast socket input buffer (SO_RCVBUF).
- getLocalDiscoveryAddress() - Method in interface com.tangosol.net.ClusterDependencies
- 
Return the InetAddress on which this member will listen for discovery requests.
- getLocalEntry() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Obtains a representation ofChangeRecord.Entryas it appears in the local participant.
- getLocalizedMessage() - Method in exception com.tangosol.util.WrapperException
- 
Creates a localized description of thisWrapperException.
- getLocalListenerPriority() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the priority of the "local" PacketListener daemon thread.
- getLocalMember() - Method in class com.tangosol.net.AbstractServiceLoadBalancer
- 
Return the Member object representing the local cluster member.
- getLocalMember() - Method in interface com.tangosol.net.Cluster
- 
Returns a Member object representing the local (i.e. this JVM) member of the cluster.
- getLocalMember() - Method in interface com.tangosol.net.events.partition.TransferEvent
- 
Return the localMemberassociated with this transfer operation.
- getLocalMember() - Method in interface com.tangosol.net.OperationalContext
- 
Return a Member object representing this process.
- getLocalName() - Method in class com.tangosol.run.xml.QualifiedName
- 
Returns the local name of theQualifiedName.
- getLocalPort() - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- getLocalPort() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the unicast port number that the member will listen on.
- getLocalPort() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- getLocalPortAutoAdjust() - Method in interface com.tangosol.net.ClusterDependencies
- 
Return the maximum unicast port that can be auto-adjusted to.
- getLocalServiceProvider(String) - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain aClusterDependencies.ServiceProviderthat can build an instance of a given service type.
- getLocalTcpPort() - Method in interface com.tangosol.net.OperationalContext
- 
Return the TCP port on which this member is bound.
- getLocalTransaction(NamedCache) - Static method in class com.tangosol.net.CacheFactory
- 
Factory method returning an instance of the TransactionMap that is based on the specified NamedCache and is local to this JVM.
- getLocalXmlName() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Determine the "local" XML element name that will be used to hold the property value.
- getLocation() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Get the location where the executor is running.
- getLock() - Method in class com.tangosol.util.SafeLongArray
- 
Return the lock used to protect this LongArray, with the unsafe delegate as itsresource.
- getLock() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- 
Return the ReadWriteLock that is used to manage concurrent access and modifications to the underlying map.
- getLock() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- 
Return the ReadWriteLock that is used to manage concurrent access and modifications to the underlying map.
- getLock() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
Return the ReadWriteLock that is used to manage concurrent access and modifications to the underlying map.
- getLockAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Return the registered action for lock().
- getLockCount() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Return the lock count.
- getLockDelaySeconds() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine the number of seconds to wait for a lock in debug mode.
- getLockDescription(Object) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Make a human-readable description of the information kept about the passed key.
- getLockDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the directory used to store lock files.
- getLockExtentId(long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return the extent identifier that contains lock registration information for the cache with the given identifier.
- getLockHolder() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Return the holder of this lockable entry, or null if this entry is not locked.
- getLockMap() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Obtain the map used for managing key- and map-level locks to ensure data consistency.
- getLockThread() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Return the Thread object holding this Lock.
- getLockTypeDescription() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Return a human readable description of the Lock type.
- getLog() - Static method in class com.tangosol.util.Base
- 
Obtains the current writer used for logging.
- getLoggingConfig() - Static method in class com.tangosol.net.CacheFactory
- 
Return the configuration info for the logging facility as defined by the "logging-config" element in the tangosol-coherence.xml configuration file.
- getLong() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the long which this PofValue represents.
- getLong() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the long which this PofValue represents.
- getLong() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a long.
- getLong() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a long.
- getLong(long) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a long.
- getLong(long) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a long.
- getLong(String) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as a Long.
- getLong(String, long) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as a long.
- getLongArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the long[] which this PofValue represents.
- getLongArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the long[] which this PofValue represents.
- getLongArray() - Static method in class com.tangosol.util.NullImplementation
- 
Returns an immutable emptyLongArray.
- getLongArray(LongArray<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a LongArray storing values with typeFand converting to typeVas and when required.
- getLostPacketThreshold() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the number of sequential packets which may be lost before declaring a member paused, and starting to trickle packets.
- getLowerBound() - Method in class com.tangosol.util.filter.BetweenFilter
- 
Obtain the lower bound of the range being used to evaluate values by this BetweenFilter.
- getLowerFilter() - Method in class com.tangosol.util.filter.BetweenFilter
- getLowUnitFairShare() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Return the fair share of low-units per partition map.
- getLowUnits() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getLowUnits() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Determine the point to which the cache will shrink when it prunes.
- getLowUnits() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the point to which the cache will shrink when it prunes.
- getLowUnits() - Method in class com.tangosol.net.cache.SerializationCache
- 
Determine the point to which the cache will shrink when it prunes.
- getLowUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the point to which the cache will shrink when it prunes.
- getLowUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Return the lowest number of units that a cache is pruned down to when pruning takes place.
- getLowUnits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Return the lowest number of units that a cache is pruned down to when pruning takes place.
- getLruArray() - Method in class com.tangosol.net.cache.SerializationCache
- 
Get the LRU data structure.
- getMachineCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Return the site count.
- getMachineId() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the Member's machine Id.
- getMachineId() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the Member's machine Id.
- getMachineName() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the configured name for the Machine (such as a host name) in which this Member resides.
- getMachineName() - Method in interface com.tangosol.net.MemberIdentityProvider
- 
Return the name for the Machine (such as a host name) in which this Member resides.
- getMachineName() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the configured name for the Machine (such as a host name) in which this Member resides.
- getMachineName() - Method in class com.tangosol.net.URLMemberIdentityProvider
- getMachineName() - Method in class com.tangosol.util.NullImplementation.NullMemberIdentityProvider
- getManagement() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor
- 
Return aDaemonPoolExecutor.DaemonPoolManagementto manage this executor.
- getManagement() - Method in interface com.tangosol.net.Cluster
- 
Returns the current management registry.
- getManagement() - Method in class com.tangosol.net.Coherence
- 
Returns the current management registry.
- getManagementConfig() - Static method in class com.tangosol.net.CacheFactory
- 
Return the management framework configuration.
- getManager() - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Return the BackingMapManager this object is a context for.
- getManager() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return the DistributionManager.
- getManager() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Return the underlying PersistenceManager.
- getManager() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Return the BackingMapManager this object is a context for.
- getManagerContext() - Method in interface com.tangosol.net.BackingMapContext
- 
Return the "parent"BackingMapManagerContextfor this context.
- getManagerContext() - Method in interface com.tangosol.net.events.partition.cache.Event
- 
Return theBackingMapManagerContextthis event was raised from.
- getManagerContinuation(PersistenceManager<R>) - Method in interface com.tangosol.persistence.SafePersistenceWrappers.FailureContinuationFactory
- 
Return a failure continuation to handle unexpected exceptions thrown by operations against the specified PersistenceManager.
- getMandatoryProperty(String, Type, XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains the strongly typed value for the property defined at the path relative to the specifiedXmlElement.
- getMandatoryProperty(String, Type, XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains the strongly typed value for the property defined at the path relative to the specifiedXmlElement.
- getMap() - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Return the map that is used as the underlying entity store.
- getMap() - Method in class com.tangosol.net.cache.MapCacheStore
- 
Returns the Map that this CacheStore uses for its storage.
- getMap() - Method in class com.tangosol.net.cache.SeppukuMapListener
- 
Returns the front Map invalidated by this listener.
- getMap() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Return the underlying Map.
- getMap() - Method in class com.tangosol.util.MapEvent
- 
Return an ObservableMap object on which this event has actually occurred.
- getMap() - Method in class com.tangosol.util.MapSet
- 
Obtain the underlying Map for purposes of synchronization or read-only access; the caller must never directly modify the returned Map.
- getMap() - Static method in class com.tangosol.util.NullImplementation
- 
Returns an instance of the NullMap.
- getMap() - Method in class com.tangosol.util.WrapperObservableMap
- 
Get the Map that is wrapped by this wrapper.
- getMap(String, NamedMap.Option...) - Method in class com.tangosol.net.CoherenceSession
- getMap(String, NamedMap.Option...) - Method in interface com.tangosol.net.Session
- getMap(Map) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the Map which this PofValue represents.
- getMap(Map) - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the Map which this PofValue represents.
- getMap(Map<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of Map.
- getMap(Map, Class, Class) - Static method in class com.tangosol.util.RestrictedCollections
- 
Returns a restricted instance of Map.
- getMapArray() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Get the mapping between partition IDs and backing maps.
- getMapEvent() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Return the underlying MapEvent.
- getMapEvent() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Return the wrapped event.
- getMapEvent(ObservableMap, MapEvent, Converter, Converter) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns an instance of a MapEvent that uses Converters to retrieve the event's data.
- getMapEvent(ObservableMap, MapEvent, Converter, Converter, BackingMapManagerContext) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns an instance of a MapEvent that uses Converters to retrieve the event's data, and additionally provides access to the BackingMapManagerContext.
- getMapEventFilter() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughListenerRegistration
- 
Obtains theMapEventFilterfor the registration
- getMapFactories() - Method in class com.tangosol.io.bdb.DatabaseFactoryManager
- 
Get the Map of Database factories.
- getMapFilters() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
- 
Return a map of key to Filter used to test against the corresponding key/value within the ObjectName.
- getMapListener() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughListenerRegistration
- 
Obtains theMapListenerfor the registration.
- getMapListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Obtain the configuredMapListenerfor thisContinuousQueryCache.
- getMapListener() - Method in class com.tangosol.util.MapListenerSupport.WrapperListener
- 
Return the underlying MapListener.
- getMapListener(ObservableMap, MapListener, Converter, Converter) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a converter listener for the specified listener and Converters.
- getMapListeners() - Method in class com.oracle.coherence.cdi.CoherenceExtension
- 
Returns the discovered map listeners.
- getMapListeners(String, String) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListenerManager
- 
Return all map listeners that should be registered for a particular service and cache combination.
- getMapListenersRegistry() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- getMapListenerSupport() - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Accessor for the MapListenerSupport for sub-classes.
- getMapListenerSupport() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Accessor for the MapListenerSupport for sub-classes.
- getMapListenerSupport() - Method in class com.tangosol.net.cache.OverflowMap
- 
Accessor for the MapListenerSupport for sub-classes.
- getMapListenerSupport() - Method in class com.tangosol.util.ObservableHashMap
- 
Accessor for the MapListenerSupport for sub-classes.
- getMapListenerSupport() - Method in class com.tangosol.util.WrapperObservableMap
- 
Accessor for the MapListenerSupport for sub-classes.
- getMappingRegistry() - Method in class com.tangosol.coherence.config.CacheConfig
- 
Obtain the cache/topicResourceMappingRegistryfor theCacheConfig.
- getMappingRegistry() - Method in class com.tangosol.coherence.config.CacheMappingRegistry
- 
Deprecated.Get the underlyingResourceMappingRegistry.
- getMarkInternal() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Obtain the offset of the stream mark.
- getMarshaller(Class, String) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Return the marshaller for the specified root class and media type.
- getMarshaller(Class, MediaType) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Return the marshaller for the specified root class and media type.
- getMarshallerMap() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Return a map of marshaller classes keyed by media type.
- getMarshallerRegistry() - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Return the configured marshaller registry.
- getMask() - Method in enum com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- 
Get the mask for thisConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule.
- getMathContext() - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Returns the specifiedMathContextor null.
- getMaxBacklog() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getMaxBatchSizeBytes() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Return the maximum size of a batch.
- getMaxCapacity() - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Determine the maximum size that the managed buffer can reach.
- getMaxCapacity() - Method in class com.tangosol.io.nio.AbstractStoreManager
- 
Determine the maximum size that the managed buffers can reach.
- getMaxCapacity() - Method in interface com.tangosol.io.nio.ByteBufferManager
- 
Determine the maximum size that the managed buffer can reach.
- getMaxDecDigits(int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Calculate the number of decimal digits needed to display the passed value.
- getMaxDecDigits(int) - Static method in class com.tangosol.util.Base
- 
Calculate the number of decimal digits needed to display the passed value.
- getMaxHexDigits(int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Calculate the number of hex digits needed to display the passed value.
- getMaxHexDigits(int) - Static method in class com.tangosol.util.Base
- 
Calculate the number of hex digits needed to display the passed value.
- getMaximumCapacity() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in class com.tangosol.io.ByteArrayWriteBuffer.Allocator
- 
Determine the largest amount of aggregate WriteBuffer capacity that this factory can provide.
- getMaximumCapacity() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in interface com.tangosol.io.MultiBufferWriteBuffer.WriteBufferPool
- 
Determine the largest amount of aggregate WriteBuffer capacity that this factory can provide.
- getMaximumCapacity() - Method in interface com.tangosol.io.WriteBuffer
- 
Determine the maximum number of bytes that the buffer can hold.
- getMaximumCapacity() - Method in class com.tangosol.util.ExternalizableHelper.Stats
- 
Determine the largest amount of aggregate WriteBuffer capacity that this factory can provide.
- getMaximumPages() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine the maximum number of pages that the cache will manage, beyond which the oldest pages are destroyed.
- getMaximumPages() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Determine the maximum number of pages that the cache will manage, beyond which the oldest pages are destroyed.
- getMaximumSize(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractNioManagerBuilder
- 
Return the maximum buffer size in bytes.
- getMaximumSize(ParameterResolver) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
- 
Return the maximum buffer size in bytes for off-heap and file-mapped backup maps.
- getMaximumSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Return the maximum buffer size in bytes for off-heap and file-mapped backup maps.
- getMaxIncrement() - Method in class com.tangosol.io.nio.AbstractBufferManager
- getMaxLoadFactor() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the load factor for the map.
- getMaxLoadNodeId() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the node id with the maximum storage size.
- getMaxLoadNodeId() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
Return node ID with maximum node storage size.
- getMaxLoadNodeId() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the node id with the maximum storage size.
- getMaxPartitionSize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
Return maximum partition storage size.
- getMaxPartitionSizeKB() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the maximum partition storage size.
- getMaxPartitionSizeKB() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the maximum partition storage size.
- getMaxPoolSize() - Method in interface com.tangosol.net.ThreadPoolManager
- 
Return the maximum size of the thread pool.
- getMaxResults() - Method in class com.tangosol.coherence.rest.config.NamedQuery
- 
Return the max allowed result set size.
- getMaxResults() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Return the max size of result set this resource is allowed to return.
- getMaxStorageSize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
Return maximum node storage size.
- getMaxStorageSizeKB() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get maximum node storage size.
- getMaxStorageSizeKB() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get maximum node storage size.
- getMaxTaskBacklog() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMaxTaskBacklog() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the maximum backlog value since the last time the statistics were reset.
- getMaxThreadCount() - Method in class com.tangosol.coherence.config.builder.DaemonPoolBuilder
- getMaxWaitMillis(long) - Method in class com.tangosol.util.Daemon
- 
If this Daemon is guarded, return the maximum wait time that the Daemon is allowed to wait for, according to its SLA.
- getMBean() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Get JMX Bean associated with Cache.
- getMBean() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- getMBean() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Get JMX Management Bean.
- getMBean() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- getMBean() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- getMBeanDomain() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
The MBean Domain to be used for the query.
- getMBeanInfo(String) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Return the MBeanInfo for a given MBean.
- getMBeanInfo(String) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- getMBeanName(String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Obtain the PersistenceManagerMBean name for a given service.
- getMBeanServer() - Method in class com.tangosol.net.management.MBeanReference
- 
Return the MbeanServer where the ObjectName is located.
- getMBeanServerProxy() - Method in interface com.tangosol.net.management.Registry
- 
Obtain a reference to the MBeanServerProxy for this Registry.
- getMediaType() - Method in class com.tangosol.coherence.rest.util.StaticContent
- 
Return media type of this content.
- getMember() - Method in class com.tangosol.net.MemberEvent
- 
Return the Member associated with this event.
- getMember() - Method in interface com.tangosol.net.NameService.RequestContext
- 
Get the clientMemberthat sent the request.
- getMember(int) - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return the ownership-enabled service member with the specified mini-id, or null if the member does not exist.
- getMember(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return the PartitionedService Member with the specified mini-id.
- getMemberGUIDs() - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Return a Map of member id to an array of GUIDs.
- getMemberId() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Get the member id where the executor is running.
- getMemberId() - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- 
Return the member UID.
- getMemberId() - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- 
Return the member UUID.
- getMemberId(String) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Parse the specified GUID and return the originating member-id.
- getMemberIdentity() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the member identity.
- getMemberIdentityProvider() - Static method in class com.tangosol.util.NullImplementation
- 
Return an instance of a null implementationMemberIdentityProvider.
- getMemberJoinDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return the amount of time in ms to delay the analysis after a member has joined.
- getMemberList(Member) - Method in class com.tangosol.net.proxy.DefaultProxyServiceLoadBalancer
- getMemberList(Member) - Method in interface com.tangosol.net.ServiceLoadBalancer
- 
Called by the Service when a new client connects to obtain an ordered list of Members to which the new client should be redirected.
- getMemberList(Member) - Method in class com.tangosol.net.SimpleServiceLoadBalancer
- 
Called by the Service when a new client connects to obtain an ordered list of Members to which the new client should be redirected.
- getMemberLoad(Member, boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the (primary or backup) partition load of the specified member.
- getMemberLocatorType(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.ReadLocatorBuilder
- 
Return a string that represents the member to target reads against.
- getMemberName() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the configured name for the Member.
- getMemberName() - Method in interface com.tangosol.net.MemberIdentityProvider
- 
Return the name for the Member.
- getMemberName() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the configured name for the Member.
- getMemberName() - Method in class com.tangosol.net.URLMemberIdentityProvider
- getMemberName() - Method in class com.tangosol.util.NullImplementation.NullMemberIdentityProvider
- getMemberSet() - Method in interface com.tangosol.net.Cluster
- 
Returns a Set of Member objects, one for each Member of the cluster.
- getMembersOwningPartition(Map<Integer, Object[]>, String) - Static method in class com.tangosol.persistence.ArchiverHelper
- 
Deprecated.Return theSetof members who are aware of a particular store.
- getMemorySize() - Method in class com.tangosol.coherence.config.unit.Units
- 
Return theMemorySize.
- getMemorySize(String) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as aMemorySize.
- getMemorySize(String, String) - Static method in class com.tangosol.coherence.config.Config
- 
Return Coherence system property value as aMemorySize.
- getMemoryUsage() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Returns index memory usage in bytes.
- getMessage() - Method in exception com.tangosol.config.ConfigurationException
- getMessage() - Method in exception com.tangosol.io.pof.PortableException
- 
Return the detail message string of this PortableException.
- getMessage() - Method in exception com.tangosol.util.WrapperException
- 
Returns the error message string of this WrapperException object.
- getMessageBacklogIncoming() - Method in interface com.tangosol.net.ServiceLoad
- 
Return the number of messages that are queued for processing.
- getMessageBacklogOutgoing() - Method in interface com.tangosol.net.ServiceLoad
- 
Return the number of messages that are queued for delivery.
- getMessageDuration75thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDuration75thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 75th percentile value from the distribution of samples in the latest snapshot of the message duration metric.
- getMessageDuration95thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDuration95thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 95th percentile value from the distribution of samples in the latest snapshot of the message duration metric.
- getMessageDuration98thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDuration98thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 98th percentile value from the distribution of samples in the latest snapshot of the message duration metric.
- getMessageDuration999thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDuration999thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 99.9th percentile value from the distribution of samples in the latest snapshot of the message duration metric.
- getMessageDuration99thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDuration99thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 99th percentile value from the distribution of samples in the latest snapshot of the message duration metric.
- getMessageDurationMax() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDurationMax() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the maximum value from the distribution of samples in the latest snapshot of the message duration metric.
- getMessageDurationMean() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDurationMean() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the mean value from the distribution of samples in the latest snapshot of the message duration metric.
- getMessageDurationMin() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDurationMin() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the minimum value from the distribution of samples in the latest snapshot of the message duration metric.
- getMessageDurationStdDev() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessageDurationStdDev() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the standard deviation from the distribution of samples in the latest snapshot of the message duration metric.
- getMessagesReceivedCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessagesReceivedCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the count of messages received.
- getMessagesReceivedFifteenMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessagesReceivedFifteenMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the fifteen minute rate of messages received.
- getMessagesReceivedFiveMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessagesReceivedFiveMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the five minute rate of messages received.
- getMessagesReceivedMeanRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessagesReceivedMeanRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the mean rate of messages received.
- getMessagesReceivedOneMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getMessagesReceivedOneMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the one minute rate of messages received.
- getMetadata() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return metadata for this manager.
- getMetadata(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Internal implementation to retrieve the metadata stored for the archived snapshot.
- getMetadata(String) - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
- getMethodName() - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- getMethodName() - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Determine the name of the method that this extractor is configured to invoke.
- getMethodName() - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Determine the name of the method that this extractor is configured to invoke.
- getMethodName() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Return the method name that this extractor is configured to invoke.
- getMethodName() - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Determine the name of the method that this extractor is configured to invoke.
- getMethodName() - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- 
Returns the name of the method to invoke.
- getMetrics() - Method in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
Obtain the gRPC metrics instance for this service.
- getMetrics() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyService
- 
Obtain the gRPC metrics instance for this service.
- getMetrics() - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- getMinCapacity() - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Determine the minimum size that the managed buffer can reach.
- getMinCapacity() - Method in class com.tangosol.io.nio.AbstractStoreManager
- 
Determine the minimum size that the managed buffers can reach.
- getMinCapacity() - Method in interface com.tangosol.io.nio.ByteBufferManager
- 
Determine the minimum size that the managed buffer can reach.
- getMinimumServiceVersion() - Method in interface com.tangosol.net.Service
- 
Return the minimum version for the members in this set.
- getMinimumServiceVersion() - Method in class com.tangosol.net.WrapperService
- getMinLoadFactor() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the "unload factor" for the map.
- getMinPoolSize() - Method in interface com.tangosol.net.ThreadPoolManager
- 
Return the minimum size of the thread pool.
- getMinThreadCount() - Method in class com.tangosol.coherence.config.builder.DaemonPoolBuilder
- getMinute() - Method in class com.tangosol.io.pof.RawTime
- 
Determine the time's minute value.
- getMinuteOffset() - Method in class com.tangosol.io.pof.RawTime
- 
Determine the timezone's minute offset value.
- getMinutes() - Method in class com.tangosol.io.pof.RawDayTimeInterval
- 
Determine the number of minutes in the day-time interval.
- getMinutes() - Method in class com.tangosol.io.pof.RawTimeInterval
- 
Determine the number of minutes in the time interval.
- getMinVersion(EventListener[]) - Static method in class com.tangosol.util.MapListenerSupport
- 
Return a minimum version for the provided listeners.
- getMinVersions(Filter) - Method in class com.tangosol.util.MapListenerSupport
- getMinVersions(Object) - Method in class com.tangosol.util.MapListenerSupport
- 
Return the minimumversionsfor the provided key.
- getMinVersions(EventListener[]) - Static method in class com.tangosol.util.MapListenerSupport
- 
Return the minimum versions received for all partitions for the provided listeners.
- getMissCache() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Returns the optional miss cache.
- getMissCacheScheme() - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
- 
Return the scheme for the cache used to maintain information on cache misses.
- getMissCacheScheme() - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return theSchemefor the cache used to maintain information on cache misses.
- getMissedSoftTimeout() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the last missed soft-timeout for this Guardable (that resulted in a recovery attempt).
- getMissesCache() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the optional map used to cache CacheLoader (or CacheStore) misses.
- getMode() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the Mode for the "license type", i.e. evaluation, development or production use.
- getMode() - Method in class com.tangosol.net.Coherence
- 
Return theCoherence.Modethat this instance is running as.
- getMode() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- getMode() - Method in interface com.tangosol.net.SessionConfiguration
- 
Return an optionalCoherence.Modethat the session should use to set thecoherence.clientproperty.
- getMode() - Method in interface com.tangosol.net.SessionProvider.Context
- 
Returns the mode thatCoherenceis running in.
- getMode() - Method in class com.tangosol.net.SessionProvider.DefaultContext
- getMode() - Method in class com.tangosol.net.WrapperSessionConfiguration
- getModificationCount() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Gets the number of times the internal value has been modified (set)
- getModificationCount() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Gets the number of times the internal value has been modified (set)
- getModificationTime() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Gets the time (since the Epoc) in milliseconds since the internal value was last modified.
- getModificationTime() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Gets the time (since the Epoc) in milliseconds since the internal value was last modified.
- getModifiedEntry() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Obtain a representation of the modifiedChangeRecord.Entry.
- getModulo() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the current modulo.
- getMonth() - Method in class com.tangosol.io.pof.RawDate
- 
Determine the date's month value.
- getMonths() - Method in class com.tangosol.io.pof.RawYearMonthInterval
- 
Determine the number of months in the year-month interval.
- getMostRecentTaskTime() - Method in class com.tangosol.util.TaskDaemon
- 
Determine when the most recent task was run.
- getMutator() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Obtain the Method object that is used to call the property mutator.
- getMvelParserContext() - Static method in class com.tangosol.coherence.rest.util.MvelHelper
- 
Return an instance of ParserContext to be used for MVEL compilation.
- getMvelParserContext() - Static method in class com.tangosol.coherence.rest.util.RestHelper
- 
Return an instance of ParserContext as an Object to be used for evaluation.
- getName() - Method in interface com.oracle.coherence.cdi.SessionInitializer
- getName() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Return the logical name of the registeredExecutorService.
- getName() - Method in class com.oracle.coherence.mp.config.CoherenceConfigSource
- getName() - Method in class com.oracle.coherence.mp.config.CoherenceDefaultsConfigSource
- getName() - Method in class com.oracle.coherence.mp.metrics.CoherenceTagsConfigSource
- getName() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Get the logical name / identifier for thisEventInterceptor.
- getName() - Method in class com.tangosol.coherence.config.builder.NamedResourceBuilder
- getName() - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry.Registration
- 
Obtains the name of the builder.
- getName() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.BuilderRegistration
- getName() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
- 
Return the builder name.
- getName() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ProviderBuilder
- 
Referenced provider name
- getName() - Method in class com.tangosol.coherence.config.SchemeMappingRegistry.SchemeMappingKey
- 
Return the resource name.
- getName() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- getName() - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- 
Get the JCache map name
- getName() - Method in class com.tangosol.coherence.rest.config.NamedQuery
- 
Return the query name.
- getName() - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Return the property name.
- getName() - Method in class com.tangosol.config.expression.Parameter
- 
Obtains the name of theParameter.
- getName() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
Get the name of the underlying Database.
- getName() - Method in class com.tangosol.io.ConfigurableSerializerFactory
- 
Deprecated.
- getName() - Method in class com.tangosol.io.DefaultSerializer
- getName() - Method in class com.tangosol.io.MultiplexingSerializer
- getName() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- getName() - Method in class com.tangosol.io.pof.PofPrincipal
- 
Return the name of this Principal.
- getName() - Method in exception com.tangosol.io.pof.PortableException
- 
Return the name of the exception.
- getName() - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
- getName() - Method in class com.tangosol.io.pof.SimplePofContext
- getName() - Method in interface com.tangosol.io.Serializer
- 
Return the name of this serializer.
- getName() - Method in interface com.tangosol.io.SerializerFactory
- 
Return the name of this serializer factory.
- getName() - Method in class com.tangosol.net.cache.AbstractEvictionPolicy
- 
Obtain the name of the eviction policy.
- getName() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.EvictionPolicy
- 
Obtain the name of the eviction policy.
- getName() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.UnitCalculator
- 
Obtain the name of the unit calculator.
- getName() - Method in class com.tangosol.net.cache.OldCache.InternalEvictionPolicy
- 
Deprecated.Obtain the name of the eviction policy.
- getName() - Method in class com.tangosol.net.cache.OldCache.InternalUnitCalculator
- 
Deprecated.Obtain the name of the unit calculator.
- getName() - Method in class com.tangosol.net.cache.SerializationCache.InternalEvictionPolicy
- 
Obtain the name of the eviction policy.
- getName() - Method in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
Obtain the name of the unit calculator.
- getName() - Method in class com.tangosol.net.Coherence
- 
Returns the name of thisCoherenceinstance.
- getName() - Method in interface com.tangosol.net.CoherenceConfiguration
- 
Return the name to use for theCoherenceinstance.
- getName() - Method in class com.tangosol.net.CoherenceConfiguration.SimpleConfig
- getName() - Method in class com.tangosol.net.CoherenceSession
- getName() - Method in interface com.tangosol.net.events.CoherenceDispatcher
- 
Return the name of theCoherenceinstance that thisCoherenceDispatcheris associated with.
- getName() - Method in interface com.tangosol.net.events.SessionDispatcher
- 
Return the name of theSessioninstance that thisSessionDispatcheris associated with.
- getName() - Method in interface com.tangosol.net.NamedCollection
- 
Obtain the name of this NamedCollection.
- getName() - Method in interface com.tangosol.net.NamedMap
- getName() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Determine the name of the cache for which this PartitionAwareBackingMap exists.
- getName() - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
- 
Determine the name of the cache for which this PartitionAwareBackingMap exists.
- getName() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Determine the name of the cache for which this PartitionAwareBackingMap exists.
- getName() - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Determine the name of the cache for which this PartitionAwareBackingMap exists.
- getName() - Method in class com.tangosol.net.security.SimpleHandler
- 
Return the name of this principal.
- getName() - Method in interface com.tangosol.net.Session
- 
Return the name of this session, if available.
- getName() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- getName() - Method in interface com.tangosol.net.SessionConfiguration
- 
Return the name of theSession.
- getName() - Method in enum com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
- getName() - Method in class com.tangosol.net.ssl.AbstractCertificateLoader
- 
Returns the name of theCertificateto load.
- getName() - Method in class com.tangosol.net.ssl.AbstractKeyStoreLoader
- getName() - Method in class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- 
Return the name of the private ky to load.
- getName() - Method in interface com.tangosol.net.topic.NamedTopic.ElementCalculator
- 
Obtain the name of the unit calculator.
- getName() - Method in class com.tangosol.net.topic.Subscriber.Name
- 
Return the group name.
- getName() - Method in class com.tangosol.net.WrapperSessionConfiguration
- getName() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the name of this manager.
- getName() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Return the name of this manager.
- getName() - Method in class com.tangosol.persistence.Snapshot
- 
Return the name of the snapshot.
- getName() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Obtain the name of the property that this PropertyAdapter handles.
- getName() - Method in class com.tangosol.run.xml.QualifiedName
- 
Returns the entire qualified name, including the prefix and local name.
- getName() - Method in class com.tangosol.run.xml.SimpleAttribute
- 
Return the name of theXmlAttribute.
- getName() - Method in class com.tangosol.run.xml.SimpleElement
- 
Get the name of the element.
- getName() - Method in interface com.tangosol.run.xml.XmlAttribute
- 
Get the name of theXmlAttribute
- getName() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Determine the element name that the XML bean will use when serializing to XML.
- getName() - Method in interface com.tangosol.run.xml.XmlElement
- 
Get the name of the element.
- getName() - Method in class com.tangosol.util.AbstractScript
- 
Return the name of the script that needs to be evaluated.
- getName() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Return the name passed intoUniversalExtractor(String).
- getName() - Method in class com.tangosol.util.filter.AllFilter
- getName() - Method in class com.tangosol.util.filter.AnyFilter
- getName() - Method in class com.tangosol.util.filter.ArrayFilter
- getName() - Method in interface com.tangosol.util.fsm.ExecutionContext
- 
Obtains the name of theFiniteStateMachinethat produced theExecutionContext.
- getName() - Method in interface com.tangosol.util.fsm.FiniteStateMachine
- 
Obtains the name of theFiniteStateMachine.
- getName() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Obtains the name of theFiniteStateMachine.
- getName() - Method in class com.tangosol.util.fsm.Transition
- 
Obtains the name of theTransition.
- getName() - Method in interface com.tangosol.util.HealthCheck
- 
Returns the unique name of this health check.
- getName() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Return the name of this manager.
- getName() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryKey
- 
Return the resource name.
- getName(String) - Static method in class com.tangosol.io.FileHelper
- 
Gets the name minus the path from a full filename.
- getNamedCache() - Method in interface com.tangosol.net.AsyncNamedCache
- 
Return theNamedCacheinstance thisAsyncNamedCacheis based on.
- getNamedCache() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Return the underlying NamedCache.
- getNamedCache(NamedCache<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of NamedCache that converts between the raw/from types to the desired/to types.
- getNamedCacheName() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- 
Obtains the desired mapping of a JCacheCachename to an CoherenceNamedCache.
- getNamedMap() - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return theNamedCacheinstance thisAsyncNamedCacheis based on.
- getNamedQuery(String) - Method in class com.tangosol.coherence.rest.config.QueryConfig
- 
Return the named query.
- getNamedSerializer(String, ClassLoader) - Method in class com.oracle.coherence.cdi.SerializerProducer
- 
Produces instances of a namedSerializer.
- getNamedSerializer(String, ClassLoader) - Method in interface com.tangosol.io.NamedSerializerFactory
- 
Produces instances of a namedSerializer.
- getNamedSerializer(InjectionPoint) - Method in class com.oracle.coherence.cdi.SerializerProducer
- 
Produces instances of a namedSerializer.
- getNamedSerializerFactory() - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- getNamedSerializerFactory() - Method in interface com.oracle.coherence.grpc.proxy.GrpcServiceDependencies
- 
Return theNamedSerializerFactory.
- getNamedTopic() - Method in interface com.tangosol.net.topic.Publisher
- 
Returns the underlyingNamedTopicthat thisPublisherpublishes to.
- getNamedTopic() - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns the underlyingNamedTopicthat thisSubscriberis subscribed to, which could be of a different generic type to thisSubscriberif the subscriber is using a transformer.
- getNameList() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
- getNamePattern() - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Obtains the pattern used to match resource names to thisResourceMapping.
- getNamespaceHandler(String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains theNamespaceHandlerwhich is capable of processing the namespace with the specified prefix.
- getNamespaceHandler(String) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains theNamespaceHandlerwhich is capable of processing the namespace with the specified prefix.
- getNamespaceHandler(URI) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains theNamespaceHandlerthat is capable of processing the namespace defined with the specifiedURI.
- getNamespaceHandler(URI) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains theNamespaceHandlerthat is capable of processing the namespace defined with the specifiedURI.
- getNamespaceHandlers() - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains theNamespaceHandlers that are currently in scope for thisProcessingContext.
- getNamespaceHandlers() - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains theNamespaceHandlers that are currently in scope for thisProcessingContext.
- getNamespacePrefix() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Determine the default namespace prefix for the property.
- getNamespacePrefix() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Obtain the default namespace prefix for this XML bean.
- getNamespacePrefix(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Retrieve the Namespace prefix for a given URI in a context of the specified XmlElement.
- getNamespaceUri() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Determine the namespace URI for the property.
- getNamespaceUri() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Obtain the namespace URI for this XML bean.
- getNamespaceUri(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Retrieve the Namespace URI for a given prefix in a context of the specified XmlElement.
- getNamespaceURI(String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains theURIthat is associated with the specified prefix.
- getNamespaceURI(String) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains theURIthat is associated with the specified prefix.
- getNameUsing(String) - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Determines the name of a resource given a value for the wildcard (assuming the resource name pattern for the mapping is using a wildcard).
- getNano() - Method in class com.tangosol.io.pof.RawTime
- 
Determine the time's nanosecond value.
- getNanos() - Method in class com.tangosol.io.pof.RawDayTimeInterval
- 
Determine the number of nanoseconds in the day-time interval.
- getNanos() - Method in class com.tangosol.io.pof.RawTimeInterval
- 
Determine the number of nanoseconds in the time interval.
- getNanos(Date) - Static method in class com.tangosol.io.pof.PofBufferWriter
- 
Extract the nanoseconds from the date.
- getNavigator() - Method in class com.tangosol.util.extractor.PofExtractor
- 
Obtain the POF navigator for this extractor.
- getNest() - Method in class com.tangosol.coherence.dsltools.precedence.NestingOPToken
- 
Obtain the NestedBaseTokens that this token will process.
- getNestEnd() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
- 
Obtain the character that ends the nesting.
- getNestStart() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
- 
Obtain the character that begins the nesting.
- getNewEntry() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Return a Map Entry that represents the state of the Entry after the change occurred that generated this event.
- getNewEntry() - Method in class com.tangosol.util.MapEvent
- 
Return a Map Entry that represents the state of the Entry after the change occurred that generated this event.
- getNewestGUID(int) - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Return the newest GUID for the specified partition.
- getNewestGUIDs(PartitionSet) - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Return the list of the newest GUIDs for the specified set of partitions.
- getNewObjectInput(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Get a new ObjectInput for the passed DataInput, even if the passed DataInput is an ObjectInput.
- getNewValue() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Return the new value associated with this event.
- getNewValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Return a new value associated with this event.
- getNewValue() - Method in class com.tangosol.util.MapEvent
- 
Return a new value associated with this event.
- getNewValue() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Return a new value associated with this event.
- getNewValueExtractor() - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Return a ValueExtractor used to transfrom the event's NewValue.
- getNext() - Method in class com.tangosol.util.SafeLinkedList.Node
- getNextAddress() - Method in interface com.tangosol.net.AddressProvider
- 
Covariant ofSocketAddressProvider.getNextAddress()which returns anInetSocketAddress.
- getNextAddress() - Method in class com.tangosol.net.CompositeAddressProvider
- 
Covariant ofSocketAddressProvider.getNextAddress()which returns anInetSocketAddress.
- getNextAddress() - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
- 
Covariant ofSocketAddressProvider.getNextAddress()which returns anInetSocketAddress.
- getNextAddress() - Method in class com.tangosol.net.CompositeSocketAddressProvider
- 
Obtain a next available address to use.
- getNextAddress() - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Covariant ofSocketAddressProvider.getNextAddress()which returns anInetSocketAddress.
- getNextAddress() - Method in class com.tangosol.net.RefreshableAddressProvider
- 
Covariant ofSocketAddressProvider.getNextAddress()which returns anInetSocketAddress.
- getNextAddress() - Method in interface com.tangosol.net.SocketAddressProvider
- 
Obtain a next available address to use.
- getNextAddress() - Method in class com.tangosol.util.NullImplementation.NullAddressProvider
- 
Covariant ofSocketAddressProvider.getNextAddress()which returns anInetSocketAddress.
- getNextAddressInternal() - Method in class com.tangosol.net.RefreshableAddressProvider
- 
Obtain the next available address to use.
- getNextBlockOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the offset of the next Block in the Buffer.
- getNextCheckTime() - Method in class com.tangosol.net.GuardSupport
- 
Return the next time at which the Guardables should be checked.
- getNextCompactBlock() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the next block to compact.
- getNextDestination() - Method in class com.tangosol.net.LoadBalancer
- 
Determine the next AddressPort combination to route to.
- getNextDestinationSocket() - Method in class com.tangosol.net.LoadBalancer
- 
Open a socket to route to.
- getNextEntry() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.Entry
- 
Get the next entry in the linked list
- getNextExpiryTime() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getNextExpiryTime() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Determine the next expiry time for the cache entries.
- getNextExpiryTime() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the next expiry time for the cache entries.
- getNextExpiryTime() - Method in class com.tangosol.net.cache.SerializationCache
- 
Determine the next expiry time for the cache entries.
- getNextExpiryTime() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the next expiry time for the cache entries.
- getNextNodeOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the offset of the next Block in the linked list.
- getNextPosition() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
For complex values with contiguous values, obtain the next position.
- getNextPosition() - Method in class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
- 
For complex values with contiguous values, obtain the next position.
- getNextPropertyIndex() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Return the index of the next property in the POF stream.
- getNextRehashBucket() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the next bucket to rehash.
- getNextValidator() - Method in class com.tangosol.run.jca.SimpleValidator
- 
Retrive the next Validator.
- getNextValidator() - Method in interface com.tangosol.util.TransactionMap.Validator
- 
Retrive the next Validator.
- getNode(int) - Method in class com.tangosol.util.SafeLinkedList
- 
Find and return the specified Node.
- getNonBlockingEntryStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
The wrapped NonBlockingEntryStore.
- getNonceCounter() - Method in class com.tangosol.util.SortedBag
- 
Return the nonce counter used to assign unique element ids.
- getNonPartialIndexes(Map) - Method in class com.tangosol.util.filter.NotFilter
- 
Get a Map of the available non-partial indexes from the given Map of all available indexes.
- getNonPassThruCache() - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- 
Obtain theNamedCachethat the request executes on.
- getNonWildcardMapListeners() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListenerManager
- 
Return all map listeners that should be registered against a specific remote cache or map in a specific session.
- getNotificationInfo() - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
- getNotificationInfo() - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean.SilentEmitter
- getNotificationInfo(Class<?>) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return anMBeanNotificationInfoif aNotificationannotation is present on the provided MBean interface.
- getNotificationManager() - Method in interface com.tangosol.net.management.Registry
- 
Obtain a reference to the NotificationManager for this Registry.
- getNotificationTimeout() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Returns the timeout that a subscriber will use when waiting for its first allocation of channels.
- getNudASTName() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Get nud AST Name for this token
- getNullPasswordProviderBuilder() - Static method in class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor
- 
Rerturns a builder for null password values.
- getNumber() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Obtain the Number representation of the node.
- getNumFactor() - Method in class com.tangosol.util.processor.NumberMultiplier
- 
Returns the number to multiply by.
- getNumInc() - Method in class com.tangosol.util.processor.NumberIncrementor
- 
Returns the number to increment by.
- getObject() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Obtain the Object representation of the node.
- getObject() - Method in class com.tangosol.util.SafeLinkedList.Node
- getObject() - Method in class com.tangosol.util.ThreadLocalObject
- 
Get the value of the ThreadLocalObject for the current thread.
- getObjectArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the Object[] which this PofValue represents.
- getObjectArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the Object[] which this PofValue represents.
- getObjectInput() - Method in class com.tangosol.io.WrapperObjectInputStream
- 
Obtain the underlying object providing the ObjectInput interface that this object is delegating to.
- getObjectInput(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Get an ObjectInput for the passed DataInput object.
- getObjectInput(DataInput, ClassLoader, boolean) - Method in interface com.tangosol.io.ObjectStreamFactory
- 
Obtain an ObjectInput based on the passed DataInput.
- getObjectInput(DataInput, ClassLoader, boolean) - Method in class com.tangosol.util.ExternalizableHelper.DefaultObjectStreamFactory
- 
Obtain an ObjectInput based on the passed DataInput.
- getObjectInputFilter() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- getObjectInputFilter() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Returns an ObjectInputFilter (or null) that should be used by the caller to confirm / deny deserialization of a class encoded in this input stream.
- getObjectInputFilter() - Method in class com.tangosol.io.WrapperBufferInput
- getObjectInputFilter(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Return ObjectInputFilter associated withDataInput.
- getObjectMapper() - Static method in class com.tangosol.coherence.rest.providers.JacksonMapperProvider
- getObjectName() - Method in class com.tangosol.net.management.MBeanReference
- 
Return the ObjectName of the qualified name.
- getObjectNameFilter() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
- 
Return a Filter that can be applied against an ObjectName and ensures all the Filters within themapof filters test successfully (logical AND).
- getObjectOutput() - Method in class com.tangosol.io.WrapperObjectOutputStream
- 
Obtain the underlying object providing the ObjectOutput interface that this object is delegating to.
- getObjectOutput(DataOutput) - Method in interface com.tangosol.io.ObjectStreamFactory
- 
Obtain an ObjectOutput based on the passed DataOutput.
- getObjectOutput(DataOutput) - Method in class com.tangosol.util.ExternalizableHelper.DefaultObjectStreamFactory
- 
Obtain an ObjectOutput based on the passed DataOutput.
- getObjectOutput(DataOutput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Get an ObjectOutput for the passed DataOutput object.
- getObjectStreamFactory() - Static method in class com.tangosol.util.ExternalizableHelper
- 
Return the ObjectStreamFactory used to convert DataInput/Output into ObjectInput/Output streams.
- getObservableMap() - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
- 
Return the underlying ObservableMap.
- getObservableMap() - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
- 
Return the underlying ObservableMap.
- getObservableMap() - Static method in class com.tangosol.util.NullImplementation
- 
Returns an instance of the NullObservableMap.
- getObservableMap(ObservableMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of ObservableMap.
- getObservedQualifiers() - Method in class com.oracle.coherence.cdi.CdiEventObserver
- getObservedQualifiers() - Method in class com.oracle.coherence.cdi.CdiMapEventObserver
- getObservedQualifiers() - Method in interface com.oracle.coherence.cdi.events.AnnotatedMapListener.MapEventObserver
- 
Return the qualifiers for the observer that wil be used to further qualify which events are received.
- getObservedQualifiers() - Method in interface com.oracle.coherence.cdi.events.EventObserverSupport.EventObserver
- 
Return the qualifiers for the observer that wil be used to further qualify which events are received.
- getObserver() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryValue
- 
Return the lifecycle observer for the registered resource.
- getOffset() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Determine the current offset of this BufferInput within the underlying ReadBuffer.
- getOffset() - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Determine the current offset of this BufferOutput within the underlying WriteBuffer.
- getOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the offset of this Block in the Buffer.
- getOffset() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Determine the current offset of this BufferInput within the underlying ReadBuffer.
- getOffset() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the offset of this value from the beginning of POF stream.
- getOffset() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Determine the current offset of this BufferInput within the underlying ReadBuffer.
- getOffset() - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- getOffset() - Method in class com.tangosol.io.WrapperBufferInput
- 
Determine the current offset of this BufferInput within the underlying ReadBuffer.
- getOffset() - Method in class com.tangosol.io.WrapperBufferOutput
- 
Determine the current offset of this BufferOutput within the underlying WriteBuffer.
- getOffset() - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Determine the current offset of this BufferOutput within the underlying WriteBuffer.
- getOldEntry() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Return a Map Entry that represents the state of the Entry before the change occurred that generated this event.
- getOldEntry() - Method in class com.tangosol.util.MapEvent
- 
Return a Map Entry that represents the state of the Entry before the change occurred that generated this event.
- getOldestActivePage() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Obtain the oldest active page.
- getOldestMember() - Method in interface com.tangosol.net.Cluster
- 
Returns a Member object representing the senior cluster member.
- getOldestMember() - Method in interface com.tangosol.net.ServiceInfo
- 
Return the "most senior" Member that is running this Service.
- getOldValue() - Method in class com.oracle.coherence.mp.config.ConfigPropertyChanged
- 
The old value of the configuration property that was modified.
- getOldValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- 
Obtains the old value for the entry.
- getOldValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
- getOldValue() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
- getOldValue() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Return the old value associated with this event.
- getOldValue() - Method in class com.tangosol.util.AbstractKeyBasedMap.DeferredCacheEvent
- 
Return an old value associated with this event.
- getOldValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Return an old value associated with this event.
- getOldValue() - Method in class com.tangosol.util.MapEvent
- 
Return an old value associated with this event.
- getOldValue() - Method in class com.tangosol.util.MapListenerSupport.FilterEvent
- 
Return an old value associated with this event.
- getOldValueExtractor() - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Return a ValueExtractor used to transfrom the event's OldValue.
- getOpenBundle() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Retrieve any Bundle that is currently in the open state.
- getOperationalContext() - Method in class com.oracle.coherence.cdi.server.ClusterProducer
- 
Produces the singleton CoherenceOperationalContextinstance.
- getOperationName(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Return the operation name for which calls performed concurrently on multiple threads are "bundled" into a functionally analogous "bulk" operation that takes a collection of arguments instead of a single one.
- getOperationStatus() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Return the status of the current operation issued by the persistence coordinator.
- getOperator() - Method in class com.tangosol.util.filter.AllFilter
- getOperator() - Method in class com.tangosol.util.filter.AnyFilter
- getOperator() - Method in class com.tangosol.util.filter.ArrayFilter
- getOperator() - Method in class com.tangosol.util.filter.ComparisonFilter
- getOperator() - Method in class com.tangosol.util.filter.ContainsAllFilter
- getOperator() - Method in class com.tangosol.util.filter.ContainsAnyFilter
- getOperator() - Method in class com.tangosol.util.filter.ContainsFilter
- getOperator() - Method in class com.tangosol.util.filter.EqualsFilter
- getOperator() - Method in class com.tangosol.util.filter.GreaterEqualsFilter
- getOperator() - Method in class com.tangosol.util.filter.GreaterFilter
- getOperator() - Method in class com.tangosol.util.filter.InFilter
- getOperator() - Method in class com.tangosol.util.filter.LessEqualsFilter
- getOperator() - Method in class com.tangosol.util.filter.LessFilter
- getOperator() - Method in class com.tangosol.util.filter.LikeFilter
- getOperator() - Method in class com.tangosol.util.filter.NotEqualsFilter
- getOperator() - Method in class com.tangosol.util.filter.RegexFilter
- getOperator() - Method in class com.tangosol.util.filter.XorFilter
- getOperator(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return theBaseOperatormapped to the given symbol.
- getOperators() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return the set of CohQL Operators characters.
- getOption(int) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- getOptionalProperty(String, Type, T, XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains the strongly typed value for the property defined at the path relative to the specifiedXmlElement.
- getOptionalProperty(String, Type, T, XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains the strongly typed value for the property defined at the path relative to the specifiedXmlElement.
- getOPToken(String) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
Obtain theOPTokenthat is mapped to the specified identifier.
- getOrDefault(Object, Object) - Method in class com.tangosol.util.SafeSortedMap
- getOrDefault(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- getOrDefault(Object, V) - Method in class com.tangosol.net.cache.NearCache
- getOrDefault(Object, V) - Method in interface com.tangosol.util.InvocableMap
- getOrDefault(Object, V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- getOrDefault(Object, V) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- getOrDefault(K, V) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Returns the value to which the specified key is mapped, orvalueDefaultif this map contains no mapping for the key.
- getOrder() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Return theInterceptor.Orderof this interceptor.
- getOrder() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Return the priority of this interceptor in the chain of interceptors.
- getOrderId() - Method in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
Return unit-of-order id.
- getOrderId() - Method in interface com.tangosol.net.topic.Publisher.Orderable
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderBy
- 
Return unit-of-order id.
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderById
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderByNone
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderByThread
- getOrderId(V) - Method in class com.tangosol.net.topic.Publisher.OrderByValue
- getOrdinal() - Method in class com.oracle.coherence.mp.config.CoherenceConfigSource
- getOrdinal() - Method in class com.oracle.coherence.mp.config.CoherenceDefaultsConfigSource
- getOrdinal() - Method in class com.oracle.coherence.mp.metrics.CoherenceTagsConfigSource
- getOriginal() - Method in class com.tangosol.util.DeltaSet
- 
Determine what items were in the original set.
- getOriginal() - Method in class com.tangosol.util.SubSet
- 
Determine what items were in the original set.
- getOriginalBinaryValue() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return a raw original binary value for this entry.
- getOriginalBinaryValue() - Method in interface com.tangosol.util.BinaryEntry
- 
Return a raw original binary value for this entry.
- getOriginalBinaryValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Return a raw original binary value for this entry.
- getOriginalBinaryValue() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- getOriginalBuffer() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Get the original buffer the changes should be applied to.
- getOriginalEntry() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Obtain a representation of theChangeRecord.Entryprior to any changes occurring.
- getOriginalException() - Method in exception com.tangosol.util.WrapperException
- getOriginalException(RuntimeException) - Static method in class com.oracle.coherence.common.base.Exceptions
- 
Unwind the wrapper (runtime) exception to extract the original
- getOriginalException(RuntimeException) - Static method in class com.tangosol.util.Base
- 
Unwind the wrapper (runtime) exception to extract the original
- getOriginalValue() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return an original value for this entry.
- getOriginalValue() - Method in interface com.tangosol.net.events.partition.cache.EntryEvent
- 
Return the original value of the entry on which the action represented by thisEntryEventoccurred.
- getOriginalValue() - Method in interface com.tangosol.util.BinaryEntry
- 
Return an original value for this entry.
- getOriginalValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Return an original value for this entry.
- getOriginalValue() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- getOriginalValue() - Method in interface com.tangosol.util.MapTrigger.Entry
- 
Determine the value that existed before the start of the mutating operation that is being evaluated by the trigger.
- getOriginalValue() - Method in class com.tangosol.util.SimpleMapEntry
- 
Determine the value that existed before the start of the mutating operation that is being evaluated by the trigger.
- getOrphanedPartitions() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the partitions deemed orphaned as a result of a previous execution ofanalyzeOrphans.
- getOrphanedPartitions() - Method in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
- 
Return the set of orphaned partitions.
- getOut() - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Obtain the underlying BufferOutput.
- getOut() - Static method in class com.tangosol.util.Base
- 
Obtains the current writer used for printing.
- getOutputStream() - Method in class com.tangosol.io.WrapperOutputStream
- 
Obtain the underlying OutputStream.
- getOutputStream() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a OutputStream.
- getOutputStream(DataOutput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Get an OutputStream for the passed DataOutput object.
- getOutputStream(OutputStream) - Method in interface com.tangosol.io.WrapperStreamFactory
- 
Deprecated.Requests an OutputStream that wraps the passed OutputStream.
- getOutputStream(OutputStream) - Method in class com.tangosol.net.CompressionFilter
- 
Deprecated.Requests an OutputStream that wraps the passed OutputStream.
- getOutputWriter() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getOutputWriter() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return an instance of aPrintWriterthat should be used to display query output.
- getOutstandingPacketMaximum() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the maximum allowable flow-control rate measured in packets.
- getOutstandingPacketMinimum() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the minimum allowable flow-control rate measured in packets.
- getOverrideProcessor() - Method in class com.tangosol.coherence.config.xml.CacheConfigNamespaceHandler
- 
Obtains theOverrideProcessorthat is suitable for processing the xml override.
- getOverrideProcessor() - Method in interface com.tangosol.config.xml.NamespaceHandler
- 
Obtains theOverrideProcessorthat is suitable for processing the xml override.
- getOwnedCode() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getOwnedCode() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns a numeric representation of if the channel is owned by this subscriber where1represents true and0represents false.
- getOwnedPartitions(Member) - Method in interface com.tangosol.net.PartitionedService
- 
Determine the PartitionSet that is currently owned by a cluster Member.
- getOwnedPartitions(Member, int) - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return the set of partitions for which the specified member owns the specified storage index (replica).
- getOwnedPartitions(Member, int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the set of partitions for which the specified member owns (or has been assigned by this analysis to own) the specified storage index.
- getOwner() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Returns the identity of the process and thread that currently owns this lock, ornullif not owned.
- getOwner() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Returns the thread that currently owns the write lock, ornullif not owned.
- getOwner(int) - Method in class com.tangosol.net.partition.Ownership
- 
Return the owner id for the specified storage for this partition.
- getOwners() - Method in class com.tangosol.net.partition.Ownership
- 
Return an array containing owner ids for this partition.
- getOwners(int[]) - Method in class com.tangosol.net.partition.Ownership
- 
Return an array containing owner ids for this partition.
- getOwnership() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter
- 
Return the ownership used to evaluate member safety.
- getOwnership() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
- 
Return the ownership used to evaluate member safety.
- getOwnership() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
- 
Return the ownership to use in comparing member strength.
- getOwnershipEnabledMembers() - Method in interface com.tangosol.net.PartitionedService
- 
Return a Set of Member objects, one for each Member that has registered this PartitionedService and is partition ownership-enabled.
- getOwnershipLeavingMembers() - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return the set of ownership-enabled members in the partitioned service that are in the process of leaving.
- getOwnershipMembers() - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return the set of ownership-enabled members in the partitioned service.
- getOwnershipMembers() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the set of members across which to distribute the partition ownership.
- getOwnershipMemberSet() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Return the set of ownership-enabled members in the associated PartitionedService.
- getOwnershipMembersList() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return an array containing the members across which to distribute the partition ownership, arranged in arbitrary order.
- getOwnershipSenior() - Method in interface com.tangosol.net.PartitionedService
- 
Return the senior ownership-enabled member in the service.
- getOwnershipVersion(int) - Method in interface com.tangosol.net.PartitionedService
- 
Determine the primary owner's version of the specified partition.
- getOwnerThread() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine the thread that owns the Status object, if the Status object is processing or committing.
- getOwnerThread() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine the thread that owns the Status object, if the Status object is processing or committing.
- getPackage(String) - Method in class com.tangosol.coherence.rest.util.PartialObject.PartialClassLoader
- getPackageName(Class) - Static method in class com.tangosol.util.ClassHelper
- 
Determine the package name of a class.
- getPackageName(String) - Static method in class com.tangosol.util.ClassHelper
- 
Determine the package name from a class (or package) name.
- getPackageResources(Class) - Static method in class com.tangosol.util.ClassHelper
- 
Load the default package resources for the specified class.
- getPackageResources(String) - Static method in class com.tangosol.util.ClassHelper
- 
Load the default package resources for the specified class name.
- getPackages() - Method in class com.tangosol.coherence.rest.util.PartialObject.PartialClassLoader
- getPacketBundlingAggression() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the aggression factor to use in deferring a packet once it has reached the average bundle size.
- getPacketBundlingThresholdNanos() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the maximum amount of time to defer a packet while waiting for additional packets to bundle.
- getPacketMaxLength() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the maximum size, in bytes, of the network packets that will be sent and received on the local and group sockets.
- getPacketPreferredLength() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the preferred size, in bytes, of the network packets that will be sent and received on the local sockets.
- getPage() - Method in class com.tangosol.util.filter.LimitFilter
- 
Obtain a current page number (zero-based).
- getPage(int) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Get the BinaryStore for the page specified by the passed page number.
- getPageAdvanceTime() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine the time that the next page should be created.
- getPagedBinaryStore() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Returns the BinaryStore that this map uses for its storage.
- getPagedKeyMap() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Obtain the map that manages the mapping from Binary keys to BinaryStore objects.
- getPageDuration() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine the length of time that the most recently created page is kept as the current page.
- getPageDurationSeconds(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Return the length of time that a page in the cache is current.
- getPageLimit(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Return the maximum number of pages that the cache manages before older pages are destroyed.
- getPageSize() - Method in class com.tangosol.util.filter.LimitFilter
- 
Obtain the page size (expressed as a number of entries per page).
- getPageSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return the binary limit of the size of a page in a topic.
- getParallelAggregator() - Method in interface com.tangosol.util.InvocableMap.ParallelAwareAggregator
- 
Deprecated.Get an aggregator that can take the place of this aggregator in situations in which the InvocableMap can aggregate in parallel.
- getParameterAnnotation(Method, int, Class<A>) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Retrieve anAnnotationfor a parameter to a method.
- getParameterName(Class, MBeanOperationInfo, MBeanParameterInfo, int) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Retrieve the parameter name for the specified parameter by finding aDescriptionannotation on the corresponding method.
- getParameterName(MBeanOperationInfo, MBeanParameterInfo, int) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean
- 
Retrieve the parameter name for the specified parameter by finding aDescriptionannotation on the operation.
- getParameterName(MBeanOperationInfo, MBeanParameterInfo, int) - Method in class com.tangosol.net.management.AnnotatedStandardMBean
- 
Retrieve the parameter name for the specified parameter by finding aDescriptionannotation on the operation.
- getParameterResolver() - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Obtains theParameterResolverthat is to be used to resolveParameters associated with thisResourceMapping.
- getParameterResolver() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- getParameterResolver() - Method in interface com.tangosol.net.SessionConfiguration
- 
Returns an optionalParameterResolverto use to resolve configuration parameters when creating the session.
- getParameterResolver() - Method in class com.tangosol.net.WrapperSessionConfiguration
- getParameterResolver(String, Class<M>, ClassLoader, BackingMapManagerContext) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return the ParameterResolver that has been initialized with the built-in Coherence parameters.
- getParameterResolver(String, ClassLoader, BackingMapManagerContext) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return the ParameterResolver that has been initialized with the built-in Coherence parameters.
- getParameters() - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Return the array of arguments used to invoke the method.
- getParameters() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Return the array of arguments used to invoke the method.
- getParameterTypes() - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine.ParsedQuery
- 
Return a map of parameter types keyed by parameter name.
- getParent() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the parent of this value.
- getParent() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the parent of this value.
- getParent() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the parent element of this element.
- getParent() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the parent element of this value.
- getParentDirectory() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Get the configured parent directory.
- getParentParser() - Method in class com.tangosol.io.pof.PofBufferReader
- 
If this parser is contextually within a user type, obtain the parser which created this parser in order to parse the user type.
- getParentParser() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
If this parser is contextually within a user type, obtain the parser which created this parser in order to parse the user type.
- getParentSpan() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Return the associated parent Span if any.
- getParentWriter() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
If this writer is contextually within a user type, obtain the writer which created this writer in order to write the user type.
- getParentWriter() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
If this writer is contextually within a user type, obtain the writer which created this writer in order to write the user type.
- getParentXmlBean() - Method in class com.tangosol.run.xml.XmlBean
- 
Obtain the XmlBean that contains this XmlBean.
- getParser() - Static method in class com.tangosol.run.xml.SaxParser
- 
Get an instance of non-validating SAX parser.
- getParseString() - Method in exception com.tangosol.util.FilterBuildingException
- 
Answer the String that was being processed when the Exception occurred
- getPartialClass() - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Return the partial class for this property.
- getPartialClass(Class, PropertySet) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Return a partial class for the specified source class and property set.
- getPartialClassLoader() - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Return a PartialClassLoader corresponding to the Context ClassLoader.
- getPartialClassMap(PartialObject.PartialClassLoader) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Return the partial class map corresponding to the PartialClassLoader.
- getPartialConstructorMap(PartialObject.PartialClassLoader) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Return the partial constructor map corresponding to the PartialClassLoader.
- getPartialResult() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- getPartialResult() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- getPartialResult() - Method in exception com.tangosol.net.RequestIncompleteException
- 
Return a partial execution result that may have been assembled before an exception occurred.
- getPartialResult() - Method in class com.tangosol.util.aggregator.AbstractAggregator
- getPartialResult() - Method in class com.tangosol.util.aggregator.CompositeAggregator
- getPartialResult() - Method in class com.tangosol.util.aggregator.Count
- getPartialResult() - Method in class com.tangosol.util.aggregator.GroupAggregator
- getPartialResult() - Method in class com.tangosol.util.aggregator.PriorityAggregator
- getPartialResult() - Method in class com.tangosol.util.aggregator.QueryRecorder
- getPartialResult() - Method in class com.tangosol.util.aggregator.ScriptAggregator
- getPartialResult() - Method in class com.tangosol.util.aggregator.TopNAggregator
- getPartialResult() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
Return the partial result of the aggregation.
- getPartition() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the id of the partition for which these statistics apply.
- getPartition() - Method in interface com.tangosol.net.partition.VersionedPartitions.Iterator
- 
Return the current partition.
- getPartition() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- getPartition() - Method in class com.tangosol.util.MapEvent
- 
Return the partition this MapEvent represents or -1 if the event source is not partition aware.
- getPartition(String) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Parse the specified GUID and return the partition-id.
- getPartitionAssignmentStrategy() - Method in interface com.tangosol.net.PartitionedService
- 
Determine the strategy for assigning partitions to cluster members that this service has been configured to use.
- getPartitionAssignmentStrategy() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a PartitionAssignmentStrategy.
- getPartitionAwareBackingMap() - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Obtain the PartitionAwareBackingMap that this ReadWriteBackingMap uses as its backing map.
- getPartitionCache(Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Obtain the backing cache for a particular key.
- getPartitionCacheArray() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Obtain the array of backing caches.
- getPartitionCount() - Method in class com.tangosol.net.partition.PartitionSet
- 
Return the number of partitions represented by this PartitionSet.
- getPartitionCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the configured number of partitions for the service.
- getPartitionCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the configured number of partitions for the service.
- getPartitionCount() - Method in interface com.tangosol.net.PartitionedService
- 
Determine the number of partitions that the service has been configured to "break up" the conceptual "key set" into.
- getPartitionCount(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return the partition count that has been stored in the specified store.
- getPartitionId() - Method in interface com.tangosol.net.events.partition.TransferEvent
- 
Return the ID of the partition being transferred.
- getPartitionId() - Method in interface com.tangosol.net.partition.KeyPartitioningStrategy.PartitionAwareKey
- 
Return the partition id that this key should be associated with.
- getPartitionId() - Method in class com.tangosol.net.partition.SimplePartitionKey
- 
Return the partition id that this key should be associated with.
- getPartitionKey(int) - Static method in class com.tangosol.net.partition.SimplePartitionKey
- 
Factory method for a SimplePartitionKey.
- getPartitionKeys(String, int) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Obtain a collection of keys in the internal format that belong to the specified partition for the specified backing map.
- getPartitionKeys(String, int) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Obtain a collection of keys in the internal format that belong to the specified partition for the specified backing map.
- getPartitionLoad(int, boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the load (as defined by the appropriate load calculator) for the specified partition.
- getPartitionMap(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Obtain a Map view for the data in a specific partition.
- getPartitionMap(int) - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
- 
Obtain a Map view for the data in a specific partition.
- getPartitionMap(int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Obtain a Map view for the data in a specific partition.
- getPartitionMap(int) - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Obtain a Map view for the data in a specific partition.
- getPartitionMap(PartitionSet) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Obtain a Map view for the data in a specific set of partitions.
- getPartitionMap(PartitionSet) - Method in interface com.tangosol.net.partition.PartitionAwareBackingMap
- 
Obtain a Map view for the data in a specific set of partitions.
- getPartitionMap(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Obtain a Map view for the data in a specific set of partitions.
- getPartitionMap(PartitionSet) - Method in class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Obtain a Map view for the data in a specific set of partitions.
- getPartitionMapType() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Return the uniform type used by each partition map.
- getPartitionOwner(int) - Method in interface com.tangosol.net.PartitionedService
- 
Determine the primary owner of the specified partition.
- getPartitionOwnership(int) - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return the Ownership information for the specified partition.
- getPartitionOwnership(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the Ownership information (or the ownership assigned by this analysis) for the specified partition.
- getPartitions() - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- getPartitions() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
- 
Obtain an array of all of the current partition IDs for which there are backing maps.
- getPartitions() - Method in interface com.tangosol.net.partition.VersionedPartitions
- 
Return the partitions being tracked.
- getPartitions() - Method in interface com.tangosol.util.QueryRecord.PartialResult
- 
Get the set of partitions associated with this partial result.
- getPartitions() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Get the set of partitions associated with this partial result.
- getPartitions(Map<Integer, Object[]>, int) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Return aPartitionSetwith all partitions present in the providedmapStores.
- getPartitionSet() - Method in class com.tangosol.net.partition.PartitionEvent
- 
Determine the set of partitions represented by this event.
- getPartitionSet() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
- 
Obtain a PartitionSet containing partition IDs for which there are backing maps.
- getPartitionSet() - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Obtain the PartitionSet that specifies what partitions the wrapped filter will be applied to.
- getPartitionSplittingBackingMap() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Obtain the underlying PartitionSplittingBackingMap.
- getPartitionStats() - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return an array of the most recently available partition statistics, indexed by partition-id.
- getPartitionUnitFactor() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the unit factor for individual partition maps.
- getPassThroughCache(String, String) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Obtain anNamedCache.
- getPassword() - Method in class com.tangosol.net.security.UsernameAndPassword
- 
Return the password.
- getPasswordProviderBuilderForPasswordStr(String) - Static method in class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor
- 
Generates a ParameterizedBuilder using the DefaultPasswordProvider.class by passing the string-input to its single-param constructor.
- getPath(File) - Static method in class com.tangosol.io.FileHelper
- 
Return the path of a file.
- getPathElements() - Method in class com.tangosol.io.pof.reflect.AbstractPofPath
- 
Return a collection of path elements.
- getPathElements() - Method in class com.tangosol.io.pof.reflect.SimplePofPath
- 
Return a collection of path elements.
- getPathNoEndSeparator(String) - Static method in class com.tangosol.io.FileHelper
- 
Gets the path from a full filename, which excludes the prefix, and also excluding the final directory separator.
- getPattern() - Method in class com.tangosol.util.filter.LikeFilter
- 
Obtain the filter's pattern string.
- getPendingAsyncStoreOps() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the number of pending non-blocking store operations.
- getPendingMap() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Obtain the map that contains all of the pending store and erase data.
- getPendingMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Obtain a map of entries removed from the queue, but not yet persisted to the underlying datastore.
- getPendingRemoves() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the pending removes key set for the CacheStore used by this backing map.
- getPendingWrites() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the size of the write-behind queue if configured, or the number of pending writes of the non-blocking store, if configured.
- getPermission() - Method in class com.tangosol.net.security.PermissionInfo
- 
Return the ClusterPermission object.
- getPermissionsConfig() - Method in class com.tangosol.net.security.DefaultController
- 
Obtain the permission configuration descriptor.
- getPersistenceActiveDirectory() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- getPersistenceActiveDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the directory under which cached data is actively persisted by the environment.
- getPersistenceActiveDirectory() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
- 
Return the directory under which cached data is actively persisted by the environment.
- getPersistenceActiveSpaceUsed() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- getPersistenceActiveSpaceUsed() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the total size in bytes used by the persistence layer to persist mutating cache operations.
- getPersistenceActiveSpaceUsed() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
- 
Return the total size in bytes used by the persistence layer to persist mutating cache operations.
- getPersistenceBackupDirectory() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- getPersistenceBackupDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the directory under which cached data is actively persisted by the environment.
- getPersistenceBackupDirectory() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
- 
Return the directory under which cached data is actively persisted by the environment.
- getPersistenceBackupSpaceUsed() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- getPersistenceBackupSpaceUsed() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the total size in bytes used by the persistence layer to persist backups of mutating cache operations.
- getPersistenceBackupSpaceUsed() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
- 
Return the total size in bytes used by the persistence layer to persist backups of mutating cache operations.
- getPersistenceEnvironment() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the environment that created this manager.
- getPersistenceEnvironment() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aPersistenceEnvironment.
- getPersistenceEnvironment(Class<R>) - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aPersistenceEnvironment.
- getPersistenceEnvironmentInfo(String, String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Return aPersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfoencapsulating the configuration this builder uses to constructenvironments.
- getPersistenceEventsDirectory() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- getPersistenceEventsDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the directory under which cached data is actively persisted by the environment.
- getPersistenceEventsDirectory() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
- 
Return the directory under which cached data is actively persisted by the environment.
- getPersistenceInfo() - Method in class com.tangosol.persistence.AbstractPersistenceTools
- getPersistenceInfo() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- getPersistenceManager() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aPersistenceManager.
- getPersistenceManager(Class<R>) - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aPersistenceManager.
- getPersistenceMode() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- getPersistenceMode() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- 
Return the persistence mode.
- getPersistenceMode() - Method in interface com.tangosol.net.PartitionedService
- 
Return the persistence mode, ornullif persistence is not configured.
- getPersistenceSnapshotDirectory() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- getPersistenceSnapshotDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the directory under which copies of cached data are persisted by the environment.
- getPersistenceSnapshotDirectory() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
- 
Return the directory under which copies of cached data are persisted by the environment.
- getPersistenceTools() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- getPersistenceTools() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Return an instance ofPersistenceToolsallowing offline operations to be performed against the associated PersistenceManager and appropriatePersistentStore.
- getPersistenceTools(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- getPersistenceTools(String) - Method in interface com.tangosol.persistence.SnapshotArchiver
- 
Return an instance ofPersistenceToolsallowing offline operations to be performed against the associated PersistenceManager and appropriatePersistentStore.
- getPersistenceTrashDirectory() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- getPersistenceTrashDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the directory under which potentially corrupted persisted data is stored by the environment.
- getPersistenceTrashDirectory() - Method in interface com.tangosol.persistence.PersistenceEnvironmentInfo
- 
Return the directory under which potentially corrupted persisted data is stored by the environment.
- getPersistenceVersion(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return the persistence version the provided store was written with.
- getPersistentStore() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aPersistentStore.
- getPersistentStore(Class<R>) - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aPersistentStore.
- getPersistentStoreMap() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the map of open PersistentStore instances keyed by their identifiers.
- getPersistentVersionCache() - Method in class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Get the cache of version info for the data stored in the persistent store behind this backing map (and other related backing maps if this is backing a distributed cache).
- getPofConfig() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Obtain the PofConfig that represents the initialized state of the ConfigurablePofContext.
- getPofConfigURI() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- getPofContext() - Method in class com.tangosol.io.pof.PofBufferReader
- 
Return the PofContext object used by this PofReader to deserialize user types from a POF stream.
- getPofContext() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Return the PofContext object used by this PofWriter to serialize user types to a POF stream.
- getPofContext() - Method in interface com.tangosol.io.pof.PofReader
- 
Return the PofContext object used by this PofReader to deserialize user types from a POF stream.
- getPofContext() - Method in interface com.tangosol.io.pof.PofWriter
- 
Return the PofContext object used by this PofWriter to serialize user types to a POF stream.
- getPofContext() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the POF context to use for serialization and deserialization.
- getPofContext() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a PofContext.
- getPofHandler() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Return the WritingPofHandler used internally by this PofBufferWriter to write the POF stream.
- getPofHandler() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a PofHandler.
- getPofNavigator() - Method in class com.tangosol.io.pof.reflect.PofReflectionHelper.NavigatorAndType
- getPofNavigator(Class, String) - Static method in class com.tangosol.io.pof.reflect.PofReflectionHelper
- 
Obtain thePofNavigatorto use to navigate to the specified field in a class.
- getPofReader() - Method in class com.tangosol.io.pof.PofInputStream
- 
Obtain the underlying PofReader.
- getPofSerializer(int) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Return a PofSerializer that can be used to serialize and deserialize an object of the specified user type to and from a POF stream.
- getPofSerializer(int) - Method in interface com.tangosol.io.pof.PofContext
- 
Return a PofSerializer that can be used to serialize and deserialize an object of the specified user type to and from a POF stream.
- getPofSerializer(int) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Return a PofSerializer that can be used to serialize and deserialize an object of the specified user type to and from a POF stream.
- getPofSerializer(int) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Return a PofSerializer that can be used to serialize and deserialize an object of the specified user type to and from a POF stream.
- getPofSerializer(int) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Return a PofSerializer that can be used to serialize and deserialize an object of the specified user type to and from a POF stream.
- getPofTypeId(PofContext) - Method in class com.tangosol.util.extractor.PofExtractor
- 
compute the expected pof type id based on the class.
- getPofTypeId(Class, PofContext) - Static method in class com.tangosol.io.pof.PofHelper
- 
Return an identifier that represents the POF type of the specified class.
- getPofWriter() - Method in class com.tangosol.io.pof.PofOutputStream
- 
Obtain the underlying PofWriter.
- getPolicyPopulation() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Calculate and return the current size of the member set that contributes to the quorum for this policy domain.
- getPolicyPopulation() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Calculate and return the current size of the member set that contributes to the quorum for this policy domain.
- getPolls() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getPolls() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returns the number of elements polled by this subscriber.
- getPool() - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- 
Obtain the underlyingDaemonPool.
- getPoolSize() - Method in interface com.tangosol.net.ThreadPoolManager
- 
Return the current size of the thread pool.
- getPort() - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Returns the port that the gRPC server has bound to.
- getPort() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Return the port number.
- getPort() - Method in interface com.tangosol.net.Member
- 
Return the port of the Member's DatagramSocket for point-to-point communication.
- getPort() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the port of the Member's DatagramSocket for point-to-point communication.
- getPort() - Method in class com.tangosol.util.UUID
- 
Determine the port portion of the UUID.
- getPortMin() - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
Return the minimum port number.
- getPortMinOriginal() - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
Return the minimum port number provided in the constructor.
- getPosition() - Method in interface com.tangosol.net.topic.Publisher.Status
- 
Returns thePositionin the channel that the element was published to.
- getPosition() - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- 
Returns the requested commitPosition.
- getPosition() - Method in interface com.tangosol.net.topic.Subscriber.Element
- 
Returns the position of this element within the channel in a topic.
- getPostFactor() - Method in class com.tangosol.util.processor.NumberMultiplier
- 
Returns whether to return the value before it was multiplied.
- getPostFilterKeySetSize() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
- 
Get the size of the key set remaining after evaluating the filter or applying an index.
- getPostFilterKeySetSize() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Get the size of the key set remaining after evaluating the filter or applying an index.
- getPostInc() - Method in class com.tangosol.util.processor.NumberIncrementor
- 
Returns Whether to return the value before it was incremented ("post-increment") or after it is incremented ("pre-increment").
- getPreferredSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Return the bundle size threshold.
- getPreFilterKeySetSize() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
- 
Get the size of the key set prior to evaluating the filter or applying an index.
- getPreFilterKeySetSize() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Get the size of the key set prior to evaluating the filter or applying an index.
- getPrefix() - Method in class com.tangosol.run.xml.QualifiedName
- 
Returns the xml prefix of theQualifiedName.
- getPrefixLength(String) - Static method in class com.tangosol.io.FileHelper
- 
Returns the length of the filename prefix, such asC:/or~/.
- getPrevBlockOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the offset of the previous Block in the Buffer.
- getPrevious() - Method in class com.tangosol.util.SafeLinkedList.Node
- getPreviousModulo() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the previous modulo.
- getPreviousPropertyIndex() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Return the index of the most recent property read or (if it were missing) requested.
- getPrevNodeOffset() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the offset of the previous Block in the linked list.
- getPrimaryKey() - Method in class com.tangosol.util.CompositeKey
- 
Return the primary key component.
- getPrimaryLoadCalculator() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the LoadCalculator used to calculate the primary partition load.
- getPrimaryOwner() - Method in class com.tangosol.net.partition.Ownership
- 
Return the primary owner id for this partition.
- getPrimaryPolicy() - Method in class com.tangosol.net.CompositeActionPolicy
- 
Return the primary policy.
- getPrimitive(long) - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Return the value stored at the specified index.
- getPrimitiveValue() - Method in class com.tangosol.util.PrimitiveSparseArray.Iterator
- 
Returns the current value, which is the same value returned by the most recent call to the nextPrimitive method, or the most recent value passed to setPrimitiveValue if setPrimitiveValue were called after the nextPrimitive method.
- getPrimitiveValue() - Method in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
- 
Get the long value for the Node.
- getPrintWriter() - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Obtain the PrintWriter that is used by this LoggingPofHandler.
- getPriority() - Method in interface com.oracle.coherence.cdi.SessionInitializer
- getPriority() - Method in interface com.oracle.coherence.grpc.proxy.GrpcServerBuilderProvider
- 
Deprecated.Obtain the priority of thisGrpcServerBuilderProvider.
- getPriority() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Calculate a cache priority.
- getPriority() - Method in interface com.tangosol.net.management.MapJsonBodyHandler
- 
Return the priority of thisMapJsonBodyHandler.
- getPriority() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the priority (or "weight") of the local Member.
- getPriority() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the priority (or "weight") of the local Member.
- getPriority() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- getPriority() - Method in interface com.tangosol.net.SessionConfiguration
- 
Returns the priority for this configuration.
- getPriority() - Method in interface com.tangosol.net.SessionProvider
- 
Obtain the priority that thisSessionProvidershould have over otherSessionProviders when multiple providers may be able to provide aSession.
- getPriority() - Method in class com.tangosol.net.WrapperSessionConfiguration
- getProblem() - Method in exception com.tangosol.config.ConfigurationException
- 
Returns what the problem was.
- getProcessedEntries() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.LoadOperationObserver
- 
Set of entries successfully processed in loadAll().
- getProcessName() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the configured name for the Process (such as a JVM) in which this Member resides.
- getProcessName() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the configured name for the Process (such as a JVM) in which this Member resides.
- getProcessor() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- getProcessor() - Method in interface com.tangosol.net.events.partition.cache.EntryProcessorEvent
- 
Return theInvocableMap.EntryProcessorassociated with thisEntryProcessorEvent.
- getProcessor() - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
Obtain the underlying entry processor.
- getProcessor() - Method in class com.tangosol.util.processor.PriorityProcessor
- 
Obtain the underlying processor.
- getProcessor(String) - Method in class com.tangosol.coherence.rest.util.processor.ProcessorRegistry
- 
Returns a configured processor.
- getProcessor(String...) - Method in class com.tangosol.coherence.rest.util.processor.DefaultProcessorFactory
- 
Return a processor instantiated by calling a processor class constructor.
- getProcessor(String...) - Method in class com.tangosol.coherence.rest.util.processor.NumberIncrementorFactory
- 
Returns a processor instance.
- getProcessor(String...) - Method in class com.tangosol.coherence.rest.util.processor.NumberMultiplierFactory
- 
Returns a processor instance.
- getProcessor(String...) - Method in interface com.tangosol.coherence.rest.util.processor.ProcessorFactory
- 
Returns a processor instance.
- getProcessorClass() - Method in class com.tangosol.coherence.rest.config.ProcessorConfig
- 
Determine the class of the processor or its factory.
- getProcessorName() - Method in class com.tangosol.coherence.rest.config.ProcessorConfig
- 
Determine the name of the processor.
- getProcessorRegistry() - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Return the configured processor registry.
- getProcessRandom() - Static method in class com.oracle.coherence.common.base.Randoms
- 
Return a random number assigned to this process.
- getProcessRandom() - Static method in class com.tangosol.util.Base
- 
Return a random number assigned to this process.
- getProperties() - Method in class com.oracle.coherence.mp.config.CoherenceConfigSource
- getProperties() - Method in class com.oracle.coherence.mp.config.CoherenceDefaultsConfigSource
- getProperties() - Method in class com.oracle.coherence.mp.metrics.CoherenceTagsConfigSource
- getProperties() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- getProperties() - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Return the internal property set.
- getProperty(String) - Method in class com.oracle.coherence.mp.config.ConfigPropertyResolver
- getProperty(String) - Static method in class com.tangosol.coherence.config.Config
- 
Get the value of Coherence propertysName
- getProperty(String) - Method in class com.tangosol.coherence.config.SystemPropertyResolver.Default
- getProperty(String) - Method in interface com.tangosol.coherence.config.SystemPropertyResolver
- 
Return the value of the specified system property.
- getProperty(String, boolean) - Method in class com.tangosol.net.LoadBalancer
- 
Determine the value of a boolean option.
- getProperty(String, int) - Method in class com.tangosol.net.LoadBalancer
- 
Determine the value of an integer option.
- getProperty(String, String) - Static method in class com.tangosol.coherence.config.Config
- 
Get a Coherence property value, return default if property lookup fails.
- getProperty(String, String) - Method in interface com.tangosol.coherence.config.SystemPropertyResolver
- 
Return the value of the specified system property, or the specified default value if the property doesn't exist.
- getProperty(String, String) - Method in class com.tangosol.net.LoadBalancer
- 
Determine the value of a String option.
- getProperty(String, Supplier<String>) - Static method in class com.tangosol.coherence.config.Config
- 
Get a Coherence property value, returning the value provided by the supplier if property lookup fails.
- getPropertyIndex() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- getPropertyName() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Return the property name of this extractor.
- getPropertyNames() - Method in class com.oracle.coherence.mp.metrics.CoherenceTagsConfigSource
- getPropertySet() - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Return the set of nested properties.
- getPropertyValue(String, Type, XmlElement, boolean) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Attempts to resolve the named property of the specified type in the current context and if required will parse the specifiedXmlElementin order to do so.
- getProtocol() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Get the SSL protocol name
- getProviderBuilder() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Get the SSL provider builder.
- getProviderList() - Method in class com.tangosol.net.CompositeAddressProvider
- 
Return the provider list.
- getProviderName() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Returns the SSL provider name.
- getProviderType(String) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
Get the provider type for the given socket provider id
- getProviderType(String) - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
- 
Get the provider type for the given socket provider id
- getProxy(String, K) - Method in interface com.tangosol.util.Proxyable
- 
Return a proxy for a cached value.
- getPruneDelay() - Method in class com.tangosol.util.ThreadLocalObject
- 
Deprecated.as of Coherence 3.3 this method always returns zero.
- getPublisherAckDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the amount of time that the Publisher may delay sending an ACK packet.
- getPublisherCloggedCount() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the maximum number of packets in the send and re-send queues that the Publisher will tolerate before determining that it is clogged and must slow down client requests (requests from local non-system threads).
- getPublisherCloggedDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the amount of time that the Publisher will pause a client thread that is trying to send a message when the Publisher is clogged.
- getPublisherGroupThreshold() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the group threshold which is used to determine whether a packet will be sent via unicast or multicast.
- getPublisherNackDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the amount of time that the Publisher will delay sending a NACK packet.
- getPublisherPriority() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the priority of the PacketPublisher daemon thread.
- getPublisherResendDelayMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the minimum amount of time before a packet is resent across the network if it has not been acknowledged.
- getPublisherResendTimeoutMillis() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the maximum amount of time that the publisher will be resending a packet before the packet recipient is considered departed.
- getPublisherSocketBufferSize() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the preferred size of the unicast socket output buffer (SO_SNDBUF).
- getPutBundler() - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Obtain the bundler for the "put" operations.
- getQualifiedName() - Method in class com.tangosol.run.xml.SimpleAttribute
- 
Return theQualifiedNameof theXmlAttribute.
- getQualifiedName() - Method in class com.tangosol.run.xml.SimpleElement
- 
Obtains theQualifiedNameof theXmlElement.
- getQualifiedName() - Method in interface com.tangosol.run.xml.XmlAttribute
- 
Get theQualifiedNameof theXmlAttribute.
- getQualifiedName() - Method in interface com.tangosol.run.xml.XmlElement
- 
Obtains theQualifiedNameof theXmlElement.
- getQualifiedName(String, String) - Static method in class com.tangosol.util.ClassHelper
- 
Build the fully qualified name of a class based on a package name and a simple class name.
- getQuery() - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine.ParsedQuery
- 
Return the query string with parameter types removed.
- getQuery() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
- 
Return the query to reduce the ObjectNames to consider.
- getQueryConfig() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Return the query configuration for this resource.
- getQueryEngine(String) - Method in class com.tangosol.coherence.rest.query.QueryEngineRegistry
- 
Return a query engine for the specified name.
- getQueryEngineClass() - Method in class com.tangosol.coherence.rest.config.QueryEngineConfig
- 
Determine the class of the query engine.
- getQueryEngineName() - Method in class com.tangosol.coherence.rest.config.NamedQuery
- 
Return the name of the query engine responsible to execute this query.
- getQueryEngineName() - Method in class com.tangosol.coherence.rest.config.QueryEngineConfig
- 
Determine the name of the query engine.
- getQueryEngineRegistry() - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Return the configured query engine registry.
- getQueryMap() - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
- 
Return the underlying QueryMap.
- getQueryMap(QueryMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of QueryMap.
- getQueryParameters(UriInfo) - Static method in class com.tangosol.coherence.rest.util.RestHelper
- 
Return a map containing query parameters from UriInfo instance.
- getQueue() - Method in class com.tangosol.net.LoadBalancer
- 
Determine the Queue that Socket connections are placed into.
- getQueueDaemon() - Method in class com.tangosol.io.AsyncBinaryStore
- getQueuedLimit() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Determine the size, in bytes, of the data that can be queued to be written asynchronously by the QueueDaemon thread.
- getQueuedLimit() - Method in class com.tangosol.io.AsyncBinaryStoreManager
- getQueuedSize() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Determine the current number of bytes that are pending being written.
- getQueueLength() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Returns an estimate of the number of threads waiting to acquire this lock.
- getQueueLength() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Returns an estimate of the number of threads waiting to acquire this lock.
- getQuorumInfo() - Method in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
- 
Return the "last good" service membership info.
- getQuorumRules() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Return the quorum rules used by this policy.
- getRackCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Return the rack count.
- getRackName() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the configured name for the Rack (such as a physical rack, cage or blade frame) in which this Member resides.
- getRackName() - Method in interface com.tangosol.net.MemberIdentityProvider
- 
Return the name for the Rack (such as a physical rack, cage or blade frame) in which this Member resides.
- getRackName() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the configured name for the Rack (such as a physical rack, cage or blade frame) in which this Member resides.
- getRackName() - Method in class com.tangosol.net.URLMemberIdentityProvider
- getRackName() - Method in class com.tangosol.util.NullImplementation.NullMemberIdentityProvider
- getRandom() - Static method in class com.oracle.coherence.common.base.Randoms
- 
Obtain a Random object that can be used to get random values.
- getRandom() - Static method in class com.tangosol.util.Base
- 
Obtain a Random object that can be used to get random values.
- getRandomBinary(int, int) - Static method in class com.oracle.coherence.common.base.Randoms
- 
Generates a random-length Binary within the length bounds provided whose contents are random bytes.
- getRandomBinary(int, int) - Static method in class com.tangosol.util.Base
- 
Generates a random-length Binary within the length bounds provided whose contents are random bytes.
- getRandomBinary(int, int, byte...) - Static method in class com.oracle.coherence.common.base.Randoms
- 
Generates a random-length Binary includingabHeadat the head of the Binary, in addition to random bytes within the length bounds provided.
- getRandomBinary(int, int, byte...) - Static method in class com.tangosol.util.Base
- 
Generates a random-length Binary includingabHeadat the head of the Binary, in addition to random bytes within the length bounds provided.
- getRandomDestination() - Method in class com.tangosol.net.LoadBalancer
- 
Determine a random AddressPort combination to route to.
- getRandomString(int, int, boolean) - Static method in class com.oracle.coherence.common.base.Randoms
- 
Generates a random-length String within the length bounds provided.
- getRandomString(int, int, boolean) - Static method in class com.tangosol.util.Base
- 
Generates a random-length String within the length bounds provided.
- getRawByteArray() - Method in class com.tangosol.io.ByteArrayReadBuffer
- 
Obtain the byte array that this ReadBuffer uses.
- getRawByteArray() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Obtain the byte array that this WriteBuffer uses.
- getRawDate() - Method in class com.tangosol.io.pof.RawDateTime
- 
Obtain the date portion of the raw date-time value.
- getRawOffset() - Method in class com.tangosol.io.ByteArrayReadBuffer
- 
Determine the offset into the byte array returned fromByteArrayReadBuffer.getRawByteArray()that this ReadBuffer uses.
- getRawTime() - Method in class com.tangosol.io.pof.RawDateTime
- 
Obtain the time portion of the raw date-time value.
- getReadBuffer() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer() - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer() - Method in interface com.tangosol.io.WriteBuffer
- 
Get a ReadBuffer object that is a snapshot of this WriteBuffer's data.
- getReadBuffer(int, int) - Method in class com.tangosol.io.AbstractReadBuffer
- 
Obtain a ReadBuffer for a portion of this ReadBuffer.
- getReadBuffer(int, int) - Method in interface com.tangosol.io.ReadBuffer
- 
Obtain a ReadBuffer for a portion of this ReadBuffer.
- getReader() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return theBufferedReaderthat can be used to obtain user input, typically fromSystem.in.
- getReader() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getReader() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return theBufferedReaderto use to obtain user input.
- getReader() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a Reader.
- getReadHoldCount() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Queries the number of reentrant read holds on this lock by the current thread.
- getReadLocator(String) - Method in interface com.tangosol.net.BackingMapManager
- getReadLocator(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- getReadLocatorBuilder() - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Return a builder that is capable of building BiFunction's that return the Member reads for a partitioned cache should be targeted against.
- getReadLockCount() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Queries the number of read locks held for this lock.
- getReadOnlyEntry(Object) - Method in interface com.tangosol.net.BackingMapContext
- 
Return a read-only InvocableMap.Entry for the specified key (in its internal format) from the associated cache.
- getReadQueue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the queue of keys that are yet to be read.
- getReadThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the refresh-ahead thread.
- getReceiveCount() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getReceiveCount() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Return the number of completed receive requests.
- getReceived() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getReceived() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Return the number of completed receive requests.
- getReceivedFifteenMinuteRate() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getReceivedFifteenMinuteRate() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Return the fifteen-minute rate of completed receive requests.
- getReceivedFiveMinuteRate() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getReceivedFiveMinuteRate() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Return the five-minute rate of completed receive requests.
- getReceivedMeanRate() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getReceivedMeanRate() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Return the mean rate of completed receive requests.
- getReceivedOneMinuteRate() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- getReceivedOneMinuteRate() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Return the one-minute rate of completed receive requests.
- getReceiverPriority() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the priority of the PacketReceiver daemon thread.
- getRecentIterator() - Method in class com.tangosol.util.ChainedEnumerator
- 
Get the recently used iterator, if any.
- getReconnectInterval() - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- getReconnectInterval() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Return the reconnection interval (in milliseconds).
- getReconnectInterval() - Method in interface com.tangosol.net.management.ViewMBean
- 
Return the reconnection interval (in milliseconds).
- getReconnectInterval() - Method in class com.tangosol.net.management.ViewMBeanImpl
- getReconnectRetryMillis() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Return the amount of time publishers and subscribers will wait between attempts to reconnect after being disconnected.
- getReconnectRetryMillis(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return the amount of time publishers and subscribers will wait between attempts to reconnect after being disconnected.
- getReconnectTimeoutMillis() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Returns the maximum amount of time publishers and subscribers will attempt to reconnect after being disconnected.
- getReconnectTimeoutMillis(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Returns the maximum amount of time publishers and subscribers will attempt to reconnect after being disconnected.
- getReconnectWaitMillis() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Return the amount of time publishers and subscribers will wait before attempting to reconnect after being disconnected.
- getReconnectWaitMillis(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return the amount of time publishers and subscribers will wait before attempts to reconnect after being disconnected.
- getRecoveryMillis() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the recovery interval for this Guardable.
- getReference() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicMarkableReference
- 
Returns the current value of the reference.
- getReference() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicStampedReference
- 
Returns the current value of the reference.
- getReference() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
- getReference() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
- getReference() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- getReference() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- getReference() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicMarkableReference
- 
Returns the current value of the reference.
- getReference() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicStampedReference
- 
Returns the current value of the reference.
- getReference() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- getReference() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- getReference() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- getReference() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- getRefreshAheadFactor() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the refresh-ahead factor.
- getRefreshAheadFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return refresh-ahead-factor used to calculate the "soft-expiration" time for cache entries.
- getRefreshFrequency() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- getRefreshPeriod() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Return the period to use to auto-refresh keys and certs.
- getRefreshPolicy() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Returns theRefreshPolicyto use to determine whether keys and certs should be refreshed.
- getRegisteredAsynchronousEventListeners() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Get asynchronous CacheEntryEventListeners.
- getRegisteredAsynchronousEventListeners() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
get asynchronous CacheEntryListenerRegistrations
- getRegisteredDbs() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Get the registered Databases.
- getRegisteredName() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Return registered name ofEventInterceptor.
- getRegisteredSynchronousEventListeners() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Get synchronous CacheEntryEventListeners.
- getRegisteredSynchronousEventListeners() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
get synchronous CacheEntryListenerRegistrations
- getRegistrationBehavior() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Returns the behavior upon duplicate registration.
- getRegistrationContext() - Method in class com.tangosol.net.cache.NearCache
- 
Obtain the context (tier) used to register a CacheMBean for this cache.
- getRegistry() - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- getRegistry() - Method in interface com.oracle.coherence.grpc.proxy.GrpcServiceDependencies
- 
Return the optional managementRegistryto register the proxy MBean with.
- getRegistryPort() - Static method in class com.tangosol.net.management.MBeanConnector
- 
Get the configured registry port for the RMI Connector Server.
- getReifiedTypes(Class<?>, Class<?>) - Static method in class com.tangosol.util.ClassHelper
- 
Returns a map of types by type name as defined inclzDefiningType.
- getReliableTransport() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the name of the default reliable transport used by this node.
- getRemainingDistributionCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the number of distributions (partition transfers) that remain to be completed before the service achieves the goals set by this strategy.
- getRemainingDistributionCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the number of distributions (partition transfers) that remain to be completed before the service achieves the goals set by this strategy.
- getRemainingMessages() - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns the number of remaining messages to be read from the topic for this subscriber.
- getRemainingMessages(int) - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns the number of remaining messages to be read from the topic channel for this subscriber.
- getRemainingMessages(String) - Method in interface com.tangosol.net.topic.NamedTopic
- 
Returns the number of remaining messages to be read from the topic for the specific subscriber group.
- getRemainingMessages(String, int...) - Method in interface com.tangosol.net.topic.NamedTopic
- 
Returns the number of remaining messages to be read from the topic for the specific subscriber group, and optionally for one or more specific channels.
- getRemoteCacheScheme() - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Return theRemoteCacheScheme.
- getRemoteMember() - Method in interface com.tangosol.net.events.partition.TransferEvent
- 
Return the remoteMemberassociated with this transfer operation.
- getRemoteStack(StatusException) - Static method in class com.oracle.coherence.grpc.ErrorsHelper
- 
Obtain the remote stack trace from the specifiedStatusException.
- getRemoteStack(StatusRuntimeException) - Static method in class com.oracle.coherence.grpc.ErrorsHelper
- 
Obtain the remote stack trace from the specifiedStatusRuntimeException.
- getRemoveAction() - Method in class com.tangosol.util.SegmentedHashMap
- 
Return the registered action for remove().
- getRemoveBundler() - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Obtain the bundler for the "remove" operations.
- getRemoved() - Method in class com.tangosol.util.DeltaSet
- 
Determine what items were removed from the delta set.
- getRemoved() - Method in class com.tangosol.util.SubSet
- 
Determine what items were removed from the subset.
- getReplicatedCacheConfig() - Static method in class com.tangosol.net.CacheFactory
- 
Return the default replicated cache configuration.
- getRequest() - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Obtain the cache request.
- getRequestCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics.ConnectionMetricsMBean
- 
Returns the number of requests made by this connection.
- getRequestCount() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the number of requests/second issued for the partition.
- getRequestCountFifteenMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics.ConnectionMetricsMBean
- 
Returns the fifteen minute rate of requests made by this connection.
- getRequestCountFiveMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics.ConnectionMetricsMBean
- 
Returns the five minute rate of requests made by this connection.
- getRequestCountMeanRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics.ConnectionMetricsMBean
- 
Returns the mean rate of requests made by this connection.
- getRequestCountOneMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics.ConnectionMetricsMBean
- 
Returns the one minute rate of requests made by this connection.
- getRequestDuration75thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDuration75thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 75th percentile value from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestDuration95thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDuration95thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 95th percentile value from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestDuration98thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDuration98thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 98th percentile value from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestDuration999thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDuration999thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 99.9th percentile value from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestDuration99thPercentile() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDuration99thPercentile() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the 99th percentile value from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestDurationMax() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDurationMax() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the maximum value from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestDurationMean() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDurationMean() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the mean value from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestDurationMin() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDurationMin() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the minimum value from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestDurationStdDev() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getRequestDurationStdDev() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the standard deviation from the distribution of samples in the latest snapshot of the request duration metric.
- getRequestTimeout(ServiceScheme) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return the request timeout determined by theServiceScheme.
- getRequestTimeout(XmlElement) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Return the request timeout based on theXmlElement.
- getRequestTimeoutMillis() - Method in class com.tangosol.net.AbstractInvocable
- 
Obtain the maximum amount of time a calling thread is willing to wait for a result of the request execution.
- getRequestTimeoutMillis() - Method in class com.tangosol.net.AbstractPriorityTask
- 
Obtain the maximum amount of time a calling thread is willing to wait for a result of the request execution.
- getRequestTimeoutMillis() - Method in interface com.tangosol.net.PriorityTask
- 
Obtain the maximum amount of time a calling thread is willing to wait for a result of the request execution.
- getRequestTimeoutMillis() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain a default request timeout value.
- getRequestTimeoutMillis() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
- 
Obtain the maximum amount of time a calling thread is willing to wait for a result of the request execution.
- getResolver() - Method in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
- 
Return the GUID resolver.
- getResolver(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Return theParameterResolverfor the given cache.
- getResource() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryValue
- 
Return the registered resource.
- getResource(Class<R>) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Attempts to retrieve the resource that was registered with the specified class.
- getResource(Class<R>) - Method in class com.tangosol.util.ChainedResourceResolver
- 
Attempts to retrieve the resource that was registered with the specified class.
- getResource(Class<R>) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
- getResource(Class<R>) - Method in interface com.tangosol.util.ResourceResolver
- 
Attempts to retrieve the resource that was registered with the specified class.
- getResource(Class<R>) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Attempts to retrieve the resource that was registered with the specified class.
- getResource(Class<R>, String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Attempts to retrieve the resource that was registered with the specified class and name.
- getResource(Class<R>, String) - Method in class com.tangosol.util.ChainedResourceResolver
- 
Attempts to retrieve the resource that was registered with the specified class and name.
- getResource(Class<R>, String) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
- getResource(Class<R>, String) - Method in interface com.tangosol.util.ResourceResolver
- 
Attempts to retrieve the resource that was registered with the specified class and name.
- getResource(Class<R>, String) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Attempts to retrieve the resource that was registered with the specified class and name.
- getResource(String) - Method in interface com.tangosol.net.Cluster
- 
Deprecated.UseCluster.getResourceRegistry()to manage resources.
- getResourceClass() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryKey
- 
Return the resource class.
- getResourceRegistry() - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Obtains theResourceRegistrythat holds resources associated with theResourceMapping.
- getResourceRegistry() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return theResourceRegistrythat may be used to register ad-hoc resources with this context as a way to maintain state between different command executions.
- getResourceRegistry() - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Obtains theResourceRegistryassociated with theProcessingContext.
- getResourceRegistry() - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Obtains theResourceRegistryfor theDocumentProcessor.
- getResourceRegistry() - Method in interface com.tangosol.config.xml.DocumentProcessor.Dependencies
- 
Obtains theResourceRegistryfor theDocumentProcessor.
- getResourceRegistry() - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Obtains theResourceRegistryassociated with theProcessingContext.
- getResourceRegistry() - Method in interface com.tangosol.net.Cluster
- 
Retrieves a Cluster scopedResourceRegistry.
- getResourceRegistry() - Method in class com.tangosol.net.Coherence
- 
Return theResourceRegistryfor thisCoherenceinstance.
- getResourceRegistry() - Method in class com.tangosol.net.CoherenceSession
- getResourceRegistry() - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Return theResourceRegistryfor this factory.
- getResourceRegistry() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Return theResourceRegistryfor this factory.
- getResourceRegistry() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DefaultDependencies
- 
Obtains theResourceRegistryfor anExtensibleConfigurableCacheFactory.
- getResourceRegistry() - Method in interface com.tangosol.net.ExtensibleConfigurableCacheFactory.Dependencies
- 
Obtains theResourceRegistryfor anExtensibleConfigurableCacheFactory.
- getResourceRegistry() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return theResourceRegistryfor this factory.
- getResourceRegistry() - Method in interface com.tangosol.net.Service
- 
Retrieves a Service scopedResourceRegistry.
- getResourceRegistry() - Method in interface com.tangosol.net.Session
- 
Return theResourceRegistryfor this session.
- getResourceRegistry() - Method in class com.tangosol.net.WrapperService
- 
Retrieves a Service scopedResourceRegistry.
- getResourceRegistry() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of aResourceRegistry.
- getResources() - Method in class com.tangosol.coherence.rest.config.RestConfig
- 
Return a map of configured resources, keyed by cache name or alias.
- getResources(Class, String) - Static method in class com.tangosol.util.ClassHelper
- 
Load the named resources for the specified class.
- getResponsesSentCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getResponsesSentCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the count of responses sent.
- getResponsesSentFifteenMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getResponsesSentFifteenMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the fifteen minute rate of responses sent.
- getResponsesSentFiveMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getResponsesSentFiveMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the five minute rate of responses sent.
- getResponsesSentMeanRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getResponsesSentMeanRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the mean rate of responses sent.
- getResponsesSentOneMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getResponsesSentOneMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the one minute rate of responses sent.
- getResponsiveMemberSet() - Method in interface com.tangosol.net.Cluster.MemberTimeoutAction
- 
Return the set of Members that have recently responded to this member.
- getResult() - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Obtain the holder's result value.
- getResult() - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- getResult() - Method in interface com.tangosol.coherence.dslquery.StatementResult
- 
Return the actual result Object that this StatementResult wraps.
- getResult() - Method in interface com.tangosol.coherence.dsltools.termtrees.TermWalker
- 
Return the result of the previous TermTree walk.
- getResult() - Method in class com.tangosol.net.AbstractInvocable
- 
Determine the result from the invocation of this object.
- getResult() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- getResult() - Method in interface com.tangosol.net.Invocable
- 
Determine the result from the invocation of this object.
- getResult() - Method in class com.tangosol.util.AsynchronousAgent
- 
Helper method that callsAsynchronousAgent.get()and re-throws checked exceptions as a RuntimeException.
- getResults() - Method in interface com.tangosol.util.QueryRecord
- 
Get the list of partial results for this query record.
- getResults() - Method in class com.tangosol.util.SimpleQueryRecord
- 
Get the list of partial results for this query record.
- getRetained() - Method in class com.tangosol.util.SubSet
- 
Determine what items were added to the subset.
- getRipeArray() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Return aLongArrayindexed by ripe time (when entries become eligible to be written), and associated to a list of binary keys.
- getRipeMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Determine when the entry becomes ripe to be persisted.
- getRMIConnectorAttributes() - Static method in class com.tangosol.net.management.MBeanConnector
- 
Get the attributes for the RMI Connector Server.
- getRole() - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
- getRoleName() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the configured role name for the Member.
- getRoleName() - Method in interface com.tangosol.net.MemberIdentityProvider
- 
Return the role name for the Member.
- getRoleName() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the configured role name for the Member.
- getRoleName() - Method in class com.tangosol.net.URLMemberIdentityProvider
- getRoleName() - Method in class com.tangosol.util.NullImplementation.NullMemberIdentityProvider
- getRoles() - Method in interface com.tangosol.net.MemberIdentity
- 
Return a set of role names for the Member.
- getRollover() - Method in class com.tangosol.util.ThreadLocalObject
- 
Deprecated.as of Coherence 3.3 this method always returns zero.
- getRoot() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the root of the hierarchy this value belongs to.
- getRoot() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the root of the hierarchy this value belongs to.
- getRoot() - Method in class com.tangosol.run.xml.SimpleElement
- 
Get the root element.
- getRoot() - Method in interface com.tangosol.run.xml.XmlElement
- 
Get the root element.
- getRootCause() - Method in exception com.tangosol.util.WrapperException
- 
Return the root cause of this exception.
- getRootClass() - Method in class com.tangosol.coherence.rest.io.AbstractMarshaller
- 
Return class of the root object this marshaller is for.
- getRoundingMode() - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Returns theRoundingModethat is applied to aggregation results.
- getRoundRobinDestination() - Method in class com.tangosol.net.LoadBalancer
- 
Using a round-robin algorithm, determine the next AddressPort combination to route to.
- getRoutableAddresses(InetAddress, boolean, Collection<InetAddress>, boolean) - Static method in class com.tangosol.net.InetAddressHelper
- 
Return the set of addresses from the specified destination addresses which appear to be routable from addrLocal.
- getRule(int) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Return the quorum rule for the specified mask.
- getRuleMask() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Return the numeric representation of the actions allowed by this rule.
- getSafeAttribute(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Get an attribute value, and return a temporary value if the attribute does not exist.
- getSafeAttribute(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Get an attribute value, and return a temporary value if the attribute does not exist.
- getSafeElement(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Return the specified child element using the same path notation as supported by findElement, but return a read-only element if the specified element does not exist.
- getSafeElement(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Return the specified child element using the same path notation as supported by findElement, but return a read-only element if the specified element does not exist.
- getSafeTimeMillis() - Static method in class com.oracle.coherence.common.base.TimeHelper
- 
Returns a "safe" current time in milliseconds.
- getSafeTimeMillis() - Static method in class com.tangosol.util.Base
- 
Returns a "safe" current time in milliseconds.
- getSampleDuration() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the duration (ms) over which data was collected for this sample.
- getSampleStartTime() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the time (on the sampling member) at which this data collection for this sample started.
- getSamplingPeriod() - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return the sampling period at which partition statistics are collected.
- getScale() - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Returns the specified scale.
- getScanner() - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Obtain the OPScanner that backs this parser
- getSchedulingPriority() - Method in class com.tangosol.net.AbstractInvocable
- 
Obtain this task's scheduling priority.
- getSchedulingPriority() - Method in class com.tangosol.net.AbstractPriorityTask
- 
Obtain this task's scheduling priority.
- getSchedulingPriority() - Method in interface com.tangosol.net.PriorityTask
- 
Obtain this task's scheduling priority.
- getSchedulingPriority() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
- 
Obtain this task's scheduling priority.
- getSchemaLocations(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Retrieve a listing of schema locations (schemaLocation/noNamespaceSchemaLocation) URL's referenced in XmlElement and all of its children.
- getSchemeMappingClass() - Method in class com.tangosol.coherence.config.SchemeMappingRegistry.SchemeMappingKey
- 
Return the scheme mapping class.
- getSchemeName() - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Obtains the name of the caching scheme to be used that match thisResourceMapping.
- getSchemeName() - Method in class com.tangosol.coherence.config.scheme.AbstractScheme
- 
Obtains the name of theScheme.
- getSchemeName() - Method in interface com.tangosol.coherence.config.scheme.Scheme
- 
Obtains the name of theScheme.
- getSchemeName() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- getSchemeName() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.Obtain the scheme name.
- getScopedResolver(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Return theScopedParameterResolverfor the given cache.
- getScopedServiceName() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Return the service name with any scoping applied.
- getScopedServiceName() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Return the service name with any scoping applied.
- getScopedServiceName() - Method in class com.tangosol.coherence.config.scheme.ViewScheme
- getScopedServiceName() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- getScopedServiceName(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Apply the scope name prefix to the given service name.
- getScopedServiceName(String, String) - Static method in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Return a scoped service name
- getScopeName() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Return the name of the scope this listener is for, ornullif it should be registered regardless of the scope name.
- getScopeName() - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
Return the name of the scope this interceptor should be registered with.
- getScopeName() - Method in interface com.oracle.coherence.cdi.SessionInitializer
- getScopeName() - Method in interface com.tangosol.coherence.config.builder.ServiceBuilder
- 
Return the scope name.
- getScopeName() - Method in class com.tangosol.coherence.config.CacheConfig
- 
Obtain the scope name of theCacheConfig.
- getScopeName() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Return the scope name.
- getScopeName() - Method in class com.tangosol.net.CoherenceSession
- getScopeName() - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Return the scope name of this cache factory, if available.
- getScopeName() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Return the scope name for this ConfigurableCacheFactory.
- getScopeName() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEvent
- 
The scope name that this event is associated with.
- getScopeName() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEventDispatcher
- 
Return the optional scope name that this dispatcher is associated with.
- getScopeName() - Method in interface com.tangosol.net.events.partition.cache.PartitionedCacheDispatcher
- getScopeName() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return the scope name for this ConfigurableCacheFactory.
- getScopeName() - Method in interface com.tangosol.net.Session
- 
Return the scope name of this cache factory, if available.
- getScopeName() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- getScopeName() - Method in interface com.tangosol.net.SessionConfiguration
- 
Return the scope name of theSession.
- getScopeName() - Method in class com.tangosol.net.WrapperSessionConfiguration
- getScopePrefix() - Method in interface com.tangosol.net.SessionProvider.Context
- 
Return any prefix to prepend to the scope name of the session.
- getScopePrefix() - Method in class com.tangosol.net.SessionProvider.DefaultContext
- getScopePrefix(String, ContainerContext) - Static method in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Return a scope name prefixed with any tenancy name.
- getScopeResolver() - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Obtain the scope resolver for this builder.
- getSecond() - Method in class com.tangosol.io.pof.RawTime
- 
Determine the time's second value.
- getSecondaryKey() - Method in class com.tangosol.util.CompositeKey
- 
Return the secondary key component.
- getSecondaryPolicy() - Method in class com.tangosol.net.CompositeActionPolicy
- 
Return the secondary policy.
- getSecondMap() - Method in class com.tangosol.util.ChainedMap
- 
Get the second (back) map.
- getSeconds() - Method in class com.tangosol.io.pof.RawDayTimeInterval
- 
Determine the number of seconds in the day-time interval.
- getSeconds() - Method in class com.tangosol.io.pof.RawTimeInterval
- 
Determine the number of seconds in the time interval.
- getSecurityConfig() - Static method in class com.tangosol.net.CacheFactory
- 
Return the security framework configuration.
- getSegmentForKey(Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Return the Segment object for the specified key.
- getSegmentIndex(int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Calculate the segment index for the the specified bucket.
- getSerializedValue() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return this value's serialized form.
- getSerializedValue() - Method in class com.tangosol.io.pof.reflect.PofSparseArray.NilPofValue
- 
Return this value's serialized form.
- getSerializer() - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Obtain the request'sSerializer.
- getSerializer() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return aSerializerthat is used to serialize/deserialize this entry.
- getSerializer() - Method in interface com.tangosol.net.Service
- 
Return a Serializer used by this Service.
- getSerializer() - Method in class com.tangosol.net.WrapperService
- 
Return a Serializer used by this Service.
- getSerializer() - Method in interface com.tangosol.util.BinaryEntry
- 
Return aSerializerthat is used to serialize/deserialize this entry.
- getSerializer() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Return aSerializerthat is used to serialize/deserialize this entry.
- getSerializer() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- 
Return aSerializerthat is used to serialize/deserialize this entry.
- getSerializer(String, String, Supplier<Serializer>, Supplier<ClassLoader>) - Method in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- getSerializerFactory() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain theSerializerFactoryused by this service.
- getSerializerMap() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the Serializer map.
- getSerializerMap() - Method in interface com.tangosol.net.OperationalContext
- 
Return a Map of serializer factories.
- getServerBuilder(int) - Method in interface com.oracle.coherence.grpc.proxy.GrpcServerBuilderProvider
- 
Deprecated.Returns aServerBuilderthat may be used to build a gRPC server.
- getService() - Method in class com.tangosol.net.AbstractInvocable
- 
Obtain the containing InvocationService.
- getService() - Method in class com.tangosol.net.AbstractServiceLoadBalancer
- 
Obtain the containing Service.
- getService() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Return the Cluster service.
- getService() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Return the Service which this policy applies to.
- getService() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Return the associated PartitionedService.
- getService() - Method in interface com.tangosol.net.events.partition.cache.Event
- 
Return theCacheServicethis event was raised from.
- getService() - Method in interface com.tangosol.net.events.partition.Event
- 
Return thePartitionedServicethis event was raised from.
- getService() - Method in interface com.tangosol.net.events.partition.PartitionedServiceDispatcher
- 
Return thePartitionedServicefor this dispatcher.
- getService() - Method in class com.tangosol.net.MemberEvent
- 
Return the Service that fired the event
- getService() - Method in interface com.tangosol.net.NamedCollection
- 
Return the Service that this NamedCollection is a part of.
- getService() - Method in interface com.tangosol.net.NamedMap
- getService() - Method in interface com.tangosol.net.partition.DistributionManager
- 
Return the partitioned service for which this DistributionManager coordinates the distribution.
- getService() - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Return the partitioned service for which this assignment strategy controls the distribution.
- getService() - Method in class com.tangosol.net.partition.PartitionEvent
- 
Determine the partitioned service that this event originates from.
- getService() - Method in class com.tangosol.net.WrapperService
- 
Return the wrapped Service.
- getService() - Method in class com.tangosol.util.ServiceEvent
- 
Return the Service that fired the event.
- getService(String) - Static method in class com.tangosol.net.CacheFactory
- 
Return an instance of a service configured by the current ConfigurableCacheFactory.
- getService(String) - Method in interface com.tangosol.net.Cluster
- 
Returns a Service object for the specified service name.
- getService(String) - Method in class com.tangosol.net.CoherenceSession
- getService(String) - Method in interface com.tangosol.net.Session
- 
Returns a service for the given name ornullif no service exists in this session with the specified name.
- getServiceBanner() - Method in interface com.tangosol.net.Cluster
- 
Return a description of the running services in this Cluster.
- getServiceBanner(Collection<Service>) - Method in class com.tangosol.net.DefaultCacheServer
- 
Return a service banner for a collection of services.
- getServiceBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Return theServiceBuilderthat is needed to build a service.
- getServiceBuilder() - Method in class com.tangosol.coherence.config.scheme.NearScheme
- 
Return theServiceBuilderthat is needed to build a service.
- getServiceBuilder() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Return theServiceBuilderthat is needed to build a service.
- getServiceBuilder() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- getServiceConfig(String) - Static method in class com.tangosol.net.CacheFactory
- 
Return the configuration for the specified service type.
- getServiceDependencies() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Obtains theServiceDependenciesthat will be used to configureServiceproduced by this scheme.
- getServiceFailurePolicyBuilder() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the service failure policy builder.
- getServiceFilterMap() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain a map of service name to filter list.
- getServiceInfo(String) - Method in interface com.tangosol.net.Cluster
- 
Returns a ServiceInfo object for the specified service name.
- getServiceJoinTime(String) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Parse the specified GUID and return the service join time.
- getServiceMachineCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the number of machines that host storage-enabled nodes running this service.
- getServiceMachineCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the number of machines that host storage-enabled nodes running this service.
- getServiceMap() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the service map.
- getServiceMap() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return a map of services that were successfully started by this factory where values are corresponding non-scoped service names.
- getServiceMember(int) - Method in interface com.tangosol.net.ServiceInfo
- 
Return the Member with the specified mini-id that is running this Service.
- getServiceMembers() - Method in interface com.tangosol.net.ServiceInfo
- 
Return a Set of Member objects, one for each Member that has registered this Service.
- getServiceMonitor() - Method in class com.tangosol.net.DefaultCacheServer.LifecycleContext
- getServiceName() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Return the name of the service this listener is for, or'*'if it should be registered regardless of the service name.
- getServiceName() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Return the service name.
- getServiceName() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Return the service name.
- getServiceName() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- getServiceName() - Method in class com.tangosol.net.ClusterPermission
- 
Return the service name for this permission object or null if the permission applies to any service.
- getServiceName() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Return the name of the service this interceptor should receive events from.
- getServiceName() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEvent
- 
The name of the service that the event is associated with.
- getServiceName() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEventDispatcher
- 
Return the optional name of theservicethat this dispatcher is associated with.
- getServiceName() - Method in interface com.tangosol.net.events.partition.cache.PartitionedCacheDispatcher
- 
Return the name of theservicethat this PartitionedCacheDispatcher is associated with.
- getServiceName() - Method in interface com.tangosol.net.events.partition.PartitionedServiceDispatcher
- 
Return the name of theservicethat this PartitionedServiceDispatcher is associated with.
- getServiceName() - Method in class com.tangosol.net.security.PermissionInfo
- 
Return the service name.
- getServiceName() - Method in interface com.tangosol.net.ServiceInfo
- 
Return the name of the Service.
- getServiceNames() - Method in interface com.tangosol.net.Cluster
- 
Returns an Enumeration of String objects, one for each service that has been previously registered in the cluster.
- getServiceNodeCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the number of storage-enabled nodes running this service.
- getServiceNodeCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the number of storage-enabled nodes running this service.
- getServiceProvider() - Method in class com.tangosol.coherence.config.scheme.BaseGrpcScheme
- 
Returns theClusterDependencies.ServiceProviderinstance to use to create new instances of the service.
- getServiceRackCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the number of racks that host storage-enabled nodes running this service.
- getServiceRackCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the number of racks that host storage-enabled nodes running this service.
- getServiceSchemeRegistry() - Method in class com.tangosol.coherence.config.CacheConfig
- 
Obtain theServiceSchemeRegistryfor theCacheConfig.
- getServiceSerializer() - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Obtain the cache'sSerializer.
- getServiceSiteCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get the number of sites that host storage-enabled nodes running this service.
- getServiceSiteCount() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get the number of sites that host storage-enabled nodes running this service.
- getServiceStore(Cluster) - Method in class com.tangosol.coherence.config.scheme.ViewScheme
- 
Obtain theScopedServiceReferenceStorefrom the providedCluster.
- getServiceType() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Return the Service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.BaseGrpcCacheScheme
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.ClassScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.InvocationScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.NearScheme
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.OptimisticScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.ProxyScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.RemoteCacheScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.RemoteInvocationScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.ReplicatedScheme
- 
Return the service type.
- getServiceType() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.TransactionalScheme
- 
Return the service type.
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.ViewScheme
- getServiceType() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- getServiceType() - Method in interface com.tangosol.net.ServiceInfo
- 
Return the type of the Service.
- getServiceVersion(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Deprecated.
- getServiceVersion(Member) - Method in interface com.tangosol.net.ServiceInfo
- 
Return a String with Service version for the specified service Member.
- getSession() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return the currentSessionthat will be used by commands executed under this context.
- getSession() - Method in class com.tangosol.net.Coherence
- getSession() - Method in interface com.tangosol.net.events.SessionLifecycleEvent
- 
TheSessioninstance that this event is associated with.
- getSession() - Method in interface com.tangosol.net.SessionProvider.Context
- 
Return theSessioncreated by the provider, ornullif no session could be created.
- getSession() - Method in class com.tangosol.net.SessionProvider.DefaultContext
- getSession(String) - Method in class com.oracle.coherence.cdi.AbstractCacheInterceptor
- 
Obtains the namedSessionor the default one if session name was not specified.
- getSession(String) - Method in class com.tangosol.net.Coherence
- getSessionConfigurations() - Method in interface com.tangosol.net.CoherenceConfiguration
- 
Return an immutableMapof namedSessionConfigurationinstances that will be used by theCoherenceinstance to createSessions.
- getSessionConfigurations() - Method in class com.tangosol.net.CoherenceConfiguration.SimpleConfig
- getSessionIfPresent(String) - Method in class com.tangosol.net.Coherence
- getSessionName() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Return the name of the session that this listener is for
- getSessionName() - Method in interface com.tangosol.net.events.partition.cache.CacheLifecycleEvent
- 
The optional Session name that this event is associated with.
- getSessionNames() - Method in class com.tangosol.net.Coherence
- 
Return a set of session names that thisCoherenceinstance has.
- getSessionProvider() - Method in interface com.tangosol.net.SessionProvider.Provider
- 
Provide an optionalSessionProvider.
- getSessionScopeNames() - Method in class com.tangosol.net.Coherence
- 
Return a set of session scope names that thisCoherenceinstance has.
- getSessionsWithScope(String) - Method in class com.tangosol.net.Coherence
- getSessionWithName(InjectionPoint) - Method in class com.oracle.coherence.cdi.SessionProducer
- 
Produces aSessionfor a given scope.
- getSessionWithSessionName(InjectionPoint) - Method in class com.oracle.coherence.cdi.SessionProducer
- 
Produces aSessionfor a given scope.
- getSet() - Method in class com.tangosol.util.ImmutableArrayList
- 
Return a java.util.Set view of this ImmutableArrayList.
- getSet() - Method in class com.tangosol.util.ImmutableMultiList
- 
Return a java.util.Set view of this ImmutableMultiList.
- getSet() - Static method in class com.tangosol.util.NullImplementation
- 
Returns an instance of the NullSet.
- getSet(Set<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns an instance of Set that uses a Converter to view an underlying Set.
- getSet(Set, Class) - Static method in class com.tangosol.util.RestrictedCollections
- 
Returns a restricted instance of Set.
- getSetList(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the AST node that represents the list of "Set statements" from the given AST node.
- getSharedDirectoryPath() - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
- 
The shared directory to write archives to.
- getShieldedOutputStream(OutputStream) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Get a shielded OutputStream for the passed OutputStream object.
- getShort() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the short which this PofValue represents.
- getShort() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the short which this PofValue represents.
- getShortArray() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the short[] which this PofValue represents.
- getShortArray() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the short[] which this PofValue represents.
- getShortClassName() - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- getShrinkageCount() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the level at which the modulo will decrease.
- getShrinkageThreshold() - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Determine the level (what number of bytes used) below which the current ByteBuffer will need to be "resized" downwards.
- getShrinkageThreshold() - Method in interface com.tangosol.io.nio.ByteBufferManager
- 
Determine the level (what number of bytes used) below which the current ByteBuffer will need to be "resized" downwards.
- getShutdownHookOption() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the value of the ShutdownHook setting.
- getSignedPermission() - Method in class com.tangosol.net.security.PermissionInfo
- 
Return the encrypted ClusterPermission object.
- getSimpleFactory(Continuation<? super T>) - Static method in class com.tangosol.persistence.SafePersistenceWrappers
- 
Return a simple FailureContinuationFactory that uses the specified failure continuation to handle failures at any layer of the persistence implementation.
- getSimpleName() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Return the simple class name for this instance.
- getSimpleName(Class) - Static method in class com.oracle.coherence.common.base.Classes
- 
Determine the simple (unqualified) name of a class.
- getSimpleName(Class) - Static method in class com.tangosol.util.ClassHelper
- 
Determine the simple (unqualified) name of a class.
- getSimpleName(String) - Static method in class com.oracle.coherence.common.base.Classes
- 
Determine the simple (unqualified) name of a class.
- getSimpleName(String) - Static method in class com.tangosol.util.ClassHelper
- 
Determine the simple (unqualified) name of a class.
- getSingletonFactory() - Method in class com.tangosol.net.SingletonCacheFactoryBuilder
- 
Return the singleton cache factory.
- getSiteCount() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Return the site count.
- getSiteName() - Method in interface com.tangosol.net.MemberIdentity
- 
Return the configured name for the Site (such as a data center) in which this Member resides.
- getSiteName() - Method in interface com.tangosol.net.MemberIdentityProvider
- 
Return the name for the Site (such as a data center) in which this Member resides.
- getSiteName() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the configured name for the Site (such as a data center) in which this Member resides.
- getSiteName() - Method in class com.tangosol.net.URLMemberIdentityProvider
- getSiteName() - Method in class com.tangosol.util.NullImplementation.NullMemberIdentityProvider
- getSize() - Method in class com.tangosol.coherence.rest.util.StaticContent
- 
Return content size in bytes.
- getSize() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the size of the encoded value in bytes.
- getSize() - Method in class com.tangosol.net.cache.OverflowMap
- 
Obtain the number of entries in the OverflowMap.
- getSize() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- getSize() - Method in interface com.tangosol.net.management.ViewMBean
- 
Returns the number of key-value mappings in this cache.
- getSize() - Method in class com.tangosol.net.management.ViewMBeanImpl
- getSize() - Method in class com.tangosol.util.AbstractLongArray
- 
Determine the size of the LongArray.
- getSize() - Method in class com.tangosol.util.AbstractSafeLongArray
- getSize() - Method in class com.tangosol.util.AbstractSparseArray
- 
Determine the size of the LongArray.
- getSize() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- getSize() - Method in interface com.tangosol.util.LongArray
- 
Determine the size of the LongArray.
- getSize() - Method in class com.tangosol.util.NullImplementation.NullLongArray
- getSize() - Method in class com.tangosol.util.SimpleLongArray
- 
Determine the size of the LongArray.
- getSize() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Return index content map size.
- getSize() - Method in class com.tangosol.util.StringTable
- 
Determine the number of strings in the table.
- getSize() - Method in class com.tangosol.util.Tree
- 
Determine the size of the tree.
- getSize() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.EntryWriter
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.JsonCollectionWriter
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.ObjectWriter
- getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlCollectionWriter
- getSize(Map, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlMapWriter
- getSize(Set, Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlKeysWriter
- getSizeAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Return the registered action for size().
- getSizeCode() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the "free block size code" for a block of this size.
- getSizeThreshold() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Obtain the bundle size threshold value.
- getSnapshotArchiverMap() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the snapshot archiver map.
- getSnapshotArchiverMap() - Method in interface com.tangosol.net.OperationalContext
- 
Return a Map of snapshot archiver factories.
- getSnapshotName() - Method in interface com.tangosol.net.events.partition.TransferEvent.RecoveryTransferEvent
- 
Return the name of the snapshot if the partition was recovered from a snapshot and not active persistence.
- getSnapshotPersistenceTools(File) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return an implementation specific instance ofPersistenceToolsfor the given local snapshot directory.
- getSnapshots() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Return a list of snapshots that are available for recovery.
- getSocketProvider(XmlElement) - Method in class com.tangosol.net.SocketProviderFactory
- 
Deprecated.
- getSocketProvider(String) - Method in class com.tangosol.net.SocketProviderFactory
- 
Return a Socket provider
- getSocketProvider(String, SocketProviderFactory.Dependencies, int) - Method in class com.tangosol.net.SocketProviderFactory
- 
Return a Socket provider
- getSocketProviderBuilder() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Get delegate socket provider builder
- getSocketProviderBuilder(XmlElement) - Method in class com.tangosol.net.SocketProviderFactory
- 
Deprecated.
- getSocketProviderBuilder(XmlElement, boolean) - Method in class com.tangosol.net.SocketProviderFactory
- 
Deprecated.
- getSocketProviderFactory() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the SocketProviderFactory associated with the cluster.
- getSocketProviderFactory() - Method in interface com.tangosol.net.OperationalContext
- 
Return a SocketProviderFactory.
- getSocketProviderFactory() - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
Get the associated SocketProviderFactory for the Dependency object.
- getSocketProviderFactory() - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
- 
Get the associated SocketProviderFactory for the Dependency object.
- getSocketProviderFactory(ProcessingContext, XmlElement) - Static method in class com.tangosol.net.SocketProviderFactory
- 
Return the cluster'sSocketProviderFactory.
- getSoftTimeout() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the next soft-timeout for this Guardable.
- getSoftTimeoutMillis() - Method in interface com.tangosol.net.Guardian.GuardContext
- 
Return the soft timeout interval for the represented Guardable.
- getSoftTimeoutMillis() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the soft timeout interval for the represented Guardable.
- getSortedMap() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- 
Return the underlying SortedMap.
- getSortedMap(SortedMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns a Converter instance of SortedMap.
- getSortedMap(SortedMap, Class, Class) - Static method in class com.tangosol.util.RestrictedCollections
- 
Returns a restricted instance of SortedMap.
- getSortedSet() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- 
Return the underlying SortedSet.
- getSortedSet() - Method in class com.tangosol.util.ImmutableArrayList
- 
Return a java.util.SortedSet view of this ImmutableArrayList.
- getSortedSet(SortedSet<F>, Converter<F, T>, Converter<T, F>) - Static method in class com.tangosol.util.ConverterCollections
- 
Returns an instance of SortedSet that uses a Converter to view an underlying SortedSet.
- getSortedSet(SortedSet, Class) - Static method in class com.tangosol.util.RestrictedCollections
- 
Returns a restricted instance of SortedSet.
- getSource() - Method in interface com.tangosol.coherence.federation.ChangeRecord.Entry
- 
Obtain the name of the Participant from which the entry originated.
- getSource() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Return theSegmentedConcurrentMapcontaining thisEntry.
- getSourceAddress() - Method in interface com.tangosol.net.NameService.RequestContext
- 
Get theInetAddressthat the request originated from.
- getSpan(Object) - Method in class com.tangosol.net.partition.BroadKeyPartitioningStrategy
- 
Calculate the partition span for a logical group of keys represented by the specified "base" key.
- getSpeakerPriority() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the priority of the PacketSpeaker daemon thread.
- getSpeakerVolumeMinimum() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the minimum number of packets which must be ready to be sent in order for the speaker to be utilized.
- getSqlTokenTable(boolean) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return an initialized TokenTable for the full CoherenceQueryLanguage.
- getSSLDependencies(String) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
Get the SSLSocketProvider's dependencies associated with the given socket provider id
- getSSLDependencies(String) - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
- 
Get the SSLSocketProvider's dependencies associated with the given socket provider id
- getSSLDependenciesBuilderMap() - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- getSSLSettings() - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
- 
Return SSLSettings forSocketProviderBuilder.
- getSSLSettings(SocketProvider) - Method in class com.tangosol.net.SocketProviderFactory
- 
Return SSLSettings for the specified SocketProvider.
- getSSLSettings(SocketProviderBuilder) - Method in class com.tangosol.net.SocketProviderFactory
- 
Return SSLSettings for the specified SocketProviderBuilder.
- getSSLSettings(XmlElement) - Method in class com.tangosol.net.SocketProviderFactory
- 
Deprecated.
- getStableBucketArray() - Method in class com.tangosol.util.SafeHashMap
- 
Get the bucket array, or if a resize is occurring, wait for the resize to complete and return the new bucket array.
- getStableBucketArray() - Method in class com.tangosol.util.SegmentedHashMap
- 
Get the bucket array, or if a resize is occurring, wait for the resize to complete and return the new bucket array.
- getStackFrame() - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Get the StackFrame information for the current method.
- getStackFrame() - Static method in class com.tangosol.util.Base
- 
Get the StackFrame information for the current method.
- getStackFrames() - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Iterate the StackFrame information for all callers, going from the inside outwards, and starting with the caller of this method.
- getStackFrames() - Static method in class com.tangosol.util.Base
- 
Iterate the StackFrame information for all callers, going from the inside outwards, and starting with the caller of this method.
- getStackTrace() - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Build a stack trace for the current thread.
- getStackTrace() - Static method in class com.tangosol.util.Base
- 
Build a stack trace for the current thread.
- getStackTrace(Thread) - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Print stack trace for running thread.
- getStackTrace(Thread) - Static method in class com.tangosol.util.Base
- 
Print stack trace for running thread.
- getStackTrace(Throwable) - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Build a stack trace for the passed exception that does not include the exception description itself.
- getStackTrace(Throwable) - Static method in class com.tangosol.util.Base
- 
Build a stack trace for the passed exception that does not include the exception description itself.
- getStalePartitions(PartitionedService.PartitionRecoveryAction, PartitionSet, PartitionSet) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Return staled partition set.
- getStamp() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicStampedReference
- 
Returns the current value of the stamp.
- getStamp() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
- getStamp() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- getStamp() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicStampedReference
- 
Returns the current value of the stamp.
- getStamp() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- getStamp() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- getState() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Get the state of the executor.
- getState() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Obtain the state of theContinuousQueryCache.
- getState() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine the state of the Status object.
- getState() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine the state of the Status object.
- getState() - Method in interface com.tangosol.net.Guardian.GuardContext
- 
Return the state of the Guardable.
- getState() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the state of the Guardable.
- getState() - Method in class com.tangosol.net.partition.FailoverAccessPolicy
- 
Return the current endangered state (one of the STATE_* constants).
- getState() - Method in class com.tangosol.util.Daemon
- 
Obtain the state of the daemon.
- getState() - Method in interface com.tangosol.util.fsm.FiniteStateMachine
- 
Obtains the current state of theFiniteStateMachine.
- getState() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Obtains the current state of theFiniteStateMachine.
- getState(String) - Method in class com.tangosol.util.fsm.SimpleModel
- 
Obtains the state with the specified name from theSimpleModel.
- getStateClass() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
- getStateClass() - Method in interface com.tangosol.util.fsm.Model
- getStateClass() - Method in class com.tangosol.util.fsm.SimpleModel
- getStateCode() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Get the state of the executor as an integer.
- getStateEntryActions() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
- 
Obtains theStateEntryActions defined for the states in theModel.
- getStateEntryActions() - Method in interface com.tangosol.util.fsm.Model
- 
Obtains theStateEntryActions defined for the states in theModel.
- getStateEntryActions() - Method in class com.tangosol.util.fsm.SimpleModel
- 
Obtains theStateEntryActions defined for the states in theModel.
- getStateExitActions() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
- 
Obtains theStateExitActions defined for the states in theModel.
- getStateExitActions() - Method in interface com.tangosol.util.fsm.Model
- 
Obtains theStateExitActions defined for the states in theModel.
- getStateExitActions() - Method in class com.tangosol.util.fsm.SimpleModel
- 
Obtains theStateExitActions defined for the states in theModel.
- getStateFrom() - Method in exception com.tangosol.util.fsm.RollbackTransitionException
- 
Obtain the state from which theTransitionwas rolled back.
- getStatementBuilder(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return theStatementBuilderfor a given CohQL AST functor.
- getStatementBuilders() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return the map ofStatementBuilderinstances.
- getStatementExecutor() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return theStatementExecutorto use to parse and execute statements.
- getStatementExecutor() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getStatementExecutor() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return theStatementExecutorto use to parse and execute statements.
- getStatements() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getStatements() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return the list of statements that should be executed prior to the start of the CohQL session.
- getStates() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
- 
Obtains the valid states defined by theModel.
- getStates() - Method in interface com.tangosol.util.fsm.Model
- 
Obtains the valid states defined by theModel.
- getStates() - Method in class com.tangosol.util.fsm.SimpleModel
- 
Obtains the valid states defined by theModel.
- getStateString(int) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Return a String description of the providedSTATE_*variables.
- getStateTo() - Method in exception com.tangosol.util.fsm.RollbackTransitionException
- 
Obtain the state to which theTransitiondid not occur.
- getStatistics() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Get JCache Statistics associated with Cache.
- getStatistics() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
- 
Return the statistics for this storage node.
- getStatistics() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Get JCache statistics.
- getStatistics() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Get JCache statistics
- getStatistics() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- getStatistics() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- getStatistics() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistenceSnapshotTools
- 
Get thePersistenceStatisticsfor a local snapshot by using the implementation manager and visiting the store.
- getStatistics() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- getStatus() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine the enumerated status of the Status object.
- getStatus() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine the enumerated status of the Status object.
- getStatus() - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- 
Returns theresultof the commit request.
- getStatusDescription() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Return a String that describes the current Quorum state.
- getStatusDescription() - Method in class com.tangosol.net.ConfigurableQuorumPolicy
- 
Return a String that describes the current Quorum state.
- getStatusDescription() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Return a String that describes the current Quorum state.
- getStatusDescription() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ProxyQuorumPolicy
- 
Return a String that describes the current Quorum state.
- getStatusMap() - Method in class com.tangosol.net.cache.OverflowMap
- 
Obtain the Map of Status objects for entries managed by this Overflow Map.
- getStatusMap() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Obtain the Map of Status objects for entries managed by this Overflow Map.
- getSteps() - Method in interface com.tangosol.util.QueryRecord.PartialResult
- 
Get the list of steps for this query record partial result in the order that they occurred.
- getSteps() - Method in interface com.tangosol.util.QueryRecord.PartialResult.Step
- 
Return inner nested steps, may be null if not nested.
- getSteps() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Get the list of steps for this query record partial result in the order that they occurred.
- getSteps() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Return inner nested steps, may be null if not nested.
- getStorageAccessAuthorizer() - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Obtains theExpressiondefining the name of theStorageAccessAuthorizer.
- getStorageAccessAuthorizer() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Obtains theExpressiondefining the name of theStorageAccessAuthorizer.
- getStorageAccessAuthorizer(String) - Method in interface com.tangosol.net.BackingMapManager
- 
Determine theStorageAccessAuthorizerthat is used by a CacheService to secure access to the NamedCache with the specified name.
- getStorageAccessAuthorizer(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Determine theStorageAccessAuthorizerthat is used by a CacheService to secure access to the NamedCache with the specified name.
- getStorageAccessAuthorizer(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.Determine theStorageAccessAuthorizerthat is used by a CacheService to secure access to the NamedCache with the specified name.
- getStorageAccessAuthorizer(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Determine theStorageAccessAuthorizerthat is used by a CacheService to secure access to the NamedCache with the specified name.
- getStorageAccessAuthorizer(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
- 
Determine theStorageAccessAuthorizerthat is used by a CacheService to secure access to the NamedCache with the specified name.
- getStorageEnabledMembers() - Method in interface com.tangosol.net.DistributedCacheService
- 
Deprecated.As of Coherence 3.6, replaced byPartitionedService.getOwnershipEnabledMembers().
- getStorageFormat() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the storage format used by this manager.
- getStorageIndex() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
- 
Return the storage index at which to evaluate members for safety.
- getStorageScheme() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return theBackingMapSchemeused for the storage of this scheme.
- getStorageScheme(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return theBackingMapSchemeused for the storage of this scheme.
- getStorageSize() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the total size (in bytes) of the storage associated with the partition.
- getStorageVersion() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the version of the storage format used by this manager.
- getStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Return the cache store object to which this wrapper delegates.
- getStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Return the cache store object to which this wrapper delegates.
- getStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Return the cache store object to which this wrapper delegates.
- getStore() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Return the cache store object to which this wrapper delegates.
- getStore() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Return the underlying PersistentStore.
- getStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Obtain the bundler for the "store" operations.
- getStoreContinuation(PersistentStore<R>) - Method in interface com.tangosol.persistence.SafePersistenceWrappers.FailureContinuationFactory
- 
Return a failure continuation to handle unexpected exceptions thrown by operations against the specified PersistentStore.
- getStoreFailures() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the number of store() failures.
- getStoreMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the cumulative time spent on store() operations.
- getStoreName(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Specifies the name for a database table that the Berkeley Database JE store manager uses to store data in.
- getStoreOps() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine the number of store() operations.
- getStrategyName() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Get name of the PartitionAssignmentStrategy in use.
- getStrategyName() - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Get name of the PartitionAssignmentStrategy in use.
- getStreamFormat(Object) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Internal: Select an optimal stream format to use to store the passed object in a stream (as used by the DefaultSerializer).
- getStrength() - Method in class com.tangosol.util.CacheCollator
- 
Returns this Collator's strength property.
- getString() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the String which this PofValue represents.
- getString() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the String which this PofValue represents.
- getString() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a String.
- getString() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a String.
- getString() - Method in class com.tangosol.util.AnyEvent
- 
Gets the associated value as a java.lang.String.
- getString(String) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a String.
- getString(String) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a String.
- getString(String, String) - Method in class com.oracle.coherence.common.base.Resources
- 
Get the specified resource text.
- getString(String, String[], String) - Method in class com.oracle.coherence.common.base.Resources
- 
Get the specified resource string.
- getSubject() - Method in class com.tangosol.net.security.PermissionInfo
- 
Return the encryptor subject.
- getSubMappings() - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Obtain the list of sub-mappings that this mapping contains
- getSubscriberGroupBuilders() - Method in class com.tangosol.coherence.config.TopicMapping
- 
Get the durableSubscriberGroupBuilders for thisTopicMapping.
- getSubscriberGroupMBeanName(SubscriberGroupId, String, Service) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return the MBean name for a subscriber group.
- getSubscriberGroupName(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.SubscriberGroupBuilder
- 
Get the subscriber group name.
- getSubscriberGroups() - Method in interface com.tangosol.net.topic.NamedTopic
- 
Return the set ofnamedsubscriber group(s) and statically configured subscriber-group(s).
- getSubscriberGroups(String) - Method in interface com.tangosol.net.PagedTopicService
- 
Returns thesubscriber groupsfor a topic known to this service.
- getSubscriberMBeanName(PagedTopicSubscriber) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return the MBean name for aPagedTopicSubscriber.
- getSubscriberMBeanPattern(NamedTopic<?>, boolean) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return the MBean name pattern for all subscribers in a topic.
- getSubscriberMBeanPattern(NamedTopic<?>, SubscriberGroupId, boolean) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return the MBean name pattern for all subscribers in a subscriber group for topic.
- getSubscribers(String, SubscriberGroupId) - Method in interface com.tangosol.net.PagedTopicService
- 
Returns thesubscriber idsknown to this service and subscribed to a subscriber group for a topic .
- getSubscriberTimeout(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Returns the subscriber timeout value.
- getSubscriberTimeoutMillis() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Returns number of milliseconds within which a subscriber must issue a heartbeat or be forcefully considered closed.
- getSubscription(long) - Method in interface com.tangosol.net.PagedTopicService
- 
Return aPagedTopicSubscription.
- getSubscriptionId(String, SubscriberGroupId) - Method in interface com.tangosol.net.PagedTopicService
- 
Return the subscription id for a subscriber group.
- getSuccessfulRequestCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getSuccessfulRequestCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the count of requests that responded with success.
- getSuccessfulRequestFifteenMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getSuccessfulRequestFifteenMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the fifteen minute rate of successful requests.
- getSuccessfulRequestFiveMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getSuccessfulRequestFiveMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the five minute rate of successful requests.
- getSuccessfulRequestMeanRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getSuccessfulRequestMeanRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the one minute rate of successful requests.
- getSuccessfulRequestOneMinuteRate() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getSuccessfulRequestOneMinuteRate() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the one minute rate of successful requests.
- getSuggestionCompletionDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return the amount of time in ms to delay the analysis after a distribution suggestion has been made and before it is carried out.
- getSuggestionDelay() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return the amount of time in ms to delay the analysis.
- getSupplier() - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- 
Returns the supplier that should be used when an entry is not present.
- getSupportedTypes() - Method in interface com.tangosol.net.events.EventDispatcher
- 
Return the set ofEventtypes thisEventDispatchersupports.
- getSymbol() - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
Return the symbol to use in CohQL that represents this operator.
- getSynchronousListeners() - Method in class com.tangosol.util.Listeners
- 
Get the array of synchronous event listeners.
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder
- getSyntax() - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
- getSyntax() - Method in interface com.tangosol.coherence.dslquery.StatementBuilder
- 
Return the syntax of the CohQL command.
- getSyntheticEventsMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the map of keys for which the events should be marked as synthetic (internal).
- getSyntheticInfo(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.Generate a synthetic CacheInfo for a cache that has a name suffixed with the specified string.
- getTail(int) - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns thePositionthat is currently the tail for the specified channel orOptional.empty()if the channel is not owned by thisSubscriber.
- getTails() - Method in interface com.tangosol.net.topic.Subscriber
- 
Returns aMapof thePositionsthat are currently the tail for each channel owned by thisSubscriber; that is the last message in the channel.
- getTarget() - Method in class com.tangosol.util.extractor.AbstractExtractor
- getTarget() - Method in interface com.tangosol.util.ValueExtractor
- 
ReturnAbstractExtractor.VALUE.
- getTaskActiveMillis() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getTaskActiveMillis() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the total number of milliseconds spent by all Daemon threads while executing tasks since the last time the statistics were reset.
- getTaskAddCount() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getTaskAddCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getTaskAddCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the total number of tasks added to the pool since the last time the statistics were reset.
- getTaskBacklog() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getTaskBacklog() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the number of tasks that have been added to the pool, but not yet scheduled for execution.
- getTaskCount() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getTaskCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getTaskCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the total number of tasks executed by Daemon threads since the last time the statistics were reset.
- getTaskExecutionTime() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the total amount of time (in ms) that tasks/requests for this partition spent executing.
- getTaskHungThresholdMillis() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain the amount of time that a task can execute before it's considered "hung".
- getTasks() - Method in class com.tangosol.util.TaskDaemon
- 
Obtain the pending tasks.
- getTasksCompletedCount() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Get the completed tasks count for the executor.
- getTasksInProgressCount() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Get the in progress tasks count for the executor.
- getTasksRejectedCount() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Get the number of tasks rejected by the executor.
- getTaskTimeout() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getTaskTimeout() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getTaskTimeout() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the default timeout value for PriorityTasks that don't explicitly specify the execution timeout value.
- getTaskTimeoutCount() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- getTaskTimeoutCount() - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Return the total number of timed-out tasks since the last time the statistics were reset.
- getTaskTimeoutMillis() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain the default task timeout value.
- getTaskWaitTime() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Return the total amount of time (in ms) that tasks/requests for this partition spent waiting before execution.
- getTcpBacklog() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the listener backlog for TCMP's TCP listener.
- getTcpDatagramSocketDependencies(String) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
Get the TcpDatagramSocketProvider's dependencies associated with the given socket provider id
- getTcpDatagramSocketDependencies(String) - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
- 
Get the TcpDatagramSocketProvider's dependencies associated with the given socket provider id
- getTcpDatagramSocketOptions() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the SocketOptions to apply when TCMP runs on a TcpDatagramSocket.
- getTcpRingSocketOptions() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the TcpRing SocketOptions.
- getThread() - Method in interface com.tangosol.net.ServiceMonitor
- 
Return the thread used by this ServiceMonitor.
- getThread() - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Return the thread used by this ServiceMonitor.
- getThread() - Method in class com.tangosol.util.Daemon.DaemonWorker
- getThread() - Method in class com.tangosol.util.Daemon
- 
Accessor to obtain the Daemon thread object.
- getThreadContext() - Static method in class com.tangosol.net.GuardSupport
- 
Obtain the GuardContext associated with the current thread.
- getThreadContextClassLoader() - Method in class com.tangosol.util.Daemon
- 
Determine the configured context ClassLoader for the daemon thread.
- getThreadDecreaseInterval() - Method in interface com.tangosol.net.ThreadPoolManager
- 
Return the time interval for dynamically decreasing the size of the thread pool.
- getThreadDump() - Static method in class com.tangosol.net.GuardSupport
- 
Get the full thread dump.
- getThreadFactory() - Static method in class com.tangosol.util.Base
- 
Return the configured thread factory.
- getThreadId() - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- 
Return the thread ID.
- getThreadId() - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- 
Return the thread ID.
- getThreadIncreaseInterval() - Method in interface com.tangosol.net.ThreadPoolManager
- 
Return the time interval for dynamically increasing the size of the thread pool.
- getThreadPriority() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain the priority of the service thread.
- getThreadThreshold() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Obtains the minimum number of threads that will trigger the bundler to switch from a pass through to a bundled mode.
- getThreadThreshold(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Return the minimum number of threads that must be concurrently executing individual(non-bundled) requests for the bundler to switch from a pass-through to a bundling mode.
- getThreshold() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Return the size threshold for this rule.
- getThresholdFactor() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Return the percentage threshold for this rule.
- getTime() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a Time.
- getTime() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a Time.
- getTime(Time) - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as a Time.
- getTime(Time) - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as a Time.
- getTimedOutMemberSet() - Method in interface com.tangosol.net.Cluster.MemberTimeoutAction
- 
Return the set of Members that have exceeded their timeout.
- getTimeMillis() - Method in interface com.tangosol.net.Cluster
- 
Returns the current "cluster time", which is analogous to theSystem.currentTimeMillis()except that the cluster time is the roughly the same for all Members in the cluster.
- getTimeout() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Obtain the number of mill-seconds to wait for aStatementto execute before timing out.
- getTimeout() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getTimeout() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return the initial value that will be set as the CohQL statement timeout.
- getTimeout() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the next timeout for this Guardable.
- getTimeoutCount() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- getTimeoutMillis() - Method in interface com.tangosol.net.Guardian.GuardContext
- 
Return the hard timeout interval for the represented Guardable.
- getTimeoutMillis() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return the hard timeout interval for the represented Guardable.
- getTimestamp() - Method in interface com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics.ConnectionMetricsMBean
- 
Returns the time that the connection was opened.
- getTimestamp() - Method in interface com.tangosol.net.Member
- 
Return the date/time value (in cluster time) that the Member joined.
- getTimestamp() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the date/time value (in cluster time) that the Member joined.
- getTimestamp() - Method in interface com.tangosol.net.topic.Subscriber.Element
- 
Return the timestamp that the element was published.
- getTimestamp() - Method in class com.tangosol.util.UID
- 
Determine the date/time value that the UID instance was generated.
- getTimestamp() - Method in class com.tangosol.util.UUID
- 
Determine the date/time value that the UUID instance was generated.
- getTimeToLive() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- getTimeUnit() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DelayedTransitionTo
- 
Obtains theTimeUnitfor theNonBlockingFiniteStateMachine.DelayedTransitionTo.getDuration()
- getTimeUnit() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.ProcessEventLater
- 
Obtains theTimeUnitfor theNonBlockingFiniteStateMachine.ProcessEventLater.getDuration().
- getTimeZone(String) - Static method in class com.oracle.coherence.common.base.TimeHelper
- 
Gets theTimeZonefor the given ID.
- getTimeZone(String) - Static method in class com.tangosol.util.Base
- 
Gets theTimeZonefor the given ID.
- getTitle() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return the String to use for title that heads each result.
- getTitle() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- getTitle() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return the String to use for title that heads each result.
- getTokens() - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
- 
Return an array of BaseTokens making up the receiver.
- getTokens() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
- 
Return an array of BaseTokens making up the receiver.
- getTokens() - Method in class com.tangosol.coherence.dsltools.base.SequenceBaseToken
- 
Return an array of BaseTokens making up the receiver.
- getToMember() - Method in class com.tangosol.net.partition.PartitionEvent
- 
Determine the member that holds the partitions after the action represented by this event.
- getTopAnchor() - Method in class com.tangosol.util.filter.LimitFilter
- 
Obtain the top anchor object, which is the last value object on a previous page.
- getTopic(String) - Method in interface com.tangosol.net.Session
- 
Acquire aNamedTopicusing the specifiedValueTypeAssertion.
- getTopic(String, NamedCollection.Option...) - Method in class com.tangosol.net.CoherenceSession
- getTopic(String, NamedCollection.Option...) - Method in interface com.tangosol.net.Session
- 
Acquire aNamedTopicusing the specifiedValueTypeAssertion.
- getTopicBackingMapManager() - Method in interface com.tangosol.net.PagedTopicService
- 
Return theTopicBackingMapManagerfor this service.
- getTopicBackingMapManager() - Method in interface com.tangosol.net.TopicService
- 
Return theTopicBackingMapManager.
- getTopicDependencies(String) - Method in class com.tangosol.net.topic.TopicBackingMapManager
- 
Get theTopicDependenciesfor a topic.
- getTopicMBeanName(NamedTopic<?>) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return the MBean name for the topic.
- getTopicMBeanPattern() - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return the MBean name pattern that will match all topic MBeans.
- getTopicMBeanPattern(TopicService) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return the MBean name pattern that will match all topic MBeans for the service.
- getTopicNames() - Method in interface com.tangosol.net.TopicService
- 
Returns the names of the topics known to this service.
- getTopicService() - Method in interface com.tangosol.net.topic.NamedTopic
- 
Return theTopicServicemanaging thisNamedTopic.
- getTopicStatistics(String) - Method in interface com.tangosol.net.PagedTopicService
- 
Returns thePagedTopicStatisticsfor a topic.
- getTotalGets() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the total number of get() operations since the cache statistics were last reset.
- getTotalGets() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the total number of get() operations since the cache statistics were last reset.
- getTotalGets() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the total number of get() operations since the cache statistics were last reset.
- getTotalGetsMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the total number of milliseconds spent on get() operations since the cache statistics were last reset.
- getTotalGetsMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the total number of milliseconds spent on get() operations since the cache statistics were last reset.
- getTotalGetsMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the total number of milliseconds spent on get() operations since the cache statistics were last reset.
- getTotalPageCount() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Determine the number of pages that the PagedBinaryStore has managed in total, including those it is currently managing.
- getTotalPuts() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the total number of put() operations since the cache statistics were last reset.
- getTotalPuts() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the total number of put() operations since the cache statistics were last reset.
- getTotalPuts() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the total number of put() operations since the cache statistics were last reset.
- getTotalPutsMillis() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Determine the total number of milliseconds spent on put() operations since the cache statistics were last reset.
- getTotalPutsMillis() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Determine the total number of milliseconds spent on put() operations since the cache statistics were last reset.
- getTotalPutsMillis() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Determine the total number of milliseconds spent on put() operations since the cache statistics were last reset.
- getTotalRegisterListener() - Method in class com.tangosol.net.cache.CachingMap
- 
Determine the total number ofCachingMap.registerListener(Object oKey)operations since the cache statistics were last reset.
- getTouchCount() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
- 
Determine the number of times that the cache entry has been touched (since the touch count was last reset).
- getTouchCount() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Determine the number of times that the cache entry has been touched.
- getTouchCount() - Method in class com.tangosol.net.cache.SerializationCache.EntryAttributes
- 
Determine the absolute order of the entry within in the LRU list.
- getTouchCount() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Determine the number of times that the cache entry has been touched (since the touch count was last reset).
- getTouchCount() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Determine the number of times that the cache entry has been touched (since the touch count was last reset).
- getTouchCount() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- 
Determine the number of times that the cache entry has been touched (since the touch count was last reset).
- getTouchCounter() - Method in class com.tangosol.net.cache.SerializationCache
- 
Determine the next value from the touch counter.
- getTransactionIsolation() - Method in interface com.tangosol.util.TransactionMap
- 
Retrieve this TransactionMap's current transaction isolation level.
- getTransactionTimeout() - Method in interface com.tangosol.util.TransactionMap
- 
Retrieve transaction timeout value for this TransactionMap.
- getTransferThreshold() - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- getTransferThreshold() - Method in interface com.oracle.coherence.grpc.proxy.GrpcServiceDependencies
- 
Return the transfer threshold.
- getTransformationState() - Method in class com.tangosol.net.cache.CacheEvent
- 
Return true iff this event istransformable.
- getTransformer() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Obtain theMapEventTransformerthat should be used when registering this listener.
- getTransformer() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Obtain the transformer that thisContinuousQueryCacheis using to transform the results from the underlying cache prior to storing them locally.
- getTransformer() - Method in interface com.tangosol.net.management.ViewMBean
- 
Obtain the transformer that thisContinuousQueryCacheis using to transform the results from the underlying cache prior to storing them locally.
- getTransformer() - Method in class com.tangosol.net.management.ViewMBeanImpl
- getTransformer(InjectionPoint) - Method in class com.oracle.coherence.cdi.MapEventTransformerProducer
- 
ProducesMapEventTransformerbased on injection point metadata.
- getTransformerBuilder() - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- 
Return theParameterizedBuilderused to construct theValueExtractorto be used as a transformer by theContinuousQueryCache.
- getTransientExpression() - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Return theExpressiontransient. to use to determine whether the backing map is transient.
- getTransientVersionCache() - Method in class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Get the cache of version info for the data maintained in this backing map (and other related backing maps if this is backing a distributed cache).
- getTransitionCount() - Method in interface com.tangosol.util.fsm.ExecutionContext
- 
Obtains the number of successful transitions that have occurred on theFiniteStateMachinethus far.
- getTransitionCount() - Method in interface com.tangosol.util.fsm.FiniteStateMachine
- 
Obtains the number of transitions that have occurred in theFiniteStateMachine.
- getTransitionCount() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Obtains the number of transitions that have occurred in theFiniteStateMachine.
- getTransitions() - Method in class com.tangosol.util.fsm.AnnotationDrivenModel
- 
Obtains theTransitions defined by theModel.
- getTransitions() - Method in interface com.tangosol.util.fsm.Model
- 
Obtains theTransitions defined by theModel.
- getTransitions() - Method in class com.tangosol.util.fsm.SimpleModel
- 
Obtains theTransitions defined by theModel.
- getTrashDirectory() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the directory used to store "safe-deleted" persisted data.
- getTrigger() - Method in class com.tangosol.util.MapTriggerListener
- 
Obtain the MapTrigger agent represented by this TriggerListener.
- getTriggerExtentId(long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return the extent identifier that contains trigger registration information for the cache with the given identifier.
- getTrustManager() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Get the SSL trust manager
- getTTL() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- getType() - Method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Obtain the type code of this token.
- getType() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Return the event type.
- getType() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the current Block type.
- getType() - Method in class com.tangosol.io.pof.reflect.PofReflectionHelper.NavigatorAndType
- getType() - Method in interface com.tangosol.net.events.Event
- 
Return theEvent's type.
- getType() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Obtain the type of the property (the class of the object declared as being returned by the accessor and passed to the mutator).
- getType() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Get the class of the specific XML bean implementation.
- getType() - Method in class com.tangosol.util.aggregator.QueryRecorder
- 
Get the record type for this query recorder.
- getType() - Method in interface com.tangosol.util.QueryRecord
- 
Get thetypethat was specified when this query record was created.
- getType() - Method in class com.tangosol.util.SimpleQueryRecord
- 
Get thetypethat was specified when this query record was created.
- getTypeCode() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Obtain the typecode for the node.
- getTypedCache(String, TypeAssertion<K, V>) - Static method in class com.tangosol.net.CacheFactory
- 
Return an instance of a cache with the given name satisfying the specifiedTypeAssertion.
- getTypedCache(String, ClassLoader, TypeAssertion<K, V>) - Static method in class com.tangosol.net.CacheFactory
- 
Return an instance of a cache with the given name satisfying the specifiedTypeAssertion.
- getTypeId() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Obtain the POF type identifier for this value.
- getTypeId() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Obtain the POF type identifier for this value.
- getTypeIds() - Method in class com.tangosol.io.pof.EvolvableHolder
- 
Return type identifiers for all the Evolvables within this holder.
- getTypeMetadata() - Method in class com.tangosol.io.pof.PofAnnotationSerializer
- 
Return theTypeMetadatainstance that holds structural information regarding the class this serializer (de)serializes.
- getTypeName(int) - Static method in interface com.tangosol.io.pof.PofConstants
- getUid() - Method in interface com.tangosol.net.Member
- 
Return the unique identifier of the Member.
- getUid() - Method in class com.tangosol.net.proxy.RemoteMember
- 
Return the unique identifier of the Member.
- getUID() - Method in interface com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics.ConnectionMetricsMBean
- 
Returns the UID for the connection.
- getUndecorated() - Method in class com.tangosol.util.ExternalizableHelper.DecoratedMultiBufferReadBuffer
- 
Return the undecorated value.
- getUndecorated(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
If the passed ReadBuffer is decorated, extract the original contents that the decorations were added to, otherwise return the passed Binary value.
- getUndecorated(Binary) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Deprecated.as of Coherence 3.7.2
- getUnicastSocketProviderBuilder() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the cluster's unicastSocketProviderBuilder.
- getUnicastSocketProviderXml() - Method in interface com.tangosol.net.ClusterDependencies
- 
Deprecated.
- getUniformElementType() - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Return the uniform element type (if this is a uniform collection).
- getUniformType() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
If the object encoding is using uniform encoding, obtain the type id of the uniform type.
- getUniformType() - Method in class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
- 
If the object encoding is using uniform encoding, obtain the type id of the uniform type.
- getUniformType() - Method in class com.tangosol.io.pof.WritingPofHandler.Complex
- 
If the object encoding is using uniform encoding, obtain the type id of the uniform type.
- getUniformType() - Method in class com.tangosol.io.pof.WritingPofHandler.ComplexMap
- 
If the object encoding is using uniform encoding, obtain the type id of the uniform type.
- getUniqueDbName() - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Get a unique (within the Factory) database name.
- getUnitCalculator() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getUnitCalculator() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Obtain the current UnitCalculator used by the cache.
- getUnitCalculator() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Obtain the current UnitCalculator used by the cache.
- getUnitCalculator() - Method in class com.tangosol.net.cache.SerializationCache
- 
Obtain the current UnitCalculator used by the cache.
- getUnitCalculator() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Obtain the current UnitCalculator used by the cache.
- getUnitCalculatorBuilder() - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Return the UnitCalculatorBuilder used to build a UnitCalculator.
- getUnitCalculatorBuilder() - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Return the UnitCalculatorBuilder used to build a UnitCalculator.
- getUnitCalculatorBuilder() - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Return the UnitCalculatorBuilder used to build a UnitCalculator.
- getUnitCalculatorBuilder() - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Return the UnitCalculatorBuilder used to build a UnitCalculator.
- getUnitCalculatorType() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the current unit calculator type.
- getUnitCalculatorType(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.UnitCalculatorBuilder
- 
Return theConfigurableCacheMap.UnitCalculatortype.
- getUnitCount() - Method in class com.tangosol.coherence.config.unit.Units
- 
Return the unit count.
- getUnitFactor() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getUnitFactor() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Determine the factor by which the Units, LowUnits and HighUnits properties are adjusted.
- getUnitFactor() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the factor by which the Units, LowUnits and HighUnits properties are adjusted.
- getUnitFactor() - Method in class com.tangosol.net.cache.SerializationCache
- 
Determine the factor by which the Units, LowUnits and HighUnits properties are adjusted.
- getUnitFactor() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the factor by which the Units, LowUnits and HighUnits properties are adjusted.
- getUnitFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Return the unit-factor element specifies the factor by which the units, low-units and high-units properties are adjusted.
- getUnitFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Return the unit-factor element specifies the factor by which the units, low-units and high-units properties are adjusted.
- getUnitFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Return the unit-factor element specifies the factor by which the units, low-units and high-units properties are adjusted.
- getUnitFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Return the unit-factor element specifies the factor by which the units, low-units and high-units properties are adjusted.
- getUnitOfOrderId() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- getUnitOfOrderId() - Method in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
- 
Return a unit-of-order id associated with this aggregator.
- getUnitOfOrderId() - Method in class com.tangosol.util.AsynchronousAgent
- 
Return a unit-of-order id associated with this agent.
- getUnitOfOrderId() - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
Return a unit-of-order id associated with this processor.
- getUnits() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- getUnits() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
- 
Determine the number of cache units used by this Entry.
- getUnits() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Determine the number of units that the cache currently stores.
- getUnits() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Determine the number of cache units used by this Entry.
- getUnits() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the number of units that the cache currently stores.
- getUnits() - Method in class com.tangosol.net.cache.SerializationCache.EntryAttributes
- 
Determine the number of units of storage used by the entry.
- getUnits() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Determine the number of cache units used by this Entry.
- getUnits() - Method in class com.tangosol.net.cache.SerializationCache
- 
Determine the number of units that the cache currently stores.
- getUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Determine the number of cache units used by this Entry.
- getUnits() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the number of units that the cache currently stores.
- getUnits() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- 
Determine the number of cache units used by this Entry.
- getUnits() - Method in interface com.tangosol.util.MapIndex
- getUnits() - Method in class com.tangosol.util.SimpleMapIndex
- 
Retrieve the size of this index in units (as defined by theUnitCalculator).
- getUniversalName(String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Return a universal XML element name.
- getUnlockAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Return the registered action for unlock().
- getUnownedPartitions(PartitionSet, int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Calculate a subset of the PartitionSet consisting of partitions that are not owned (primary or backup) by the specified member.
- getUnresolvedPartitions() - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Retrieve a PartitionSet containing all partitions that don't have any corresponding GUIDs.
- getUnsafe() - Static method in class com.tangosol.util.Unsafe
- 
Return the singletonUnsafeinstance.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Get a ReadBuffer object to read data from this buffer.
- getUnsafeReadBuffer() - Method in interface com.tangosol.io.WriteBuffer
- 
Get a ReadBuffer object to read data from this buffer.
- getUnsafeWriteBuffer() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Create a "shallow clone" of the ByteBufferWriteBuffer that uses the same underlying memory but through a different (a duplicate) ByteBuffer.
- getUnsynchronizedKeyEnumerator() - Method in class com.tangosol.util.Tree
- 
Get an enumerator of the nodes in the tree.
- getUnsynchronizedKeyEnumerator(Comparable) - Method in class com.tangosol.util.Tree
- 
Get an enumerator of the nodes in the tree.
- getUpdatedPartitions() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return the set of updated partitions; may be null.
- getUpdater() - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Retrieve the underlying ValueUpdater reference.
- getUpdater() - Method in class com.tangosol.util.extractor.CompositeUpdater
- 
Retrieve the ValueUpdater part.
- getUpdater() - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Retrieve the underlying ValueUpdater reference.
- getUpdater() - Method in interface com.tangosol.util.ValueManipulator
- 
Retrieve the underlying ValueUpdater reference.
- getUpperBound() - Method in class com.tangosol.util.filter.BetweenFilter
- 
Obtain the upper bound of the range being used to evaluate values by this BetweenFilter.
- getUpperFilter() - Method in class com.tangosol.util.filter.BetweenFilter
- getUpTimeMillis() - Static method in class com.oracle.coherence.common.base.TimeHelper
- 
Return the number of milliseconds which have elapsed since the JVM was started.
- getUpTimeMillis() - Static method in class com.tangosol.util.Base
- 
Return the number of milliseconds which have elapsed since the JVM was started.
- getURI() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- getURL() - Method in class com.tangosol.net.URLPasswordProvider
- 
Returns the URL to read the password from.
- getUsedCapacity() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine the number of types in the buffer that are in use by Entry blocks.
- getUserContext() - Method in interface com.tangosol.net.Service
- 
Return the user context object associated with this Service.
- getUserContext() - Method in class com.tangosol.net.WrapperService
- 
Return the user context object associated with this Service.
- getUsername() - Method in class com.tangosol.net.security.UsernameAndPassword
- 
Return the username.
- getUserPrincipal() - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
- getUserTypeId() - Method in class com.tangosol.io.pof.PofBufferReader
- 
Determine the user type that is currently being parsed.
- getUserTypeId() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Determine the user type that is currently being parsed.
- getUserTypeId() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Determine the user type that is currently being written.
- getUserTypeId() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Determine the user type that is currently being written.
- getUserTypeId() - Method in interface com.tangosol.io.pof.PofReader
- 
Determine the user type that is currently being parsed.
- getUserTypeId() - Method in interface com.tangosol.io.pof.PofWriter
- 
Determine the user type that is currently being written.
- getUserTypeIdentifier(Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(Class) - Method in interface com.tangosol.io.pof.PofContext
- 
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(Class) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(Class) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(Class) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Determine the user type identifier associated with the given class.
- getUserTypeIdentifier(Object) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine the user type identifier associated with the given object.
- getUserTypeIdentifier(Object) - Method in interface com.tangosol.io.pof.PofContext
- 
Determine the user type identifier associated with the given object.
- getUserTypeIdentifier(Object) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine the user type identifier associated with the given object.
- getUserTypeIdentifier(Object) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Determine the user type identifier associated with the given object.
- getUserTypeIdentifier(String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine the user type identifier associated with the given class name.
- getUserTypeIdentifier(String) - Method in interface com.tangosol.io.pof.PofContext
- 
Determine the user type identifier associated with the given class name.
- getUserTypeIdentifier(String) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Determine the user type identifier associated with the given class name.
- getUserTypeIdentifier(String) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine the user type identifier associated with the given class name.
- getUserTypeIdentifier(String) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Determine the user type identifier associated with the given class name.
- getUserTypeIdentifierInternal(Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine the user type identifier associated with the given class.
- getUserTypeIdentifierInternal(String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine the user type identifier associated with the given class name.
- getUuid() - Method in interface com.tangosol.net.Member
- 
Return the universal unique id of the Member.
- getValidator() - Method in interface com.tangosol.util.TransactionMap
- 
Retrieve the topmost Validator in TransactionMap's validation chain.
- getValue() - Method in class com.oracle.coherence.mp.config.ConfigPropertyChanged
- 
The new value of the configuration property that was modified.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.IdentifierBaseToken
- 
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
- 
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.OperatorBaseToken
- 
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.base.PunctuationBaseToken
- 
Return the string representation of this LeafBaseToken.
- getValue() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Get a string value that identifies this token
- getValue() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Obtain the string value for the node.
- getValue() - Method in interface com.tangosol.coherence.federation.ChangeRecord.Entry
- 
Obtain the value corresponding to this entry.
- getValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- getValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
- 
Return current value.
- getValue() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
- getValue() - Method in class com.tangosol.coherence.rest.EntryResource
- 
Get the entry value.
- getValue() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Get the Entry value in the block, lazy loading it if necessary.
- getValue() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the deserialized value which this PofValue represents.
- getValue() - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the deserialized value which this PofValue represents.
- getValue() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Return the value corresponding to this entry.
- getValue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
- 
Return the result of the load operation.
- getValue() - Method in interface com.tangosol.net.events.partition.cache.EntryEvent
- 
Return the value of the entry on which the action represented by thisEntryEventoccurred.
- getValue() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Returns the value corresponding to this entry.
- getValue() - Method in interface com.tangosol.net.topic.Subscriber.Element
- 
Return the received value
- getValue() - Method in exception com.tangosol.net.topic.TopicPublisherException
- 
Returns the deserialized value that failed to be published.
- getValue() - Method in class com.tangosol.run.xml.SimpleValue
- 
Get the value as an Object.
- getValue() - Method in interface com.tangosol.run.xml.XmlValue
- 
Get the value as an Object.
- getValue() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.Entry
- 
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- getValue() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Returns the current value, which is the same value returned by the most recent call to the next method, or the most recent value passed to setValue if setValue were called after the next method.
- getValue() - Method in class com.tangosol.util.AbstractSparseArray.Node
- 
Get the value associated with the node.
- getValue() - Method in class com.tangosol.util.AnyEvent
- 
Gets the associated value.
- getValue() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- getValue() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray.ConverterLongArrayIterator
- getValue() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- getValue() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
Returns the current value, which is the same value returned by the most recent call to the next method, or the most recent value passed to setValue if setValue were called after the next method.
- getValue() - Method in class com.tangosol.util.ExternalizableHelper.IntDecoratedObject
- 
Return the underlying value.
- getValue() - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Get the object to compare the reflection result with.
- getValue() - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Return the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- 
Return an OriginalValue from the underlying entry.
- getValue() - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Returns the value corresponding to this entry.
- getValue() - Method in interface com.tangosol.util.LongArray.Iterator
- 
Returns the current value, which is the same value returned by the most recent call to the next method, or the most recent value passed to setValue if setValue were called after the next method.
- getValue() - Method in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
- 
Get the value associated with the node.
- getValue() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
- 
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.SafeHashMap.Entry
- 
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.SafeSortedMap.NullableEntry
- getValue() - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.SimpleLongArray.Iterator
- 
Returns the current value, which is the same value returned by the most recent call to the next method, or the most recent value passed to setValue if setValue were called after the next method.
- getValue() - Method in class com.tangosol.util.SimpleMapEntry
- 
Returns the value corresponding to this entry.
- getValue() - Method in class com.tangosol.util.SparseArray.ObjectNode
- 
Get the value associated with the node.
- getValue() - Method in class com.tangosol.util.ThreadLocalObject
- 
Get the value stored by this instance of ThreadLocalObject.
- getValue() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- getValue() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- getValue(int) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the deserialized value which this PofValue represents.
- getValue(int) - Method in class com.tangosol.io.pof.reflect.PofSparseArray.NilPofValue
- 
Return the deserialized value which this PofValue represents.
- getValue(int) - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the deserialized value which this PofValue represents.
- getValue(Class) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return the deserialized value which this PofValue represents.
- getValue(Class) - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Return the deserialized value which this PofValue represents.
- getValue(Object) - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Extract the value of this property from a target object.
- getValue(String) - Method in class com.oracle.coherence.mp.config.CoherenceConfigSource
- getValue(String) - Method in class com.oracle.coherence.mp.config.CoherenceDefaultsConfigSource
- getValue(String) - Method in class com.oracle.coherence.mp.metrics.CoherenceTagsConfigSource
- getValue(String) - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Get value ofsParamNameassociated with thisCacheMapping
- getValue(String, Class<T>) - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Get value ofsParamNameassociated with thisCacheMapping
- getValue(Supplier<V>) - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Return the value corresponding to this entry, or the default value returned by thedefaultValueSupplier, if the entry value isnull.
- getValue(V) - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Return the value corresponding to this entry, or the specifieddefaultValue, if the entry value isnull.
- getValueAdapter() - Method in class com.tangosol.run.xml.MapAdapter
- getValueBuffer() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Get the raw value buffer.
- getValueClass() - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Determine the class of the cached values.
- getValueClassName() - Method in class com.tangosol.coherence.config.CacheMapping
- 
Obtains the name of the value class forNamedCaches using thisCacheMapping.
- getValueClassName() - Method in class com.tangosol.coherence.config.TopicMapping
- 
Obtains the name of the value class forNamedTopics using thisTopicMapping.
- getValueClassName() - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
- 
Get Value ClassName
- getValueClassName() - Method in class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
- 
Get Value ClassName
- getValueConverter() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Get value converter for this.
- getValueExtractor() - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Determine the ValueExtractor whose values this aggregator is aggregating.
- getValueExtractor() - Method in class com.tangosol.util.filter.BetweenFilter
- 
Obtain the ValueExtractor used by this filter.
- getValueExtractor() - Method in class com.tangosol.util.filter.ExtractorFilter
- 
Obtain the ValueExtractor used by this filter.
- getValueExtractor() - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Obtain the ValueExtractor object that the MapIndex uses to extract an indexable Object from a value stored in the indexed Map.
- getValueExtractor() - Method in interface com.tangosol.util.MapIndex
- 
Obtain the ValueExtractor object that the MapIndex uses to extract an indexable Object from a value stored in the indexed Map.
- getValueExtractor() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a ValueExtractor.
- getValueExtractor() - Method in class com.tangosol.util.SimpleMapIndex
- 
Obtain the ValueExtractor object that the MapIndex uses to extract an indexable Object from a value stored in the indexed Map.
- getValueExtractor(InjectionPoint) - Method in class com.oracle.coherence.cdi.ExtractorProducer
- 
Create an instance of aValueExtractorbased on injection point metadata.
- getValueFromInternalConverter() - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Return a converter that allows the manager (or a backing map managed thereby) to convert a value object from its internal form (as managed by the CacheService) into its "normal" (Object) form.
- getValueFromInternalConverter() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Return a converter that allows the manager (or a backing map managed thereby) to convert a value object from its internal form (as managed by the CacheService) into its "normal" (Object) form.
- getValueIndex() - Method in class com.tangosol.util.ImmutableArrayList
- 
Create a reverse index from value to position if this List is big enough to warrant it.
- getValueInternal() - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Returns the value corresponding to this entry, or NO_VALUE if this Entry is synthetid.
- getValueLength() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Get the length of the Entry value in the block.
- getValues(int, int, String, PropertySet, String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Return the cache values (or a subset of their properties) that satisfy the specified criteria.
- getValues(PropertySet) - Method in class com.tangosol.coherence.rest.EntrySetResource
- 
Return the entries' values or a subset of their properties.
- getValues(UriInfo, int, int, String, PropertySet) - Method in class com.tangosol.coherence.rest.NamedQueryResource
- 
Return the cache values that satisfy criteria defined by this resource.
- getValueToInternalConverter() - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Return a converter that allows the manager (or a backing map managed thereby) to convert a value object into its internal form as managed by the CacheService.
- getValueToInternalConverter() - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Return a converter that allows the manager (or a backing map managed thereby) to convert a value object into its internal form as managed by the CacheService.
- getValueType() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- getValueType() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
- getValueType() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- getVariance(SimpleAssignmentStrategy.AnalysisContext, boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return the maximum load variance in the partition assignments represented by the analysis context.
- getVersion() - Method in class com.tangosol.io.pof.reflect.PofUserType
- 
Return the data version of this value.
- getVersion() - Method in class com.tangosol.net.partition.VersionedOwnership
- 
Return the ownership version.
- getVersion() - Method in interface com.tangosol.net.partition.VersionedPartitions.VersionedIterator
- 
Return the current version.
- getVersion() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- getVersion() - Method in class com.tangosol.util.MapEvent
- 
Return the version that represents the change that caused this MapEvent.
- getVersion(int) - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- getVersion(int) - Method in interface com.tangosol.net.partition.VersionedPartitions
- 
Return the version last received for the given partition.
- getVersion(String) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Parse the specified GUID and return the partition-version.
- getVersionCache() - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Obtain the NamedCache object that holds the version data.
- getVersionId() - Method in class com.tangosol.io.pof.PofBufferReader
- 
Determine the version identifier of the user type that is currently being parsed.
- getVersionId() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Determine the version identifier of the user type that is currently being parsed.
- getVersionId() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Determine the version identifier of the user type that is currently being written.
- getVersionId() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Determine the version identifier of the user type that is currently being written.
- getVersionId() - Method in interface com.tangosol.io.pof.PofReader
- 
Determine the version identifier of the user type that is currently being parsed.
- getVersionId() - Method in interface com.tangosol.io.pof.PofWriter
- 
Determine the version identifier of the user type that is currently being written.
- getVersionIndicator() - Method in class com.tangosol.coherence.rest.util.JsonMap
- getVersionIndicator() - Method in interface com.tangosol.util.Versionable
- 
Get the version indicator for this object.
- getVersionMap() - Method in class com.tangosol.run.jca.SimpleValidator
- 
Obtain a map that holds the version objects for resources enlisted into a transaction.
- getVersions() - Method in interface com.tangosol.net.partition.VersionAwareMapListener
- 
Return a data structure that holds a mapping ofpartition -> version.
- getViewName() - Method in interface com.tangosol.net.management.ViewMBean
- 
Returns name of this cache.
- getViewName() - Method in class com.tangosol.net.management.ViewMBeanImpl
- getWaitingThread() - Method in class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
- 
Return the thread which is waiting on this notifier.
- getWaitMillis() - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Return the number of milliseconds to continue trying to obtain a lock in case when the locking is enforced.
- getWeaker() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Return the next weakest BackupStrength.
- getWellKnownAddresses() - Method in interface com.tangosol.net.ClusterDependencies
- 
Obtain the AddressProvider that provides the well known addresses (WKA) represented by InetSocketAddress objects.
- getWhere(NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Return the AST node that represents the where clause from the given AST node.
- getWildcardMatch(String) - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Determines the value the wildcard * declared in the resource name pattern for theResourceMappingmatches.
- getWorker() - Method in class com.tangosol.util.Daemon
- 
Accessor to obtain the Daemon worker object.
- getWorkerThreadCount() - Method in interface com.tangosol.net.ServiceDependencies
- 
Deprecated.Since 12.2.1, replaced by returning the same value fromServiceDependencies.getWorkerThreadCountMin()andServiceDependencies.getWorkerThreadCountMax().
- getWorkerThreadCountMax() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain the maximum number of background worker threads.
- getWorkerThreadCountMin() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain the minimum number of background worker threads.
- getWorkerThreadPriority() - Method in interface com.tangosol.net.ServiceDependencies
- 
Obtain the priority of the worker threads.
- getWrapper() - Method in exception com.tangosol.util.WrapperException
- getWriteBatchFactor() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the write-batch factor.
- getWriteBatchFactor(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return the write-batch-factor element is used to calculate the "soft-ripe" time for write-behind queue entries.
- getWriteBehindMillis() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the number of milliseconds between write-behind writes to the CacheStore or 0 if write-behind is not enabled.
- getWriteBehindSeconds() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the number of seconds between write-behind writes to the CacheStore or 0 if write-behind is not enabled.
- getWriteBuffer(int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Obtain a WriteBuffer starting at a particular offset within this WriteBuffer.
- getWriteBuffer(int) - Method in interface com.tangosol.io.WriteBuffer
- 
Obtain a WriteBuffer starting at a particular offset within this WriteBuffer.
- getWriteBuffer(int, int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Obtain a WriteBuffer for a portion of this WriteBuffer.
- getWriteBuffer(int, int) - Method in interface com.tangosol.io.WriteBuffer
- 
Obtain a WriteBuffer for a portion of this WriteBuffer.
- getWriteDelay(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return the time interval to defer asynchronous writes to the cache store for a write-behind queue.
- getWriteDelaySeconds(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return the write behind delay in seconds.
- getWriteHoldCount() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Queries the number of reentrant write holds on this lock by the current thread.
- getWriteMaxBatchSize() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the maximum size of the write-behind batch.
- getWriteMaxBatchSize(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return the maximum number of entries to write in a single storeAll operation.
- getWriteQueue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the queue of entries that are yet to be written.
- getWriter() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return thePrintWriterthat can be used by commands to display output.
- getWriter() - Static method in class com.tangosol.util.NullImplementation
- 
Factory method: Obtain a null implementation of a Writer.
- getWriteRequeueThreshold() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Return the maximum size of the write-behind queue for which failed CacheStore write operations are requeued or 0 if write-behind requeueing is disabled.
- getWriteRequeueThreshold(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return the size of the write-behind queue at which additional actions could be taken.
- getWriteThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Get the write-behind thread.
- getXml() - Method in interface com.tangosol.coherence.config.builder.ServiceBuilder
- 
Deprecated.
- getXml() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Deprecated.
- getXmlConfig() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Get the XML Configuration.
- getXmlConfig(ClassLoader, URL) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Return theXML configrelating to the provided ClassLoader and URL, or null.
- getXmlDocument() - Method in class com.tangosol.run.xml.XmlDocumentReference
- 
Retrieves a copy of theXmlDocumentspecified by theXmlDocumentReference.
- getXmlDocument(ClassLoader) - Method in class com.tangosol.run.xml.XmlDocumentReference
- 
Retrieves a copy of theXmlDocumentspecified by theXmlDocumentReference.
- getXmlElement() - Method in class com.tangosol.run.xml.SimpleAttribute
- 
Return theXmlElementin which theXmlAttributeis defined.
- getXmlElement() - Method in interface com.tangosol.run.xml.XmlAttribute
- 
Get theXmlElementin which theXmlAttributeis defined.
- getXmlInitParams(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Return the BDB init params needed to construct a BerkeleyDBBinaryStoreManager.
- getXmlName() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Return the XML element name used to generate an XML.
- getXmlValue() - Method in class com.tangosol.run.xml.SimpleAttribute
- 
Return theXmlValuedefined by theXmlAttribute.
- getXmlValue() - Method in interface com.tangosol.run.xml.XmlAttribute
- 
Get theXmlValuedefined by thgeXmlAttribute.
- getYear() - Method in class com.tangosol.io.pof.RawDate
- 
Determine the date's year value.
- getYears() - Method in class com.tangosol.io.pof.RawYearMonthInterval
- 
Determine the number of years in the year-month interval.
- GlobalSocketProviderProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse a <global-socket-provider> and produce the globalSocketProviderBuilder.
- GlobalSocketProviderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.GlobalSocketProviderProcessor
- grabBlock(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Grab a block object for the specified offset.
- greater(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted value is greater than the specified value.
- greaterEqual(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted value is greater than or equal to the specified value.
- GreaterEqualsFilter<T,E extends Comparable<? super E>> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value for "Greater or Equal" condition.
- GreaterEqualsFilter() - Constructor for class com.tangosol.util.filter.GreaterEqualsFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- GreaterEqualsFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.GreaterEqualsFilter
- 
Construct a GreaterEqualFilter for testing "Greater or Equal" condition.
- GreaterEqualsFilter(String, E) - Constructor for class com.tangosol.util.filter.GreaterEqualsFilter
- 
Construct a GreaterEqualFilter for testing "Greater or Equal" condition.
- GreaterEqualsOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the conditional greater than or equal to operator.
- GreaterEqualsOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
- 
Construct a GreaterEqualsOperator.
- GreaterFilter<T,E extends Comparable<? super E>> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value for "Greater" condition.
- GreaterFilter() - Constructor for class com.tangosol.util.filter.GreaterFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- GreaterFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.GreaterFilter
- 
Construct a GreaterFilter for testing "Greater" condition.
- GreaterFilter(String, E) - Constructor for class com.tangosol.util.filter.GreaterFilter
- 
Construct a GreaterFilter for testing "Greater" condition.
- GreaterOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the greater than operator.
- GreaterOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.GreaterOperator
- 
Construct a GreaterOperator.
- GroupAggregator<K,V,T,E,R> - Class in com.tangosol.util.aggregator
- 
The GroupAggregator provides an ability to split a subset of entries in an InvocableMap into a collection of non-intersecting subsets and then aggregate them separately and independently.
- GroupAggregator() - Constructor for class com.tangosol.util.aggregator.GroupAggregator
- 
Default constructor (necessary for the ExternalizableLite interface).
- GroupAggregator(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<? super K, ? super V, R>, Filter) - Constructor for class com.tangosol.util.aggregator.GroupAggregator
- 
Construct a GroupAggregator based on a specified ValueExtractor and underlying EntryAggregator.
- GroupAggregator.Parallel<K,V,T,E,R> - Class in com.tangosol.util.aggregator
- 
Deprecated.As of Coherence 12.2.1. Use GroupAggregator instead.
- groupBy(Filter<?>, ValueExtractor<? super T, ? extends K>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(Filter<?>, ValueExtractor<? super T, ? extends K>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(Filter<?>, ValueExtractor<? super T, ? extends K>, Remote.Comparator<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the grouping of entities by the specified extractor, ordered by the specified attribute within each group.
- groupBy(Filter<?>, ValueExtractor<? super T, ? extends K>, Remote.Comparator<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the grouping of entities by the specified extractor, ordered by the specified attribute within each group.
- groupBy(Filter<?>, ValueExtractor<? super T, ? extends K>, Remote.Supplier<M>, RemoteCollector<? super T, A, R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(Filter<?>, ValueExtractor<? super T, ? extends K>, Remote.Supplier<M>, RemoteCollector<? super T, A, R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(Filter<?>, ValueExtractor<? super T, ? extends K>, RemoteCollector<? super T, A, R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(Filter<?>, ValueExtractor<? super T, ? extends K>, RemoteCollector<? super T, A, R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(ValueExtractor<? super T, ? extends K>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(ValueExtractor<? super T, ? extends K>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(ValueExtractor<? super T, ? extends K>, Remote.Comparator<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the grouping of entities by the specified extractor, ordered by the specified attribute within each group.
- groupBy(ValueExtractor<? super T, ? extends K>, Remote.Comparator<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the grouping of entities by the specified extractor, ordered by the specified attribute within each group.
- groupBy(ValueExtractor<? super T, ? extends K>, Remote.Supplier<M>, RemoteCollector<? super T, A, R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(ValueExtractor<? super T, ? extends K>, Remote.Supplier<M>, RemoteCollector<? super T, A, R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(ValueExtractor<? super T, ? extends K>, RemoteCollector<? super T, A, R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the grouping of entities by the specified extractor.
- groupBy(ValueExtractor<? super T, ? extends K>, RemoteCollector<? super T, A, R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the grouping of entities by the specified extractor.
- grouping(InvocableMap.EntryAggregator<K, V, R>, Filter, String...) - Static method in class com.tangosol.util.Aggregators
- 
Create an instance of group aggregator based on a specified property or method name(s) and anInvocableMap.EntryAggregator.
- grouping(InvocableMap.EntryAggregator<K, V, R>, String...) - Static method in class com.tangosol.util.Aggregators
- 
Create an instance of group aggregator based on a specified property or method name(s) and anInvocableMap.EntryAggregator.
- grouping(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<? super K, ? super V, R>, Filter) - Static method in class com.tangosol.util.Aggregators
- 
Create an instance of group aggregator based on a specified property or method name(s) and anInvocableMap.EntryAggregator.
- grouping(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<K, V, R>) - Static method in class com.tangosol.util.Aggregators
- 
Create an instance of group aggregator based on a specified property or method name(s) and anInvocableMap.EntryAggregator.
- groupingBy(ValueExtractor<? super U, ? extends K>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorimplementing a "group by" operation on input elements of typeT, grouping elements according to a classification function, and returning the results in aMap.
- groupingBy(ValueExtractor<? super U, ? extends K>, Remote.Supplier<M>, RemoteCollector<? super T, A, D>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorimplementing a cascaded "group by" operation on input elements of typeT, grouping elements according to a classification function, and then performing a reduction operation on the values associated with a given key using the specified downstreamCollector.
- groupingBy(ValueExtractor<? super U, ? extends K>, RemoteCollector<? super T, A, D>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorimplementing a cascaded "group by" operation on input elements of typeT, grouping elements according to a classification function, and then performing a reduction operation on the values associated with a given key using the specified downstreamCollector.
- groupMembersByRole(Set<Member>) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Group the specified set of Members by their roles.
- GROUPS_PER_LINE - Static variable in class com.tangosol.io.Base64OutputStream
- 
The number of Base64 character groups in one line.
- grow() - Method in class com.tangosol.util.Dequeue
- 
Increase the capacity of the Dequeue.
- grow() - Method in class com.tangosol.util.SafeHashMap
- 
Resize the bucket array, rehashing all Entries.
- grow() - Method in class com.tangosol.util.SegmentedHashMap
- 
Resize the bucket array, rehashing all Entries.
- grow(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Grow the underlying byte array to at least the specified size.
- grow(int) - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Request that the buffer be grown based on the number of bytes currently required.
- grow(int) - Method in interface com.tangosol.io.nio.ByteBufferManager
- 
Request that the buffer be grown based on the number of bytes currently required.
- grow(int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Resize the bucket array to the specified size, rehashing all Entries.
- Grpc - com.tangosol.net.Coherence.Mode
- 
TheCoherenceinstance should run as a non-cluster member gRPC client.
- GRPC - com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
- GrpcConnectionMetrics - Class in com.oracle.coherence.grpc.proxy
- 
A holder for gRPC connection metrics.
- GrpcConnectionMetrics.ConnectionMetricsMBean - Interface in com.oracle.coherence.grpc.proxy
- 
A MBean to track gRPC connections.
- GrpcFixed - com.tangosol.net.Coherence.Mode
- 
TheCoherenceinstance should run as a non-cluster member gRPC client, configured with a fixed address and port.
- GrpcMetricsInterceptor - Class in com.oracle.coherence.grpc.proxy
- 
AServerInterceptorthat enables capturing of gRPC metrics.
- GrpcMetricsInterceptor(GrpcProxyMetrics) - Constructor for class com.oracle.coherence.grpc.proxy.GrpcMetricsInterceptor
- 
Create aGrpcMetricsInterceptor.
- GrpcProxyMetrics - Class in com.oracle.coherence.grpc.proxy
- 
The gRPC Proxy metrics MBean implementation.
- GrpcProxyMetrics(String, DaemonPoolExecutor.DaemonPoolManagement) - Constructor for class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- 
Create aGrpcProxyMetrics.
- GrpcProxyMetricsMBean - Interface in com.oracle.coherence.grpc.proxy
- 
The gRPC Proxy metrics MBean.
- GrpcProxyService - Interface in com.oracle.coherence.grpc.proxy
- 
An interface implemented by gRPC proxy services.
- GrpcServerBuilderProvider - Interface in com.oracle.coherence.grpc.proxy
- 
Deprecated.the gRPC proxy server is configured and built as a normal proxy service configured with a gRPC acceptor in the system cache configuration file
- GrpcServerConfiguration - Interface in com.oracle.coherence.grpc.proxy
- 
A class that can configure gRPC server builders prior to them being used to start the servers.
- GrpcServerController - Class in com.oracle.coherence.grpc.proxy
- 
A controller class that starts and stops the default gRPC server by responding toDefaultCacheServerlifecycle events.
- GrpcServerController.Listener - Class in com.oracle.coherence.grpc.proxy
- 
A listener that will start the gRPC server base onCoherenceorDefaultCacheServerlifecycle events.
- GrpcServiceDependencies - Interface in com.oracle.coherence.grpc.proxy
- 
The dependencies for a gRPC bindable service.
- GrpcServiceDependencies.DefaultDependencies - Class in com.oracle.coherence.grpc.proxy
- 
The defaultGrpcServiceDependenciesimplementation.
- guard(Guardable) - Method in interface com.tangosol.net.Guardian
- 
Register the specified Guardable based on the Guardian's SLA parameters.
- guard(Guardable, long, float) - Method in interface com.tangosol.net.Guardian
- 
Register the specified Guardable with the specified SLA parameters.
- GUARD_RECOVERY - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
- 
The recovery threshold to use for guarded execution of write-behind/refresh-ahead threads.
- Guardable - Interface in com.tangosol.net
- 
A Guardable is a logical execution unit whose lifetime may be guarded by a Guardian.
- Guardian - Interface in com.tangosol.net
- 
A Guardian is responsible for monitoring the registeredGuardableobjects.
- GUARDIAN_EARLY_THRESHOLD - Static variable in class com.tangosol.net.GuardSupport
- 
The threshold before which than which a guardian considers itself early in checking its guardables.
- GUARDIAN_LATE_THRESHOLD - Static variable in class com.tangosol.net.GuardSupport
- 
The threshold past which a guardian considers itself late in checking its guardables.
- GUARDIAN_LOG_INTERVAL - Static variable in class com.tangosol.net.GuardSupport
- 
The minimum interval at which the Guardian should log thread dumps.
- GUARDIAN_MAX_CHECK_INTERVAL - Static variable in class com.tangosol.net.GuardSupport
- 
The maximum interval at which the Guardian thread should call check() to verify its guardables.
- Guardian.GuardContext - Interface in com.tangosol.net
- 
A GuardContext represents the lifecycle status of a Guardable.
- guardIfNeeded() - Method in class com.tangosol.util.Daemon
- 
If this Daemon has a Guardian and SLA policy specified, ensure that it is registered with its Guardian.
- GuardSupport - Class in com.tangosol.net
- 
A concrete implementation of Guardian/Guardable interactions.
- GuardSupport(Guardian) - Constructor for class com.tangosol.net.GuardSupport
- 
Construct a GuardSupport for the specified Guardian.
- GuardSupport.Context - Class in com.tangosol.net
- 
Base implementation for GuardContext's used by GuardSupport.
- GUIDHelper - Class in com.tangosol.persistence
- 
Static helper methods to encode and decode the attributes related to the storage of a persistent form of a partition.
- GUIDHelper() - Constructor for class com.tangosol.persistence.GUIDHelper
- GUIDHelper.GUIDResolver - Class in com.tangosol.persistence
- 
Resolver used during a recovery to discover the newest available GUID for a given partition.
- GUIDResolver(int) - Constructor for class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Construct a GUIDResolver for the specified partition-count.
H
- handle(Callback[]) - Method in class com.tangosol.net.security.SimpleHandler
- 
Invoke an array of Callbacks.
- HANDLE_COMPILE_EXPRESSION - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
MethodHandle for method compileExpression(String expr, ParserContext ctx) from org.mvel2.MVEL.
- HANDLE_COMPILE_SET_EXPRESSION - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
MethodHandle for method compileSetExpression(String expr, ParserContext ctx) from org.mvel2.MVEL.
- HANDLE_EXECUTE_EXPRESSION - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
MethodHandle for method executeExpression(Object compiledExpr, Object ctx) from org.mvel2.MVEL.
- HANDLE_EXECUTE_SET_EXPRESSION - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
MethodHandle for method executeSetExpression(Serializable compiledExpr, Object ctx, Object value) from org.mvel2.MVEL.
- HANDLE_PARSER_CONFIGURATION_SET_CLASS_LOADER - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
MethodHandle for method setClassLoader() from org.mvel2.ParserConfiguration.
- HANDLE_PARSER_CONTEXT_ADD_PACKAGE_IMPORT - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
MethodHandle for method addPackageImport(String) from org.mvel2.ParserContext.
- HANDLE_PARSER_CONTEXT_GET_PARSER_CONFIGURATION - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
MethodHandle for method getParserConfiguration() from org.mvel2.ParserContext.
- handleEnsureServiceException(RuntimeException) - Method in class com.tangosol.net.DefaultCacheServer
- 
Invoked if starting a service raises an exception.
- handleError(Throwable, StreamObserver<Resp>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
A handler method that will callStreamObserver.onError(Throwable)if the error parameter is notnull.
- handleError(Resp, Throwable) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
A handler method that will return the response if there is no error or if there is an error then ensure that it is aStatusRuntimeException.
- handleErrorOrComplete(Throwable, StreamObserver<Resp>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
A handler method that will callStreamObserver.onError(Throwable)if the error parameter is notnullotherwise callsStreamObserver.onCompleted().
- handleMapOfEntries(RequestHolder<?, Map<Binary, Binary>>, Throwable, StreamObserver<Entry>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
Handle the result of the asynchronous invoke all request sending the results, or any errors to theStreamObserver.
- handleMapOfEntries(RequestHolder<?, Map<Binary, Binary>>, Throwable, StreamObserver<Entry>, boolean) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
Handle the result of the asynchronous invoke all request sending the results, or any errors to theStreamObserver.
- handleSetOfEntries(RequestHolder<?, Set<Map.Entry<Binary, Binary>>>, Throwable, StreamObserver<Entry>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
Handle the result of the asynchronous entry set request sending the results, or any errors to theStreamObserver.
- handleSetOfEntries(RequestHolder<?, Set<Map.Entry<Binary, Binary>>>, Throwable, StreamObserver<Entry>, boolean) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
Handle the result of the asynchronous entry set request sending the results, or any errors to theStreamObserver.
- handleStream(RequestHolder<?, ? extends Iterable<Binary>>, Throwable, StreamObserver<BytesValue>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- handleStream(Iterable<Resp>, Throwable, StreamObserver<Resp>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
A handler method that streams results from anIterableto aStreamObserverand completes theStreamObserver, or if an error is provided callsStreamObserver.onError(Throwable).
- handleStream(Stream<Resp>, Throwable, StreamObserver<Resp>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
A handler method that streams results to aStreamObserverand completes theStreamObserveror if an error is provided callsStreamObserver.onError(Throwable).
- handleStreamOfEntries(RequestHolder<?, ?>, Stream<Map.Entry<Binary, Binary>>, StreamObserver<Entry>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
Handle the result of the asynchronous invoke all request sending the results, or any errors to theStreamObserver.
- handleStreamOfEntries(RequestHolder<?, ?>, Stream<Map.Entry<Binary, Binary>>, StreamObserver<Entry>, boolean) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
Handle the result of the asynchronous invoke all request sending the results, or any errors to theStreamObserver.
- handleUnary(R, Throwable, StreamObserver<R>) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
Handle an unary request.
- hasArchivedSnapshot(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Return true if the specified snapshot exists for this archiver.
- hasCurrent() - Method in class com.tangosol.run.xml.SimpleParser
- 
Determine if there is a current token.
- hasDomain(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return true if the Canonical name is prefixed with the domain name.
- hasElement(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Return true iff the specified element has a child element of the specified name.
- hasEvent() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if an event has occurred against the Entry for which this Status exists.
- hasEvent() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if an event has occurred against the Entry for which this Status exists.
- hasExpiry() - Method in class com.tangosol.net.cache.OverflowMap.ExpirableStatus
- 
Determine if this Status represents an entry that will automatically expire.
- hasExpiry() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if this Status represents an entry that will automatically expire.
- hasFilterAnnotation() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Returnstrueif this listener has a filter annotation to resolve.
- hash(boolean[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the boolean array value.
- hash(boolean[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the boolean array value.
- hash(boolean, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the boolean value.
- hash(boolean, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the boolean value.
- hash(byte[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the byte array value.
- hash(byte[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the byte array value.
- hash(byte, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the byte value.
- hash(byte, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the byte value.
- hash(char[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the char array value.
- hash(char[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the char array value.
- hash(char, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the char value.
- hash(char, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the char value.
- hash(double[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the double array value.
- hash(double[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the double array value.
- hash(double, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the double value.
- hash(double, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the double value.
- hash(float[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the float array value.
- hash(float[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the float array value.
- hash(float, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the float value.
- hash(float, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the float value.
- hash(int[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the int array value.
- hash(int[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the int array value.
- hash(int, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the int value.
- hash(int, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the int value.
- hash(long[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the long array value.
- hash(long[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the long array value.
- hash(long, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the long value.
- hash(long, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the long value.
- hash(short[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the short array value.
- hash(short[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the short array value.
- hash(short, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the short value.
- hash(short, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the short value.
- hash(Object) - Method in class com.tangosol.run.xml.ArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
compute a hash code for the passed object.
- hash(Object) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
compute a hash code for the passed object.
- hash(Object[], int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the Object array value.
- hash(Object[], int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the Object array value.
- hash(Object, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the Object value.
- hash(Object, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the Object value.
- hash(String) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Shift the value into a different charset order.
- hash(String) - Static method in class com.tangosol.util.HashHelper
- 
Shift the value into a different charset order.
- hash(Collection, int) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Calculate a running hash using the Collection value.
- hash(Collection, int) - Static method in class com.tangosol.util.HashHelper
- 
Calculate a running hash using the Collection value.
- hashCode() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- hashCode() - Method in class com.oracle.coherence.cdi.AnnotationInstance
- hashCode() - Method in class com.oracle.coherence.cdi.AnnotationLiteral
- hashCode() - Method in class com.oracle.coherence.common.base.IdentityHolder
- hashCode() - Method in class com.oracle.coherence.common.base.MutableLong
- hashCode() - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- hashCode() - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- hashCode() - Method in class com.oracle.coherence.grpc.proxy.GrpcMetricsInterceptor
- hashCode() - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.MapListenerAdapter
- hashCode() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
- hashCode() - Method in class com.tangosol.coherence.config.SchemeMappingRegistry.SchemeMappingKey
- hashCode() - Method in class com.tangosol.coherence.config.xml.processor.TopicMappingProcessor
- hashCode() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- hashCode() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- hashCode() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- hashCode() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryListenerRegistration
- hashCode() - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- hashCode() - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Determine a hash value for the MvelExtractor object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Determine a hash value for the MvelManipulator object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Return hash code for this object.
- hashCode() - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Return hash code for this object.
- hashCode() - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Determine a hash value for the MvelUpdater object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Computes the hash code of the BerkeleyDBBinaryStoreManager.
- hashCode() - Method in class com.tangosol.io.pof.PofPrincipal
- 
Return a hashcode for this Principal.
- hashCode() - Method in class com.tangosol.io.pof.RawDate
- 
Obtain the hashcode for this object.
- hashCode() - Method in class com.tangosol.io.pof.RawDateTime
- 
Obtain the hashcode for this object.
- hashCode() - Method in class com.tangosol.io.pof.RawDayTimeInterval
- hashCode() - Method in class com.tangosol.io.pof.RawQuad
- 
Obtain the hashcode for this object.
- hashCode() - Method in class com.tangosol.io.pof.RawTime
- 
Obtain the hashcode for this object.
- hashCode() - Method in class com.tangosol.io.pof.RawTimeInterval
- hashCode() - Method in class com.tangosol.io.pof.RawYearMonthInterval
- hashCode() - Method in class com.tangosol.io.pof.reflect.SimplePofPath
- 
Determine a hash value for the SimplePofPath object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Returns the hash code value for this entry.
- hashCode() - Method in class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
- 
Determine a hash value for the EventRouter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Returns the hash code value for this map.
- hashCode() - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
- hashCode() - Method in class com.tangosol.net.ClusterPermission
- 
Return the hash code value for this ClusterPermission object.
- hashCode() - Method in class com.tangosol.net.CompositeAddressProvider
- 
Return the hash code for this AddressProvider.
- hashCode() - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
- 
Return the hash code for this SocketAddressProvider.
- hashCode() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Return the hash code for this ProvidedAddress.
- hashCode() - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Return the hash code for this AddressProvider.
- hashCode() - Method in class com.tangosol.net.events.NamedEventInterceptor
- hashCode() - Method in class com.tangosol.net.management.ObjectNameExcludeFilter
- 
Determine a hash value for the ObjectNameExcludeFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.net.management.ViewMBeanImpl
- hashCode() - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- hashCode() - Method in class com.tangosol.net.partition.Ownership
- 
Determine the hash code for this Ownership object.
- hashCode() - Method in class com.tangosol.net.partition.PartitionSet
- 
Returns a hash code value for this PartitionSet.
- hashCode() - Method in class com.tangosol.net.partition.SimplePartitionKey
- hashCode() - Method in class com.tangosol.net.RefreshableAddressProvider
- 
Return the hash code for this SocketAddressProvider.
- hashCode() - Method in class com.tangosol.net.security.SimpleHandler
- 
Return a hashcode for this principal.
- hashCode() - Method in interface com.tangosol.net.SocketAddressProvider
- 
Return the hash code for this SocketAddressProvider.
- hashCode() - Method in class com.tangosol.net.ssl.AbstractCertificateLoader
- hashCode() - Method in class com.tangosol.net.ssl.AbstractKeyStoreLoader
- hashCode() - Method in class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- hashCode() - Method in class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
- hashCode() - Method in class com.tangosol.run.xml.QualifiedName
- hashCode() - Method in class com.tangosol.run.xml.SimpleDocument
- 
Provide a hash value for this XML document and all of its contained information.
- hashCode() - Method in class com.tangosol.run.xml.SimpleElement
- 
Provide a hash value for this XML element and all of its contained information.
- hashCode() - Method in class com.tangosol.run.xml.SimpleValue
- 
Provide a hash value for this XML value.
- hashCode() - Method in class com.tangosol.run.xml.XmlBean
- 
Determine a hash code for this value object.
- hashCode() - Method in interface com.tangosol.run.xml.XmlDocument
- 
Provide a hash value for this XML document and all of its contained information.
- hashCode() - Method in interface com.tangosol.run.xml.XmlElement
- 
Provide a hash value for this XML element and all of its contained information.
- hashCode() - Method in interface com.tangosol.run.xml.XmlValue
- 
Provide a hash value for this XML value.
- hashCode() - Method in class com.tangosol.util.AbstractByteSequence
- hashCode() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.Entry
- 
Returns the hash code value for this map entry.
- hashCode() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns the hash code value for this Map.
- hashCode() - Method in class com.tangosol.util.AbstractLongArray
- hashCode() - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Returns a hash code value for this object.
- hashCode() - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- hashCode() - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Determine a hash value for the MultiExtractor object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Determine a hash value for the GroupAggregator object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.Binary
- 
Returns a hash code value for the object.
- hashCode() - Method in class com.tangosol.util.CacheCollator
- 
Generates the hash code for this Collator.
- hashCode() - Method in class com.tangosol.util.ClassFilter
- 
Determine a hash value for the ClassFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Return the hash code for this comparator.
- hashCode() - Method in class com.tangosol.util.comparator.SafeComparator
- 
Return the hash code for this comparator.
- hashCode() - Method in class com.tangosol.util.CompositeKey
- 
Returns a hash code value for this object.
- hashCode() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- hashCode() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- hashCode() - Method in class com.tangosol.util.ConverterCollections.ConverterHolder
- hashCode() - Method in class com.tangosol.util.ConverterCollections.ConverterList
- hashCode() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- hashCode() - Method in class com.tangosol.util.ConverterCollections.ConverterSet
- hashCode() - Method in class com.tangosol.util.CopyOnWriteMap
- hashCode() - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
Compute a hash value for the AbstractCompositeExtractor object Ifcanonical nameis non-null, return hashcode of canonical name string; otherwise, compute the hashcode as a sum of allhashCodes.
- hashCode() - Method in class com.tangosol.util.extractor.AbstractExtractor
- 
HashCode value is hashCode of non-nullcanonical name; otherwise, it is the identity hashCode value.
- hashCode() - Method in class com.tangosol.util.extractor.CompositeUpdater
- hashCode() - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
HashCode value is hashCode of non-nullcanonical name; otherwise, it is the identity hashCode value.
- hashCode() - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
HashCode value is hashCode of non-nullcanonical name; otherwise, it is the identity hashCode value.
- hashCode() - Method in class com.tangosol.util.extractor.IdentityExtractor
- 
Return the hashCode ofcanonical name.
- hashCode() - Method in class com.tangosol.util.extractor.KeyExtractor
- 
Compute hashCode from underlyingValueExtractor.
- hashCode() - Method in class com.tangosol.util.extractor.PofExtractor
- 
Return the hashCode of a non-nullcanonical name; otherwise, the hash code isPofNavigator.hashCode() implementation.
- hashCode() - Method in class com.tangosol.util.extractor.PofUpdater
- 
Determine a hash value for the PofUpdater object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
HashCode value is hashCode of non-nullcanonical name; otherwise, it is the hashCode ofsNamepassed to {#link ReflectionExtractor(String)}.
- hashCode() - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Determine a hash value for the ReflectionUpdater object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
HashCode value is hashCode of non-nullcanonical name; otherwise, it is the hashCode ofsNamepassed to {#link UniversalExtractor(String)}.
- hashCode() - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Determine a hash value for the UniversalUpdater object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Determine a hash value for the AlwaysFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.ArrayFilter
- 
Determine a hash value for the ArrayFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.CacheEventFilter
- 
Determine a hash value for the CacheEventFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Determine a hash value for the ComparisonFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.FilterTrigger
- 
Determine a hash value for the FilterTrigger object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Determine a hash value for the KeyAssociatedFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.MapEventFilter
- 
Determine a hash value for the MapEventFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Determine a hash value for the MapEventTransformerFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.NeverFilter
- 
Determine a hash value for the NeverFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.NotFilter
- 
Determine a hash value for the NotFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Determine a hash value for the PartitionedFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.PresentFilter
- 
Determine a hash value for the PresentFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- 
Determine a hash value for the ValueChangeEventFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Returns the hash code value for this MapIndex.
- hashCode() - Method in class com.tangosol.util.Fragment
- hashCode() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent.Discriminator
- hashCode() - Method in class com.tangosol.util.ImmutableArrayList.ListView
- hashCode() - Method in class com.tangosol.util.ImmutableArrayList.SetView
- hashCode() - Method in class com.tangosol.util.ImmutableArrayList.SortedSetView
- hashCode() - Method in class com.tangosol.util.ImmutableMultiList.ListView
- 
Returns the hash code value for this list.
- hashCode() - Method in class com.tangosol.util.ImmutableMultiList.SetView
- 
Returns the hash code value for this set.
- hashCode() - Method in class com.tangosol.util.InflatableCollection
- hashCode() - Method in class com.tangosol.util.InflatableList
- hashCode() - Method in class com.tangosol.util.InvocableMapHelper.IndexAdapter
- 
Return a hash code value for the IndexMapListener object.
- hashCode() - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Return a hash code value for the SimpleEntry object.
- hashCode() - Method in class com.tangosol.util.MapListenerSupport.WrapperListener
- 
Determine a hash value for the WrapperListener object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.NullFilter
- 
Determine a hash value for the NullFilter object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.NullImplementation.NullMap
- hashCode() - Method in class com.tangosol.util.NullImplementation.NullSet
- hashCode() - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Determine a hash value for the ValueExtractor object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.CompositeProcessor
- 
Determine a hash value for the ConditionalProcessor object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Determine a hash value for the ConditionalProcessor object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.ConditionalPut
- 
Determine a hash value for the ConditionalPut object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Determine a hash value for the ConditionalPutAll object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Determine a hash value for the ConditionalRemove object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.ExtractorProcessor
- 
Determine a hash value for the ExtractorProcessor object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.PreloadRequest
- 
Determine a hash value for the PreloadRequest object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Determine a hash value for the PropertyManipulator object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Determine a hash value for the PropertyProcessor object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.UpdaterProcessor
- 
Determine a hash value for the UpdaterProcessor object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.VersionedPut
- 
Determine a hash value for the VersionedPut object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Determine a hash value for the VersionedPutAll object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Returns the hash code value for this collection.
- hashCode() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Returns the hash code value for this collection.
- hashCode() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
- 
Returns the hash code value for this map entry.
- hashCode() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
- 
Returns the hash code value for this Iterator.
- hashCode() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns the hash code value for this map.
- hashCode() - Method in class com.tangosol.util.SafeHashMap.Entry
- 
Returns the hash code value for this map entry.
- hashCode() - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Returns the hash code value for this map entry.
- hashCode() - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns the hash code value for this Map.
- hashCode() - Method in class com.tangosol.util.SimpleHolder
- hashCode() - Method in class com.tangosol.util.SimpleMapEntry
- 
Returns the hash code value for this map entry.
- hashCode() - Method in class com.tangosol.util.SimpleMapIndex
- 
Returns the hash code value for this MapIndex.
- hashCode() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- hashCode() - Method in class com.tangosol.util.SimpleResourceRegistry.RegistryKey
- hashCode() - Method in class com.tangosol.util.SubList
- hashCode() - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Determine a hash value for the ExtractorEventTransformer object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
- 
Determine a hash value for the SemiLiteEventTransformer object according to the generalObject.hashCode()contract.
- hashCode() - Method in class com.tangosol.util.UID
- 
Determine a hash code for the UID object.
- hashCode() - Method in class com.tangosol.util.UUID
- 
Determine a hash code for the UUID object.
- hashCode() - Method in interface com.tangosol.util.ValueExtractor
- 
Return the hashCode for this extractor.
- hashCode() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- hashCode() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- hashCode() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- hashCode() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- hashCode() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- hashCode() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- hashCode() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- hashCode() - Method in class com.tangosol.util.WrapperObservableMap
- hashCode(Object) - Static method in class com.oracle.coherence.common.base.HashHelper
- 
Return the hash code for the supplied object or 0 for null.
- hashCode(Object) - Static method in class com.tangosol.util.Base
- 
Return the hash code for the supplied object or 0 for null.
- hashCode(V) - Method in interface com.oracle.coherence.common.base.Hasher
- 
Return a hash for the specified object.
- hashCode(V) - Method in class com.oracle.coherence.common.base.IdentityHasher
- 
Return a hash for the specified object.
- hashCode(V) - Method in class com.oracle.coherence.common.base.NaturalHasher
- 
Return a hash for the specified object.
- HashcodeComparator() - Constructor for class com.tangosol.net.cache.SimpleOverflowMap.HashcodeComparator
- hashElement(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Provide a hash value for the XML element and all of its contained information.
- HashEncoded - Interface in com.tangosol.util
- 
HashEncoded interface represents an ability to retrieve an encoded hash value; most commonly used to calculate a partition id.
- Hasher<V> - Interface in com.oracle.coherence.common.base
- 
A Hasher provides an external means for producing hash codes and comparing objects for equality.
- HashHelper - Class in com.oracle.coherence.common.base
- 
This abstract class contains helper functions for calculating hash code values for any group of java intrinsics.
- HashHelper - Class in com.tangosol.util
- 
This abstract class contains helper functions for calculating hash code values for any group of java intrinsics.
- HashHelper() - Constructor for class com.oracle.coherence.common.base.HashHelper
- HashHelper() - Constructor for class com.tangosol.util.HashHelper
- hashValue(XmlValue) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Provide a hash value for the XML value.
- hasListeners() - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Determine if this map has any listeners at all.
- hasListeners() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine if the OldCache has any listeners at all.
- hasListeners() - Method in class com.tangosol.net.cache.OverflowMap
- 
Determine if the OverflowMap has any listeners at all.
- hasListeners() - Method in class com.tangosol.util.ObservableHashMap
- 
Determine if the OverflowMap has any listeners at all.
- hasListeners() - Method in class com.tangosol.util.WrapperObservableMap
- 
Determine if the OverflowMap has any listeners at all.
- hasLocalSnapshot(PersistenceEnvironment<ReadBuffer>, String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Return true if the specified snapshot exists for the PersistenceEnvironment.
- hasMoreElements() - Method in class com.tangosol.util.ChainedEnumerator
- 
Tests if this enumeration contains more elements.
- hasMoreElements() - Method in class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Tests if this enumeration contains more elements.
- hasMoreElements() - Method in class com.tangosol.util.Dequeue
- 
Determines if the Dequeue contains more elements.
- hasMoreElements() - Method in class com.tangosol.util.FilterEnumerator
- 
Tests if this enumeration contains more elements.
- hasMoreElements() - Method in class com.tangosol.util.IteratorEnumerator
- 
Tests if this enumeration contains more elements.
- hasMoreElements() - Method in class com.tangosol.util.NullImplementation.NullEnumerator
- 
Tests if this enumeration contains more elements.
- hasMoreElements() - Method in class com.tangosol.util.SimpleEnumerator
- 
Tests if this enumeration contains more elements.
- hasNext() - Method in class com.tangosol.coherence.dsltools.termtrees.Term.TermIterator
- hasNext() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterator
- hasNext() - Method in class com.tangosol.coherence.jcache.common.MapEntryIteratorToCacheEntryIteratorAdapter
- hasNext() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache.EntryIterator
- hasNext() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache.EntryIterator
- hasNext() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
- hasNext() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet.EntrySetIterator
- hasNext() - Method in class com.tangosol.run.xml.SimpleElement.ElementIterator
- hasNext() - Method in class com.tangosol.run.xml.SimpleParser
- 
Determine if there is a next token.
- hasNext() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.EntrySetIterator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection.ValuesIterator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- hasNext() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.ChainedEnumerator
- 
Tests if this Iterator contains more elements.
- hasNext() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
- hasNext() - Method in class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Determine if this Iterator contains more elements.
- hasNext() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- hasNext() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.DeltaSet.DeltaIterator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.Dequeue
- 
Tests if this Iterator contains more elements.
- hasNext() - Method in class com.tangosol.util.EnumerationIterator
- 
Tests if this Iterator contains more elements.
- hasNext() - Method in class com.tangosol.util.FilterEnumerator
- 
Tests if this Iterator contains more elements.
- hasNext() - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
- hasNext() - Method in class com.tangosol.util.IteratorEnumerator
- 
Tests if this Iterator contains more elements.
- hasNext() - Method in interface com.tangosol.util.LongArray.Iterator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.NullImplementation.NullEnumerator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.PagedIterator
- 
Check whether or not the iterator has more elements.
- hasNext() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Returns true if this list iterator has more elements when traversing the list in the forward direction.
- hasNext() - Method in class com.tangosol.util.SimpleEnumerator
- 
Tests if this Iterator contains more elements.
- hasNext() - Method in class com.tangosol.util.SimpleLongArray.Iterator
- 
Returns true if the iteration has more elements.
- hasNext() - Method in class com.tangosol.util.SimpleStreamer
- hasNext() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- hasPendingEvents() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Determines if there are any pendingEvents for theFiniteStateMachineto process.
- hasPrefix() - Method in class com.tangosol.run.xml.QualifiedName
- 
Returns boolean based on if theQualifiedNamehas a namespace prefix.
- hasPrevious() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- hasPrevious() - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
- hasPrevious() - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Returns true if this list iterator has more elements when traversing the list in the reverse direction.
- hasPrevious() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
- hasQueuedThread(Thread) - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Queries whether the given thread is waiting to acquire this lock.
- hasQueuedThread(Thread) - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Queries whether the given thread is waiting to acquire this lock.
- hasQueuedThreads() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Queries whether any threads are waiting to acquire this lock.
- hasQueuedThreads() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Queries whether any threads are waiting to acquire this lock.
- hasRemaining(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Determine if it is possible to write something of a specified length to the underlying buffer.
- hasSession() - Method in interface com.tangosol.net.SessionProvider.Context
- 
Returntrueif the context contains a non-nullSessioninstance.
- hasSession() - Method in class com.tangosol.net.SessionProvider.DefaultContext
- hasSession(String) - Method in class com.tangosol.net.Coherence
- hasSubscription(long) - Method in interface com.tangosol.net.PagedTopicService
- 
Determine whether a subscriber group exists.
- hasTimezone() - Method in class com.tangosol.io.pof.RawTime
- 
Determine if the time value has an explicit timezone.
- hasTransformerAnnotation() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Returnstrueif this listener has a transformer annotation to resolve.
- HEAD - Static variable in interface com.tangosol.net.partition.VersionAwareMapListener
- 
A constant that suggests to an event source to send all future events.
- headBag(E) - Method in class com.tangosol.util.SortedBag
- 
Returns a view of the portion of this bag whose elements are strictly less than toElement.
- headBag(E) - Method in class com.tangosol.util.SortedBag.ViewBag
- 
Returns a view of the portion of this bag whose elements are strictly less than toElement.
- headChildrenTermEqual(Term) - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Find the Term amongst the children whose functor equals the given functor.
- HEADER_SIZE - Static variable in class com.tangosol.net.TcpDatagramSocket.Impl
- 
The fixed header size for packets.
- headMap(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedMap
- 
Returns a view of the portion of this sorted map whose keys are strictly less than toKey.
- headMap(Object) - Method in class com.tangosol.util.SafeSortedMap
- headMap(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- headMap(Object, boolean) - Method in class com.tangosol.util.SafeSortedMap
- headMap(Object, boolean) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- headMap(K) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- headMap(TK) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- headSet(E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
- headSet(Object) - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns a view of the portion of this sorted set whose elements are found in the set in a position before toElement.
- headSet(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedSet
- 
Returns a view of the portion of this sorted set whose elements are strictly less than toElement.
- headSet(Object) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- headSet(Object, boolean) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- headSet(T) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- headsMatch(NodeTerm, NodeTerm) - Static method in class com.tangosol.coherence.dslquery.statement.AbstractStatementBuilder
- 
Test to see if the AST for the group-by is equal to the head of the list from the select clause AST.
- HEALTH_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the HealthCheck MBeans.
- HealthCheck - Interface in com.tangosol.util
- 
A class that can return its health status
- HealthCheckClient - Class in com.tangosol.util
- 
A simple executable class that will perform a health check query against a specific URL.
- HealthCheckClient() - Constructor for class com.tangosol.util.HealthCheckClient
- HealthProcessor - Class in com.tangosol.coherence.config.xml.processor
- HealthProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.HealthProcessor
- HealthProcessor.XMLHealthCheckDependencies - Class in com.tangosol.coherence.config.xml.processor
- heartbeat() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Issue a service guardian "heartbeat" for the current thread.
- heartbeat() - Method in interface com.tangosol.net.Guardian.GuardContext
- 
Called by the Guardable to signal that it is still alive.
- heartbeat() - Method in class com.tangosol.net.GuardSupport.Context
- 
Called by the Guardable to signal that it is still alive.
- heartbeat() - Static method in class com.tangosol.net.GuardSupport
- 
Issue a heartbeat on the GuardContext associated with the current thread.
- heartbeat() - Method in interface com.tangosol.net.topic.Subscriber
- 
Send a heartbeat to the server to keep this subscriber alive.
- heartbeat() - Method in class com.tangosol.util.Daemon
- 
If this Daemon is being guarded, issue a heartbeat to the Guardian.
- heartbeat(long) - Method in interface com.tangosol.net.Guardian.GuardContext
- 
Called by the Guardable to signal that it is still alive, and that it should not be considered timed out for the specified number of milliseconds.
- heartbeat(long) - Method in class com.tangosol.net.GuardSupport.Context
- 
Called by the Guardable to signal that it is still alive, and that it should not be considered timed out for the specified number of milliseconds.
- heartbeat(long) - Static method in class com.tangosol.net.GuardSupport
- 
Issue a heartbeat of the specified duration on the GuardContext associated with the current thread.
- heartbeat(long) - Method in class com.tangosol.util.Daemon
- 
If this Daemon is being guarded, issue a heartbeat to the Guardian.
- HELP_COMMAND_LINE_ARG - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Command line argument used to output usage.
- HelpCommandOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder.HelpCommandOPToken
- 
Construct a HelpCommandOPToken.
- Helper - Class in com.tangosol.coherence.jcache.common
- 
Helper methods for the Coherence JCache implementation.
- Helper() - Constructor for class com.tangosol.coherence.jcache.common.Helper
- HelpQueryPlusStatement() - Constructor for class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder.HelpQueryPlusStatement
- HelpStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
- 
AStatementBuilderthat builds the QueryPlus "HELP" command.
- HelpStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
- HelpStatementBuilder.HelpCommandOPToken - Class in com.tangosol.coherence.dslquery.queryplus
- 
A CohQL OPToken representing the QueryPlus "help" command.
- HelpStatementBuilder.HelpQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
- 
A class representing the QueryPlus "HELP" command.
- HEX - Static variable in class com.oracle.coherence.common.base.Formatting
- 
Hex digits.
- hexValue(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Returns the integer value of a hexadecimal digit.
- hexValue(char) - Static method in class com.tangosol.util.Base
- 
Returns the integer value of a hexadecimal digit.
- HIGH - com.tangosol.net.events.annotation.Interceptor.Order
- 
Indicates an intention to be higher in the chain ofEventInterceptors.
- higher(Object) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- higherEntry(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- higherKey(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- HistoricCacheEvent(ObservableMap, int, Object, Object, Object, boolean, Object) - Constructor for class com.tangosol.net.cache.OverflowMap.HistoricCacheEvent
- 
Create a Historic CacheEvent that contains the most recent value before the now-current value.
- Holder<V> - Interface in com.oracle.coherence.common.base
- 
A Holder is a reference like object, i.e. it simply holds another object.
- honorOrder() - Method in class com.tangosol.util.filter.ArrayFilter
- 
Deprecated, for removal: This API element is subject to removal in a future version.
- HostnameVerifierBuilder() - Constructor for class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.HostnameVerifierBuilder
- HTTP_COMMAND_LINE_ARG - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Command line argument to start HTTP server.
- HTTP_PORT_PROPERTY - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Property name to specify HTTP port.
- HttpAcceptorDependenciesProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorto produce aHttpAcceptorDependenciesfrom a <http-acceptor%gt; configuration.
- HttpAcceptorDependenciesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.HttpAcceptorDependenciesProcessor
I
- id(int) - Static method in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
Return the order that will use the specified unit-of-order for all async operations, regardless of whether they were invoked from the same client thread or not.
- id(int) - Static method in class com.tangosol.net.topic.Publisher.OrderBy
- 
Return an OrderBy that will ensure ordering ofsent valuesacross all threads which share the same id.
- Identifiable - Interface in com.tangosol.run.xml
- 
An interface for access to a key of a value object
- identifier() - Method in annotation type com.tangosol.net.events.annotation.Interceptor
- 
A unique identifier for the interceptor.
- IDENTIFIER_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The AST node name for an Identifier Node.
- IdentifierBaseToken - Class in com.tangosol.coherence.dsltools.base
- 
IdentifierBaseToken is a token that represents an identifier
- IdentifierBaseToken(String) - Constructor for class com.tangosol.coherence.dsltools.base.IdentifierBaseToken
- 
Construct a new IdentifierBaseToken with the given value.
- IdentifierOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
IdentifierOPToken is used to implement identifiers.
- IdentifierOPToken(String) - Constructor for class com.tangosol.coherence.dsltools.precedence.IdentifierOPToken
- 
Construct a new IdentifierOPToken with the given parameters.
- IdentifierOPToken(String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.IdentifierOPToken
- 
Construct a new IdentifierOPToken with the given parameters.
- identity() - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.DoubleUnaryOperator
- 
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.Function
- 
Returns a function that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.IntUnaryOperator
- 
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.LongUnaryOperator
- 
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.function.Remote.UnaryOperator
- 
Returns a unary operator that always returns its input argument.
- identity() - Static method in interface com.tangosol.util.ValueExtractor
- 
Returns an extractor that always returns its input argument.
- IdentityAsserter - Interface in com.tangosol.net.security
- 
IdentityAsserter validates a token in order to establish a user's identity.
- identityCast() - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that casts its input argument.
- identityCast() - Static method in interface com.tangosol.util.ValueExtractor
- 
Returns an extractor that casts its input argument.
- IdentityExtractor<T> - Class in com.tangosol.util.extractor
- 
Trivial ValueExtractor implementation that does not actually extract anything from the passed value, but returns the value itself.
- IdentityExtractor() - Constructor for class com.tangosol.util.extractor.IdentityExtractor
- 
Default constructor (necessary for the ExternalizableLite interface).
- IdentityHasher<V> - Class in com.oracle.coherence.common.base
- 
IdentityHasher provides a Hasher implementation based upon an object'sidentity hashCodeand reference equality.
- IdentityHasher() - Constructor for class com.oracle.coherence.common.base.IdentityHasher
- IdentityHolder<V> - Class in com.oracle.coherence.common.base
- 
A Holder implementation which additionally provides an equals/hashCode implementation based on the held object's identity.
- IdentityHolder() - Constructor for class com.oracle.coherence.common.base.IdentityHolder
- 
Construct an IdentityHolder holding nothing.
- IdentityHolder() - Constructor for class com.tangosol.io.pof.PofBufferReader.IdentityHolder
- IdentityHolder(V) - Constructor for class com.oracle.coherence.common.base.IdentityHolder
- 
Construct an IdentityHolder holding the specified object.
- IdentityTransformer - Interface in com.tangosol.net.security
- 
IdentityTransformer transforms a Subject to a token that asserts identity.
- IGNORE - com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor.EmptyElementBehavior
- 
When an emptyXmlElementis encountered, simply ignore it and don't process theXmlElementat all.
- IGNORE - com.tangosol.util.RegistrationBehavior
- 
Specifies that registration should be ignored and skipped (without raising an error or exception) if the artifact to be registered is already known.
- ILikeOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the case-insensitive "ilike" operator.
- ILikeOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.ILikeOperator
- 
Construct a {@code ILikeOperator).
- ImmutableArrayList - Class in com.tangosol.util
- 
Implementation of the Collection Framework interface "List" in a read- only fashion on top of an array data structure.
- ImmutableArrayList() - Constructor for class com.tangosol.util.ImmutableArrayList
- 
Default constructor (necessary for the ExternalizableLite interface).
- ImmutableArrayList(Object[]) - Constructor for class com.tangosol.util.ImmutableArrayList
- 
Construct a List from an array.
- ImmutableArrayList(Object[], int, int) - Constructor for class com.tangosol.util.ImmutableArrayList
- 
Construct a List from a specified number of items in an array starting at the specified offset.
- ImmutableArrayList(Collection) - Constructor for class com.tangosol.util.ImmutableArrayList
- 
Construct a List containing the elements of the specified Collection.
- ImmutableArrayList.ListView - Class in com.tangosol.util
- 
ListView exposes the underlying ImmutableArrayList through theListinterface, maintaining correct equals() and hashCode() semantics
- ImmutableArrayList.SetView - Class in com.tangosol.util
- 
SetView exposes the underlying ImmutableArrayList through theSetinterface, maintaining correct equals() and hashCode() semantics
- ImmutableArrayList.SortedSetView - Class in com.tangosol.util
- 
SetView exposes the underlying ImmutableArrayList through theSortedSetinterface, maintaining correct equals() and hashCode() semantics
- ImmutableMultiList - Class in com.tangosol.util
- 
Implementation of the List interface in a read-only fashion based on a collection of arrays.
- ImmutableMultiList(Object[][]) - Constructor for class com.tangosol.util.ImmutableMultiList
- 
Construct a List containing the elements of the specified array of Object arrays.
- ImmutableMultiList(Collection) - Constructor for class com.tangosol.util.ImmutableMultiList
- 
Construct a List containing the elements of the specified Collection of Object arrays.
- ImmutableMultiList.ListView - Class in com.tangosol.util
- 
ListView exposes the underlying ImmutableMultiList through theListinterface, maintaining correct equals() and hashCode() semantics
- ImmutableMultiList.MultiIterator - Class in com.tangosol.util
- 
ListIterator implementation based on the ImmutableMultiList.
- ImmutableMultiList.SetView - Class in com.tangosol.util
- 
SetView exposes the underlying ImmutableMultiList through theSetinterface, maintaining correct equals() and hashCode() semantics
- Impl() - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
- 
Creates a new Impl.
- Impl() - Constructor for class com.tangosol.net.TcpDatagramSocket.Impl
- 
Create a new new Impl.
- Impl(SocketProvider) - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
- 
Creates a new Impl using aprovider.
- Impl(SocketProvider) - Constructor for class com.tangosol.net.TcpDatagramSocket.Impl
- 
Create a new Impl using aprovider.
- implies(Permission) - Method in class com.tangosol.net.ClusterPermission
- 
Check if the specified permission's actions are "implied by" this object's actions.
- in(ValueExtractor<T, ? extends E>, E...) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted value is contained in the specified array.
- in(ValueExtractor<T, ? extends E>, Set<? extends E>) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted value is contained in the specified set.
- incBytesWritten(int) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Increment the count of total number of bytes written to the wrapped DataOutput object by the specified number of bytes.
- includeEquals() - Method in class com.tangosol.util.filter.GreaterEqualsFilter
- includeEquals() - Method in class com.tangosol.util.filter.GreaterFilter
- 
Return whether the entries that match comparison value for this filter should be included in the results.
- includeEquals() - Method in class com.tangosol.util.filter.LessEqualsFilter
- includeEquals() - Method in class com.tangosol.util.filter.LessFilter
- 
Return whether the entries that match comparison value for this filter should be included in the results.
- includeMessage(Throwable) - Static method in class com.tangosol.io.nio.ByteBufferOutputStream
- 
Provide a "suffix" containing the exception message (if any).
- increment(PropertyManipulator, N, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct an increment processor that will increment a property value by a specified amount, returning either the old or the new value as specified.
- increment(String, N, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct an increment processor that will increment a property value by a specified amount, returning either the old or the new value as specified.
- incrementAndGet() - Method in class com.oracle.coherence.common.base.MutableLong
- 
Increment the long and return the new value.
- incrementAndGet() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically increments the current value.
- incrementAndGet() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically increments the current value.
- incrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- incrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- incrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- incrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- incrementAndGet() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically increments the current value.
- incrementAndGet() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically increments the current value.
- incrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- incrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- incrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- incrementAndGet() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- incrementDirtyBytesCount(int) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Increment the counter representing the estimated number of bytes in the original buffer that have been modified.
- incrementDirtyValuesCount() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Increment the counter representing the number of values within this POF hierarchy that have been modified.
- incrementVersion() - Method in class com.tangosol.coherence.rest.util.JsonMap
- incrementVersion() - Method in interface com.tangosol.util.Versionable
- 
Update the version to the next logical version indicator.
- incrementVersion(Object, Object) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Increment value's version.
- IndentingWriter - Class in com.tangosol.io
- 
An IndentingWriter is used to indent line-based output to an underlying Writer.
- IndentingWriter(Writer, int) - Constructor for class com.tangosol.io.IndentingWriter
- 
Construct an IndentingWriter that indents a certain number of spaces.
- IndentingWriter(Writer, String) - Constructor for class com.tangosol.io.IndentingWriter
- 
Construct an IndentingWriter that indents using an indention string.
- indentString(String, String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Indent the passed multi-line string.
- indentString(String, String) - Static method in class com.tangosol.util.Base
- 
Indent the passed multi-line string.
- indentString(String, String, boolean) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Textually indent the passed multi-line string.
- indentString(String, String, boolean) - Static method in class com.tangosol.util.Base
- 
Textually indent the passed multi-line string.
- index() - Method in annotation type com.oracle.coherence.cdi.PofExtractor
- 
Returns an array of POF indexes to use to extract the value.
- index() - Method in class com.oracle.coherence.cdi.PofExtractor.Literal
- 
The POF indexes to use to extract a value.
- IndexAdapter(MapIndex) - Constructor for class com.tangosol.util.InvocableMapHelper.IndexAdapter
- 
Construct an IndexAdapter.
- IndexAwareExtractor<T,E> - Interface in com.tangosol.util.extractor
- 
IndexAwareExtractor is an extension to theValueExtractorinterface that supports the creation and destruction of anindex.
- IndexAwareFilter<K,V> - Interface in com.tangosol.util.filter
- 
IndexAwareFilter is an extension to the EntryFilter interface that allows a filter to use a Map index to fully or partially evaluate itself.
- IndexCalculator(BackingMapContext, SimpleMapIndex) - Constructor for class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
Construct an IndexCalculator which allows for conversion of items into a serialized format.
- Indexed - Annotation Type in com.oracle.coherence.repository
- 
An annotation that should be applied to accessor methods for the properties that need to be indexed.
- IndexLookupRecord() - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Default constructor (necessary for the ExternalizableLite interface).
- IndexLookupRecord(QueryRecord.PartialResult.IndexLookupRecord) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Copy constructor for an IndexLookupRecord.
- IndexLookupRecord(ValueExtractor, MapIndex) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Construct an IndexLookupRecord.
- IndexLookupRecord(String, String, boolean, long, int, String) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Construct an IndexLookupRecord.
- indexOf(byte) - Method in class com.tangosol.util.Binary
- 
Returns the offset within this Binary object of the first occurrence of the specified byte.
- indexOf(byte, int) - Method in class com.tangosol.util.Binary
- 
Returns the offset within this Binary object of the first occurrence of the specified byte, starting the search at the specified offset.
- indexOf(Binary) - Method in class com.tangosol.util.Binary
- 
Returns the offset within this Binary object of the first occurrence of the specified Binary.
- indexOf(Binary, int) - Method in class com.tangosol.util.Binary
- 
Returns the offset within this Binary object of the first occurrence of the specified Binary, starting the search at the specified offset.
- indexOf(Object) - Method in class com.tangosol.util.CircularArrayList
- 
Search for the first occurence of the given argument, testing for equality using the equals method.
- indexOf(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- indexOf(Object) - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns the index in this List of the first occurrence of the specified element, or -1 if this List does not contain this element.
- indexOf(Object) - Method in class com.tangosol.util.ImmutableMultiList
- 
Returns the index in this List of the first occurrence of the specified element, or -1 if this List does not contain this element.
- indexOf(Object) - Method in class com.tangosol.util.InflatableList
- indexOf(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Returns the index in this list of the first occurrence of the specified element, or -1 if this list does not contain this element.
- indexOf(Object) - Method in class com.tangosol.util.SafeLinkedList
- 
Returns the index in this List of the first occurrence of the specified element, or -1 if this List does not contain this element.
- indexOf(Object) - Method in class com.tangosol.util.SubList
- indexOf(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- indexOf(Object, long) - Method in class com.tangosol.util.SimpleLongArray
- 
Return the index in this LongArray of the first occurrence of the specified element such that (index >= lIndex), or NOT_FOUND if this LongArray does not contain the specified element.
- indexOf(T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- indexOf(T, long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- indexOf(V) - Method in class com.tangosol.util.AbstractLongArray
- 
Return the index in this LongArray of the first occurrence of the specified element, or NOT_FOUND if this LongArray does not contain the specified element.
- indexOf(V) - Method in class com.tangosol.util.AbstractSafeLongArray
- indexOf(V) - Method in interface com.tangosol.util.LongArray
- 
Return the index in this LongArray of the first occurrence of the specified element, or NOT_FOUND if this LongArray does not contain the specified element.
- indexOf(V) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- indexOf(V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- indexOf(V, long) - Method in class com.tangosol.util.AbstractLongArray
- 
Return the index in this LongArray of the first occurrence of the specified element such that (index is greater or equal to lIndex), or NOT_FOUND if this LongArray does not contain the specified element.
- indexOf(V, long) - Method in class com.tangosol.util.AbstractSafeLongArray
- indexOf(V, long) - Method in interface com.tangosol.util.LongArray
- 
Return the index in this LongArray of the first occurrence of the specified element such that (index greater or equal to lIndex), or NOT_FOUND if this LongArray does not contain the specified element.
- indexOf(V, long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- indexOf(V, long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- indexOfExtension(String) - Static method in class com.tangosol.io.FileHelper
- 
Returns the index of the last extension separator character, which is a dot.
- indexOfLastSeparator(String) - Static method in class com.tangosol.io.FileHelper
- 
Returns the index of the last directory separator character.
- indexOfLSB(byte) - Static method in class com.tangosol.util.BitHelper
- 
Determine the least significant bit of the passed integral value.
- indexOfLSB(int) - Static method in class com.tangosol.util.BitHelper
- 
Determine the least significant bit of the passed integral value.
- indexOfLSB(long) - Static method in class com.tangosol.util.BitHelper
- 
Determine the least significant bit of the passed integral value.
- indexOfMSB(byte) - Static method in class com.tangosol.util.BitHelper
- 
Determine the most significant bit of the passed integral value.
- indexOfMSB(int) - Static method in class com.tangosol.util.BitHelper
- 
Determine the most significant bit of the passed integral value.
- indexOfMSB(long) - Static method in class com.tangosol.util.BitHelper
- 
Determine the most significant bit of the passed integral value.
- InetAddressHelper - Class in com.tangosol.net
- 
Helper class that encapsulates common InetAddress functionality.
- InetAddressHelper() - Constructor for class com.tangosol.net.InetAddressHelper
- InetAddressHelper.RoutableFilter - Class in com.tangosol.net
- 
The RoutableFilter evaluates to true for any InetAddress which is externally routable.
- InetAddressHelper.SubnetMaskFilter - Class in com.tangosol.net
- 
SubnetMaskFilter evaluates to true for any address with matches the pattern for the masked bits
- InetAddressRangeFilterBuilder - Class in com.tangosol.coherence.config.builder
- 
InetAddressRangeFilterBuilder defers evaluating configuration parameters until Filter is instantiated.
- InetAddressRangeFilterBuilder() - Constructor for class com.tangosol.coherence.config.builder.InetAddressRangeFilterBuilder
- 
Construct aInetAddressRangeFilterBuilder
- InetAddressSerializer - Class in com.tangosol.io.pof
- 
POF serializer forjava.net.InetAddress.
- InetAddressSerializer() - Constructor for class com.tangosol.io.pof.InetAddressSerializer
- InetSocketAddressSerializer - Class in com.tangosol.io.pof
- 
POF serializer forjava.net.InetSocketAddress.
- InetSocketAddressSerializer() - Constructor for class com.tangosol.io.pof.InetSocketAddressSerializer
- InFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which checks whether the result of a method invocation belongs to a predefined set of values.
- InFilter() - Constructor for class com.tangosol.util.filter.InFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- InFilter(ValueExtractor<? super T, ? extends E>, Set<? extends E>) - Constructor for class com.tangosol.util.filter.InFilter
- 
Construct an InFilter for testing "In" condition.
- InFilter(String, Set<? extends E>) - Constructor for class com.tangosol.util.filter.InFilter
- 
Construct an InFilter for testing "In" condition.
- InfixOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
InfixOPToken is used to implement infix operators.
- InfixOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixOPToken
- 
Construct a new InfixOPToken with the given parameters.
- InfixOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixOPToken
- 
Construct a new InfixOPToken with the given parameters.
- InfixOPToken(String, int, String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixOPToken
- 
Construct a new InfixOPToken with the given parameters.
- InfixRightOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
InfixRightOPToken is used to implement infix operators that like to bind to the right which is typical of exponentiation rules.
- InfixRightOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixRightOPToken
- 
Construct a new InfixRightOPToken with the given parameters.
- InfixRightOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.InfixRightOPToken
- 
Construct a new InfixRightOPToken with the given parameters.
- InflatableCollection - Class in com.tangosol.util
- 
A Collection implementation which optimizes memory consumption for collections that often contain just a single value.
- InflatableCollection() - Constructor for class com.tangosol.util.InflatableCollection
- InflatableCollection.InflatedCollection - Interface in com.tangosol.util
- 
A marker interface which is used to identify internally inflated Collections.
- InflatableList - Class in com.tangosol.util
- 
A List specialization of InflatableCollection.
- InflatableList() - Constructor for class com.tangosol.util.InflatableList
- InflatableSet - Class in com.tangosol.util
- 
A Set specialization of InflatableCollection.
- InflatableSet() - Constructor for class com.tangosol.util.InflatableSet
- InflaterInputShell(InputStream, Inflater) - Constructor for class com.tangosol.net.CompressionFilter.InflaterInputShell
- 
Deprecated.Create a new input stream with the specified decompressor.
- InflaterInputShell(InputStream, Inflater, int) - Constructor for class com.tangosol.net.CompressionFilter.InflaterInputShell
- 
Deprecated.Create a new input stream with the specified decompressor and buffer size.
- INFLATION_OVERHEAD - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
The memory cost of inflating an InflatableSet.
- info(String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.INFOseverity.
- info(String, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.INFOseverity.
- info(Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) withLogger.INFOseverity.
- info(Supplier<String>) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.INFOseverity.
- info(Supplier<String>, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.INFOseverity.
- INFO - Static variable in class com.oracle.coherence.common.base.Logger
- 
Severity 3 indicates information that should likely be logged.
- inGroup(String) - Static method in interface com.tangosol.net.topic.Subscriber
- 
Obtain aSubscriber.Optionthat specifies a group name for aSubscriber.
- inGroup(String) - Static method in class com.tangosol.net.topic.Subscriber.Name
- 
Obtain aSubscriber.Optionthat specifies a group name for aSubscriber.
- init() - Method in class com.tangosol.run.xml.SimpleParser
- 
Internal initialization.
- init() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Called in constructor and deserializers.
- init() - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Parse the property name and initialize necessary extractor and updator.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractDoubleAggregator
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.AbstractLongAggregator
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DistinctValues
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DoubleAverage
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DoubleMax
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DoubleMin
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.DoubleSum
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.LongMax
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.LongMin
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.LongSum
- 
Initialize the aggregation result.
- init(boolean) - Method in class com.tangosol.util.aggregator.ReducerAggregator
- 
Initialize the aggregation result.
- init(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Configure the Block object to point to a specific offset within the Buffer.
- init(BackingMapManagerContext) - Method in class com.tangosol.net.AbstractBackingMapManager
- 
Called by a CacheService to indicate to this manager that the manager is being associated with the CacheService.
- init(BackingMapManagerContext) - Method in interface com.tangosol.net.BackingMapManager
- 
Called by a CacheService to indicate to this manager that the manager is being associated with the CacheService.
- init(BackingMapManagerContext) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Called by a CacheService to indicate to this manager that the manager is being associated with the CacheService.
- init(BackingMapManagerContext) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Called by a CacheService to indicate to this manager that the manager is being associated with the CacheService.
- init(InvocationService) - Method in class com.tangosol.net.AbstractInvocable
- 
Called by the InvocationService exactly once on this Invocable object as part of its initialization.
- init(InvocationService) - Method in interface com.tangosol.net.Invocable
- 
Called by the InvocationService exactly once on this Invocable object as part of its initialization.
- init(DistributionManager) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Initialize the PartitionAssignmentStrategy and bind it to the specified DistributionManager.
- init(DistributionManager) - Method in interface com.tangosol.net.partition.PartitionAssignmentStrategy
- 
Initialize the PartitionAssignmentStrategy and bind it to the specified DistributionManager.
- init(DistributionManager) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Initialize the PartitionAssignmentStrategy and bind it to the specified DistributionManager.
- init(DistributionManager) - Method in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
- 
Initialize the PartitionAssignmentStrategy and bind it to the specified DistributionManager.
- init(PartitionedService) - Method in class com.tangosol.net.partition.BroadKeyPartitioningStrategy
- 
Initialize the KeyPartitioningStrategy and bind it to the specified PartitionedService.
- init(PartitionedService) - Method in class com.tangosol.net.partition.DefaultKeyAssociator
- 
Initialize the KeyAssociator and bind it to a PartitionedService.
- init(PartitionedService) - Method in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
- 
Initialize the KeyPartitioningStrategy and bind it to the specified PartitionedService.
- init(PartitionedService) - Method in interface com.tangosol.net.partition.KeyAssociator
- 
Initialize the KeyAssociator and bind it to a PartitionedService.
- init(PartitionedService) - Method in interface com.tangosol.net.partition.KeyPartitioningStrategy
- 
Initialize the KeyPartitioningStrategy and bind it to the specified PartitionedService.
- init(Service) - Method in interface com.tangosol.net.ActionPolicy
- 
Called when the specified service loads and configures this policy.
- init(Service) - Method in class com.tangosol.net.CompositeActionPolicy
- 
Called when the specified service loads and configures this policy.
- init(Service) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Called when the specified service loads and configures this policy.
- init(Service) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Called when the specified service loads and configures this policy.
- init(Service) - Method in class com.tangosol.net.partition.FailoverAccessPolicy
- 
Called when the specified service loads and configures this policy.
- init(Service) - Method in class com.tangosol.util.NullImplementation.NullActionPolicy
- 
Called when the specified service loads and configures this policy.
- init(ThreadPoolManager) - Method in interface com.tangosol.net.ThreadPoolSizingStrategy
- 
Initialize the ThreadPoolSizingStrategy and bind it to the specified manager.
- init(XmlElement) - Method in class com.tangosol.util.ExternalizableHelper.SimpleXmlBeanClassCache
- 
Initialize the XmlBeanClassCache.
- init(XmlElement) - Method in interface com.tangosol.util.ExternalizableHelper.XmlBeanClassCache
- 
Initialize the XmlBeanClassCache.
- init(Class, String, String[]) - Static method in class com.tangosol.run.xml.XmlBean
- 
For backwards compatibility only - loads reflection info.
- init(String, DatabaseFactory) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Initialize the BinaryStore.
- init(String, String, String, int) - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- 
Initialize the fields of the StackFrame object.
- init(S) - Method in class com.tangosol.net.AbstractServiceLoadBalancer
- 
Called by the Service exactly once on this object as part of its initialization.
- init(S) - Method in interface com.tangosol.net.ServiceLoadBalancer
- 
Called by the Service exactly once on this object as part of its initialization.
- initBeanInfo() - Method in class com.tangosol.run.xml.XmlBean
- 
Initialize the Object, loading the XML Bean design information if necessary.
- initBlock(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Obtain a Block object for a new block that will be located at the specified offset in the ByteBuffer.
- initFromArray(Object[], int) - Method in class com.tangosol.util.LiteSet
- 
Initialize the contents of this Set from the passed array ao containing c values.
- initialize() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Bind the ConfigurablePofContext to a ClassLoader, resolving all class names, etc.
- initialize() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Initialize the AnalysisContext.
- initialize(boolean) - Method in class com.tangosol.util.SimpleMapIndex
- 
Initialize the index's data structures.
- initialize(PortableObject, PofReader) - Method in class com.tangosol.io.pof.PortableObjectSerializer
- 
Initialize the specified (newly instantiated) PortableObject instance using the specified reader.
- initialize(Object) - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
Initialize the calculator based on the type of the specified object assuming that the indexed values are homogeneous (of the same type).
- initializeActions() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Initialize the EntryAction's for this map.
- initializeActions() - Method in class com.tangosol.util.SegmentedHashMap
- 
Initialize the EntryAction's for this map.
- initializeBuckets() - Method in class com.tangosol.io.nio.BinaryMap
- 
Create an initial array of hash buckets.
- initializeBundler(ParameterResolver, AbstractBundler, BundleManager.BundleConfig) - Method in class com.tangosol.coherence.config.scheme.BundleManager
- 
Initialize the specified bundler using the BundleConfig.
- initializeBundler(AbstractBundler, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Initialize the specified bundler using the "bundle-config" element.
- initializeConfiguredProperties() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Initialize the configurable properties of this cache-map.
- initializeFreeLists() - Method in class com.tangosol.io.nio.BinaryMap
- 
Create an array of references to lists of free blocks indexed by size code.
- initializeFunctionMap() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Creates the Map holding CohQL functions and populates it with the default functions available in CohQL.
- initializeLanguage() - Method in class com.tangosol.coherence.dslquery.QueryPlus
- 
Initialize theCoherenceQueryLanguagewith any QueryPlusStatementextensions.
- initializeOperatorMap() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Initialize the CohQL operators Map with all of the built-in CohQL operators and return the Map.
- initialStartServices(long) - Method in class com.tangosol.net.DefaultCacheServer
- 
Setup any necessary resources and start all services.
- InitiatorDependenciesProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse an <initator-config> and produce anInitiatorDependencies.
- InitiatorDependenciesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InitiatorDependenciesProcessor
- initListenerChannel(String, String, String) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aMapListenerRequestthat will initialise the bidirectional channel.
- InitParamProcessor - Class in com.tangosol.coherence.config.xml.processor
- InitParamProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor
- InitParamProcessor.CacheRefExpression - Class in com.tangosol.coherence.config.xml.processor
- 
AnExpressionimplementation that represents the use of a {cache-ref} macro in a Configuration File.
- InitParamProcessor.CollectionRefExpression - Class in com.tangosol.coherence.config.xml.processor
- 
AnExpressionimplementation that represents the use of a {collection-ref} macro in a Configuration File.
- InitParamProcessor.DataStructureRefExpression<E> - Class in com.tangosol.coherence.config.xml.processor
- 
AnExpressionimplementation that represents the use of a {cache-ref} macro in a Cache Configuration File.
- InitParamProcessor.ResourceRefExpression - Class in com.tangosol.coherence.config.xml.processor
- 
AnExpressionimplementation that represents the use of a {resource} macro in a configuration File.
- InitParamProcessor.SchemeRefExpression - Class in com.tangosol.coherence.config.xml.processor
- 
AnExpressionimplementation that represents the use of a {scheme-ref} macro in a Cache Configuration File.
- InitParamsProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnInitParamsProcessoris responsible for processing <init-params>XmlElements to produceResolvableParameterLists.
- InitParamsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamsProcessor
- initRecycling(int) - Method in class com.tangosol.util.RecyclingLinkedList
- 
Initializing the recycling data structures.
- inject(B, XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Given the information available in theProcessingContext, including the cookies, theResourceRegistrytheXmlElement, itsXmlAttributes and/or children, inject appropriately named and typed values into the specified bean (using setter injection).
- inject(B, XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Given the information available in theProcessingContext, including the cookies, theResourceRegistrytheXmlElement, itsXmlAttributes and/or children, inject appropriately named and typed values into the specified bean (using setter injection).
- inject(Object) - Method in class com.oracle.coherence.cdi.CdiInjector
- inject(T, ServiceLocator) - Static method in class com.tangosol.coherence.rest.server.InjectionBinder
- 
Inject its fields and methods of a given resource and return the resource.
- Injectable - Annotation Type in com.tangosol.config.annotation
- 
Denotes that a Java Bean setter method may be injected with a value.
- InjectionBinder - Class in com.tangosol.coherence.rest.server
- 
A binder for REST API dependencies.
- InjectionBinder(boolean) - Constructor for class com.tangosol.coherence.rest.server.InjectionBinder
- 
Construct InjectionBinder instance.
- injectScopeNameIntoService(Service) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- InKeySetFilter<T> - Class in com.tangosol.util.filter
- 
Filter that limits the underlying filter evaluation only to the specified set of keys.
- InKeySetFilter() - Constructor for class com.tangosol.util.filter.InKeySetFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- InKeySetFilter(Filter<T>, Set<K>) - Constructor for class com.tangosol.util.filter.InKeySetFilter
- 
Construct an InFilter for testing "In" condition.
- InOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the "in"operator.
- InOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.InOperator
- 
Construct a InOperator.
- InputStreaming - Interface in com.tangosol.io
- 
This is the interface represented by the Java InputStream class.
- InputStreamPasswordProvider - Class in com.tangosol.net
- 
A base class forPasswordProviderimplementations that read the contents of anInputStreamto obtain a password.
- InputStreamPasswordProvider() - Constructor for class com.tangosol.net.InputStreamPasswordProvider
- 
Create anInputStreamPasswordProvider.
- InputStreamPasswordProvider(boolean) - Constructor for class com.tangosol.net.InputStreamPasswordProvider
- 
Create anInputStreamPasswordProvider.
- insert(Map.Entry) - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Update this index in response to a insert operation on a cache.
- insert(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
- 
Update this index in response to a insert operation on a cache.
- insert(Map.Entry<? extends K, ? extends V>) - Method in interface com.tangosol.util.MapIndex
- 
Update this index in response to a insert operation on a cache.
- InsertAction() - Constructor for class com.tangosol.util.SegmentedHashMap.InsertAction
- Inserted - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any INSERTED event.
- INSERTED - com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent.Type
- 
An INSERTED event is raised after theEventInterceptorwas successfully registered with theEventDispatcher.
- INSERTED - com.tangosol.net.events.partition.cache.EntryEvent.Type
- 
ThisEntryEventis dispatched after one or moreBinaryEntry(s) have been inserted into the backing-map.
- Inserted.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theInsertedannotation.
- Inserting - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any INSERTING event.
- INSERTING - com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent.Type
- 
An INSERTING event is raised prior to theEventInterceptorbeing registered with theEventDispatcher.
- INSERTING - com.tangosol.net.events.partition.cache.EntryEvent.Type
- 
ThisEntryEventis dispatched before one or moreBinaryEntry(s) are inserted into the backing-map.
- Inserting.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theInsertingannotation.
- insertInternal(Map.Entry) - Method in class com.tangosol.util.ConditionalIndex
- 
Update this index in response to a insert operation on a cache.
- insertInternal(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
- 
Update this index in response to a insert operation on a cache.
- InsertStatement(String, Object, Object) - Constructor for class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
- 
Construct a InsertStatement that will insert the specified key and value into the specified cache.
- InsertStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aInsertStatementBuilder.InsertStatement.
- InsertStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
- InsertStatementBuilder.InsertStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "INSERT" command.
- INSTANCE - Static variable in class com.oracle.coherence.cdi.AlwaysFilter.Literal
- 
AAlwaysFilter.Literalinstance.
- INSTANCE - Static variable in class com.oracle.coherence.cdi.CacheAdd.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.CacheGet.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.CachePut.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.CacheRemove.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Activated.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Activating.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Arrived.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Assigned.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Committed.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Committing.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.CommittingLocal.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.CommittingRemote.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Connecting.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Created.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Deleted.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Departed.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Departing.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Destroyed.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Disconnected.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Disposing.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Error.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Executed.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Executing.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Inserted.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Inserting.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Lite.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Lost.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Recovered.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Removed.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Removing.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Replicating.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Rollback.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Started.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Starting.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Stopped.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Stopping.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Synced.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Synchronous.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Syncing.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Truncated.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Updated.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.events.Updating.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.Remote.Literal
- INSTANCE - Static variable in class com.oracle.coherence.cdi.View.Literal
- 
A singleton instance ofView.Literalwith the cache values flag set to true.
- INSTANCE - Static variable in class com.oracle.coherence.common.base.IdentityHasher
- 
A singleton instance of the IdentityHasher.
- INSTANCE - Static variable in class com.oracle.coherence.common.base.InverseComparator
- 
InverseComparator singleton which inverts a Comparable objects natural comparison order.
- INSTANCE - Static variable in class com.oracle.coherence.common.base.NaturalComparator
- 
NaturalComparator singleton.
- INSTANCE - Static variable in class com.oracle.coherence.common.base.NaturalHasher
- 
A singleton instance of the NaturalHasher.
- INSTANCE - Static variable in interface com.oracle.coherence.grpc.proxy.GrpcServerBuilderProvider
- 
Deprecated.The defaultGrpcServerBuilderProvider.
- INSTANCE - Static variable in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
The singleton instance of theGrpcServerController.
- INSTANCE - Static variable in class com.tangosol.coherence.config.ParameterMacroExpressionParser
- 
The singleton instance of theParameterMacroExpressionParser.
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.preprocessor.ExtendPreprocessor
- 
This singleton instance of theExtendPreprocessor.
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.preprocessor.SchemeRefPreprocessor
- 
This singleton instance of theSchemeRefPreprocessor.
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.preprocessor.SystemPropertyPreprocessor
- 
This singleton instance of theSystemPropertyPreprocessor.
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.preprocessor.ViewSchemePreprocessor
- 
SingletonViewSchemePreprocessorreference.
- INSTANCE - Static variable in class com.tangosol.coherence.config.xml.processor.NoOpElementProcessor
- 
Singleton instance ofNoOpElementProcessor
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.AdditionOperator
- 
An instance of the AndOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.AndOperator
- 
An instance of the AndOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.BetweenOperator
- 
An instance of the BetweenOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.ContainsAllOperator
- 
An instance of the ContainsAllOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.ContainsAnyOperator
- 
An instance of the ContainsAnyOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.ContainsOperator
- 
An instance of the ContainsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.DivisionOperator
- 
An instance of the DivisionOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.EqualsOperator
- 
An instance of the EqualsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
- 
An instance of the GreaterEqualsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.GreaterOperator
- 
An instance of the GreaterOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.ILikeOperator
- 
An instance of the LikeOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.InOperator
- 
An instance of the InOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.LessEqualsOperator
- 
An instance of the LessEqualsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.LessOperator
- 
An instance of the LessOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.LikeOperator
- 
An instance of the LikeOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.MultiplicationOperator
- 
An instance of the AndOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.NotEqualsOperator
- 
An instance of the NotEqualsOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.OrOperator
- 
An instance of the OrOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.SubtractionOperator
- 
An instance of the AndOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.operator.XorOperator
- 
An instance of the XorOperator.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
- 
An instance ofBackupStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
- 
An instance of CreateCacheStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
- 
An instance of a CreateIndexStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder
- 
An instance of DeleteStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder
- 
An instance of DropCacheStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder
- 
An instance of DropIndexStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
- 
An instance of a InsertStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
- 
An instance ofArchiveSnapshotStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
- 
An instance ofCreateSnapshotStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder
- 
An instance ofForceRecoveryStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder
- 
An instance ofListArchiverStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder
- 
An instance ofListServicesStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder
- 
An instance ofListSnapshotsStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder
- 
An instance ofRecoverSnapshotStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder
- 
An instance ofRemoveSnapshotStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder
- 
An instance ofResumeServiceStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder
- 
An instance ofRemoveSnapshotStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder
- 
An instance ofSuspendServiceStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder
- 
An instance ofValidateSnapshotStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder
- 
An instance of a RestoreStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
- 
An instance of a SelectStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder
- 
An instance of a SourceStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder
- 
An instance of TruncateCacheStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
- 
An instance of a UpdateStatementBuilder.
- INSTANCE - Static variable in class com.tangosol.coherence.dsltools.precedence.EndOfStatementOPToken
- INSTANCE - Static variable in class com.tangosol.coherence.dsltools.precedence.EndOPToken
- INSTANCE - Static variable in class com.tangosol.config.expression.SystemPropertyParameterResolver
- 
This singleton instance of theSystemPropertyParameterResolver.
- INSTANCE - Static variable in class com.tangosol.net.cache.BinaryMemoryCalculator
- 
Singleton BinaryMemoryCalculator instance.
- INSTANCE - Static variable in class com.tangosol.net.cache.OldCache.InternalUnitCalculator
- 
Deprecated.Singleton instance.
- INSTANCE - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.FrontFilterConverter
- INSTANCE - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.HashcodeComparator
- INSTANCE - Static variable in class com.tangosol.net.InetAddressHelper.RoutableFilter
- 
Singleton instance.
- INSTANCE - Static variable in interface com.tangosol.net.ScopeResolver
- 
A default implementation of aScopeResolverthat always returns passed in scope name.
- INSTANCE - Static variable in class com.tangosol.net.security.DefaultIdentityAsserter
- 
An instance of the DefaultIdentityAsserter.
- INSTANCE - Static variable in class com.tangosol.net.security.DefaultIdentityTransformer
- 
An instance of the DefaultIdentityTransformer.
- INSTANCE - Static variable in class com.tangosol.net.ssl.EmptyKeyStoreLoader
- INSTANCE - Static variable in class com.tangosol.net.SystemDatagramSocketProvider
- 
A default SocketProvider instance.
- INSTANCE - Static variable in class com.tangosol.net.TcpDatagramSocketProvider
- 
A default SocketProvider instance.
- INSTANCE - Static variable in class com.tangosol.net.topic.BinaryElementCalculator
- 
A singleton instance ofBinaryElementCalculator.
- INSTANCE - Static variable in class com.tangosol.net.topic.FixedElementCalculator
- INSTANCE - Static variable in class com.tangosol.net.topic.Publisher.FailOnFull
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.net.topic.Publisher.OrderByNone
- 
The none-order singleton.
- INSTANCE - Static variable in class com.tangosol.net.topic.Publisher.OrderByThread
- 
The thread-order singleton.
- INSTANCE - Static variable in class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
- 
The CompleteOnEmpty singleton.
- INSTANCE - Static variable in class com.tangosol.persistence.ArchiverHelper.DirectoryFileFilter
- 
Deprecated.Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.comparator.SafeComparator
- 
The trivial SafeComparator.
- INSTANCE - Static variable in class com.tangosol.util.DaemonThreadFactory
- 
A reuseable DaemonThreadFactory instance.
- INSTANCE - Static variable in class com.tangosol.util.extractor.IdentityExtractor
- 
An instance of the IdentityExtractor.
- INSTANCE - Static variable in class com.tangosol.util.filter.AlwaysFilter
- 
An instance of the AlwaysFilter.
- INSTANCE - Static variable in class com.tangosol.util.filter.NeverFilter
- 
An instance of the NeverFilter.
- INSTANCE - Static variable in class com.tangosol.util.filter.PresentFilter
- 
An instance of the PresentFilter.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullActionPolicy
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullAddressProvider
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullCacheStore
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullCollector
- 
Singleton (unchecked) instance of a Collector.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullContinuation
- 
Singleton instance of a NullContinuation.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullConverter
- 
Since the Converter contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullDeltaCompressor
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullEntryProcessor
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullEnumerator
- 
Since the enumerator contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullMap
- 
Since the Map contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullMemberIdentityProvider
- 
A singleton instance of aNullImplementation.NullMemberIdentityProvider.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullObservableMap
- 
Since the Map contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
- 
Singleton instance of a NullPersistenceEnvironment.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Singleton instance of a NullPersistenceManager.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPersistentStore
- 
Singleton instance of a NullPersistentStore.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPofContext
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Singleton instance.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullResourceRegistry
- 
Singleton instance of a NullResourceRegistry.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullSet
- 
Since the set contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Since the ValueExtractor contains no information, only one ever has to exist.
- INSTANCE - Static variable in class com.tangosol.util.processor.PreloadRequest
- 
An instance of the PreloadRequest processor.
- INSTANCE - Static variable in class com.tangosol.util.transformer.SemiLiteEventTransformer
- 
The SemiLiteEventTransformer singleton.
- INSTANCE() - Static method in class com.tangosol.util.comparator.SafeComparator
- 
Return the trivial SafeComparator.
- INSTANCE() - Static method in class com.tangosol.util.extractor.IdentityExtractor
- 
Return an instance of the IdentityExtractor.
- INSTANCE() - Static method in class com.tangosol.util.filter.AlwaysFilter
- 
Return an instance of the AlwaysFilter.
- INSTANCE() - Static method in class com.tangosol.util.filter.NeverFilter
- 
Return an instance of the NeverFilter.
- INSTANCE() - Static method in class com.tangosol.util.filter.PresentFilter
- 
Return an instance of the PresentFilter.
- INSTANCE() - Static method in class com.tangosol.util.processor.PreloadRequest
- 
Return an instance of the PreloadRequest processor.
- INSTANCE_BINARY - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The UnitCalculator object that measures the bytes used by entries.
- INSTANCE_FIXED - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The UnitCalculator object that counts each entry as one unit.
- INSTANCE_HYBRID - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The EvictionPolicy object for the Hybrid eviction algorithm.
- INSTANCE_LFU - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The EvictionPolicy object for the Least Frequently Used (LFU) eviction algorithm.
- INSTANCE_LRU - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The EvictionPolicy object for the Least Recently Used (LRU) eviction algorithm.
- InstanceBuilder<T> - Class in com.tangosol.coherence.config.builder
- 
AnInstanceBuilderis aParameterizedBuilderimplementation that additionally supports injection based on Coherence <instance%gt; or <class-scheme> configurations.
- InstanceBuilder() - Constructor for class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Construct anInstanceBuilder.
- InstanceBuilder(Expression<String>, Object...) - Constructor for class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Constructs aInstanceBuilderthat will realize an instance of the specifically named class.
- InstanceBuilder(Class<?>, Object...) - Constructor for class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Constructs aInstanceBuilderthat will realize an instance of the specifiedClass.
- InstanceBuilder(String, Object...) - Constructor for class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Constructs aInstanceBuilderthat will realize an instance of the specifically named class.
- InstanceProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnInstanceProcessoris responsible for processing <instance>XmlElements to produceParameterizedBuilders.
- InstanceProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InstanceProcessor
- instantiate() - Method in class com.tangosol.coherence.config.xml.processor.CustomizableBuilderProcessor
- 
Instantiate the required class to inject and return.
- instantiate() - Method in class com.tangosol.coherence.config.xml.processor.ServiceBuilderProcessor
- 
Instantiate the required class to inject and return.
- instantiateAddListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Factory Method: Instantiate aMapListenerfor adding items to theContinuousQueryCache, and (if there are listeners on theContinuousQueryCache) for dispatching inserts and updates.
- instantiateAnalysisContext() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Factory method.
- instantiateAny(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create an Object using "class-scheme" element.
- instantiateAsyncBinaryStore(BinaryStore) - Method in class com.tangosol.io.AsyncBinaryStoreManager
- 
Factory method: Instantiate an AsyncBinaryStore.
- instantiateAsyncBinaryStore(BinaryStore, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an AsyncBinaryStore using the specified parameters.
- instantiateAsyncBinaryStoreManager(BinaryStoreManager, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an AsyncBinaryStoreManager using the specified parameters.
- instantiateAttribute() - Method in class com.tangosol.run.xml.SimpleElement
- 
Instantiate an XmlValue implementation for an attribute value.
- instantiateAttributeMap() - Method in class com.tangosol.run.xml.SimpleElement
- 
Instantiate a Map implementation that will support the name to value map used to hold attributes.
- instantiateBackingMap(String) - Method in interface com.tangosol.net.BackingMapManager
- 
Instantiate a [thread safe] Map that should be used by a CacheService to store cached values for a NamedCache with the specified name.
- instantiateBackingMap(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Instantiate a [thread safe] Map that should be used by a CacheService to store cached values for a NamedCache with the specified name.
- instantiateBackingMap(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.Instantiate a [thread safe] Map that should be used by a CacheService to store cached values for a NamedCache with the specified name.
- instantiateBackingMap(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Instantiate a [thread safe] Map that should be used by a CacheService to store cached values for a NamedCache with the specified name.
- instantiateBackingMap(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
- 
Instantiate a [thread safe] Map that should be used by a CacheService to store cached values for a NamedCache with the specified name.
- instantiateBackingMapManager(int, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Instantiate a BackingMapManager for a given scheme type.
- instantiateBackMapListener() - Method in class com.tangosol.net.cache.OverflowMap
- 
Factory pattern: Back Map Listener.
- instantiateBackMapListener(int) - Method in class com.tangosol.net.cache.CachingMap
- 
Factory pattern: instantiate back map listener.
- instantiateBackupMap(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Instantiate a [thread safe] Map that should be used by a CacheService to store cached values for a NamedCache with the specified name.
- instantiateBackupStrength(Set) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Create a backup strength to be used for distribution among the specified set of ownership members.
- instantiateBean(String) - Method in class com.tangosol.run.xml.RestrictedStringAdapter
- 
Convert a String into an instance of the bean.
- instantiateBinaryStoreManager(XmlElement, ClassLoader, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a BinaryStoreManager using the specified XML configuration.
- instantiateBlock() - Method in class com.tangosol.io.nio.BinaryMap
- 
Factory method: Create a Block object.
- instantiateBufferInput() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Factory method: Instantiate a BufferInput object to read data from the ReadBuffer.
- instantiateBufferInput() - Method in class com.tangosol.io.AbstractReadBuffer
- 
Factory method: Instantiate a BufferInput object to read data from the ReadBuffer.
- instantiateBufferInput() - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Factory method: Instantiate a BufferInput object to read data from the ReadBuffer.
- instantiateBufferInput() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Factory method: Instantiate a BufferInput object to read data from the ReadBuffer.
- instantiateBufferInput(boolean) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Factory method: Instantiate a BufferInput object to read data from the ReadBuffer.
- instantiateBundle() - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler
- 
Instantiate a new Bundle object.
- instantiateBundle() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Instantiate a new Bundle object.
- instantiateBundle() - Method in class com.tangosol.net.cache.AbstractEntryBundler
- 
Instantiate a new Bundle object.
- instantiateBundle() - Method in class com.tangosol.net.cache.AbstractKeyBundler
- 
Instantiate a new Bundle object.
- instantiateBundlingNamedCache(NamedCache, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a BundlingNamedCache using the "operation-bundling" element.
- instantiateCacheLoaderCacheStore(CacheLoader) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate a CacheLoaderCacheStore wrapper around a passed CacheLoader.
- instantiateCacheResource(NamedCache, Class, Class, KeyConverter, QueryConfig, int) - Method in class com.tangosol.coherence.rest.DefaultRootResource
- 
Create an instance ofCacheResource.
- instantiateCacheResourceInternal(ResourceConfig) - Method in class com.tangosol.coherence.rest.DefaultRootResource
- 
Create an instance ofCacheResourcefor the specified resource configuration.
- instantiateCacheStore(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a CacheLoader, CacheStore or BinaryEntryStore using the "cachestore-scheme" element.
- instantiateCacheStoreWrapper(BinaryEntryStore) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate a StoreWrapper wrapper around the passed BinaryEntryStore.
- instantiateCacheStoreWrapper(CacheStore) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate a StoreWrapper wrapper around the passed CacheStore.
- instantiateCacheStoreWrapper(CacheStore) - Method in class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Factory pattern: Instantiate a CacheStore wrapper around the passed CacheStore.
- instantiateCacheStoreWrapper(NonBlockingEntryStore) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate a StoreWrapper wrapper around the passed NonBlockingEntryStore.
- instantiateCalculator() - Method in class com.tangosol.util.SimpleMapIndex
- 
Factory method used to create a new calculator.
- instantiateClusterPolicy(Map<String, Integer>) - Static method in class com.tangosol.net.ConfigurableQuorumPolicy
- 
Instantiate an action policy for the a cluster service.
- instantiateCollection() - Method in class com.tangosol.run.xml.CollectionAdapter
- instantiateCollection() - Method in class com.tangosol.util.InflatableCollection
- 
Factory method used to create a new Collection.
- instantiateCollection() - Method in class com.tangosol.util.InflatableList
- 
Factory method used to create a new Collection.
- instantiateCollection() - Method in class com.tangosol.util.InflatableSet
- 
Factory method used to create a new Collection.
- instantiateCollection(Collection<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Create a Converter Collection.
- instantiateCollection(Collection<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Create a Converter Collection.
- instantiateConditionalRemoveAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Factory for ConditionalRemoveAction
- instantiateContainsValueAction() - Method in class com.tangosol.util.SegmentedHashMap
- 
Factory for ContainsValueAction
- instantiateContext(boolean) - Method in class com.tangosol.util.SegmentedConcurrentMap.SizeAction
- 
Instantiate a context appropriate for applying SizeAction to count the number of entries in the map.
- instantiateContext(Guardable, long, float) - Method in class com.tangosol.net.GuardSupport
- instantiateContext(Object) - Method in class com.tangosol.util.SegmentedHashMap.ContainsValueAction
- 
Instantiate a context appropriate for applying ContainsValueAction to lookup oValue in the map.
- instantiateControlMap() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Create the concurrency control map for this backing map.
- instantiateConverterMap(Map<K, V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Provides out-bound conversion (i.e. conversion to values clients expect) of internal values.
- instantiateCrawler(AbstractSparseArray.Node<V>, int, boolean) - Method in class com.tangosol.util.AbstractSparseArray
- 
Instantiate a new Crawler at the specified location and direction.
- instantiateCrawler(AbstractSparseArray.Node, int, boolean) - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Instantiate a new Crawler at the specified location and direction.
- instantiateDefaultComparator() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Instantiate a default member Comparator.
- instantiateDiskBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.As of Coherence 3.0, replaced byDefaultConfigurableCacheFactory.instantiateExternalBackingMap(com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo, com.tangosol.run.xml.XmlElement, com.tangosol.net.BackingMapManagerContext, java.lang.ClassLoader)andDefaultConfigurableCacheFactory.instantiatePagedExternalBackingMap(com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo, com.tangosol.run.xml.XmlElement, com.tangosol.net.BackingMapManagerContext, java.lang.ClassLoader)
- instantiateDocument() - Method in class com.tangosol.run.xml.SimpleParser
- 
Factory method to instantiate an XmlDocument implementation.
- instantiateDumpHeldLocksAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Factory for LocksDumpAction
- instantiateElement(String, Object) - Method in class com.tangosol.run.xml.SimpleElement
- 
Instantiate an XmlElement implementation for an element.
- instantiateElementList() - Method in class com.tangosol.run.xml.SimpleElement
- 
Instantiate a List implementation that will hold child elements.
- instantiateEntry() - Method in class com.tangosol.net.cache.LocalCache
- 
Factory method.
- instantiateEntry() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Factory method.
- instantiateEntry() - Method in class com.tangosol.util.ObservableHashMap
- 
Factory method.
- instantiateEntry() - Method in class com.tangosol.util.SafeHashMap
- 
Factory pattern: instantiate an un-initialized Entry object.
- instantiateEntry(Binary, Binary) - Method in class com.tangosol.io.nio.BinaryMap
- 
Factory pattern: Instantiate an Entry object.
- instantiateEntry(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- 
Factory pattern: instantiate a Map.Entry object for the specified key.
- instantiateEntry(Object, Object) - Method in class com.tangosol.net.cache.SerializationCache.EntrySet
- 
Factory pattern.
- instantiateEntry(Object, Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet
- 
Factory pattern.
- instantiateEntry(Object, Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- 
Instantiate an Entry instance.
- instantiateEntry(Object, Object) - Method in class com.tangosol.util.OpenHashMap.EntrySet
- 
Factory pattern.
- instantiateEntry(Object, Object, int) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Factory for Entry.
- instantiateEntry(Object, Object, int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Factory for Entry.
- instantiateEntry(Object, Object, Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: instantiate a queue entry.
- instantiateEntry(Object, Object, Object, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: instantiate a queue entry.
- instantiateEntry(K, V) - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
- 
Factory pattern.
- instantiateEntry(K, V, int) - Method in class com.tangosol.util.SafeHashMap
- 
Factory pattern: instantiate initialized Entry object.
- instantiateEntryAttributes(SerializationCache.EntryAttributes, long, long, int) - Method in class com.tangosol.net.cache.SerializationCache
- 
Factory pattern: Construct an attribute holder for an entry.
- instantiateEntryResource(NamedCache, Object, Class) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Create an instance ofEntryResourcefor the specified resource configuration.
- instantiateEntrySet() - Method in class com.tangosol.io.nio.BinaryMap
- 
Factory pattern.
- instantiateEntrySet() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Factory pattern.
- instantiateEntrySet() - Method in class com.tangosol.net.cache.OverflowMap
- 
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: instantiate an entry set for this backing map.
- instantiateEntrySet() - Method in class com.tangosol.net.cache.SerializationCache
- 
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- 
Instantiate an Entry Set.
- instantiateEntrySet() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.util.ChainedMap
- 
(Factory pattern) Instantiate an Entry Set or subclass thereof.
- instantiateEntrySet() - Method in class com.tangosol.util.OpenHashMap
- 
Factory pattern: Create a Set that represents the entries in the Map.
- instantiateEntrySet() - Method in class com.tangosol.util.SafeHashMap
- 
Factory pattern.
- instantiateEntrySet() - Method in class com.tangosol.util.SegmentedHashMap
- 
Factory for EntrySet
- instantiateEntrySet(Collection<Map.Entry<FK, FV>>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Create a Converter Entry Set.
- instantiateEntrySet(Set<Map.Entry<FK, FV>>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Create a Converter Entry Set.
- instantiateEntrySetResource(NamedCache, Set, Class) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Create an instance ofEntrySetResourcefor the specified resource configuration.
- instantiateEnvironment(BerkeleyDBBinaryStoreManager) - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Create a EnvironmentHolder within the specified parent directory.
- instantiateEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Create the bundler for the erase operations.
- instantiateEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Create the bundler for the erase operations.
- instantiateEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Create the bundler for the erase operations.
- instantiateEraseBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Create the bundler for the erase operations.
- instantiateEventQueue() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Create a self-processing event queue.
- instantiateEventRouter(MapListener<? super K, ? super V_FRONT>, boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Factory Method: Instantiate a listener on the internal map that will direct events to the passed listener, either synchronously or asynchronously as appropriate.
- instantiateEventsVisitor(long, Filter, long, Map<Long, MapEvent>, Converter<Long, ReadBuffer>, Converter<ReadBuffer, Long>, Converter<Object, ReadBuffer>, Converter<ReadBuffer, Object>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Create aPersistentStore.Visitorthat can read a PersistentStore and populate the providedmapEventswith events that are larger than the provided version (inclusive) and match the givenFilter.
- instantiateEventsVisitor(long, Set, long, Map<Long, MapEvent>, Converter<Long, ReadBuffer>, Converter<ReadBuffer, Long>, Converter<Object, ReadBuffer>, Converter<ReadBuffer, Object>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Create aPersistentStore.Visitorthat can read a PersistentStore and populate the providedmapEventswith events that are larger than the provided version (inclusive) and within the given set of keys.
- instantiateExclusiveClosable() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return anAutoCloseablethat will transition this PersistentStore out of exclusive mode.
- instantiateExplainStep(Filter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Instantiate a new explain step for the given filter and add it to this result's list of steps.
- instantiateExternalBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a backing Map using the "external-scheme" element.
- instantiateFactory(ClassLoader, XmlElement, XmlElement, String, String, ParameterResolver) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Create a new instance ofConfigurableCacheFactorybased on a givenClassLoaderand cache configuration XML.
- instantiateFakeBinaryStore() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Factory method: Instantiate a FakeBinaryStore.
- instantiateFlashJournalBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a backing Map using the "flashjournal-scheme" element.
- instantiateForwardIndex() - Method in class com.tangosol.util.ConditionalIndex
- 
Instantiate the forward index.
- instantiateForwardIndex() - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Instantiate the forward index.
- instantiateForwardIndex() - Method in class com.tangosol.util.SimpleMapIndex
- 
Instantiate the forward index.
- instantiateFrontMapListener() - Method in class com.tangosol.net.cache.CachingMap
- 
Factory pattern: instantiate front map listener.
- instantiateFrontMapListener() - Method in class com.tangosol.net.cache.OverflowMap
- 
Factory pattern: Front Map Listener.
- instantiateFrontMapListener() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Factory pattern: Front Map Listener.
- instantiateGetEntryAction() - Method in class com.tangosol.util.SegmentedHashMap
- 
Factory for GetEntryAction
- instantiateInsertAction() - Method in class com.tangosol.util.SegmentedHashMap
- 
Factory for InsertAction
- instantiateInternalCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Create the internal cache used by theContinuousQueryCache.
- instantiateInternalKeySet() - Method in class com.tangosol.net.cache.OverflowMap
- 
Factory pattern: Create a read-only Set of keys in the Overflow Map
- instantiateInternalListener() - Method in class com.tangosol.net.cache.LocalCache
- 
Factory pattern: Instantiate an internal MapListener to listen to this cache and report changes to the CacheStore.
- instantiateInternalListener() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Create a MapListener that listens to the internal cache and routes those events to anyone listening to this ReadWriteBackingMap.
- instantiateInternalListener() - Method in class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Factory pattern: Create a MapListener that listens to the internal cache and routes those events to anyone listening to this VersionedBackingMap.
- instantiateInternalListener() - Method in class com.tangosol.util.WrapperObservableMap
- 
Instantiate a MapListener to listen to the wrapped map.
- instantiateInternalMap(Comparator) - Method in class com.tangosol.util.SortedBag
- 
Factory for the sorted internal map to use to hold the bag elements.
- instantiateInverseIndex(boolean, Comparator) - Method in class com.tangosol.util.SimpleMapIndex
- 
Instantiate the inverse index.
- instantiateIterator() - Method in class com.tangosol.net.cache.OverflowMap.EntrySet
- 
Factory pattern.
- instantiateIterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
- 
Factory pattern.
- instantiateIterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
- 
Factory pattern: Create a values Iterator.
- instantiateIterator() - Method in class com.tangosol.util.OpenHashMap.EntrySet
- 
Factory pattern.
- instantiateIterator() - Method in class com.tangosol.util.SafeHashMap.EntrySet
- 
Factory pattern.
- instantiateIterator() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
- 
Factory for EntrySetIterator.
- instantiateIterator(LongArray.Iterator<F>) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- 
Instantiate a new Iterator wrapping the provided iterator.
- instantiateIterator(Iterator<F>, Converter<F, T>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Create a Converter Iterator.
- instantiateKeyIterator() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Factory pattern: Create a mutable Iterator over the keys in the Map
- instantiateKeyMap() - Method in class com.tangosol.net.cache.SerializationMap
- 
Instantiate a key-map.
- instantiateKeySet() - Method in class com.tangosol.io.nio.BinaryMap
- 
Factory pattern.
- instantiateKeySet() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Factory pattern.
- instantiateKeySet() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: instantiate a key set for this backing map.
- instantiateKeySet() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.util.OpenHashMap
- 
Factory pattern: Create a Set that represents the keys in the Map
- instantiateKeySet() - Method in class com.tangosol.util.SafeHashMap
- 
Factory pattern.
- instantiateKeySet() - Method in class com.tangosol.util.SegmentedHashMap
- 
Factory for KeySet.
- instantiateKeyToBinaryConverter(ClassLoader, boolean) - Method in interface com.tangosol.net.PartitionedService
- instantiateList(List<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- 
Create a Converter List.
- instantiateListIterator(ListIterator<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- 
Create a Converter ListIterator.
- instantiateLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Create the bundler for the load operations.
- instantiateLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Create the bundler for the load operations.
- instantiateLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Create the bundler for the load operations.
- instantiateLoadBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Create the bundler for the load operations.
- instantiateLoadCalculator(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Instantiate the load calculator.
- instantiateLoadComparator(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return a comparator for primary or backup partition load.
- instantiateLocalCache(int, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a LocalCache using the specified parameters.
- instantiateLocalCache(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a backing Map using the "local-scheme" element.
- instantiateLock(Object) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Factory pattern.
- instantiateLockAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Factory for LockAction
- instantiateMap() - Method in class com.tangosol.coherence.rest.util.JsonMap
- instantiateMap() - Method in class com.tangosol.run.xml.MapAdapter
- instantiateMap() - Method in class com.tangosol.util.MapSet
- 
Factory pattern: Provide an underlying Map for this Set implementation to store its contents in.
- instantiateMap() - Method in class com.tangosol.util.SafeHashSet
- 
Factory pattern: Provide an underlying Map for this Set implementation to store its contents in.
- instantiateMap() - Method in class com.tangosol.util.SegmentedHashSet
- 
Factory pattern: Provide an underlying Map for this Set implementation to store its contents in.
- instantiateMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a backing Map using the "class-scheme" element.
- instantiateMap(Class) - Method in class com.tangosol.util.CopyOnWriteMap
- instantiateMap(Map<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Create a Converter Map.
- instantiateMapEvent(int, Object, Object, Object) - Method in class com.tangosol.net.cache.LocalCache
- 
Factory pattern: instantiate a new CacheEvent corresponding to the specified parameters.
- instantiateMapEvent(int, Object, Object, Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Factory pattern: instantiate a new MapEvent corresponding to the specified parameters.
- instantiateMapListener(AbstractRepositoryBase.Listener<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Factory method forAbstractRepositoryBase.Listeneradapter toMapListener.
- instantiateMapListener(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a MapListener using the using the "class-scheme" element.
- instantiateMemberListener() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Instantiate a member listener to subscribe to service membership events.
- instantiateModificationSet(int) - Method in class com.tangosol.util.SubSet
- 
Instantiate a new modification set containing either removed or retained items.
- instantiateNamedQueryResource(NamedCache, NamedQuery, int) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Create an instance ofNamedQueryResourcefor the specified resource configuration.
- instantiateNearCache(Map, NamedCache, int) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an NearCache using the specified parameters.
- instantiateNilValue(int, int) - Method in class com.tangosol.io.pof.reflect.PofSparseArray
- 
Instantiate aPofSparseArray.NilPofValue(factory method).
- instantiateNilValue(int, int) - Method in class com.tangosol.io.pof.reflect.PofUniformSparseArray
- 
Instantiate aPofSparseArray.NilPofValue(factory method).
- instantiateNode(long, long) - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Create a new Node with the specified key and value.
- instantiateNode(long, Long) - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Factory pattern: create a new Node with the specified key and value.
- instantiateNode(long, V) - Method in class com.tangosol.util.AbstractSparseArray
- 
Factory pattern: create a new Node with the specified key and value.
- instantiateNode(long, V) - Method in class com.tangosol.util.SparseArray
- 
Factory pattern: create a new Node with the specified key and value.
- instantiateNode(Object) - Method in class com.tangosol.util.RecyclingLinkedList
- 
Instantiate a Node.
- instantiateNode(Object) - Method in class com.tangosol.util.SafeLinkedList
- 
Instantiate a Node.
- instantiateNotOwnedFilter(Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Instantiate and return a NotOwnedFilter with the specified ownership.
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder
- 
Return the OPToken for this command.
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
- instantiateOpToken() - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder
- instantiateOverflowBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a backing Map using the "overflow-scheme" element.
- instantiateOverflowMap(ObservableMap, Map, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an OverflowMap using the specified parameters.
- instantiateOverloadedFilter(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Instantiate a filter that matches members with an over-load.
- instantiatePagedExternalBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a backing Map using the "paged-external-scheme" element.
- instantiatePagedStore(int) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Factory method: Instantiate a PagedBinaryStore.
- instantiateParser(Reader) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- instantiatePartitionedBackingMap(MapBuilder, ParameterResolver, MapBuilder.Dependencies, CachingScheme) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Instantiate a partitioned backing map (an instance ofObservableSplittingBackingMap) usingExtensibleConfigurableCacheFactory.PartitionedBackingMapManager.
- instantiatePartitionedCachePolicy(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[], AddressProvider) - Static method in class com.tangosol.net.ConfigurableQuorumPolicy
- 
Instantiate an action policy for a PartitionedCache service.
- instantiatePeriodicTask(Runnable, long) - Method in class com.tangosol.util.TaskDaemon
- 
Create a task that will automatically be run on a periodic basis.
- instantiatePersistenceTools(OfflinePersistenceInfo) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Factory method to create aPersistenceToolsimplementation.
- instantiatePersistenceTools(OfflinePersistenceInfo, String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Instantiate an instance ofPersistenceToolsrelevant to this archiver and the provided snapshot.
- instantiatePersistenceVisitor(CachePersistenceHelper.Visitor) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Instantiate avisitorfor the PersistentStore backed by the
- instantiatePersistentStore(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Factory method for PersistentStore implementations managed by this PersistenceManager.
- instantiatePofValue(PofValue, int, ReadBuffer, PofContext, int, ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.reflect.PofValueParser
- 
Creates a PofValue instance.
- instantiateProxyPolicy(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[]) - Static method in class com.tangosol.net.ConfigurableQuorumPolicy
- 
Instantiate an action policy for the a proxy service.
- instantiateQueue() - Method in class com.tangosol.net.LoadBalancer
- 
Factory method: Create a queue.
- instantiateQueueDaemon() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Factory method: Instantiate a QueueDaemon.
- instantiateRamJournalBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a backing Map using the "ramjournal-scheme" element.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.io.AbstractReadBuffer
- 
Factory method: Instantiate a ReadBuffer for a portion of this ReadBuffer.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.io.ByteArrayReadBuffer
- 
Factory method: Instantiate a ReadBuffer for a portion of this ReadBuffer.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Factory method: Instantiate a ReadBuffer for a portion of this ReadBuffer.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Factory method: Instantiate a ReadBuffer for a portion of this ReadBuffer.
- instantiateReadBuffer(int, int) - Method in class com.tangosol.util.Binary
- 
Factory method: Instantiate a ReadBuffer for a portion of this ReadBuffer.
- instantiateReadLatch(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate a new read latch the given key.
- instantiateReadQueue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate a new ReadQueue object.
- instantiateReadThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate the refresh-ahead thread.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, BinaryEntryStore, boolean, int, double) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, BinaryEntryStore, boolean, int, double, boolean) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, boolean, int, double) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, boolean, int, double, boolean) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, NonBlockingEntryStore, boolean, int, double, boolean) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Construct a ReadWriteBackingMap using the specified parameters.
- instantiateReadWriteBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a ReadWriteBackingMap using the "read-write-backing-map-scheme" element.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, BinaryEntryStore, boolean, int, double) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, BinaryEntryStore, boolean, int, double, boolean) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, CacheLoader, boolean, int, double) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, CacheLoader, boolean, int, double, boolean) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, NonBlockingEntryStore, boolean, int, double, boolean) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Construct a ReadWriteSplittingBackingMap using the specified parameters.
- instantiateRemoveAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Factory for RemoveAction
- instantiateRemoveAction() - Method in class com.tangosol.util.SegmentedHashMap
- 
Factory for RemoveAction
- instantiateRemoveListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Factory Method: Instantiate aMapListenerfor evicting items from theContinuousQueryCache.
- instantiateRequestHandler(LoadBalancer.Queue) - Method in class com.tangosol.net.LoadBalancer
- 
Factory method: Create a RequestHandler.
- instantiateResponseHandler(LoadBalancer.RequestHandler) - Method in class com.tangosol.net.LoadBalancer
- 
Factory method: Create a ResponseHandler.
- instantiateRoot(String) - Method in class com.tangosol.run.xml.SaxParser
- 
Instantiate an XmlElement implementation for a root element.
- instantiateSafeIterator(boolean, long) - Method in class com.tangosol.util.AbstractSafeLongArray
- 
Instantiate a SafeIterator around the specified delegate iterator.
- instantiateSafeIterator(boolean, long) - Method in class com.tangosol.util.ReadHeavyLongArray
- instantiateSafetyFilter(Ownership, int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Instantiate and return a SafetyFilter with the specified ownership.
- instantiateScopeResolver() - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Instantiate the defaultScopeResolver.
- instantiateSerializationCache(BinaryStore, int, boolean) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Construct an SerializationCache using the specified parameters.
- instantiateSerializationCache(BinaryStore, int, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an SerializationCache using the specified parameters.
- instantiateSerializationCache(BinaryStore, int, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Construct an SerializationCache using the specified parameters.
- instantiateSerializationCache(BinaryStore, int, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an SerializationCache using the specified parameters.
- instantiateSerializationMap(ParameterResolver, BinaryStore, boolean, ClassLoader, int, int) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Instantiate a SerializationMap, SerializationCache, SimpleSerializationMap, or any sub-class thereof.
- instantiateSerializationMap(BinaryStore, boolean) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Construct an SerializationMap using the specified parameters.
- instantiateSerializationMap(BinaryStore, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an SerializationMap using the specified parameters.
- instantiateSerializationMap(BinaryStore, boolean, ClassLoader, int, int, String, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Instantiate a SerializationMap, SerializationCache, SimpleSerializationMap, or any sub-class thereof.
- instantiateSerializationMap(BinaryStore, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Construct an SerializationMap using the specified parameters.
- instantiateSerializationMap(BinaryStore, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an SerializationMap using the specified parameters.
- instantiateSerializationPagedCache(BinaryStoreManager, int, int, boolean, boolean) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Construct an SerializationPagedCache using the specified parameters.
- instantiateSerializationPagedCache(BinaryStoreManager, int, int, boolean, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an SerializationPagedCache using the specified parameters.
- instantiateSerializationPagedCache(BinaryStoreManager, int, int, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Construct an SerializationPagedCache using the specified parameters.
- instantiateSerializationPagedCache(BinaryStoreManager, int, int, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an SerializationPagedCache using the specified parameters.
- instantiateSerializer() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Create aSerializerappropriate for the mode this cache is operating under (i.e., binary vs non-binary).
- instantiateSerializer(XmlElement, int, Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Create aPofSerializerfrom the provided XML serializer element.
- instantiateSerializer(Class<? extends PofSerializer>, Integer, Class<?>) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Instantiate specifiedPofSerializer.
- instantiateSet() - Method in class com.tangosol.util.LiteSet
- 
(Factory pattern) Instantiate a Set object to store items in once the "lite" threshold has been exceeded.
- instantiateSet() - Method in class com.tangosol.util.SimpleMapIndex
- 
Factory method used to create a new set containing the keys associated with a single value.
- instantiateSet(Set<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- 
Create a Converter Set.
- instantiateSimpleOverflowMap(ObservableMap, Map, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a SimpleOverflowMap using the specified parameters.
- instantiateSimpleSerializationMap(BinaryStore, boolean) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Construct a SimpleSerializationMap using the specified parameters.
- instantiateSimpleSerializationMap(BinaryStore, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a SimpleSerializationMap using the specified parameters.
- instantiateSimpleSerializationMap(BinaryStore, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Construct a SimpleSerializationMap using the specified parameters.
- instantiateSimpleSerializationMap(BinaryStore, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a SimpleSerializationMap using the specified parameters.
- instantiateSizeAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Factory for SizeAction
- instantiateSortedMap(SortedMap<FK, FV>, Converter<FK, TK>, Converter<TK, FK>, Converter<FV, TV>, Converter<TV, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- 
Create a Converter SortedMap.
- instantiateSortedSet(SortedSet<F>, Converter<F, T>, Converter<T, F>) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- 
Create a Converter SortedSet.
- instantiateStatus() - Method in class com.tangosol.net.cache.OverflowMap
- 
Factory method: Instantiate a Status object.
- instantiateStatus() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Factory method: Instantiate a Status object.
- instantiateStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Create the bundler for the store operations.
- instantiateStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Create the bundler for the store operations.
- instantiateStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Create the bundler for the store operations.
- instantiateStoreBundler() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Create the bundler for the store operations.
- instantiateStrengthComparator(Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Instantiate a StrengthComparator for the specified reference ownership.
- instantiateSubclass(String, Class, ClassLoader, Object[], XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an instance of the specified class using the specified parameters.
- instantiateTraceStep(Filter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Instantiate a new trace step for the given filter and add it to this result's list of steps.
- instantiateTruncateAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Factory for TruncateAction
- instantiateUnderloadedFilter(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Instantiate a filter that matches members with an under-load.
- instantiateUnlockAction() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Factory for UnlockAction
- instantiateUnmodifiableIterator(LongArray.Iterator<V>) - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Factory pattern: instantiate an UnmodifiableIterator.
- instantiateValues() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Factory pattern: Instantiate the values Collection.
- instantiateValues() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Factory pattern: Instantiate the values Collection.
- instantiateValuesCollection() - Method in class com.tangosol.io.nio.BinaryMap
- 
Factory pattern.
- instantiateValuesCollection() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Factory pattern.
- instantiateValuesCollection() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern.
- instantiateValuesCollection() - Method in class com.tangosol.util.SafeHashMap
- 
Factory pattern.
- instantiateValuesCollection() - Method in class com.tangosol.util.SegmentedHashMap
- 
Factory for ValuesCollection.
- instantiateVersionCacheListener() - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Factory method: Provide a MapListener that listens to the VersionCache and invalidates local entries accordingly.
- instantiateVersionedBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, NamedCache, NamedCache, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a VersionedBackingMap using the specified parameters.
- instantiateVersionedBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheStore, boolean, int, double, NamedCache, NamedCache, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct a VersionedBackingMap using the specified parameters.
- instantiateVersionedBackingMap(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Create a VersionedBackingMap using the "versioned-backing-map-scheme" element.
- instantiateVersionedNearCache(Map, NamedCache, NamedCache) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Construct an VersionedNearCache using the specified parameters.
- instantiateWorker() - Method in class com.tangosol.util.Daemon
- 
Instantiate a DaemonWorker that will be used as a daemon.
- instantiateWrapperStore(BinaryStore) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Factory method: Instantiate a WrapperBinaryStore.
- instantiateWriteQueue() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate a new WriteQueue object.
- instantiateWriteThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Factory pattern: Instantiate the write-behind thread.
- Instruction - Interface in com.tangosol.util.fsm
- 
A marker interface forInstructions toFiniteStateMachines.
- Instruction.ProcessEvent<S extends Enum<S>> - Class in com.tangosol.util.fsm
- Instruction.TransitionTo<S extends Enum<S>> - Class in com.tangosol.util.fsm
- INT_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
- 
An empty array of ints.
- IntAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.IntAdapter
- 
Construct a SimpleAdapter.
- IntArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Construct an IntArrayAdapter.
- intBinaryOperator(Remote.IntBinaryOperator) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable IntBinaryOperator.
- intConsumer(Remote.IntConsumer) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable IntConsumer.
- IntDecoratedObject(Object, int) - Constructor for class com.tangosol.util.ExternalizableHelper.IntDecoratedObject
- 
Construct an IntDecorated object with the specified value and decoration.
- INTEGERLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
The numberic code for a integer literal
- INTEGERLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
The numberic code for a integer literal
- interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class com.oracle.coherence.grpc.proxy.GrpcMetricsInterceptor
- interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class com.oracle.coherence.grpc.proxy.ServerLoggingInterceptor
- Interceptor - Annotation Type in com.tangosol.net.events.annotation
- 
Interceptor is an annotation that can be applied toEventInterceptorimplementations.
- Interceptor.Order - Enum in com.tangosol.net.events.annotation
- 
This enum provides an indication of whether theEventInterceptorshould request to be first in the chain ofEventInterceptors, hence have a HIGH priority.
- InterceptorMetadataResolver - Interface in com.tangosol.net.events
- 
Supports custom resolution of interceptor class in cases when the interceptor may be proxied, such as when using CDI.
- InterceptorProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AElementProcessorfor the <interceptor> element.
- InterceptorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InterceptorProcessor
- 
Construct an InterceptorProcessor.
- InterceptorRegistry - Interface in com.tangosol.net.events
- 
An InterceptorRegistry manages the registration ofEventInterceptors and facilitates the introduction of EventInterceptors toEventDispatchers.
- InterceptorsProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AElementProcessorfor the <interceptors> element.
- InterceptorsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InterceptorsProcessor
- INTERNAL_SERVICE - Static variable in class com.tangosol.net.security.LocalPermission
- 
"Service.getInternalService" permission.
- InternalCacheSchemeProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AInternalCacheSchemeProcessoris responsible for processing an internal-cache-schemeXmlElements to produce aMapBuilder.
- InternalCacheSchemeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InternalCacheSchemeProcessor
- internalClose(Consumer<? super BinaryStore>) - Method in class com.tangosol.io.AsyncBinaryStore
- 
Close the store.
- InternalConverter<T> - Interface in com.tangosol.coherence.jcache.common
- 
Converts values of a specified type to and from an internal representation.
- InternalKeySet() - Constructor for class com.tangosol.net.cache.OverflowMap.InternalKeySet
- InternalKeySetIterator() - Constructor for class com.tangosol.net.cache.OverflowMap.InternalKeySet.InternalKeySetIterator
- 
Default constructor.
- InternalListener() - Constructor for class com.tangosol.net.cache.LocalCache.InternalListener
- InternalListener() - Constructor for class com.tangosol.util.WrapperObservableMap.InternalListener
- InternalMapListener() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
- InternalMapListener() - Constructor for class com.tangosol.net.cache.VersionedBackingMap.InternalMapListener
- 
Deprecated.
- InternalMapListener(MapListenerSupport, Converter, Converter) - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.InternalMapListener
- 
Construct theMapListenerto be registered with the internalObservableMap.
- interrupted() - Static method in class com.oracle.coherence.common.base.Blocking
- 
Return true if the thread is interrupted ortimed out.
- intersects(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSet
- 
Check whether or not the specified partition set intersects with this set.
- intersects(Object[], Object[]) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Return a List of stores (GUIDs) that allows the caller to derive whether the provided sets are disjoint, intersect or equal.
- intFunction(Remote.IntFunction<R>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable IntFunction.
- intPredicate(Remote.IntPredicate) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable IntPredicate.
- introduceEventDispatcher(String, EventDispatcher) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- introduceEventDispatcher(String, EventDispatcher) - Method in class com.oracle.coherence.mp.config.CoherenceConfigSource
- introduceEventDispatcher(String, EventDispatcher) - Method in interface com.tangosol.net.Coherence.LifecycleListener
- introduceEventDispatcher(String, EventDispatcher) - Method in interface com.tangosol.net.events.EventDispatcherAwareInterceptor
- 
Introduce and possibly bind thisEventInterceptorto the specifiedEventDispatcher.
- introduceEventDispatcher(String, EventDispatcher) - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Introduce and possibly bind thisEventInterceptorto the specifiedEventDispatcher.
- intSupplier(Remote.IntSupplier) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable IntSupplier.
- intToDoubleFunction(Remote.IntToDoubleFunction) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable IntToDoubleFunction.
- intToLongFunction(Remote.IntToLongFunction) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable IntToLongFunction.
- intUnaryOperator(Remote.IntUnaryOperator) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable IntUnaryOperator.
- intValue() - Method in class com.oracle.coherence.common.base.MutableLong
- intValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Returns the current value of thisAsyncAtomicIntegeras anint.
- intValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Returns the current value of thisDistributedAtomicLongas anintafter a narrowing primitive conversion.
- intValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- intValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- intValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- intValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- intValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Returns the current value of thisAtomicIntegeras anint.
- intValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Returns the current value of thisAtomicLongas anintafter a narrowing primitive conversion.
- intValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- intValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- intValue() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- intValue() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- intValue() - Method in class com.tangosol.io.pof.RawQuad
- 
Returns the value of the specified number as anint.
- invalidate() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Drop references to the underlying Collection and the Converters.
- invalidateFront(Object) - Method in class com.tangosol.net.cache.CachingMap
- 
Invalidate the key from the front.
- INVALIDATION_STRATEGY - Static variable in class com.tangosol.net.cache.CachingMap
- 
String representation forCachingMap.LISTEN_NONE,CachingMap.LISTEN_PRESENT,CachingMap.LISTEN_ALL,CachingMap.LISTEN_AUTO,CachingMap.LISTEN_LOGICAL.
- InvalidConfigServiceLoadBalancerBuilder - Class in com.tangosol.coherence.config.builder
- 
InvalidConfigServiceLoadBalancerBuilderdefers reporting configuration exception until realized.
- InvalidConfigServiceLoadBalancerBuilder(String, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.InvalidConfigServiceLoadBalancerBuilder
- 
ConstructsInvalidConfigServiceLoadBalancerBuilder.
- inverse(Comparator) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
- 
Reverse ordering of a given comparator.
- InverseComparator<T> - Class in com.oracle.coherence.common.base
- 
InverseComparator is a wrapper comparator which simply inverses the comparison result.
- InverseComparator<T> - Class in com.tangosol.util.comparator
- 
Comparator that reverses the result of another comparator.
- InverseComparator() - Constructor for class com.tangosol.util.comparator.InverseComparator
- 
Default constructor (for ExternalizableLite and PortableObject).
- InverseComparator(Comparator<? super T>) - Constructor for class com.tangosol.util.comparator.InverseComparator
- 
Construct an InverseComparator.
- InverseComparator(Comparator<T>) - Constructor for class com.oracle.coherence.common.base.InverseComparator
- 
Construct an InverseComparator which inverts the specified comparator.
- invert() - Method in class com.tangosol.net.partition.PartitionSet
- 
Invert all the partitions.
- Invocable - Interface in com.tangosol.net
- 
The Invocable object is a cluster-portable object that can be invoked on any set of remote members and each can optionally register a return value for the invocation.
- InvocableInOrder - Interface in com.tangosol.net
- 
The InvocableInOrder interface allows to control the ordering in which the results of Invocable tasks are returned back to the caller by the Invocation service with a thread pool.
- InvocableMap<K,V> - Interface in com.tangosol.util
- 
An InvocableMap is a Map against which both entry-targeted processing and aggregating operations can be invoked.
- InvocableMap.Entry<K,V> - Interface in com.tangosol.util
- 
An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.
- InvocableMap.EntryAggregator<K,V,R> - Interface in com.tangosol.util
- 
An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.
- InvocableMap.EntryProcessor<K,V,R> - Interface in com.tangosol.util
- 
An invocable agent that operates against the Entry objects within a Map.
- InvocableMap.ParallelAwareAggregator<K,V,P,R> - Interface in com.tangosol.util
- 
Deprecated.This interface was deprecated in Coherence 12.2.1 and might be removed in a future release. UseInvocableMap.StreamingAggregatorinstead.
- InvocableMap.ParallelAwareAggregator.PartialResultAggregator<P> - Interface in com.tangosol.util
- 
Deprecated.This interface was deprecated in Coherence 12.2.1 and might be removed in a future release. UseInvocableMap.StreamingAggregatorinstead.
- InvocableMap.StreamingAggregator<K,V,P,R> - Interface in com.tangosol.util
- 
A StreamingAggregator is an extension ofInvocableMap.EntryAggregatorthat processes entries in a streaming fashion and provides better control overexecution characteristics.
- InvocableMapHelper - Class in com.tangosol.util
- 
Helper methods for InvocableMap implementations and Filter related evaluation.
- InvocableMapHelper() - Constructor for class com.tangosol.util.InvocableMapHelper
- InvocableMapHelper.IndexAdapter - Class in com.tangosol.util
- 
MapListener implementation that routes the map events into the corresponding MapIndex calls.
- InvocableMapHelper.RoutingBinaryEntry - Class in com.tangosol.util
- 
BinaryEntry wrapper that routes the getValue()/getBinaryValue() calls onto getOriginalValue()/getOriginalBinaryValue().
- InvocableMapHelper.RoutingMapTriggerEntry - Class in com.tangosol.util
- 
MapTrigger.Entry wrapper that routes the getValue() call onto getOriginalValue().
- InvocableMapHelper.SimpleEntry<K,V> - Class in com.tangosol.util
- 
Simple implementation of the InvocableMap.Entry interface.
- invocationCompleted() - Method in interface com.tangosol.net.InvocationObserver
- 
This method is called by theInvocationServiceto inform the InvocationObserver that all service members have either finished theInvocableobject execution or are not (or no longer) running the InvocationService.
- InvocationObserver - Interface in com.tangosol.net
- 
The InvocationObserver is an object that asynchronously receives notification of results from the execution of Invocable objects.
- InvocationScheme - Class in com.tangosol.coherence.config.scheme
- 
TheInvocationSchemeclass builds an Invocation service.
- InvocationScheme() - Constructor for class com.tangosol.coherence.config.scheme.InvocationScheme
- 
Constructs aInvocationScheme.
- InvocationService - Interface in com.tangosol.net
- 
The InvocationService is a Service for delivering executable objects to cluster members for distributed invocation.
- InvocationServiceProxyProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse invocation-service-proxy configuration element tp produce aDefaultInvocationServiceProxyDependenciesobject.
- InvocationServiceProxyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.InvocationServiceProxyProcessor
- invoke(CacheRequestHolder<InvokeRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theInvokeRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of theInvokeRequestrequest as a serialized Boolean.
- invoke(InvokeRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Invoke anInvocableMap.EntryProcessoragainst an entry in a cache.
- invoke(InvokeRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- invoke(InvokeRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- invoke(MBeanAccessor.QueryBuilder.ParsedQuery, String, Object[], String[]) - Method in class com.tangosol.net.management.MBeanAccessor
- 
Invoke a JMX MBean operation on one or many MBeans determined by the providedMBeanAccessor.QueryBuilder.
- invoke(Remote.Function<AtomicBoolean, R>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicBoolean, R>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicBoolean, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicBoolean, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicInteger, R>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicInteger, R>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicInteger, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicInteger, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicLong, R>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicLong, R>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicLong, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicLong, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicMarkableReference<V>, R>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicMarkableReference<V>, R>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicMarkableReference<V>, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicMarkableReference<V>, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicReference<V>, R>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicReference<V>, R>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicReference<V>, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicReference<V>, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicStampedReference<V>, R>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicStampedReference<V>, R>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicStampedReference<V>, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- 
Apply specified function against the remote object and return the result.
- invoke(Remote.Function<AtomicStampedReference<V>, R>, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- 
Apply specified function against the remote object and return the result.
- invoke(Class, Object, String, Object[]) - Static method in class com.oracle.coherence.common.base.Classes
- 
Invoke the specified method using the passed arguments.
- invoke(Class, Object, String, Object[]) - Static method in class com.tangosol.util.ClassHelper
- 
Invoke the specified method using the passed arguments.
- invoke(Object, String, Object[]) - Static method in class com.oracle.coherence.common.base.Classes
- 
Invoke the specified instance method using the passed arguments.
- invoke(Object, String, Object[]) - Static method in class com.tangosol.util.ClassHelper
- 
Invoke the specified instance method using the passed arguments.
- invoke(String, String, Object[], String[]) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Invoke an operation on the specified MBean.
- invoke(String, String, Object[], String[]) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- invoke(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aInvokeRequest.
- invoke(K, InvocableMap.EntryProcessor<K, V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Invoke the passed EntryProcessor against the Entry specified by the passed key, returning the result of the invocation.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against the Entry specified by the passed key asynchronously, returning aCompletableFuturethat can be used to obtain the result of the invocation.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.NearCache
- 
Invoke the passed EntryProcessor against the Entry specified by the passed key, returning the result of the invocation.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Invoke the passed EntryProcessor against the Entry specified by the passed key, returning the result of the invocation.
- invoke(K, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.util.InvocableMap
- 
Invoke the passed EntryProcessor against the Entry specified by the passed key, returning the result of the invocation.
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- invoke(TK, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- 
Invoke the passed EntryProcessor against the Entry specified by the passed key, returning the result of the invocation.
- invoke(TK, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Invoke the passed EntryProcessor against the Entry specified by the passed key, returning the result of the invocation.
- Invoke() - Constructor for class com.tangosol.net.management.MBeanAccessor.Invoke
- 
Default constructor.
- Invoke(MBeanAccessor.QueryBuilder.ParsedQuery, String, Object[], String[]) - Constructor for class com.tangosol.net.management.MBeanAccessor.Invoke
- 
Create an Invoke object.
- invokeAll(InvokeAllRequest, StreamObserver<Entry>) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Invoke anInvocableMap.EntryProcessoragainst multiple entries in a cache.
- invokeAll(InvokeAllRequest, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- invokeAll(InvokeAllRequest, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- invokeAll(Filter<?>, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter asynchronously, returning aCompletableFuturethat can be used to obtain the result of the invocation for each entry.
- invokeAll(Filter<?>, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super K, ? super R>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter asynchronously, returning aCompletableFuturethat can be used to determine if the operation completed successfully.
- invokeAll(Filter<?>, InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter asynchronously, returning aCompletableFuturethat can be used to determine if the operation completed successfully.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.NearCache
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.util.InvocableMap
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.
- invokeAll(Filter, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.
- invokeAll(InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against all the entries asynchronously, returning aCompletableFuturethat can be used to obtain the result of the invocation for each entry.
- invokeAll(InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.util.InvocableMap
- 
Invoke the passed EntryProcessor against all the entries, returning the result of the invocation for each.
- invokeAll(InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super K, ? super R>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against all the entries asynchronously, returning aCompletableFuturethat can be used to determine if the operation completed successfully.
- invokeAll(InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against all the entries asynchronously, returning aCompletableFuturethat can be used to determine if the operation completed successfully.
- invokeAll(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aInvokeAllRequest.
- invokeAll(String, String, String, Iterable<ByteString>, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aInvokeAllRequest.
- invokeAll(Collection<? extends Remote.Callable<T>>) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Executes the given tasks, returning a list of Futures holding their status and results when all complete.
- invokeAll(Collection<? extends Remote.Callable<T>>, long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Executes the given tasks, returning a list of Futures holding their status and results when all complete or the timeout expires, whichever happens first.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V_FRONT, R>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys, returning the result of the invocation for each.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys asynchronously, returning aCompletableFuturethat can be used to obtain the result of the invocation for each entry.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.NearCache
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys, returning the result of the invocation for each.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys, returning the result of the invocation for each.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>) - Method in interface com.tangosol.util.InvocableMap
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys, returning the result of the invocation for each.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super K, ? super R>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys asynchronously, returning aCompletableFuturethat can be used to determine if the operation completed successfully.
- invokeAll(Collection<? extends K>, InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys asynchronously, returning aCompletableFuturethat can be used to determine if the operation completed successfully.
- invokeAll(Collection<? extends TK>, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys, returning the result of the invocation for each.
- invokeAll(Collection<? extends TK>, InvocableMap.EntryProcessor<TK, TV, R>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Invoke the passed EntryProcessor against the entries specified by the passed keys, returning the result of the invocation for each.
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- invokeAllAsync(NamedCache<K, V>, Collection<? extends K>, int, InvocableMap.EntryProcessor<K, V, R>, Executor, BiConsumer<? super Map<? extends K, ? extends R>, ? super Throwable>...) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Invoke the specified EntryProcessor asynchronously.
- invokeAllAsync(NamedCache<K, V>, Collection<? extends K>, ToIntFunction<K>, InvocableMap.EntryProcessor<K, V, R>, Executor, BiConsumer<? super Map<? extends K, ? extends R>, ? super Throwable>...) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Invoke the specified EntryProcessor asynchronously.
- invokeAllAsync(NamedCache<K, V>, Collection<? extends K>, ToIntFunction<K>, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super Map<? extends K, ? extends R>, ? super Throwable>...) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Invoke the specified EntryProcessor asynchronously.
- invokeAllLocked(ConcurrentMap<K, V>, Set<? extends InvocableMap.Entry<K, V>>, InvocableMap.EntryProcessor<K, V, R>) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Invoke the passed EntryProcessor against the entries specified by the passed map and entries.
- invokeAllWithFilter(CacheRequestHolder<InvokeAllRequest, Void>, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute the filteredInvokeAllRequestrequest passing the results to the providedStreamObserver.
- invokeAllWithFilter(InvokeAllRequest, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute the filteredInvokeAllRequestrequest passing the results to the providedStreamObserver.
- invokeAllWithKeys(CacheRequestHolder<InvokeAllRequest, Void>, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute the key-basedInvokeAllRequestrequest passing the results to the providedStreamObserver.
- invokeAllWithKeys(InvokeAllRequest, StreamObserver<Entry>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute the key-basedInvokeAllRequestrequest passing the results to the providedStreamObserver.
- invokeAny(Collection<? extends Remote.Callable<T>>) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Executes the given tasks, returning the result of one that has completed successfully (i.e., without throwing an exception), if any do.
- invokeAny(Collection<? extends Remote.Callable<T>>, long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Executes the given tasks, returning the result of one that has completed successfully (i.e., without throwing an exception), if any do before the given timeout elapses.
- invokeAsync(NamedCache<K, V>, K, int, InvocableMap.EntryProcessor<K, V, R>, Executor, BiConsumer<? super R, ? super Throwable>...) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Invoke the specified EntryProcessor asynchronously.
- invokeAsync(NamedCache<K, V>, K, int, InvocableMap.EntryProcessor<K, V, R>, BiConsumer<? super R, ? super Throwable>...) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Invoke the specified EntryProcessor asynchronously.
- invokeAsync(NamedCache<K, V>, K, InvocableMap.EntryProcessor<K, V, R>) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Deprecated.As of Coherence 14.1.1, use enhancedInvocableMapHelper.invokeAsync(NamedCache, Object, int, InvocableMap.EntryProcessor, BiConsumer[]).
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.ConditionalRemoveAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.DumpHeldLocksAction
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.RemoveAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.SizeAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.TruncateAction
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedConcurrentMap.UnlockAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.ContainsValueAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in interface com.tangosol.util.SegmentedHashMap.EntryAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.EntryActionAdapter
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.GetEntryAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.InsertAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeFound(Object, Object, SegmentedHashMap.Entry[], int, SegmentedHashMap.Entry, SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.RemoveAction
- 
Invoke some action, holding the segment lock, when a matching Entry is found.
- invokeLocked(ConcurrentMap<K, V>, InvocableMap.Entry<K, V>, InvocableMap.EntryProcessor<K, V, R>) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Invoke the passed EntryProcessor against the specified Entry.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedConcurrentMap.DumpHeldLocksAction
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockAction
- 
Invoke some action, holding the segment lock, when no matching Entry is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedConcurrentMap.TruncateAction
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedConcurrentMap.UnlockAction
- 
Invoke some action, holding the segment lock, when no matching Entry is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in interface com.tangosol.util.SegmentedHashMap.EntryAction
- 
Invoke some action, holding the segment lock, when no matching Entry is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedHashMap.EntryActionAdapter
- 
Invoke some action, holding the segment lock, when no matching Entry is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedHashMap.GetEntryAction
- 
Invoke some action, holding the segment lock, when no matching Entry is found.
- invokeNotFound(Object, Object, SegmentedHashMap.Entry[], int) - Method in class com.tangosol.util.SegmentedHashMap.InsertAction
- 
Invoke some action, holding the segment lock, when no matching Entry is found.
- invokeOnAllKeys(Object, boolean, SegmentedHashMap.IterableEntryAction) - Method in class com.tangosol.util.SegmentedHashMap
- 
Perform an action on all Entries in the map.
- invokeOnKey(Object, Object, boolean, SegmentedHashMap.EntryAction) - Method in class com.tangosol.util.SegmentedHashMap
- 
Perform an action on the specified key.
- invokeOperation(MBeanServer, String) - Method in class com.tangosol.net.management.MBeanAccessor.Invoke
- 
Invoke the operation on the MBean.
- invokeStatic(Class, String, Object[]) - Static method in class com.oracle.coherence.common.base.Classes
- 
Invoke the specified static method using the passed arguments.
- invokeStatic(Class, String, Object[]) - Static method in class com.tangosol.util.ClassHelper
- 
Invoke the specified static method using the passed arguments.
- IO_EXCEPTIONS_LOG_LEVEL - Static variable in class com.tangosol.net.TcpDatagramSocket
- 
Debbuging flag for logging an IO exceptions which occur, set to a negative to disable the logging.
- isAcceptable(EventDispatcher) - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Determine whether theEventDispatchershould be accepted by this interceptor.
- isAcquiredByCurrentThread() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Queries if an permit is acquired by the current thread.
- isActive() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Return true if the persistence mode is active.
- isActive() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- 
Return whether the persistence mode is active.
- isActive() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- isActive() - Method in class com.tangosol.net.cache.NearCache
- 
Specifies whether or not the NamedCache is active.
- isActive() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Determine if the backing map is still active.
- isActive() - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Returnstrueif this map is not released or destroyed.
- isActive() - Method in class com.tangosol.net.Coherence
- isActive() - Method in class com.tangosol.net.CoherenceSession
- isActive() - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Returnstrueif thisConfigurableCacheFactoryis activated.
- isActive() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Returnstrueif thisExtensibleConfigurableCacheFactoryis activated.
- isActive() - Method in interface com.tangosol.net.NamedMap
- 
Returnstrueif this map is not released or destroyed.
- isActive() - Method in interface com.tangosol.net.Releasable
- 
Specifies whether the Releasable is active.
- isActive() - Method in interface com.tangosol.net.Session
- 
Returntrueif thisSessionis active and has not been closed.
- isActive() - Method in interface com.tangosol.net.topic.Publisher
- 
Specifies whether or not thePublisheris active.
- isActive() - Method in interface com.tangosol.net.topic.Subscriber
- 
Determine whether thisSubscriberis active.
- isActive() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Returnstrueif this map is not released or destroyed.
- isActiveBackup() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Return true if the persistence mode is active-backup.
- isActiveIterator() - Method in class com.tangosol.util.SafeHashMap
- 
Determine if there are any active Iterators, which may mean that they are in the middle of iterating over the Map.
- isActiveIterator() - Method in class com.tangosol.util.SegmentedHashMap
- 
Determine if there are any active Iterators, which may mean that they are in the middle of iterating over the Map.
- isAddressIncluded() - Method in class com.tangosol.util.UUID
- 
This is true if the IP address is a real IP address.
- isAlive(Thread) - Static method in class com.tangosol.util.SegmentedConcurrentMap
- 
For diagnostic use only, detect Daemon pool thread is no longer active.
- isAllInclusive() - Method in interface com.tangosol.util.Streamer
- 
A convenience accessor to check if this streamer isStreamer.ALL_INCLUSIVE.
- isAllowAutoAdjust() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Check whether or not the auto-adjustment is allowed.
- isAllowed(Service, Action) - Method in interface com.tangosol.net.ActionPolicy
- 
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.CompositeActionPolicy
- 
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ProxyQuorumPolicy
- 
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.net.partition.FailoverAccessPolicy
- 
Evaluate if the specified action is currently allowed by this policy.
- isAllowed(Service, Action) - Method in class com.tangosol.util.NullImplementation.NullActionPolicy
- 
Evaluate if the specified action is currently allowed by this policy.
- isAllowInconsistencies() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A convenience accessor to check if this streamer isInvocableMap.StreamingAggregator.ALLOW_INCONSISTENCIES.
- isAllowUnownedCommits() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Returnstrueif the topic allows commits of a position in a channel to be made by subscribers that do not own the channel.
- isAllowUnownedCommits(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Returnstrueif the topic allows commits for a position in a channel by subscribers that do not own the channel.
- isAnonymous() - Method in class com.tangosol.coherence.config.scheme.AbstractScheme
- 
Determines if theSchemeis a defined and thus useful name.
- isAnonymous() - Method in interface com.tangosol.coherence.config.scheme.Scheme
- 
Determines if theSchemeis a defined and thus useful name.
- isAnonymous() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- isAnonymous() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Determine if this property does not have a designated element name.
- isAnyLocalAddress(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
- 
Deprecated.As of Coherence 3.0, replaced byInetAddress.isAnyLocalAddress()
- isApplicable(EventDispatcher, String) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.CoherenceLifecycleEventHandler
- isApplicable(EventDispatcher, String) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
Returntrueif this interceptor should be registered with a specified dispatcher.
- isApplicable(EventDispatcher, String) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.LifecycleEventHandler
- isApplicable(EventDispatcher, String) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.ServiceEventHandler
- isApplicable(EventDispatcher, String) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.SessionLifecycleEventHandler
- isAssignableFrom(Type, Type) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Determines if two types are assignment compatible, that is, the type of y can be assigned to type x.
- isAssignablePrimitive(Class<?>, Class<?>) - Static method in class com.tangosol.coherence.config.builder.ParameterizedBuilderHelper
- 
Determines if a primitive type is assignable to a wrapper type.
- isAssignablePrimitive(Class<?>, Class<?>) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Determines if a primitive type is assignable to a wrapper type.
- isAsync() - Method in class com.oracle.coherence.cdi.CdiEventObserver
- isAsync() - Method in class com.oracle.coherence.cdi.CdiMapEventObserver
- isAsync() - Method in interface com.oracle.coherence.cdi.events.AnnotatedMapListener.MapEventObserver
- 
Returntrueif this observer should be async.
- isAsync() - Method in interface com.oracle.coherence.cdi.events.EventObserverSupport.EventObserver
- 
Returntrueif this observer should be async.
- isAsync() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Determine if the AsyncBinaryStore is operating in an asynchronous manner.
- isAsynchronous() - Method in interface com.tangosol.util.MapListener
- 
Returns true if this listener should be fired asynchronously.
- isAsynchronousPageDeactivation() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine if a daemon should evict the items from a deactivated page to avoid blocking other work from being done.
- isAtom() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Answer whether the receiver is an Atomic Term.
- isAtom() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Answer whether the receiver is an Atomic Term.
- isAttribute() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Determine if the property is stored in an XML attribute instead of an XML element.
- isAttribute() - Method in class com.tangosol.run.xml.SimpleValue
- 
Determine if this value is an element attribute.
- isAttribute() - Method in interface com.tangosol.run.xml.XmlValue
- 
Determine if this value is an element attribute.
- isAutoAdjust(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Return true if the auto adjustment of the preferred size value (based on the run-time statistics) is allowed.
- isAutoStart() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Return true if the service has auto-start enabled.
- isAutoStart() - Method in interface com.tangosol.coherence.config.scheme.ServiceScheme
- 
Return true if the service has auto-start enabled.
- isAutoStart() - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- isAvailable() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the Status object is available.
- isAvailable() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if the Status object is available.
- isBackingMapPersistent(String) - Method in interface com.tangosol.net.BackingMapManager
- 
Determine if the contents of the Map that is used by a CacheService to store cached values for a NamedCache with the specified name should be persisted.
- isBackingMapPersistent(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Determine if the contents of the Map that is used by a CacheService to store cached values for a NamedCache with the specified name should be persisted.
- isBackingMapPersistent(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.Determine if the contents of the Map that is used by a CacheService to store cached values for a NamedCache with the specified name should be persisted.
- isBackingMapPersistent(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Determine if the contents of the Map that is used by a CacheService to store cached values for a NamedCache with the specified name should be persisted.
- isBackingMapPersistent(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
- 
Determine if the contents of the Map that is used by a CacheService to store cached values for a NamedCache with the specified name should be persisted.
- isBackingMapPersistent(String, boolean) - Method in interface com.tangosol.net.BackingMapManager
- 
Determine if the contents of the Map that is used by a CacheService to store cached values for a NamedCache with the specified name should be persisted.
- isBackingMapSlidingExpiry(String) - Method in interface com.tangosol.net.BackingMapManager
- 
Determine if the Map that is used by a CacheService to store cached values for a NamedCache with specified name enables the sliding expiry - the expiry delay being extended by the read operations.
- isBackingMapSlidingExpiry(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Determine if the Map that is used by a CacheService to store cached values for a NamedCache with specified name enables the sliding expiry - the expiry delay being extended by the read operations.
- isBackingMapSlidingExpiry(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.Determine if the Map that is used by a CacheService to store cached values for a NamedCache with specified name enables the sliding expiry - the expiry delay being extended by the read operations.
- isBackingMapSlidingExpiry(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Determine if the Map that is used by a CacheService to store cached values for a NamedCache with specified name enables the sliding expiry - the expiry delay being extended by the read operations.
- isBackingMapSlidingExpiry(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
- 
Determine if the Map that is used by a CacheService to store cached values for a NamedCache with specified name enables the sliding expiry - the expiry delay being extended by the read operations.
- isBackup() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Return true if the map is a backup map.
- isBackupPartitioned(String) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Return true if the backup map should be partitioned.
- isBackUpToDate() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the entry for which this Status exists has the same value in the front Map as in the back Map.
- isBackUpToDate() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if the entry for which this Status exists has the same value in the front Map as in the back Map.
- isBinary() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Return true if the map is binary.
- isBinaryMap() - Method in class com.tangosol.net.cache.SerializationMap
- 
Determine if the keys and values in this map are known to be all Binary.
- isBinaryMap() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Determine if the keys and values in this map are known to be all Binary.
- isBinaryNamedCache() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Returntrueif the current back cache is configured to useBinaryvalues.
- isBinaryNamedCache(NamedCache) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Returnstrueif provided cache is configured to use theNullImplementation classloaderwhich means the values to/from from the cache will beBinary.
- isBinaryOnly() - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Determine if the keys and values in this CacheStore are known to be all Binary.
- isBlackList() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
- isBlind() - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Return true if the map is in blind mode.
- isBlindPutAllowed() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Determine if the "blind put" optimization is possible.
- isBlindRemoveAllowed() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Determine if the "blind remove" optimization is possible.
- isBlocking() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Determine if the wrapped store implements blocking operations.
- isBlocking() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine if the wrapped store implements blocking operations.
- isBlocking() - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Check if datagram sockets should be blocking the use of "blocking" datagram sockets is not meant for production use and this setting should remain undocumented
- isBlocking() - Method in interface com.tangosol.net.TcpDatagramSocketProvider.Dependencies
- 
Check if datagram sockets should be blocking the use of "blocking" datagram sockets is not meant for production use and this setting should remain undocumented
- isBound() - Method in class com.tangosol.net.TcpDatagramSocket
- isByMember() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A convenience accessor to check if this streamer isInvocableMap.StreamingAggregator.BY_MEMBER.
- isByPartition() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A convenience accessor to check if this streamer isInvocableMap.StreamingAggregator.BY_PARTITION.
- isByteArrayPrivate() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Determine if the underlying byte[] should be treated as private data.
- isByteArrayPrivate() - Method in class com.tangosol.io.ByteArrayReadBuffer
- 
Determine if the underlying byte[] should be treated as private data.
- isByteArrayPrivate() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Determine if the underlying byte[] should be treated as private data.
- isByteArrayPrivate() - Method in class com.tangosol.util.Binary
- 
Determine if the underlying byte[] should be treated as private data.
- isCacheActive(String, ClassLoader) - Method in class com.tangosol.net.CoherenceSession
- isCacheActive(String, ClassLoader) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Validate whether a cache with the given name is active in the context of the givenClassLoader.
- isCacheActive(String, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Validate whether a cache with the given name is active in the context of the givenClassLoader.
- isCacheActive(String, ClassLoader) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Validate whether a cache with the given name is active in the context of the givenClassLoader.
- isCacheActive(String, ClassLoader) - Method in interface com.tangosol.net.Session
- 
Validate whether a cache with the given name is active in the context of the givenClassLoader.
- isCacheValues() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Determine if thisContinuousQueryCachecaches values locally.
- isCacheValues() - Method in interface com.tangosol.net.management.ViewMBean
- 
Determine if thisContinuousQueryCachecaches values locally.
- isCacheValues() - Method in class com.tangosol.net.management.ViewMBeanImpl
- isCanceled() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
- 
Return true if the load operation has been canceled.
- isCancelled() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- isCancelled() - Method in class com.tangosol.util.AsynchronousAgent
- isCanonicalKeySupported(Map) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Determine whether the provided map allows reference access to the keys it holds.
- isCanonicallyEquatable(Object) - Method in class com.tangosol.util.extractor.AbstractExtractor
- 
Return true if either this oroValuehave a non-nullcanonical name.
- isChanged() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Specifies whether or not the underlying value has been changed during BinaryEntryStore operations.
- isCheckPrimingExclusively(boolean) - Method in class com.tangosol.net.cache.CachingMap
- 
Return true if we can rely on the server emitting priming events (based on receiving a at least one priming event from a storage node).
- isClient() - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- 
Returntrueif this lock owner is a remote client (Extend or gRPC).
- isClient() - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- 
Returntrueif this permit acquirer is a remote client (Extend or gRPC).
- isClient() - Method in class com.oracle.coherence.grpc.RefreshableSslContext
- isCloneRequired() - Method in class com.tangosol.run.xml.DateTimeAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.IterableAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Determine if the property value must be deep-cloned.
- isCloneRequired() - Method in class com.tangosol.run.xml.RestrictedStringAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.SerializableAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter.DateAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter.TimeAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.XmlElementAdapter
- isCloneRequired() - Method in class com.tangosol.run.xml.XmlSerializableAdapter
- isClosed() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- isClosed() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- isClosed() - Method in class com.tangosol.net.Coherence
- 
Returntrueif thisCoherenceinstance has been closed.
- isClosed() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return true if the store has been closed.
- isClosed() - Method in class com.tangosol.util.ThreadGateLite
- 
Determine if any thread has closed the gate and continues to hold exclusive access.
- isClosed() - Method in class com.tangosol.util.WrapperReentrantGate
- 
Determine if any thread has closed the gate and continues to hold exclusive access.
- isClosedByCurrentThread() - Method in class com.tangosol.util.ThreadGateLite
- 
Determine if the calling thread has closed the gate and continues to hold exclusive access.
- isClosedByCurrentThread() - Method in class com.tangosol.util.WrapperReentrantGate
- 
Determine if the calling thread has closed the gate and continues to hold exclusive access.
- isClusterMember() - Method in enum com.tangosol.net.Coherence.Mode
- 
Returntrueif this mode is a cluster member.
- isCoherent() - Method in class com.tangosol.net.cache.CachingMap
- 
Determine if changes to the back map affect the front map so that data in the front map stays in sync.
- isCollectStats() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Check whether or not statistics are collected by the wrapper.
- isCollectStats() - Method in class com.tangosol.util.WrapperObservableMap
- 
Check whether or not statistics are collected by the wrapper.
- isCommentValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Validate the passed comment.
- isCommitting() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the Status object represents an Entry that has been processed and the results of that processing are being committed.
- isCommitting() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if the Status object represents an Entry that has been processed and the results of that processing are being committed.
- isCompacting() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine if the map is incrementally compacting.
- isCompareEntry() - Method in class com.tangosol.util.comparator.EntryComparator
- 
Check whether or not this EntryComparator pass entries themselves for comparison to the underlyingcompareEntries()method.
- isCompareKey() - Method in class com.tangosol.util.comparator.EntryComparator
- 
Check whether or not this EntryComparator uses entries' keys to pass for comparison to the underlying Comparator.
- isCompareValue() - Method in class com.tangosol.util.comparator.EntryComparator
- 
Check whether or not this EntryComparator uses entries' values to pass for comparison to the underlying Comparator.
- isCompatibleMethod(Method, int, Type, Type...) - Static method in class com.tangosol.util.fsm.ReflectionHelper
- 
Determines if the signature of aMethodis compatible with the specified parameters.
- isComplete() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
- 
Return true if the load operation is complete.
- isComplete() - Method in interface com.tangosol.net.SessionProvider.Context
- 
Returntrueif this context has been completed.
- isComplete() - Method in class com.tangosol.net.SessionProvider.DefaultContext
- isComplete(Object) - Method in class com.tangosol.util.SegmentedConcurrentMap.SizeAction
- 
Return true iff further key evaluations for the given context are known to be unnecessary.
- isComplete(Object) - Method in class com.tangosol.util.SegmentedHashMap.ContainsValueAction
- 
Return true iff further key evaluations for the given context are known to be unnecessary.
- isComplete(Object) - Method in class com.tangosol.util.SegmentedHashMap.EntryActionAdapter
- 
Return true iff further key evaluations for the given context are known to be unnecessary.
- isComplete(Object) - Method in interface com.tangosol.util.SegmentedHashMap.IterableEntryAction
- 
Return true iff further key evaluations for the given context are known to be unnecessary.
- isCompletedExceptionally() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- isCompletedExceptionally() - Method in class com.tangosol.util.AsynchronousAgent
- 
Helper method to check if the operation failed.
- isCompound() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token is a compound token.
- isCompound() - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
- 
Answer whether this token is a compound token.
- isCompound() - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
- 
Answer whether this token is a compound token.
- isCompressable() - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Determine if the value encoding can be compressed by combining type and value information in such a way that type information could be lost.
- isConditional() - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
Return true if this operator can be used as a conditional operator.
- isConfigured() - Method in class com.tangosol.net.SocketOptions
- 
Return true iff the XmlSocketOptions have been configured with any options.
- isContainerContext() - Method in class com.tangosol.coherence.jcache.common.ContainerHelper.JCacheLifecycleInterceptor
- 
Added for Coherence JCache functional testing.
- isContainerContext(ExtensibleConfigurableCacheFactory) - Static method in class com.tangosol.coherence.jcache.common.ContainerHelper
- 
Return true if running in a container environment.
- isContended() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Is there contention (a thread waiting) to lock this Entry?
- isContent() - Method in class com.tangosol.run.xml.SimpleValue
- 
Determine if this value is an element's content.
- isContent() - Method in interface com.tangosol.run.xml.XmlValue
- 
Determine if this value is an element's content.
- isContiguous() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
Determine if the elements are contiguous.
- isConverted() - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Check if the underlying key set has been converted.
- isCurrent() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- isCurrentThread() - Method in class com.tangosol.util.Daemon.DaemonWorker
- isDebug() - Static method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine the status of the internal debug flag.
- isDecimal(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Returns true if the passed character is a decimal digit.
- isDecimal(char) - Static method in class com.tangosol.util.Base
- 
Returns true if the passed character is a decimal digit.
- isDecorated(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
If the ReadBuffer is the result of serialization by ExternalizableHelper, determine if the buffer contains decorations.
- isDecorated(ReadBuffer, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
If the ReadBuffer is the result of serialization by ExternalizableHelper, determine if the buffer contains the specified decoration.
- isDelegateParallel() - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Returntrueif the underlying aggregator is a ParallelAwareAggregator.
- isDelegateStreaming() - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Returntrueif the underlying aggregator is a StreamingAggregator.
- isDelete() - Method in class com.tangosol.util.MapEvent
- 
Determine whether this event is a delete event.
- isDeleted() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Determine if the modified entry in the ChangeRecord was deleted.
- isDestroyed() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- isDestroyed() - Method in class com.tangosol.net.cache.NearCache
- 
Specifies whether or not this NamedCollection has been destroyed.
- isDestroyed() - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Specifies whether or not this NamedCollection has been destroyed.
- isDestroyed() - Method in interface com.tangosol.net.NamedCollection
- 
Specifies whether or not this NamedCollection has been destroyed.
- isDestroyed() - Method in interface com.tangosol.net.topic.NamedTopic
- 
Specifies whether this NamedTopic has been destroyed.
- isDestroyed() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Specifies whether or not this NamedCollection has been destroyed.
- isDirectQueryEnabled() - Method in class com.tangosol.coherence.rest.config.QueryConfig
- 
Return true if direct querying is enabled.
- isDirty() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return true if this value has been modified, false otherwise.
- isDirty() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Checks whether or not this Lock object is held by another thread.
- isDiscardable() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if this Status object can be discarded.
- isDiscardable() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if this Status object can be discarded.
- isDiscardable() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Checks whether or not this Lock object is discardable.
- isDiscarded() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Determine if this entry has already been discarded from the cache.
- isDisposed() - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Return true if this factory has been disposed via invocation ofConfigurableCacheFactory.dispose().
- isDisposed() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Return true if this factory has been disposed via invocation ofExtensibleConfigurableCacheFactory.dispose().
- isDisposed() - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Return true if thisServiceMonitorhas been disposed via invocation ofSimpleServiceMonitor.dispose().
- isDone() - Method in class com.oracle.coherence.grpc.SafeStreamObserver
- 
Returnstrueif this observer is complete.
- isDone() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Determine if the daemon thread should continue processing or should shut itself down.
- isDone() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- isDone() - Method in class com.tangosol.util.AsynchronousAgent
- isDormant() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Determine whether the daemon is dormant or not.
- isElementMatch(XmlElement) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Check whether or not the passed element matches to the property's local name and Namespace URI.
- isElementMatch(XmlElement, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Check whether or not an element matches to the specified local name and Namespace URI.
- isEmpty() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- isEmpty() - Method in class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
- 
Returnstrueif this builder contains no addresses.
- isEmpty() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- 
Determine if theParameterizedBuilderRegistryis empty (contains no registrations).
- isEmpty() - Method in interface com.tangosol.coherence.config.ParameterList
- 
Determines if there are anyParameters in theParameterList.
- isEmpty() - Method in class com.tangosol.coherence.config.ResolvableParameterList
- 
Determines if there are anyParameters in theParameterList.
- isEmpty() - Method in class com.tangosol.coherence.config.SimpleParameterList
- 
Determines if there are anyParameters in theParameterList.
- isEmpty() - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.io.pof.EvolvableHolder
- 
Returntrueif this holder is empty.
- isEmpty() - Method in interface com.tangosol.net.AsyncNamedMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.CachingMap
- isEmpty() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- isEmpty() - Method in class com.tangosol.net.cache.OverflowMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- isEmpty() - Method in class com.tangosol.net.cache.SerializationCache
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.LoadBalancer.Queue
- 
Determine if the queue is empty.
- isEmpty() - Method in class com.tangosol.net.partition.PartitionSet
- 
Check whether or not the partition set is empty.
- isEmpty() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- isEmpty() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returnstrueif the channel is empty.
- isEmpty() - Method in class com.tangosol.run.xml.SimpleValue
- 
Determine if the value is empty.
- isEmpty() - Method in interface com.tangosol.run.xml.XmlValue
- 
Determine if the value is empty.
- isEmpty() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
- 
Returns true if this Set is empty.
- isEmpty() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
- 
Returns true if this Set is empty.
- isEmpty() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
- 
Returns true if this Set is empty.
- isEmpty() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.AbstractLongArray
- 
Test for empty LongArray.
- isEmpty() - Method in class com.tangosol.util.AbstractSafeLongArray
- isEmpty() - Method in class com.tangosol.util.ChainedCollection
- isEmpty() - Method in class com.tangosol.util.ChainedSet
- isEmpty() - Method in class com.tangosol.util.CircularArrayList
- isEmpty() - Method in interface com.tangosol.util.ConcurrentMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- isEmpty() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- isEmpty() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- isEmpty() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- isEmpty() - Method in class com.tangosol.util.CopyOnWriteMap
- isEmpty() - Method in class com.tangosol.util.Dequeue
- 
Determines if the dequeue is empty.
- isEmpty() - Method in class com.tangosol.util.Listeners
- 
Check if there are no listeners.
- isEmpty() - Method in class com.tangosol.util.LiteSet
- 
Determine if this Set is empty.
- isEmpty() - Method in interface com.tangosol.util.LongArray
- 
Test for empty LongArray.
- isEmpty() - Method in class com.tangosol.util.MapListenerSupport
- 
Checks whether or not this MapListenerSupport object contains any listeners.
- isEmpty() - Method in class com.tangosol.util.NullImplementation.NullLongArray
- isEmpty() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Returns true if this Collection contains no elements.
- isEmpty() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Returns true if this Collection contains no elements.
- isEmpty() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.SafeHashMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- isEmpty() - Method in class com.tangosol.util.SafeSortedMap.Values
- isEmpty() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns true if this map contains no key-value mappings.
- isEmpty() - Method in class com.tangosol.util.SetMap
- isEmpty() - Method in class com.tangosol.util.SimpleLongArray
- 
Test for empty LongArray.
- isEmpty() - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Determine if theResourceRegistryis empty (contains no resource registrations).
- isEmpty() - Method in class com.tangosol.util.SortedBag
- isEmpty() - Method in class com.tangosol.util.StringTable
- 
Test for empty table.
- isEmpty() - Method in class com.tangosol.util.SubList
- isEmpty() - Method in class com.tangosol.util.SubSet
- isEmpty() - Method in class com.tangosol.util.Tree
- 
Test for empty tree.
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- isEmpty() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- isEmpty(IsEmptyRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Determine whether a cache is empty.
- isEmpty(IsEmptyRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- isEmpty(IsEmptyRequest, StreamObserver<BoolValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- isEmpty(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Check whether or not this element or any of its children elements have any content such as values or attributes.
- isEmpty(Filter) - Method in class com.tangosol.util.MapListenerSupport
- 
Checks whether or not this MapListenerSupport object contains any listeners for a given filter.
- isEmpty(Object) - Method in class com.tangosol.run.xml.ArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.CollectionAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.MapAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Determine if the specified value is empty.
- isEmpty(Object) - Method in class com.tangosol.util.MapListenerSupport
- 
Checks whether or not this MapListenerSupport object contains any listeners for a given key.
- isEmpty(String, String) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aIsEmptyRequest.
- isEmpty(Map[]) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Return true iff a subset of the maps that belong to specified partitions contains no entries.
- isEmptyElement(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
- 
Determines if anXmlElementis considered empty.
- isEmptyIsNull() - Method in class com.tangosol.run.xml.IterableAdapter
- isEnabled() - Static method in class com.tangosol.coherence.rest.util.MvelHelper
- 
Return true if optionalorg.mvel.mvel2module is loaded from path.
- isEnabled() - Method in interface com.tangosol.net.management.MapJsonBodyHandler
- 
Returntrueif thisMapJsonBodyHandleris enabled.
- isEnabled() - Method in interface com.tangosol.net.SessionConfiguration
- 
Returntrueif this configuration is enabled and should be used to configure a session.
- isEnabled() - Method in class com.tangosol.net.ssl.AbstractCertificateLoader
- isEnabled() - Method in interface com.tangosol.net.ssl.CertificateLoader
- isEnabled() - Method in interface com.tangosol.net.ssl.KeyStoreLoader
- isEnabled() - Method in interface com.tangosol.net.ssl.PrivateKeyLoader
- isEnabled() - Method in class com.tangosol.net.WrapperSessionConfiguration
- isEnabled(int) - Static method in class com.oracle.coherence.common.base.Logger
- 
Returntrueif the specified severity level should be logged.
- isEncodingValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Validate the passed encoding.
- isEnd() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Test whether the receiver has reached the end of the underlying Reader
- isEnd() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
- 
Answer a boolean indication as to whether the stream is at the end
- isEnd() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
If the Scanner is at the end answer true otherwise answer false.
- isEndOfStatement() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
If the scanner is at the end of a statement return true.
- isEnteredByCurrentThread() - Method in class com.tangosol.util.ThreadGateLite
- 
Determines if the current thread has entered the gate and not yet exited.
- isEnteredByCurrentThread() - Method in class com.tangosol.util.WrapperReentrantGate
- 
Determines if the current thread has entered the gate and not yet exited.
- isEntry() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine if the Block is marked as an Entry.
- isEntryExistent() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the entry for which this Status exists is present in the front map or the back map.
- isEntryInBack() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the entry for which this Status exists is present in the back map.
- isEntryInFront() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the entry for which this Status exists is present in the front map.
- isEntryInFront() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if the entry for which this Status exists is present in the front map.
- isEphemeral() - Method in class com.tangosol.coherence.config.builder.WrapperSocketAddressProviderBuilder
- 
Return the flag indicating that the addresses should be ephemeral.
- isEqual(Object) - Static method in interface com.tangosol.util.function.Remote.Predicate
- 
Returns a predicate that tests if two arguments are equal according toObjects.equals(Object, Object).
- isEraseAllSupported() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine if the wrapped store supports eraseAll() operations.
- isEraseSupported() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine if the wrapped store supports erase() operations.
- isEraseUnsupported() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Determine if the CacheStore has been determined to be read-only for erase() operations.
- isError() - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
- 
Returns boolean indicating if an error has occurred.
- isEventDeferred(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Called when an event has occurred.
- isEventFabricator() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Determine if this ObservableMap has to fabricate events itself.
- isEventFabricator() - Method in class com.tangosol.util.WrapperObservableMap
- 
Determine if this ObservableMap has to fabricate events itself.
- isEvictable() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Determine if this entry has been marked as being evictable.
- isEvictable(ConfigurableCacheMap.Entry) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.EvictionApprover
- 
Get an eviction approval for the specified entry.
- isEvolvable() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Determine if the object to be written is either Evolvable or part of an Evolvable object.
- isEvolvable() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Determine if the object to be written is either Evolvable or part of an Evolvable object.
- isException() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Check whether or not this bundle is in the "exception" state - bundled execution threw an exception and requests have to be un-bundled.
- isExclusive() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return true if this store is in exclusive mode.
- isExitWhenProcessingComplete() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- isExitWhenProcessingComplete() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return whether the QueryPlus session should exit once all of the statements added to the statements list have been executed.
- isExpired() - Method in class com.tangosol.net.cache.CacheEvent
- 
Return true iff this event is caused by an entry eviction due to time limit reached.
- isExpired() - Method in class com.tangosol.net.cache.LocalCache.KeyMask
- 
Check whether or not the currently performed operation has been initiated because the entry expired.
- isExpired() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Determine if the cache entry has expired.
- isExpired() - Method in class com.tangosol.net.cache.OverflowMap.ExpirableStatus
- 
Determine if this Status represents an entry that will automatically expire.
- isExpired() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if this Status represents an entry that will automatically expire.
- isExpiredAt(long) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Determines if the Cache Entry associated with this value would be expired at the specified time
- isExpiredAt(long) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Determines if the Cache Entry associated with this value would be expired at the specified time
- isExpiryEnabled() - Method in class com.tangosol.net.cache.OverflowMap
- 
Determine if this OverflowMap supports entry expiry.
- isExpiryEnabled(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
- 
Return the expiry enabled flag.
- isExplicitlyTyped() - Method in class com.tangosol.config.expression.Parameter
- 
Obtains if an expected/actual type of theParameterhas been specified/is known.
- isExtendedLanguageEnabled() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return whether "Extended Language" features are enabled.
- isExtendedLanguageEnabled() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- isExtendedLanguageEnabled() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return whether "Extended Language" features are enabled.
- isExtendedMBeanName() - Method in interface com.tangosol.net.management.Registry
- 
Return true iff extended global MBean names are to be used.
- isFalse(ValueExtractor<T, Boolean>) - Static method in class com.tangosol.util.Filters
- 
Return a filter that evaluates to true if the extracted value isfalse.
- isFederateApplySynthetic(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Return true iff received federated changes should be applied locally as synthetic updates.
- isFederated() - Method in class com.tangosol.coherence.config.CacheMapping
- 
Check if this CacheMapping is federated.
- isFinishing() - Method in class com.tangosol.util.TaskDaemon
- 
Determine if the daemon will finish those scheduled tasks that are ripe (presently due to be run) before stopping.
- isFirst() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Whether thisEventInterceptorshould be head of the stack.
- isFirst() - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Return whether this interceptor should request to be first in the chain of interceptors.
- isFirstLineOnly() - Method in class com.tangosol.net.InputStreamPasswordProvider
- 
Returnstrueto only treat the first line of the data returned by theInputStreamas the password.
- isFlowControlEnabled() - Method in interface com.tangosol.net.ClusterDependencies
- 
Determine whether the TCMP flow control is enabled.
- isFlushed() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Return true iff all contents have been persisted to the underlying store.
- isForeignNamespace(XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InstanceProcessor
- 
Return true if the given element meets the following criteria: there is a single sub element the namespace of the sub element is not in the Coherence namespace
- isForName(String) - Method in class com.tangosol.coherence.config.RegExCacheMapping
- isForName(String) - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Determines if theResourceMappingis for (matches) the specified resource name.
- isForwardIndexSupported() - Method in class com.tangosol.util.SimpleMapIndex
- 
Determine whether or not this SimpleMapIndex supports a forward index.
- isFound(Object) - Method in class com.tangosol.util.SegmentedHashMap.ContainsValueAction
- 
Return true iff the value was found
- isFree() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine if the Block is marked as free.
- isFrontPutBlind() - Method in class com.tangosol.net.cache.OverflowMap
- 
Determine if the front Map is more efficiently updated using putAll.
- isFrontPutBlind() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Determine if the front Map is more efficiently updated using putAll.
- isFull() - Method in class com.tangosol.net.partition.PartitionSet
- 
Check whether or not the partition set is full.
- isFull() - Method in class com.tangosol.util.Dequeue
- 
Determines if the dequeue is full.
- isGenerated() - Method in class com.tangosol.util.UUID
- 
This is true if the UUID was generated, and false if it was built.
- isGlobalPartitioningSchemePID(int) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return true iff the specified partition-id is to be used to persist (meta-)data that is logically "global".
- isGuarded() - Method in class com.tangosol.util.Daemon
- 
Return true iff this Daemon's execution is guarded.
- isHeldByCurrentThread() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Queries if this lock is held by the current thread.
- isHeldByCurrentThread() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Queries if this write lock is held by the current thread.
- isHex(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Returns true if the passed character is a hexadecimal digit.
- isHex(char) - Static method in class com.tangosol.util.Base
- 
Returns true if the passed character is a hexadecimal digit.
- isIdentifier() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token represents an identifier.
- isIdentifier() - Method in class com.tangosol.coherence.dsltools.base.IdentifierBaseToken
- 
Answer whether this token represents an identifier.
- isIdle() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Specifies whether or not the persistence coordinator is idle.
- isIgnoreCase() - Method in class com.tangosol.coherence.dslquery.operator.ILikeOperator
- isIgnoreCase() - Method in class com.tangosol.coherence.dslquery.operator.LikeOperator
- isIgnoreCase() - Method in class com.tangosol.util.filter.LikeFilter
- 
Check whether or not the filter is case incensitive.
- isIgnored(Object) - Method in class com.tangosol.net.cache.LocalCache.KeyMask
- 
Check if a key should be ignored.
- isIgnoringCase() - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Answer wheather the receiver is ignoringCase
- isIncrementalEviction() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine if incremental eviction is enabled.
- isInitialDistribution(Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Check if the distribution is in the initial state, when the coordinator owns all the partitions and there are no backups.
- isInitialized() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine if the ConfigurablePofContext has completed its initialization.
- isInnerClass(Class) - Static method in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
Return true if a given class is an inner class.
- isInsert() - Method in class com.tangosol.util.MapEvent
- 
Determine whether this event is an insert event.
- isInstanceConfigEmpty(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Check whether or not the specified configuration defines an instance of a class.
- isInstanceOf(Object, Class) - Static method in class com.tangosol.util.ClassHelper
- 
Determine if the passed object is an instance of the specified class.
- isInstanceOf(Object, String) - Static method in class com.tangosol.util.ClassHelper
- 
Determine if the passed object is an instance of the specified class.
- isIntDecorated(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Deprecated.
- isIntDecorated(ByteSequence) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Check whether or not the specified ByteSequence is a representation of an IntDecoratedObject.
- isInterfaceAllowed() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine if the ConfigurablePofContext supports the configuration of user types by specifying an interface (instead of a class) for the Java type.
- isInternal() - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Check if this ResourceMapping is for internal resources.
- isInternalKeySetIteratorMutable() - Method in class com.tangosol.net.cache.OverflowMap
- 
Determine if this Iterator should remove an iterated item by calling remove on the internal key Set Iterator, or by calling removeBlind on the map itself.
- isInternalKeySetIteratorMutable() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Determine if this Iterator should remove an iterated item by calling remove on the internal key Set Iterator, or by calling removeBlind on the map itself.
- isInternalKeySetIteratorMutable() - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Determine if this Iterator should remove an iterated item by calling remove on the internal key Set Iterator, or by calling removeBlind on the map itself.
- isInternalKeySetIteratorMutable() - Method in class com.tangosol.util.WrapperObservableMap
- 
Determine if this Iterator should remove an iterated item by calling remove on the internal key Set Iterator, or by calling removeBlind on the map itself.
- isInternalValueDecorated(Object, int) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Check whether or not the specified value in the internal form is decorated.
- isInternalValueDecorated(Object, int) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Check whether or not the specified value in the internal form is decorated.
- isIntrinsicPofType(Class) - Static method in class com.tangosol.io.pof.PofHelper
- 
Determine if the given class can be represented as an intrinsic POF type.
- isIpMonitorEnabled() - Method in interface com.tangosol.net.ClusterDependencies
- 
Determine whether the IpMonitor is enabled.
- isJCacheSynthetic(CacheEvent) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
- isJCacheSynthetic(CacheEvent) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener.NonSyntheticEntryFilter
- isJCacheSynthetic(CacheEvent) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener.NonSyntheticEntryFilter
- isKeyComparator() - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Specifies whether this comparator expects to compare keys or values.
- isKeyComparator() - Method in interface com.tangosol.util.comparator.EntryAwareComparator
- 
Specifies whether this comparator expects to compare keys or values.
- isKeyComparator() - Method in class com.tangosol.util.comparator.SafeComparator
- 
Specifies whether this comparator expects to compare keys or values.
- isKeyComparator(Comparator) - Static method in class com.tangosol.util.comparator.SafeComparator
- 
Check whether the specified comparator expects to compare keys or values.
- isKeyConverted() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Check if the event's key has been converted.
- isKeyExcluded(Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Check if the entry with the given key is excluded from the index.
- isKeyOwned(Object) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Determines whether or not the specified key (in the internal format) is managed (i.e. controlled) by this service member.
- isKeyOwned(Object) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Determines whether or not the specified key (in the internal format) is managed (i.e. controlled) by this service member.
- isLambdaAllowed() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine if implicit root lambda class processing is allowed.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token is a leaf token.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
- 
Answer whether this token is a leaf token.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
- 
Answer whether this token is a leaf token.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Answer whether the receiver has children.
- isLeaf() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Answer whether the receiver has children.
- isLeaf() - Method in class com.tangosol.util.AbstractSparseArray.Node
- 
Determine if this node is a part of a 2-3-4 leaf node (i.e. at least one null child).
- isLinked() - Method in class com.tangosol.util.AbstractSparseArray.Node
- 
Return true iff the node is linked to other nodes.
- isLinkLocalAddress(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
- 
Deprecated.As of Coherence 3.0, replaced byInetAddress.isLinkLocalAddress()
- isLite() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Returntrueif this is lite event listener.
- isLite() - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy.FilterInfo
- 
Returntrueif the filter was registered for lite events.
- isLiteral() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token represents a literal.
- isLiteral() - Method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Answer whether this token represents a literal.
- isLive() - Method in interface com.tangosol.util.HealthCheck
- 
Returns {@link true} if the resource represented by thisHealthCheckis alive, otherwise returnsfalse.
- isLoaded() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Determine if last update to this LocalValue was a load from an external resource.
- isLocal() - Method in class com.tangosol.net.MemberEvent
- 
Check whether a Member object for this event represents the local member of the cluster.
- isLocalMember(Member) - Method in class com.tangosol.net.AbstractServiceLoadBalancer
- 
Check whether the specified Member object represents the local member of the cluster.
- isLocalOnly() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Determine whether the change represented by this ChangeRecord is local only, therefore not federated.
- isLocalPortAutoAdjust() - Method in interface com.tangosol.net.ClusterDependencies
- 
Determine whether the unicast listener local port(s) will be automatically selected if the specified port cannot be bound to (e.g. it is already in use.)
- isLocalStorageEnabled() - Method in interface com.tangosol.net.DistributedCacheService
- 
Determine if local storage is enabled on this member.
- isLocked() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Queries if this lock is held by any thread.
- isLocked() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Is this entry Locked?
- isLockingEnforced() - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Obtain the flag indicating whether or not the locking is enforced for put, remove and clear operations.
- isLogEcho() - Static method in class com.tangosol.util.Base
- 
Determine if the log is echoed to the console.
- isLogEnabled(int) - Static method in class com.tangosol.net.CacheFactory
- 
Deprecated.since Coherence 14.1.2, and may be removed in a future version; useLogger.isEnabled(int)method instead.
- isLoopbackAddress(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
- 
Deprecated.As of Coherence 3.0, replaced byInetAddress.isLoopbackAddress()
- isLowerBoundInclusive() - Method in class com.tangosol.util.filter.BetweenFilter
- 
Obtain the flag indicating whether values matching the lower bound of the range evaluate to true.
- isManagementEnabled() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- isManagementEnabled() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
- isManagingTimeout() - Method in interface com.tangosol.coherence.dslquery.Statement
- 
Obtain a flag indicating whether this Statement will manage its own timeout handling.
- isManagingTimeout() - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
- isManagingTransientVersion() - Method in class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Determine if this backing map is responsible for keeping the transient version cache in sync.
- isMapActive(String, ClassLoader) - Method in class com.tangosol.net.CoherenceSession
- isMapActive(String, ClassLoader) - Method in interface com.tangosol.net.Session
- 
Validate whether a map with the given name is active in the context of the givenClassLoader.
- isMarked() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicMarkableReference
- 
Returns the current value of the mark.
- isMarked() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
- isMarked() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- isMarked() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicMarkableReference
- 
Returns the current value of the mark.
- isMarked() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- isMarked() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- isMaster() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Check whether or not this is a "master" Bundle.
- isMatch(String) - Method in class com.tangosol.util.filter.LikeFilter
- 
Check the passed String value to see if it matches the pattern that this filter was constructed with.
- isMatch(String, String) - Static method in class com.tangosol.coherence.rest.util.PartialObject
- 
Determine if a method represents a property.
- isMatching(QueryRecord.PartialResult) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Determine whether or not the given result is capable of being placed in one-to-one correspondence with this result.
- isMatching(QueryRecord.PartialResult.Step) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Determine whether or not the given step is capable of being placed in one-to-one correspondence with this step.
- isMBeanRegistered(String) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Check whether or not an MBean with the specified name is already registered.
- isMBeanRegistered(String) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- isMemberHealthCheck() - Method in class com.tangosol.coherence.config.xml.processor.HealthProcessor.XMLHealthCheckDependencies
- isMemberHealthCheck() - Method in interface com.tangosol.util.HealthCheck
- 
Returntrueif thisHealthCheckshould be included when working out this Coherence member's health status.
- isMemberLeaving(Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff the specified member is in the process of leaving.
- isMemorySize() - Method in class com.tangosol.coherence.config.unit.Units
- 
Return true if Units contains aMemorySize.
- isMetadataCompatible(Properties) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Determine if the given metadata is compatible with this manager.
- isMetadataCompatible(Properties, int, String, int) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Determine if the given metadata in thePropertiesis compatible with the metadata supplied.
- isMetadataComplete(Properties) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Determine if the given metadata in thePropertiesis complete.
- isMetadataComplete(Properties) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Determine if the given metadata in thePropertiesis complete.
- isMethodExtractor() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Return true if this a method extractor.
- isMethodUpdater() - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Return true iff this updater references a setter method.
- isModified() - Method in class com.tangosol.util.DeltaSet
- 
Determine if any items were added or removed.
- isModified() - Method in class com.tangosol.util.SubSet
- 
Determine if the set has been modified.
- isMonitoring() - Method in interface com.tangosol.net.ServiceMonitor
- 
Returns true iff the ServiceMonitor is monitoring a number of services.
- isMonitoring() - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Returns true iff the ServiceMonitor is monitoring a number of services.
- isMonitoringServices() - Method in class com.tangosol.net.DefaultCacheServer
- 
Returntrueif thisDefaultCacheServeris monitoring services.
- isMonitorStopped() - Method in class com.tangosol.net.DefaultCacheServer
- 
Return theServiceMonitorused by the cache server.
- isMutable() - Method in class com.tangosol.run.xml.SimpleValue
- 
Determine if this value can be modified.
- isMutable() - Method in class com.tangosol.run.xml.XmlBean
- 
Determine if this value can be modified.
- isMutable() - Method in interface com.tangosol.run.xml.XmlValue
- 
Determine if this value can be modified.
- isMutator() - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- 
Returns a boolean specifying whether the method mutates the state of a target object.
- isNameMatch(XmlElement, String, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Check whether or not a universal (composite) name matches to the specified local name and Namespace URI.
- isNameMutable() - Method in class com.tangosol.run.xml.SimpleElement
- 
Determine if the name can be changed.
- isNameValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Validate the passed name.
- isNest() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token represents a nested collection of tokens.
- isNest() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
- 
Answer whether this token represents a nested collection of tokens.
- isNest(char) - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Test if the given char is a character that starts nesting/
- isNested() - Method in class com.tangosol.run.xml.IterableAdapter
- isNewValueConverted() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Check if the event's new value has been converted.
- isNonBlockingCaller() - Static method in class com.oracle.coherence.common.base.NonBlocking
- 
Return true if the the calling thread has been marked as non-blocking
- isNonMemberMBean(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Returnstrueif the specified MBean name is a non-member specific name.
- isNotNull(ValueExtractor<T, E>) - Static method in class com.tangosol.util.Filters
- 
Return a filter that evaluates to true for non-null values.
- IsNotNullFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which tests the result of a method invocation for inequality to null.
- IsNotNullFilter() - Constructor for class com.tangosol.util.filter.IsNotNullFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- IsNotNullFilter(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.filter.IsNotNullFilter
- 
Construct a IsNotNullFilter for testing inequality to null.
- IsNotNullFilter(String) - Constructor for class com.tangosol.util.filter.IsNotNullFilter
- 
Construct a IsNotNullFilter for testing inequality to null.
- isNull() - Method in class com.tangosol.config.expression.Value
- 
Determines if theValuerepresents anullvalue.
- isNull(ValueExtractor<T, E>) - Static method in class com.tangosol.util.Filters
- 
Return a filter that evaluates to true for null values.
- IsNullFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with null.
- IsNullFilter() - Constructor for class com.tangosol.util.filter.IsNullFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- IsNullFilter(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.filter.IsNullFilter
- 
Construct a IsNullFilter for testing equality to null.
- IsNullFilter(String) - Constructor for class com.tangosol.util.filter.IsNullFilter
- 
Construct a IsNullFilter for testing equality to null.
- isNullFirst() - Method in class com.tangosol.util.comparator.SafeComparator
- 
Obtain the m_fNullFirst flag.
- isNullValuesAllowed() - Method in class com.tangosol.net.cache.OverflowMap
- 
Determine if null values are permitted.
- isNullValuesAllowed() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Determine if null values are permitted.
- isNumber() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Answer whether the receiver is an Atomic Term representing a Number.
- isNumber() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Answer whether the receiver is an Atomic Term representing a Number.
- isObserved() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Determine if theContinuousQueryCachehas any listeners that cannot be served by this Map listening to lite events.
- isOctal(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Returns true if the passed character is an octal digit.
- isOctal(char) - Static method in class com.tangosol.util.Base
- 
Returns true if the passed character is an octal digit.
- isOldValueAvailable() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
- isOldValueAvailable() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
- isOldValueConverted() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Check if the event's old value has been converted.
- isOnlyOwnedCommits() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Returnstrueif the topic only allows commits of a position in a channel to be made by subscribers that own the channel.
- isOnWorkerThread() - Method in class com.tangosol.util.Daemon
- 
Indicate if the current execution thread is a child of this daemon.
- isOpen() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Check whether or not this bundle is open for adding request elements.
- isOperator() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token represents a know operator.
- isOperator() - Method in class com.tangosol.coherence.dsltools.base.OperatorBaseToken
- 
Answer whether this token represents a know operator.
- isOptimizeMV() - Method in class com.tangosol.util.SimpleMapIndex
- 
Specifies whether an attempt will be made to search the forward map for an existing reference that is "equal" to the specified mutli-value and use it instead (if available) to reduce the index memory footprint.
- isOrdered() - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Determine if the MapIndex orders the contents of the indexed information.
- isOrdered() - Method in interface com.tangosol.util.MapIndex
- 
Determine if the MapIndex orders the contents of the indexed information.
- isOrdered() - Method in interface com.tangosol.util.QueryRecord.PartialResult.IndexLookupRecord
- 
Indicates whether or not the associated index is ordered.
- isOrdered() - Method in class com.tangosol.util.SimpleMapIndex
- 
Determine if the MapIndex orders the contents of the indexed information.
- isOrdered() - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Indicates whether or not the associated index is ordered.
- isOriginalPresent() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Determine whether or not the Entry existed before the start of the mutating operation that is being evaluated by the trigger.
- isOriginalPresent() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- isOriginalPresent() - Method in interface com.tangosol.util.MapTrigger.Entry
- 
Determine whether or not the Entry existed before the start of the mutating operation that is being evaluated by the trigger.
- isOriginalPresent() - Method in class com.tangosol.util.SimpleMapEntry
- 
Determine whether or not the Entry existed before the start of the mutating operation that is being evaluated by the trigger.
- isOwned() - Method in class com.tangosol.net.topic.Subscriber.Channel.EmptyChannel
- isOwned() - Method in interface com.tangosol.net.topic.Subscriber.Channel
- 
Returnstrueif the channel is owned by this subscriber.
- isOwnedByCaller() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Checks whether or not this Lock object is held by the calling thread.
- isOwnedByCurrentThread() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the current thread owns this Status object.
- isOwnedByCurrentThread() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if the current thread owns this Status object.
- isOwner(int) - Method in interface com.tangosol.net.topic.Subscriber
- 
Returnstrueif this subscriber is the owner of the specified channel.
- isPageActive(int) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Determine if the specified page number is active.
- isParallel() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A convenience accessor to check if this streamer isInvocableMap.StreamingAggregator.PARALLEL.
- isParallel() - Method in interface com.tangosol.util.stream.RemotePipeline
- 
Return whether this pipeline should be executed in parallel.
- isPartial() - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Return whether this is a partial property or not.
- isPartial() - Method in class com.tangosol.util.ConditionalIndex
- 
Determine if indexed information for any entry in the indexed Map has been excluded from this index.
- isPartial() - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Determine if indexed information for any entry in the indexed Map has been excluded from this index.
- isPartial() - Method in interface com.tangosol.util.MapIndex
- 
Determine if indexed information for any entry in the indexed Map has been excluded from this index.
- isPartial() - Method in class com.tangosol.util.SimpleMapIndex
- 
Determine if indexed information for any entry in the indexed Map has been excluded from this index.
- isPartialNameLegal(String) - Static method in class com.tangosol.util.ClassHelper
- 
Determine if a partial name (for example, a prefix, class name, package name, etc. as accepted by the above methods) is legal.
- isPartitioned(ParameterResolver, boolean) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Return true if the partitioned flag is set explicitly or a journal map is used.
- isPartitionEndangered(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff the specified partition is "endangered".
- isPartitionEndangered(Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff the specified ownership is "endangered".
- isPartitionStrong(int) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff the ownership of the specified partition is "strong", as defined by the current BackupStrength.
- isPartitionStrong(Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff the specified ownership is "strong", as defined by the current BackupStrength.
- isPassivePagedBackup() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine if this is just a passive backup for a paged cache.
- isPatchCompatible(int) - Method in class com.tangosol.io.WrapperBufferInput.VersionAwareBufferInput
- 
Determine whether the sender of the content of this BufferInput run versions that are the same as the encode version with the same or a higher patch level.
- isPatchCompatible(int) - Method in class com.tangosol.io.WrapperBufferOutput.VersionAwareBufferOutput
- 
Determine whether all the recipients of the content of this BufferOutput run versions that are the same as the encode version with the same or a higher patch level.
- isPatchCompatible(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether all the sender of the content (the given DataInput) run versions that are the same version with the same or greater patch level.
- isPatchCompatible(DataOutput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether all the recipients of the content (the given DataOutput) run versions that are the same version with the same or greater patch level.
- isPending() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Check whether or not this bundle is in the "pending" state - awaiting for the execution results.
- isPending() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Check whether or not the underlying address has been accepted.
- isPreferJavaTime() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
ReturntrueifPofReader.readObject(int)method should return the appropriate Java 8 date/time type, orfalseif a legacy date/time types should be returned in order to preserve backwards compatibility.
- isPreferJavaTime() - Method in interface com.tangosol.io.pof.PofContext
- 
ReturntrueifPofReader.readObject(int)method should return the appropriate Java 8 date/time type, orfalseif a legacy date/time types should be returned in order to preserve backwards compatibility.
- isPreferJavaTime() - Method in class com.tangosol.io.pof.SimplePofContext
- 
ReturntrueifPofReader.readObject(int)method should return the appropriate Java 8 date/time type, orfalseif a legacy date/time types should be returned in order to preserve backwards compatibility.
- isPrefixAllowed() - Method in class com.tangosol.coherence.dsltools.precedence.InfixOPToken
- 
Get the flag that control whether the operator can be used as a prefix.
- isPreLoad(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Return true if a cache pre-loads data from its CacheLoader.
- isPresent() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Determine if this Entry exists in the Map.
- isPresent() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Determine if this Entry exists in the Map.
- isPresent() - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Determine if this Entry exists in the Map.
- isPresent() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- isPresent() - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Determine if this Entry exists in the Map.
- isPresent() - Method in class com.tangosol.util.SimpleHolder
- 
Return true if the contained value is present, false otherwise.
- isPresent() - Method in class com.tangosol.util.SimpleMapEntry
- 
Determine if this Entry exists in the Map.
- isPresentOnly() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A convenience accessor to check if this streamer isInvocableMap.StreamingAggregator.PRESENT_ONLY.
- isPrimary() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.LoadComparator
- 
Return true iff the comparator should use the primary load.
- isPrimary() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
- 
Return true iff this Filter compares the primary partition load.
- isPriming() - Method in class com.tangosol.net.cache.CacheEvent
- 
Return true iff this event is caused by a priming listener registration.
- isPriming(MapEvent) - Method in class com.tangosol.net.cache.CachingMap
- 
Check if the specified event is a "priming" one.
- isPrimingListener(MapListener) - Static method in class com.tangosol.util.MapListenerSupport
- 
Check if the given listener is a PrimingListener or if it wraps one.
- isProcessed() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Check whether or not this bundle is in the "processed" state - ready to return the result of execution back to the client.
- isProcessing() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the Status object represents an Entry that is currently being processed.
- isProcessing() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if the Status object represents an Entry that is currently being processed.
- isPropertyDefined(String, XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Determines if the specified property is defined at the path relative to the specifiedXmlElement.
- isPropertyDefined(String, XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Determines if the specified property is defined at the path relative to the specifiedXmlElement.
- isPropertyExtractor() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Return true if this is a Property extractor.
- isPublicIdentifierValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Validate the passed public identifier.
- isPunctuation() - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token represents a punctuation character.
- isPunctuation() - Method in class com.tangosol.coherence.dsltools.base.PunctuationBaseToken
- isPunctuation(char) - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Test if the given char is a punctuation character.
- isPutAllOptimized(Map) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.
- isQualifiedNameLegal(String) - Static method in class com.tangosol.util.ClassHelper
- 
Determine if the passed string is a legal dot-delimited identifier.
- isQuoteRequired(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Determine if the string requires quotes.
- isQuoteRequired(String, boolean) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Determine if the string requires quotes.
- isReadLocked() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Queries if the read lock is held by any thread.
- isReadOnly() - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- isReadOnly() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Check whether this BinaryEntry allows data modification operations.
- isReadOnly() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Determine if thisContinuousQueryCachedisallows data modification operations.
- isReadOnly() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Determine if the backing map should send data changes through the CacheStore, or should just keep them in memory.
- isReadOnly() - Method in interface com.tangosol.net.management.ViewMBean
- 
Determine if thisContinuousQueryCachedisallows data modification operations.
- isReadOnly() - Method in class com.tangosol.net.management.ViewMBeanImpl
- isReadOnly() - Method in interface com.tangosol.util.BinaryEntry
- 
Check whether this BinaryEntry allows data modification operations.
- isReadOnly() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Check whether this BinaryEntry allows data modification operations.
- isReadOnly() - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- 
Check whether this BinaryEntry allows data modification operations.
- isReadOnly(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Returns true if the cache is read only.
- isReadThrough() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- isReadThrough() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
- isReadThrough() - Method in class com.tangosol.coherence.jcache.common.JCacheContext
- 
Is read-through enabled.
- isReady() - Method in class com.oracle.coherence.common.base.ConcurrentNotifier
- 
Return true if the notifier is ready, i.e. threads entering await cant return without blocking.
- isReady() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- isReady() - Method in class com.tangosol.net.cache.NearCache
- isReady() - Method in class com.tangosol.net.cache.WrapperNamedCache
- isReady() - Method in interface com.tangosol.net.NamedMap
- 
Returns whether thisNamedMapis ready to be used.
- isReady() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return true if the store is ready to accept requests.
- isReady() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- isReady() - Method in interface com.tangosol.util.HealthCheck
- 
Returns {@link true} if the resource represented by thisHealthCheckis ready, otherwise returnsfalse.
- isReady(IsReadyRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Determine whether a cache is Ready.
- isReady(IsReadyRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- isReady(IsReadyRequest, StreamObserver<BoolValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- isReceiverNackEnabled() - Method in interface com.tangosol.net.ClusterDependencies
- 
Determine whether the PacketReceiver will use negative acknowledgments (NACK packet requests) to pro-actively respond to known missing packets.
- isReferenceEnabled() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine if Identity/Reference type support is enabled for this ConfigurablePofContext.
- isReferenceEnabled() - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Determine if reference support is enabled.
- isReferenceEnabled() - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine if Identity/Reference type support is enabled for this SimplePofContext.
- isRefinementNeeded(SimpleAssignmentStrategy.AnalysisContext, PartitionedService, PartitionedService) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Return true iff the partition assignments sync'd from the specified associated service should be further refined/balanced by the local assignment strategy.
- isReflectionAllowed(Object) - Static method in class com.tangosol.util.ClassHelper
- 
ReturnstrueifoTargetis a valid type for reflection operations.
- isRefreshable() - Method in class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
- 
Returns true if any of the added addresses has been computed to be a hostname.
- isRefreshable() - Method in interface com.tangosol.net.ssl.CertificateLoader
- 
Returntrueif theCertificateloaded previously by this loader should be refreshed.
- isRefreshable() - Method in interface com.tangosol.net.ssl.KeyStoreLoader
- 
Returntrueif theKeyStoreloaded previously by this loader should be refreshed.
- isRefreshable() - Method in interface com.tangosol.net.ssl.PrivateKeyLoader
- 
Returntrueif thePrivateKeyloaded previously by this loader should be refreshed.
- isRefreshAhead() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Determine if the backing map preemptively reads soon-to-be expired entries on a refresh-ahead thread.
- isRegisterable(Class<?>) - Method in class com.tangosol.coherence.config.xml.processor.DefaultsProcessor
- 
Determines if the specifiedClassof resource should be registered with aResourceRegistry.
- isRegistered(String) - Method in interface com.tangosol.net.management.Registry
- 
Check whether or not the specified name is already registered.
- isRegistered(Cache, MBeanServerRegistrationUtility.ObjectNameType) - Static method in class com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility
- 
Checks whether an ObjectName is already registered.
- isRehashing() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine if the map is incrementally rehashing.
- isReleased() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- isReleased() - Method in class com.tangosol.net.cache.NearCache
- 
Specifies whether or this Releasable has been released.
- isReleased() - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Specifies whether or this Releasable has been released.
- isReleased() - Method in interface com.tangosol.net.Releasable
- 
Specifies whether or this Releasable has been released.
- isReleased() - Method in interface com.tangosol.net.topic.NamedTopic
- 
Specifies whether this NamedTopic has been released.
- isReleased() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Specifies whether or this Releasable has been released.
- isRemoteClient() - Method in interface com.tangosol.net.Member
- 
Check whether or not thisMemberrepresents a remote client.
- isReported() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Check whether or not the underlying address has been reported as unresolvable.
- isReserved() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if the Status object is reserved.
- isResolving(DataOutput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether the passed DataOutput handles ClassLoader resolving.
- isRespondInOrder() - Method in class com.tangosol.net.AbstractInvocable
- 
Determine whether this Invocable object has to preserve the order of responses according to the order of requests.
- isRespondInOrder() - Method in interface com.tangosol.net.InvocableInOrder
- 
Determine whether this Invocable object has to preserve the order of responses according to the order of requests.
- isRetainConsumed() - Method in interface com.tangosol.net.topic.TopicDependencies
- 
Returnstrueif this topic retains messages after they have been committed orfalseif messages are removed after all known subscribers have committed them.
- isRetainConsumed(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Determine whether to retain consumed values.
- isRetainsEntries() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A convenience accessor to check if this streamer isInvocableMap.StreamingAggregator.RETAINS_ENTRIES.
- isRethrowExceptions() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Determine if exceptions caught during synchronous CacheStore operations are rethrown to the calling thread; if false, exceptions are logged.
- isRollbackCacheStoreFailures(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Return true if exceptions caught during synchronous cachestore operations are rethrown to the calling thread (possibly over the network to a remote member).
- isRoot() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return true if this instance is the root of the PofValue hierarchy.
- isRootContext() - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Determines if theProcessingContextis the root.
- isRunning() - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- isRunning() - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Returnstrueif the server is running.
- isRunning() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- isRunning() - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- isRunning() - Method in class com.tangosol.net.WrapperService
- 
Determine whether or not the controllable service is running.
- isRunning() - Method in interface com.tangosol.util.Controllable
- 
Determine whether or not the controllable service is running.
- isRunning() - Method in class com.tangosol.util.Daemon
- 
Check if the daemon is running (has started and has not stopped).
- isRunningClusterNeeded() - Method in interface com.tangosol.coherence.config.builder.ServiceBuilder
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.BaseGrpcScheme
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.ClassScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.InvocationScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.ProxyScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.RemoteCacheScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.RemoteInvocationScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.ReplicatedScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningClusterNeeded() - Method in class com.tangosol.coherence.config.scheme.TransactionalScheme
- 
Return true if a running cluster is needed before using a service.
- isRunningInContainer() - Method in class com.tangosol.coherence.rest.server.ContainerPassThroughResourceConfig
- isRunningInContainer() - Method in class com.tangosol.coherence.rest.server.ContainerResourceConfig
- isRunningInContainer() - Method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Return whether REST API is run inside the container (true) or standalone (false).
- isSafe() - Method in interface com.tangosol.util.HealthCheck
- 
Returns {@link true} if the resource represented by thisHealthCheckis in a safe state to allow a rolling upgrade to proceed, otherwise returnsfalse.
- isSanityChecking() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return whether sanity checking should be enabled when executing commands.
- isSanityChecking() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- isSanityChecking() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return whether sanity checking should be enabled when executing statements.
- isSealed(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Return true if the specified store has been sealed.
- isSecure() - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
- isSecure() - Method in interface com.tangosol.net.DatagramSocketProvider
- 
Return true iff the provider returns sockets which are secured, for instance by TLS.
- isSecure() - Method in class com.tangosol.net.SystemDatagramSocketProvider
- isSecure() - Method in class com.tangosol.net.TcpDatagramSocketProvider
- 
Return true iff the provider returns sockets which are secured, for instance by TLS.
- isSelectStarQuery(String, NodeTerm) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
- 
Return true if this query is of the form "SELECT * FROM cache-name".
- isSerial() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A convenience accessor to check if this streamer isInvocableMap.StreamingAggregator.SERIAL.
- isSerializable(Object) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine if the resource object can be serialized using the DefaultSerializer.
- isSerializerCompatible(Serializer, Serializer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determines whether or not the specified serializers are compatible.
- isSerializerCompatible(Service, Service) - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Determines whether or not the serializers for the specified services are compatible.
- isSerializerCompatible(Service, Service) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Determines whether or not the serializers for the specified services are compatible.
- isSet() - Static method in class com.oracle.coherence.common.base.Timeout
- 
Return true if calling thread specified a timeout.
- isShallowCloneable() - Method in class com.tangosol.io.ByteArrayReadBuffer
- 
Determine whether a clone can be made without cloning the byte array.
- isSharedStorage() - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Check whether ior not all the partition stores visible by every member.
- isShutdown() - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Returnstrueif this executor has been shut down.
- isSilent() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return true if the current query session is running in silent mode.
- isSilent() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- isSilent() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return true if the current query session is running in silent mode.
- isSimpleNameLegal(String) - Static method in class com.tangosol.util.ClassHelper
- 
Determine if the passed string is a legal simple name.
- isSimpleSequence(List<XmlElement>) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Check whether or not the specified list contains only simple elements with the same names.
- isSiteLocalAddress(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
- 
Deprecated.As of Coherence 3.0, replaced byInetAddress.isSiteLocalAddress()
- isSized() - Method in interface com.tangosol.util.Streamer
- 
A convenience accessor to check if this streamer isStreamer.SIZED.
- isSkippable() - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Determine if the value encoding can be skipped.
- isSlidingExpiry(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Return true iff sliding expiry is enabled.
- isSparse() - Method in class com.tangosol.io.pof.WritingPofHandler.Complex
- 
Determine if the position information is encoded with the values of the complex type, and if the Complex type is terminated in the POF stream with an illegal position (-1).
- isSparse() - Method in class com.tangosol.run.xml.IterableAdapter
- isSpeakerEnabled() - Method in interface com.tangosol.net.ClusterDependencies
- 
Determine whether the packet speaker is enabled.
- isStarted() - Method in class com.tangosol.net.Coherence
- 
Returntrueif thisCoherenceinstance has been started.
- isStarted() - Method in interface com.tangosol.util.HealthCheck
- 
Returns {@link true} if the resource represented by thisHealthCheckis started, otherwise returnsfalse.
- isStartingState(S) - Method in class com.tangosol.util.fsm.Transition
- 
Determines if the specified state is one of the possible starting states for theTransition.
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Get JCache Statistics status
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- isStatisticsEnabled() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- isStopOnError() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return the flag indicating whether CohQL should stop processing multiple statements if an error occurs (for example when processing a file), or whether errors should be logged and statement processing continue.
- isStopping() - Method in class com.tangosol.util.Daemon.DaemonWorker
- isStopping() - Method in class com.tangosol.util.Daemon
- 
Check if the daemon is supposed to stop.
- isStoreAllSupported() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine if the wrapped store supports storeAll() operations.
- isStoreByValue() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- isStoreByValue() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
- isStoreByValue() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- isStoreSupported() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Determine if the wrapped store supports store() operations.
- isStoreUnsupported() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Determine if the CacheStore has been determined to be read-only for store() operations.
- isStrict() - Method in class com.tangosol.io.nio.BinaryMap
- 
Determine if the buffer should be initialized and if blocks should be cleared when not in use.
- isStrict() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Determine if any access to data in missing partitions is being treated as an error.
- isStringable() - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- isStringable() - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- isStringable() - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- isStringable() - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- isStripTrailingZeros() - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Shall trailing zeros be removed from the aggregation result?
- isStrong(Member, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff the specified members are mutually "strong", as defined by the backup strength.
- isStrong(Member, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Return true iff the specified members are mutually "strong".
- isStrong(Member, Ownership) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff the specified member is "strong" with respect to the specified ownership, as defined by the backup strength.
- isStrongPossible(Set, Map) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff a "strong" balanced distribution is achievable for the specified set of members, split among a set of categories (e.g. machine, rack, site).
- isStuck() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- isStuck() - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- 
Returntrueif the pool is stuck.
- isSubclassAllowed() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine if the ConfigurablePofContext supports the serialization of an object that is an instance of a sub-class of a configured type, but not actually an instance of a class of a configured type.
- isSubjectScopingEnabled() - Method in interface com.tangosol.net.OperationalContext
- 
Indicates if Subject scoping is enabled.
- isSubscribedTo(String) - Method in interface com.tangosol.net.management.NotificationManager
- 
Determine if any subscriptions exist for the specified MBean.
- isSubscriptionDestroyed(long) - Method in interface com.tangosol.net.PagedTopicService
- 
Determine whether a subscriber group has been destroyed.
- isSuccess() - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- 
Returnstrueif the result can be considered successful, i.e. its status is not a failure status.
- isSupported(OptionalFeature) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- isSuspect(long) - Method in class com.tangosol.net.GuardSupport.Context
- 
Is the Guardable represented by this GuardContext suspect (in danger of timing out soon).
- isSuspended() - Method in interface com.tangosol.net.Service
- 
Returnstrueif this service is currently suspended.
- isSuspended() - Method in class com.tangosol.net.WrapperService
- isSynchronous() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Returntrueif this is synchronous event listener.
- isSynchronous() - Method in interface com.tangosol.util.MapListener
- 
Returns true if this listener should be fired synchronously.
- isSynthetic() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Determine if this Entry has been synthetically mutated.
- isSynthetic() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Determine if this Entry has been synthetically mutated.
- isSynthetic() - Method in class com.tangosol.net.cache.CacheEvent
- 
Return true iff this event is caused by the cache internal processing such as eviction or loading
- isSynthetic() - Method in class com.tangosol.net.cache.LocalCache.KeyMask
- 
Check whether or not the currently performed operation is internally initiated.
- isSynthetic() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Determine if this Entry has been synthetically mutated.
- isSynthetic() - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Determine if this Entry has been synthetically mutated.
- isSynthetic() - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- isSynthetic() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Is this Entry synthetic?
- isSynthetic() - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Is this Entry synthetic?
- isSynthetic() - Method in class com.tangosol.util.SimpleMapEntry
- 
Determine if this Entry has been synthetically mutated.
- isSynthetic(MapEvent) - Static method in class com.tangosol.net.cache.OverflowMap
- 
Helper method to determine if an event is synthetic.
- isSynthetic(MapEvent<K, V>) - Static method in class com.tangosol.util.WrapperObservableMap
- 
Helper method to determine if an event is synthetic.
- isSyntheticUpdate() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
determine if last update was considered synthetic
- isSystemIdentifierValid(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Validate the passed system identifier.
- isTcmpEnabled() - Method in interface com.tangosol.net.ClusterDependencies
- 
Determine whether the TCMP is enabled.
- isTcpRingEnabled() - Method in interface com.tangosol.net.ClusterDependencies
- 
Determine whether the TcpRing is enabled.
- isTemporary() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
Return if the database is temporary.
- isTemporary() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Return true if this is a manager for temporary stores.
- isTemporary() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Return true if this is a temporary environment.
- isTerminated() - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Returnstrueif all tasks have completed following shut down.
- isTimedOut() - Static method in class com.oracle.coherence.common.base.Timeout
- 
Return true if the calling thread is timed out.
- isTimedOut(long) - Method in class com.tangosol.net.GuardSupport.Context
- 
Is the Guardable represented by this GuardContext timed out?
- isTopicActive(String, ClassLoader) - Method in class com.tangosol.net.CoherenceSession
- isTopicActive(String, ClassLoader) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Validate whether a topic with the given name is active in the context of the givenClassLoader.
- isTopicActive(String, ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Validate whether a topic with the given name is active in the context of the givenClassLoader.
- isTopicActive(String, ClassLoader) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Validate whether a topic with the given name is active in the context of the givenClassLoader.
- isTopicActive(String, ClassLoader) - Method in interface com.tangosol.net.Session
- 
Validate whether a topic with the given name is active in the context of the givenClassLoader.
- isTraceEnabled() - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Return whether trace to display output when executing commands.
- isTraceEnabled() - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- isTraceEnabled() - Method in interface com.tangosol.coherence.dslquery.QueryPlus.Dependencies
- 
Return whether trace is enabled.
- isTraceLogging() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Return a boolean to indicate whether the executor trace logging is enabled (true) or not (false).
- isTrackingRetained() - Method in class com.tangosol.util.SubSet
- 
Determine if the SubSet is tracking retained items versus removed items.
- isTransferStrong(int, int, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Return true iff the specified partition transfer would result in a "strong" ownership, as defined by the current BackupStrength.
- isTransformed() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Determine if thisContinuousQueryCachetransforms values.
- isTransformed() - Method in interface com.tangosol.net.management.ViewMBean
- 
Determine if thisContinuousQueryCachetransforms values.
- isTransformed() - Method in class com.tangosol.net.management.ViewMBeanImpl
- isTransformedEvent(MapEvent) - Method in class com.tangosol.util.MapListenerSupport
- 
Return true iff the specified event represents a transformed CacheEvent.
- isTransient(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Return true if the backing map is transient.
- isTranslateEvents() - Method in class com.tangosol.util.WrapperObservableMap
- 
Check whether or not an event source has to be translated by the wrapper.
- isTrue(ValueExtractor<T, Boolean>) - Static method in class com.tangosol.util.Filters
- 
Return a filter that evaluates to true if the extracted value istrue.
- isTypeIdEncoded(int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Determine if the type should be encoded for the current value.
- isUniform() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
Determine if the object encoding within the Complex type is uniform.
- isUniform() - Method in class com.tangosol.io.pof.ValidatingPofHandler.ComplexMap
- 
Determine if the object encoding within the Complex type is uniform.
- isUniform() - Method in class com.tangosol.io.pof.WritingPofHandler.Complex
- 
Determine if the object encoding within the Complex type is uniform.
- isUniform() - Method in class com.tangosol.io.pof.WritingPofHandler.ComplexMap
- 
Determine if the object encoding within the Complex type is uniform.
- isUniformCollection() - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Return true if this complex value is encoded as one of uniform collection types.
- isUniformEncoded() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Return true if the buffer contains only the value, without the type identifier.
- isUpdate() - Method in class com.tangosol.util.MapEvent
- 
Determine whether this event is an update event.
- isUpperBoundInclusive() - Method in class com.tangosol.util.filter.BetweenFilter
- 
Obtain the flag indicating whether values matching the upper bound of the range evaluate to true.
- isUserInRole(String) - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
- isUserType(Class) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine if the given class is a user type known to this PofContext.
- isUserType(Class) - Method in interface com.tangosol.io.pof.PofContext
- 
Determine if the given class is a user type known to this PofContext.
- isUserType(Class) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Determine if the given class is a user type known to this PofContext.
- isUserType(Class) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine if the given class is a user type known to this PofContext.
- isUserType(Class) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Determine if the given class is a user type known to this PofContext.
- isUserType(Object) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine if the given object is of a user type known to this PofContext.
- isUserType(Object) - Method in interface com.tangosol.io.pof.PofContext
- 
Determine if the given object is of a user type known to this PofContext.
- isUserType(Object) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine if the given object is of a user type known to this PofContext.
- isUserType(Object) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Determine if the given object is of a user type known to this PofContext.
- isUserType(String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Determine if the class with the given name is a user type known to this PofContext.
- isUserType(String) - Method in interface com.tangosol.io.pof.PofContext
- 
Determine if the class with the given name is a user type known to this PofContext.
- isUserType(String) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Determine if the class with the given name is a user type known to this PofContext.
- isUserType(String) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Determine if the class with the given name is a user type known to this PofContext.
- isUserType(String) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Determine if the class with the given name is a user type known to this PofContext.
- isUTC() - Method in class com.tangosol.io.pof.RawTime
- 
Determine if the time value uses UTC.
- isValid() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine if the Status object is valid.
- isValid() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine if the Status object is valid.
- isValidNumber() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Test whether the value is of a valid number format.
- isValidQName(String) - Method in class com.tangosol.run.xml.QNameAdapter
- 
Specifies whether or not the specified QName value is associated with a known namespace declaration.
- isValueChanged() - Method in interface com.tangosol.util.BinaryEntry
- 
Check whether the value of this BinaryEntry is changed.
- isValueLoaded() - Method in interface com.tangosol.util.BinaryEntry
- 
Check whether this BinaryEntry is loaded by a "read-through" operation.
- isValueRemoved() - Method in interface com.tangosol.util.BinaryEntry
- 
Check whether the value of this BinaryEntry is removed.
- isValuesImmutable() - Method in interface com.tangosol.util.TransactionMap
- 
Check whether or not the values stored in this TransactionMap are known to be immutable.
- isValueUpdated() - Method in interface com.tangosol.util.BinaryEntry
- 
Check whether the value of this BinaryEntry is updated.
- isVersionAware() - Method in interface com.tangosol.util.MapListener
- 
Returns true if this listener should track versions thus allowing missed versions to be replayed if supported by the event source.
- isVersionAware(MapListener) - Method in class com.tangosol.util.MapListenerSupport
- 
Return true if the provided listener is version aware.
- isVersionCompatible(int) - Method in class com.tangosol.io.WrapperBufferInput.VersionAwareBufferInput
- 
Determine whether the sender of the content of this BufferInput runs a version that supersedes (greater or equal to) the specified version.
- isVersionCompatible(int) - Method in class com.tangosol.io.WrapperBufferOutput.VersionAwareBufferOutput
- 
Determine whether all the recipients of the content of this BufferOutput run versions that supersede (greater or equal to) the specified version.
- isVersionCompatible(int) - Method in interface com.tangosol.net.Service
- 
Check whether the members of this service run a version that is greater than or equal to the specified version.
- isVersionCompatible(int) - Method in class com.tangosol.net.WrapperService
- isVersionCompatible(int, int, int) - Method in class com.tangosol.io.WrapperBufferInput.VersionAwareBufferInput
- 
Determine whether the sender of the content of this BufferInput runs a version that supersedes (greater or equal to) the specified version.
- isVersionCompatible(int, int, int) - Method in class com.tangosol.io.WrapperBufferOutput.VersionAwareBufferOutput
- 
Determine whether all the recipients of the content of this BufferOutput run versions that supersede (greater or equal to) the specified version.
- isVersionCompatible(int, int, int) - Method in interface com.tangosol.net.Service
- 
Check whether the members of this service run a version that is greater than or equal to the specified version.
- isVersionCompatible(int, int, int) - Method in class com.tangosol.net.WrapperService
- isVersionCompatible(int, int, int, int, int) - Method in class com.tangosol.io.WrapperBufferInput.VersionAwareBufferInput
- 
Determine whether the sender of the content of this BufferInput runs a version that supersedes (greater or equal to) the specified version.
- isVersionCompatible(int, int, int, int, int) - Method in class com.tangosol.io.WrapperBufferOutput.VersionAwareBufferOutput
- 
Determine whether all the recipients of the content of this BufferOutput run versions that supersede (greater or equal to) the specified version.
- isVersionCompatible(int, int, int, int, int) - Method in interface com.tangosol.net.Service
- 
Check whether the members of this service run a version that is greater than or equal to the specified version.
- isVersionCompatible(int, int, int, int, int) - Method in class com.tangosol.net.WrapperService
- isVersionCompatible(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether the sender of the content (the given DataInput) runs a version that supersedes (greater or equal to) the specified version.
- isVersionCompatible(DataInput, int, int, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether the sender of the content (the given DataInput) runs a version that supersedes (greater or equal to) the specified version.
- isVersionCompatible(DataInput, int, int, int, int, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether the sender of the content (the given DataInput) runs a version that supersedes (greater or equal to) the specified version.
- isVersionCompatible(DataOutput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether all the recipients of the content (the given DataOutput) run versions that supersede (greater or equal to) the specified version.
- isVersionCompatible(DataOutput, int, int, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether all the recipients of the content (the given DataOutput) run versions that supersede (greater or equal to) the specified version.
- isVersionCompatible(DataOutput, int, int, int, int, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Determine whether all the recipients of the content (the given DataOutput) run versions that supersede (greater or equal to) the specified version.
- isVersionCompatible(IntPredicate) - Method in interface com.tangosol.net.Service
- 
Check whether the members of this service run a minimum service version that matches a specifiedIntPredicate.
- isVersionCompatible(IntPredicate) - Method in class com.tangosol.net.WrapperService
- isVersioningEnabled() - Method in interface com.tangosol.util.Versionable
- 
Return the value specifying if the versioning is enabled.
- isVersionUpdate() - Method in class com.tangosol.net.cache.CacheEvent
- 
Return true iff this event is caused by a synthetic version update sent by the server to notify clients of the current version.
- isVersionUpdate() - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- isVersionUpdate(MapEvent) - Method in class com.tangosol.util.MapListenerSupport
- 
Return true if the provided MapEvent is due to a synthetic version update.
- isVirtualErase() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Determine if BinaryStore erase commands will be done only in memory (to the cached list of keys) and not passsed to the underlying BinaryStore, thus improving performance and cutting I/O, but potentially wasting disk space (or whatever resource the paged data are stored on.)
- isWaitingOnPending() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Check whether any threads are waiting for the store operation to complete.
- isWhitespace(char) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Test if the specified character is XML whitespace.
- isWildCardCacheName() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Returntrueif this listener is for a wild-card cache name.
- isWildCardServiceName() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Returntrueif this listener is for a wild-card cache name.
- isWLSContainer() - Static method in class com.tangosol.coherence.jcache.common.ContainerHelper
- 
Deprecated.
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.EntryWriter
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.JsonCollectionWriter
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.ObjectWriter
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlCollectionWriter
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlKeysWriter
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.tangosol.coherence.rest.providers.XmlMapWriter
- isWriteBehind() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Determine if the backing map writes changes on a write-behind thread through the CacheStore.
- isWriteBehindRemove() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Determine if the backing map should apply write-behind delay to remove from CacheStore.
- isWriteBehindRemove(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Returns true if the write-behind applies to remove.
- isWriteLocked() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Queries if the write lock is held by any thread.
- isWriteLockedByCurrentThread() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Queries if the write lock is held by the current thread.
- isWriteThrough() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- isWriteThrough() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheMXBean
- isWriteThrough() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Determine if the backing map writes changes immediately through the CacheStore.
- Iterable(IterableCacheLoader<K, V>) - Constructor for class com.tangosol.net.cache.CacheLoaderCacheStore.Iterable
- 
The CacheLoader to delegate to.
- IterableAdapter - Class in com.tangosol.run.xml
- 
An IterableAdapter is the base class for any data type that must be iterated over to serialize/deserialize, such as arrays, collections and maps.
- IterableAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.IterableAdapter
- 
Construct a IterableAdapter.
- IterableCacheLoader<K,V> - Interface in com.tangosol.net.cache
- 
A JCache CacheLoader that can iterate its underlying contents.
- iterate(PersistentStore.Visitor<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Iterate the key-value pairs in the persistent store, applying the specified visitor to each key-value pair.
- iterate(PersistentStore.Visitor<R>) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Iterate the key-value pairs in the persistent store, applying the specified visitor to each key-value pair.
- iterate(PersistentStore.Visitor<R>) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- iterateBinaryStores() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Obtain an iterator of all registered (not destroyed) BinaryStore objects being used by this cache.
- iterateInternal(PersistentStore.Visitor<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Iterate the key-value pairs in the underlying persistent storage, applying the specified visitor to each key-value pair.
- iterateKeys() - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EvictingBackupMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.util.KeyValueArrayMap
- 
Create an iterator over the keys in this Map.
- iterateKeys() - Method in class com.tangosol.util.OpenHashMap
- 
Create an iterator over the keys in this Map.
- iterateKeys(Map[]) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Create an iterator over the keys in maps that belong to partitions contained in the specified PartitionSet.
- iterator() - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- iterator() - Method in class com.tangosol.coherence.config.CacheMappingRegistry
- 
Deprecated.
- iterator() - Method in class com.tangosol.coherence.config.ResolvableParameterList
- iterator() - Method in class com.tangosol.coherence.config.SchemeMappingRegistry
- iterator() - Method in class com.tangosol.coherence.config.ServiceSchemeRegistry
- iterator() - Method in class com.tangosol.coherence.config.SimpleParameterList
- iterator() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- iterator() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterable
- iterator() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- iterator() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- iterator() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- iterator() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- iterator() - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Return an iterator for this property set.
- iterator() - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.io.nio.BinaryMap.KeySet
- 
Obtain an iterator over the keys in the Map.
- iterator() - Method in class com.tangosol.io.nio.BinaryMap.ValuesCollection
- 
Obtain an iterator over the values in the Map.
- iterator() - Method in class com.tangosol.net.cache.OldCache.EntrySet
- 
Deprecated.Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- iterator() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ValuesCollection
- 
Obtain an iterator over the values in the Map.
- iterator() - Method in class com.tangosol.net.CompositeAddressProvider
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in interface com.tangosol.net.events.partition.cache.EntryProcessorEvent
- 
Returns an iterator over theentriesin this event.
- iterator() - Method in interface com.tangosol.net.events.partition.TransactionEvent
- 
Returns an iterator over theentriesin this event.
- iterator() - Method in interface com.tangosol.net.events.partition.UnsolicitedCommitEvent
- 
Returns an iterator over theentriesin this event.
- iterator() - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- iterator() - Method in class com.tangosol.net.partition.PartitionSet
- iterator() - Method in interface com.tangosol.net.partition.VersionedPartitions
- 
Returns aVersionedPartitions.VersionedIteratorthat allows retrieval of the next element as aprimitive.
- iterator() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet
- iterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.AbstractSafeLongArray
- iterator() - Method in class com.tangosol.util.AbstractSparseArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray.
- iterator() - Method in class com.tangosol.util.ChainedCollection
- iterator() - Method in class com.tangosol.util.ChainedMap.EntrySet
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.ChainedSet
- iterator() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- iterator() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- iterator() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- iterator() - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in order of increasing indices.
- iterator() - Method in class com.tangosol.util.CopyOnWriteMap.EntrySet
- iterator() - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
- iterator() - Method in class com.tangosol.util.DeltaSet
- 
Returns an Iterator over the elements contained in this Collection.
- iterator() - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns an iterator over the elements in this list in proper sequence.
- iterator() - Method in class com.tangosol.util.ImmutableMultiList
- 
Returns an iterator over the elements in this list in proper sequence.
- iterator() - Method in class com.tangosol.util.InflatableCollection
- iterator() - Method in class com.tangosol.util.LiteSet
- 
Returns an Iterator over the elements in this Set.
- iterator() - Method in interface com.tangosol.util.LongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in order of increasing indices.
- iterator() - Method in class com.tangosol.util.MapSet
- 
Returns an iterator over the elements in this Set.
- iterator() - Method in class com.tangosol.util.NullImplementation.NullEnumerator
- 
Returns an Iterator instance with no values to enumerate.
- iterator() - Method in class com.tangosol.util.NullImplementation.NullLongArray
- iterator() - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Returns an Iterator over the elements contained in this Collection.
- iterator() - Method in class com.tangosol.util.OpenHashSet
- iterator() - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray.
- iterator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Returns an Iterator over the elements contained in this Collection.
- iterator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Returns an Iterator over the elements contained in this Collection.
- iterator() - Method in class com.tangosol.util.SafeHashMap.EntrySet
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.SafeHashMap.KeySet
- 
Obtain an iterator over the keys in the Map.
- iterator() - Method in class com.tangosol.util.SafeHashMap.ValuesCollection
- 
Obtain an iterator over the values in the Map.
- iterator() - Method in class com.tangosol.util.SafeSortedMap.EntrySet
- iterator() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- iterator() - Method in class com.tangosol.util.SafeSortedMap.Values
- iterator() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
- 
Returns an iterator over the elements contained in this collection.
- iterator() - Method in class com.tangosol.util.SegmentedHashMap.KeySet
- 
Obtain an iterator over the keys in the Map.
- iterator() - Method in class com.tangosol.util.SegmentedHashMap.ValuesCollection
- 
Obtain an iterator over the values in the Map.
- iterator() - Method in class com.tangosol.util.SimpleLongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray.
- iterator() - Method in class com.tangosol.util.SortedBag
- iterator() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- iterator() - Method in interface com.tangosol.util.stream.RemoteIntStream
- iterator() - Method in interface com.tangosol.util.stream.RemoteLongStream
- iterator() - Method in class com.tangosol.util.SubList
- iterator() - Method in class com.tangosol.util.SubSet
- iterator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- iterator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- iterator() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- iterator() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntrySet
- iterator(long) - Method in class com.tangosol.util.AbstractSafeLongArray
- iterator(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray, starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is greater than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- iterator(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- iterator(long) - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in order of increasing indices, starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is greater than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- iterator(long) - Method in interface com.tangosol.util.LongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in order of increasing indices, starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is greater than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- iterator(long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- iterator(long) - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray, starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is greater than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- iterator(long) - Method in class com.tangosol.util.SimpleLongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray, starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is greater than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- iterator(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- Iterator(int, boolean) - Constructor for class com.tangosol.util.SimpleLongArray.Iterator
- 
Construct an iterator that will iterate over the SimpleLongArray starting with the specified index.
- Iterator(AbstractSparseArray.Node, int, boolean) - Constructor for class com.tangosol.util.PrimitiveSparseArray.Iterator
- 
Instantiate a new PrimitiveIterator at the specified location and direction.
- iteratorActivated(Iterator) - Method in class com.tangosol.util.SafeHashMap
- 
Register the activation of an Iterator.
- iteratorActivated(Iterator) - Method in class com.tangosol.util.SegmentedHashMap
- 
Register the activation of an Iterator.
- iteratorDeactivated(Iterator) - Method in class com.tangosol.util.SafeHashMap
- 
Unregister the (formerly active) Iterator.
- IteratorEnumerator - Class in com.tangosol.util
- 
Provide a implementation of an enumerator based on data from an Iterator.
- IteratorEnumerator(Iterator) - Constructor for class com.tangosol.util.IteratorEnumerator
- 
Construct the enumerator based on an Iterator.
J
- J_BIG_DECIMAL - Static variable in interface com.tangosol.io.pof.PofConstants
- J_BIG_INTEGER - Static variable in interface com.tangosol.io.pof.PofConstants
- J_BINARY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_BOOLEAN - Static variable in interface com.tangosol.io.pof.PofConstants
- J_BOOLEAN_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_BYTE - Static variable in interface com.tangosol.io.pof.PofConstants
- J_BYTE_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_CHAR_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_CHARACTER - Static variable in interface com.tangosol.io.pof.PofConstants
- J_COLLECTION - Static variable in interface com.tangosol.io.pof.PofConstants
- J_DATE - Static variable in interface com.tangosol.io.pof.PofConstants
- J_DATETIME - Static variable in interface com.tangosol.io.pof.PofConstants
- J_DOUBLE - Static variable in interface com.tangosol.io.pof.PofConstants
- J_DOUBLE_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_FLOAT - Static variable in interface com.tangosol.io.pof.PofConstants
- J_FLOAT_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_INT_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_INTEGER - Static variable in interface com.tangosol.io.pof.PofConstants
- J_LOCAL_DATE - Static variable in interface com.tangosol.io.pof.PofConstants
- J_LOCAL_DATETIME - Static variable in interface com.tangosol.io.pof.PofConstants
- J_LOCAL_TIME - Static variable in interface com.tangosol.io.pof.PofConstants
- J_LONG - Static variable in interface com.tangosol.io.pof.PofConstants
- J_LONG_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_MAP - Static variable in interface com.tangosol.io.pof.PofConstants
- J_NULL - Static variable in interface com.tangosol.io.pof.PofConstants
- J_OBJECT_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_OFFSET_DATETIME - Static variable in interface com.tangosol.io.pof.PofConstants
- J_OFFSET_TIME - Static variable in interface com.tangosol.io.pof.PofConstants
- J_QUAD - Static variable in interface com.tangosol.io.pof.PofConstants
- J_RAW_DATE - Static variable in interface com.tangosol.io.pof.PofConstants
- J_RAW_DATETIME - Static variable in interface com.tangosol.io.pof.PofConstants
- J_RAW_DAY_TIME_INTERVAL - Static variable in interface com.tangosol.io.pof.PofConstants
- J_RAW_TIME - Static variable in interface com.tangosol.io.pof.PofConstants
- J_RAW_TIME_INTERVAL - Static variable in interface com.tangosol.io.pof.PofConstants
- J_RAW_YEAR_MONTH_INTERVAL - Static variable in interface com.tangosol.io.pof.PofConstants
- J_SHORT - Static variable in interface com.tangosol.io.pof.PofConstants
- J_SHORT_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_SPARSE_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- J_STRING - Static variable in interface com.tangosol.io.pof.PofConstants
- J_TIME - Static variable in interface com.tangosol.io.pof.PofConstants
- J_TIMESTAMP - Static variable in interface com.tangosol.io.pof.PofConstants
- J_USER_TYPE - Static variable in interface com.tangosol.io.pof.PofConstants
- J_ZONED_DATETIME - Static variable in interface com.tangosol.io.pof.PofConstants
- JAASIdentityAsserter - Class in com.tangosol.net.security
- 
JAAS-based implementation ofIdentityAsserter.
- JAASIdentityAsserter(String) - Constructor for class com.tangosol.net.security.JAASIdentityAsserter
- 
Construct a JAASIdentityAsserter instance.
- JacksonJsonMarshaller<T> - Class in com.tangosol.coherence.rest.io
- 
Jackson-based marshaller that marshals object to/from JSON.
- JacksonJsonMarshaller(Class<T>) - Constructor for class com.tangosol.coherence.rest.io.JacksonJsonMarshaller
- 
Construct JacksonJsonMarshaller instance.
- JacksonMapperProvider - Class in com.tangosol.coherence.rest.providers
- 
Provider responsible for converting Java object to/from JSON/XML.
- JacksonMapperProvider() - Constructor for class com.tangosol.coherence.rest.providers.JacksonMapperProvider
- JavaPofSerializer() - Constructor for class com.tangosol.io.pof.SafeConfigurablePofContext.JavaPofSerializer
- JaxbXmlMarshaller<T> - Class in com.tangosol.coherence.rest.io
- 
JAXB-based marshaller that marshals object to/from XML.
- JaxbXmlMarshaller(Class<T>) - Constructor for class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
- 
Construct an JaxbXmlMarshaller instance.
- JCACHE_CONFIG_BACK_SCHEME_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence Scheme that will manageCoherenceBasedCache.JCACHE_CONFIG_CACHE_NAMEback-scheme caches.
- JCACHE_CONFIG_BACK_SCHEME_SERVICE_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence Scheme that will manageCoherenceBasedCache.JCACHE_CONFIG_CACHE_NAMEback-scheme service.
- JCACHE_CONFIG_CACHE_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence NamedCache that will hold JCacheConfigurations.
- JCACHE_CONFIG_SCHEME_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence Scheme that will manageCoherenceBasedCache.JCACHE_CONFIG_CACHE_NAMEcaches.
- JCACHE_CONFIG_SERVICE_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence Service that will manageCoherenceBasedCache.JCACHE_CONFIG_CACHE_NAMEcaches.
- JCACHE_EXTEND_PROXY_SERVICE_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- JCACHE_EXTEND_SCHEME_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- JCACHE_EXTEND_SERVICE_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- JCACHE_LOCAL_CACHE_NAME_PATTERN - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence NamedCache onto which Local JCaches will be mapped.
- JCACHE_LOCAL_CACHE_NAME_PREFIX - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The Coherence NamedCache name prefix that JCache Local Caches will use.
- JCACHE_LOCAL_SCHEME_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence Scheme that will manage Local caches.
- JCACHE_LOCAL_SERVICE_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence Service that will manage Local caches.
- JCACHE_PARTITIONED_CACHE_NAME_PATTERN - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence NamedCache onto which Partitioned JCaches will be mapped.
- JCACHE_PARTITIONED_CACHE_NAME_PREFIX - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The Coherence NamedCache name prefix that JCache Partitioned Caches use internally.
- JCACHE_PARTITIONED_SCHEME_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence Scheme that will manage partitioned caches.
- JCACHE_PARTITIONED_SERVICE_NAME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence Service that will manage partitioned caches.
- JCACHE_REMOTE_SCHEME - Static variable in interface com.tangosol.coherence.jcache.CoherenceBasedCache
- 
The name of the Coherence remote scheme for JCache.
- JCACHE_SYNTHETHIC_LOADED - com.tangosol.coherence.jcache.localcache.LocalCacheValue.JCacheSyntheticKind
- JCACHE_SYNTHETIC_CLEAR - com.tangosol.coherence.jcache.localcache.LocalCacheValue.JCacheSyntheticKind
- JCACHE_SYNTHETIC_NONE - com.tangosol.coherence.jcache.localcache.LocalCacheValue.JCacheSyntheticKind
- JCACHE_SYNTHETIC_UPDATE - com.tangosol.coherence.jcache.localcache.LocalCacheValue.JCacheSyntheticKind
- JCacheContext - Class in com.tangosol.coherence.jcache.common
- 
Coherence JCache Context on each storage member node for JCache Cache.
- JCacheContext(JCacheIdentifier, CompleteConfiguration) - Constructor for class com.tangosol.coherence.jcache.common.JCacheContext
- 
Constructs a context for a JCache cache on each coherence storage node.
- JCacheEntryMetaInf - Class in com.tangosol.coherence.jcache.common
- 
Represents the JCache metadata for a key and value pair stored in aCache.
- JCacheEntryMetaInf() - Constructor for class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Constructs aJCacheEntryMetaInf.
- JCacheEntryMetaInf(long, ExpiryPolicy) - Constructor for class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Constructs anJCacheEntryMetaInf.
- JCacheEntryMetaInf(JCacheEntryMetaInf) - Constructor for class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Copy constructor
- JCacheExpiryEntryFilter() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter
- JCacheExtendNamespace - Class in com.tangosol.coherence.jcache
- 
ANamespaceHandlerto enable and enhance Coherence-based configurations to be used with the Coherence-based JCache Extend implementation
- JCacheExtendNamespace() - Constructor for class com.tangosol.coherence.jcache.JCacheExtendNamespace
- JCacheIdentifier - Class in com.tangosol.coherence.jcache.common
- 
An internal class to represent the unique identity of a JCache cache.
- JCacheIdentifier() - Constructor for class com.tangosol.coherence.jcache.common.JCacheIdentifier
- 
ConstructsJCacheIdentifier
- JCacheIdentifier(String) - Constructor for class com.tangosol.coherence.jcache.common.JCacheIdentifier
- 
ConstructsJCacheIdentifierfrom the internal encoded CoherenceBased cache map name.
- JCacheIdentifier(String, String) - Constructor for class com.tangosol.coherence.jcache.common.JCacheIdentifier
- 
ConstructsJCacheIdentifier
- JCacheLifecycleInterceptor() - Constructor for class com.tangosol.coherence.jcache.common.ContainerHelper.JCacheLifecycleInterceptor
- JCacheNamespace - Class in com.tangosol.coherence.jcache
- 
ANamespaceHandlerto enable and enhance Coherence-based configurations to be used with the Coherence-based JCache implementation
- JCacheNamespace() - Constructor for class com.tangosol.coherence.jcache.JCacheNamespace
- JCacheStatistics - Interface in com.tangosol.coherence.jcache.common
- 
Interface for JCache Statistics.
- JE_PROPERTY_PREFIX - Static variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Prefix for all Berkeley DB JE configuration settings.
- JmxmpServer - Class in com.tangosol.net.management
- 
An implementation of a CoherenceMBeanServerFinderthat creates aJMXConnectorServerserver that uses JMXMP as its transport rather than RMI.
- JmxmpServer() - Constructor for class com.tangosol.net.management.JmxmpServer
- 
Create aJmxmpServerthat binds to the any local address.
- JmxmpServer(String) - Constructor for class com.tangosol.net.management.JmxmpServer
- 
Create aJmxmpServerthat binds to the specified address.
- JMXPartitionStats() - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- join(Binary[]) - Static method in class com.tangosol.util.Binary
- 
Join an array of Binaries into a single Binary.
- join(InetAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- JOIN - Static variable in class com.tangosol.net.ClusterPermission
- 
Join action.
- joinGroup(SocketAddress, NetworkInterface) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- JOURNAL_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the JournalMBean.
- JsonCollectionWriter - Class in com.tangosol.coherence.rest.providers
- 
Provider responsible for converting Java collections to a JSON formatted stream.
- JsonCollectionWriter() - Constructor for class com.tangosol.coherence.rest.providers.JsonCollectionWriter
- 
Default constructor.
- JsonCollectionWriter(MarshallerRegistry) - Constructor for class com.tangosol.coherence.rest.providers.JsonCollectionWriter
- 
Construct a JsonCollectionWriter instance.
- JsonJacksonMarshaller<T> - Class in com.tangosol.coherence.rest.io
- 
Deprecated.As of 12.2.1.0.0, replaced byJacksonJsonMarshaller
- JsonJacksonMarshaller(Class<T>) - Constructor for class com.tangosol.coherence.rest.io.JsonJacksonMarshaller
- 
Deprecated.Construct JsonJacksonMarshaller instance.
- JsonMap - Class in com.tangosol.coherence.rest.util
- 
A simple wrapper aroundLiteMapthat preserves the order of elements and adds support for POF serialization without fidelity loss in order to support JSON pass-through.
- JsonMap() - Constructor for class com.tangosol.coherence.rest.util.JsonMap
- 
Construct a JsonMap.
- JsonMap(Map<String, ?>) - Constructor for class com.tangosol.coherence.rest.util.JsonMap
- 
Construct a JsonMap with the same mappings as the given map.
- JsonMap.Serializer - Class in com.tangosol.coherence.rest.util
- 
POF serializer for JsonMap.
K
- key - Variable in class com.tangosol.util.AbstractSparseArray.Node
- 
The key of the node.
- KEY - Static variable in annotation type com.tangosol.net.management.annotation.MetricsScope
- 
The MBean descriptor key.
- KEY - Static variable in class com.tangosol.util.extractor.AbstractExtractor
- 
Indicates that theAbstractExtractor.extractFromEntry(java.util.Map.Entry)operation should use the Entry's key.
- KEY_CLUSTER - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "cluster" key of an ObjectName for an extended global MBean.
- KEY_ERROR - Static variable in class com.oracle.coherence.grpc.ErrorsHelper
- 
The metadata key for an exception stack trace.
- KEY_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
ThisParameterizedBuilderhandles the key() function.
- KEY_ID - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "id" name part of ObjectName for an MBean.
- KEY_MEMBER - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "member" key of an ObjectName for an extended global MBean.
- KEY_NAME - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "name" part of ObjectName for MBeans.
- KEY_NODE_ID - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "nodeId" key of an ObjectName for a global MBean.
- KEY_RESPONSIBILITY - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "responsibility" key of an ObjectName for a global MBean.
- KEY_SERVICE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "service" key of an ObjectName for an extended global MBean.
- KEY_SUBTYPE_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "subtype" key of ObjectName for a Durable Subscriber MBean.
- KEY_TOPIC - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "topic" name part of ObjectName for the Paged Topic MBean.
- KEY_TOPIC_GROUP - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "group" name part of ObjectName for the Paged Topic Subscriber MBean.
- KeyAssociatedFilter<T> - Class in com.tangosol.util.filter
- 
Filter which limits the scope of another filter according to the key association information.
- KeyAssociatedFilter() - Constructor for class com.tangosol.util.filter.KeyAssociatedFilter
- 
Default constructor (required by ExternalizableLite interface).
- KeyAssociatedFilter(Filter<T>, Object) - Constructor for class com.tangosol.util.filter.KeyAssociatedFilter
- 
Construct a key associated filter.
- KeyAssociation<T> - Interface in com.tangosol.net.cache
- 
A KeyAssociation represents a key object that has a natural association with another key object.
- KeyAssociator - Interface in com.tangosol.net.partition
- 
A KeyAssociator provides key associations on behalf of a set of keys.
- KeyConverter - Interface in com.tangosol.coherence.rest
- 
An interface that must be implemented by key converters.
- KeyConverter(CacheRequestHolder<MapListenerRequest, Void>) - Constructor for class com.oracle.coherence.grpc.proxy.MapListenerProxy.KeyConverter
- 
Constructs a newKeyConverter.
- KeyConverterAdapter - Class in com.tangosol.coherence.rest.io
- 
Marshaller that marshalls objects using a cache's key converter.
- KeyConverterAdapter(KeyConverter) - Constructor for class com.tangosol.coherence.rest.io.KeyConverterAdapter
- 
Construct KeyConverterAdapter instance.
- KeyExtractor<T,E> - Class in com.tangosol.util.extractor
- 
The KeyExtractor is a special purpose ValueExtractor implementation that serves as an indicator that a query should be run against the key objects rather than the values.
- KeyExtractor() - Constructor for class com.tangosol.util.extractor.KeyExtractor
- 
Default constructor (necessary for the ExternalizableLite and PortableObject interfaces).
- KeyExtractor(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.extractor.KeyExtractor
- 
Construct a KeyExtractor based on a specified ValueExtractor.
- KeyExtractor(String) - Constructor for class com.tangosol.util.extractor.KeyExtractor
- 
Construct a KeyExtractor for a specified method name.
- KeyFilter<T> - Class in com.tangosol.util.filter
- 
EntryFilter which checks whether an entry key belongs to a set.
- KeyFilter(Set<T>) - Constructor for class com.tangosol.util.filter.KeyFilter
- 
Construct a key filter.
- KeyIterator() - Constructor for class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
- 
Default constructor.
- KeyIterator(Iterator<K>) - Constructor for class com.tangosol.util.AbstractKeySetBasedMap.KeyIterator
- 
Construct a KeyIterator.
- KeyMask() - Constructor for class com.tangosol.net.cache.LocalCache.KeyMask
- KeyPartitioningStrategy - Interface in com.tangosol.net.partition
- 
A KeyPartitioningStrategy is a pluggable strategy for assigning keys to specific partitions.
- KeyPartitioningStrategy.PartitionAwareKey - Interface in com.tangosol.net.partition
- 
PartitionAwareKey is a well-known interface that should be respected byKeyPartitioningStrategyimplementations.
- keys() - Method in class com.tangosol.io.AbstractBinaryStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Iterate all keys in the underlying store.
- keys() - Method in interface com.tangosol.io.BinaryStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.io.nio.BinaryMapStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.net.cache.CacheLoaderCacheStore.Iterable
- 
Iterate all keys in the underlying store.
- keys() - Method in interface com.tangosol.net.cache.IterableCacheLoader
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.net.cache.MapCacheStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Iterate all keys in the underlying store.
- keys() - Method in class com.tangosol.net.MapViewBuilder
- 
The resultingviewwill only map keys.
- keys() - Method in class com.tangosol.net.ViewBuilder
- 
The resultingviewwill only cache keys.
- keys() - Method in interface com.tangosol.util.LongArray
- 
Return an array of the indices into this LongArray.
- keys() - Method in class com.tangosol.util.StringTable
- 
Enumerate the table's strings.
- keys() - Method in class com.tangosol.util.Tree
- 
Create an in-order enumerator for the tree's keys.
- keys(String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Returns a set of keys that satisfy the criteria expressed by the query.
- keys(UriInfo) - Method in class com.tangosol.coherence.rest.NamedQueryResource
- 
Return the keys of cache entries that satisfy the named query criteria.
- keysEquals(StringTable) - Method in class com.tangosol.util.StringTable
- 
Test for equality of the keys in two string tables.
- keySet() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- keySet() - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns a Set view of the keys contained in this map.
- keySet() - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return a set view of all the keys contained in this map.
- keySet() - Method in class com.tangosol.net.cache.CachingMap
- keySet() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Returns an set view of the keys contained in this map.
- keySet() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns a set view of the keys contained in this map.
- keySet() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- keySet() - Method in class com.tangosol.util.CopyOnWriteMap
- 
Returns a Set view of the keys contained in the underlying map.
- keySet() - Method in class com.tangosol.util.NullImplementation.NullMap
- keySet() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns a set view of the keys contained in this map.
- keySet() - Method in class com.tangosol.util.SafeHashMap
- 
Returns a Set view of the keys contained in this map.
- keySet() - Method in class com.tangosol.util.SafeSortedMap
- keySet() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- keySet() - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns a Set view of the keys contained in this map.
- keySet() - Method in class com.tangosol.util.SetMap
- keySet() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- keySet() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- keySet(CacheRequestHolder<KeySetRequest, Void>, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute the key-basedKeySetRequestrequest passing the results to the providedStreamObserver.
- keySet(KeySetRequest, StreamObserver<BytesValue>) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Stream a set of cache keys to aStreamObserver.
- keySet(KeySetRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- keySet(KeySetRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- keySet(NamedCache) - Method in interface com.tangosol.coherence.rest.query.Query
- 
Return the keys that satisfy this query.
- keySet(Filter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- keySet(Filter) - Method in class com.tangosol.net.cache.NearCache
- 
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.
- keySet(Filter) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.
- keySet(Filter) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.
- keySet(Filter) - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
- 
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.
- keySet(Filter) - Method in interface com.tangosol.util.QueryMap
- 
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.
- keySet(Filter<?>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.
- keySet(Filter<?>, Consumer<? super K>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream the keys for the entries that satisfy the specified filter to the provided callback.
- keySet(InvocableMap<K, V>) - Static method in interface com.tangosol.util.stream.RemoteStream
- 
Create aRemoteStreamof specified map's keys.
- keySet(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create anKeySetRequest.
- keySet(Consumer<? super K>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream the keys of all the entries contained in this map to the provided callback.
- KeySet() - Constructor for class com.tangosol.io.nio.BinaryMap.KeySet
- KeySet() - Constructor for class com.tangosol.net.cache.OldCache.KeySet
- 
Deprecated.
- KeySet() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- KeySet() - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap.KeySet
- KeySet() - Constructor for class com.tangosol.util.AbstractKeyBasedMap.KeySet
- KeySet() - Constructor for class com.tangosol.util.AbstractKeySetBasedMap.KeySet
- KeySet() - Constructor for class com.tangosol.util.CopyOnWriteMap.KeySet
- KeySet() - Constructor for class com.tangosol.util.OpenHashMap.KeySet
- KeySet() - Constructor for class com.tangosol.util.SafeHashMap.KeySet
- KeySet() - Constructor for class com.tangosol.util.SegmentedHashMap.KeySet
- KEYSTORE_TYPE - Static variable in class com.tangosol.net.security.DefaultController
- 
KeyStore type used by this implementation.
- KeyStoreLoader - Interface in com.tangosol.net.ssl
- 
A class that can create aKeyStore.
- KeystoreProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse and produce a DefaultKeystoreDependencies based on a key-store configuration element.
- KeystoreProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.KeystoreProcessor
- KeyValueArrayMap - Class in com.tangosol.util
- 
KeyValueArrayMap is a Map implementation backed by an array of keys, and an array of the associated values.
- KeyValueArrayMap(Object[], int, Object[], int, int) - Constructor for class com.tangosol.util.KeyValueArrayMap
- 
Construct a KeyValueArrayMap backed by ranges of the specified key and value arrays.
- KeyValueArrayMap(Object[], Object[]) - Constructor for class com.tangosol.util.KeyValueArrayMap
- 
Construct a KeyValueArrayMap backed by the specified key and value arrays.
- KeywordOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
KeywordOPToken acts like a PunctuationOPToken when used in a led role and a Identifier when used as a nud.
- KeywordOPToken(String) - Constructor for class com.tangosol.coherence.dsltools.precedence.KeywordOPToken
- 
Construct a new KeywordOPToken with the given parameters.
L
- LAMBDA_SERIALIZATION - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Option: Use eitherstaticordynamiclambda serialization.
- last() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- last() - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns the last element currently in this sorted set.
- last() - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedSet
- 
Returns the last (highest) element currently in this sorted set.
- last() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- last() - Method in class com.tangosol.util.SortedBag
- 
Returns the last (highest) element currently in this bag.
- last() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
- LAST_ENTRY - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
A constant that suggests to a PersistentStore implementation to load the last entry.
- lastEntry() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- lastIndexOf(byte) - Method in class com.tangosol.util.Binary
- 
Returns the offset within this Binary object of the last occurrence of the specified byte.
- lastIndexOf(byte, int) - Method in class com.tangosol.util.Binary
- 
Returns the offset within this Binary object of the last occurrence of the specified byte, starting the search at the specified offset and searching backwards.
- lastIndexOf(Binary) - Method in class com.tangosol.util.Binary
- 
Returns the offset within this Binary object of the last occurrence of the specified Binary.
- lastIndexOf(Binary, int) - Method in class com.tangosol.util.Binary
- 
Returns the offset within this Binary object of the last occurrence of the specified Binary, starting the search at the specified offset.
- lastIndexOf(Object) - Method in class com.tangosol.util.CircularArrayList
- 
Returns the index of the last occurrence of the specified object in this CycicArrayList.
- lastIndexOf(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- lastIndexOf(Object) - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns the index in this List of the last occurrence of the specified element, or -1 if this List does not contain this element.
- lastIndexOf(Object) - Method in class com.tangosol.util.ImmutableMultiList
- 
Returns the index in this List of the last occurrence of the specified element, or -1 if this List does not contain this element.
- lastIndexOf(Object) - Method in class com.tangosol.util.InflatableList
- lastIndexOf(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Returns the index in this list of the last occurrence of the specified element, or -1 if this list does not contain this element.
- lastIndexOf(Object) - Method in class com.tangosol.util.SafeLinkedList
- 
Returns the index in this List of the last occurrence of the specified element, or -1 if this List does not contain this element.
- lastIndexOf(Object) - Method in class com.tangosol.util.SubList
- lastIndexOf(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- lastIndexOf(Object, long) - Method in class com.tangosol.util.SimpleLongArray
- 
Return the index in this LongArray of the last occurrence of the specified element such that (index <= lIndex), or NOT_FOUND if this LongArray does not contain the specified element.
- lastIndexOf(T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- lastIndexOf(T, long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- lastIndexOf(V) - Method in class com.tangosol.util.AbstractLongArray
- 
Return the index in this LongArray of the last occurrence of the specified element, or NOT_FOUND if this LongArray does not contain the specified element.
- lastIndexOf(V) - Method in class com.tangosol.util.AbstractSafeLongArray
- lastIndexOf(V) - Method in interface com.tangosol.util.LongArray
- 
Return the index in this LongArray of the last occurrence of the specified element, or NOT_FOUND if this LongArray does not contain the specified element.
- lastIndexOf(V) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- lastIndexOf(V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- lastIndexOf(V, long) - Method in class com.tangosol.util.AbstractLongArray
- 
Return the index in this LongArray of the last occurrence of the specified element such that (index less than or equal to lIndex), or NOT_FOUND if this LongArray does not contain the specified element.
- lastIndexOf(V, long) - Method in class com.tangosol.util.AbstractSafeLongArray
- lastIndexOf(V, long) - Method in interface com.tangosol.util.LongArray
- 
Return the index in this LongArray of the last occurrence of the specified element such that (index less then or equal to lIndex), or NOT_FOUND if this LongArray does not contain the specified element.
- lastIndexOf(V, long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- lastIndexOf(V, long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- lastKey() - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- lastKey() - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedMap
- 
Returns the last (highest) key currently in this sorted map.
- lastKey() - Method in class com.tangosol.util.SafeSortedMap
- lastKey() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- lastKey() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- Latches - Class in com.oracle.coherence.concurrent
- 
Factory methods for various distributed countdown latch implementations.
- Latches() - Constructor for class com.oracle.coherence.concurrent.Latches
- latchesMap() - Static method in class com.oracle.coherence.concurrent.Latches
- 
Return CoherenceNamedMapcontaining the countdown latches state.
- LeafBaseToken - Class in com.tangosol.coherence.dsltools.base
- 
LeafBaseToken is the abstract base class for all tokes processed by the low level BaseTokenScanner that are considered leaves.
- LeafBaseToken() - Constructor for class com.tangosol.coherence.dsltools.base.LeafBaseToken
- LeaseGranularityProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor Coherence <lease-granularity> configuration
- LeaseGranularityProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.LeaseGranularityProcessor
- leave(InetAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- leaveGroup(SocketAddress, NetworkInterface) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- led(OPParser, Term) - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder.TraceCommandOPToken
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.BetweenOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.ContainsOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.IdentifierOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.InfixOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.InfixRightOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.KeywordOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.LikeOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.LiteralOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.NotOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.ParenOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.PathOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.termlanguage.ColonToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- led(OPParser, Term) - Method in class com.tangosol.coherence.dsltools.termlanguage.CurlyToken
- 
Process this token and possibly the given leftNodein the context of a parser with the left denotation.
- left - Variable in class com.tangosol.util.AbstractSparseArray.Node
- 
The left child of this node.
- LEFT - Static variable in class com.tangosol.util.AbstractSparseArray.Crawler
- leftBindingPower() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Obtain the power that this token will bind to the left.
- length() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Answer whether the length of the receivers children
- length() - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Answer whether the length of the receivers children
- length() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Determine the length of the buffer.
- length() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Determine the length of the data that is in the buffer.
- length() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Determine the length of the data that is in the buffer.
- length() - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Determine the length of the data that is in the buffer.
- length() - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Determine the length of the buffer.
- length() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Determine the length of the data that is in the buffer.
- length() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Determine the length of the block.
- length() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Determine the length of the buffer.
- length() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Determine the length of the data that is in the buffer.
- length() - Method in interface com.tangosol.io.ReadBuffer
- 
Determine the length of the buffer.
- length() - Method in interface com.tangosol.io.WriteBuffer
- 
Determine the length of the data that is in the buffer.
- length() - Method in class com.tangosol.util.AbstractByteSequence.AggregateByteSequence
- 
Determine the number of bytes of data represented by this ByteSequence.
- length() - Method in class com.tangosol.util.AbstractByteSequence.PartialByteSequence
- 
Determine the number of bytes of data represented by this ByteSequence.
- length() - Method in interface com.tangosol.util.ByteSequence
- 
Determine the number of bytes of data represented by this ByteSequence.
- less(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted value is less than the specified value.
- lessEqual(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests if the extracted value is less than or equal to the specified value.
- LessEqualsFilter<T,E extends Comparable<? super E>> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value for "Less or Equals" condition.
- LessEqualsFilter() - Constructor for class com.tangosol.util.filter.LessEqualsFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- LessEqualsFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.LessEqualsFilter
- 
Construct a LessEqualsFilter for testing "Less or Equals" condition.
- LessEqualsFilter(String, E) - Constructor for class com.tangosol.util.filter.LessEqualsFilter
- 
Construct a LessEqualsFilter for testing "Less or Equals" condition.
- LessEqualsOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the logical less than or equal to operator.
- LessEqualsOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.LessEqualsOperator
- 
Construct a LessEqualsOperator.
- LessFilter<T,E extends Comparable<? super E>> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value for "Less" condition.
- LessFilter() - Constructor for class com.tangosol.util.filter.LessFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- LessFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.LessFilter
- 
Construct a LessFilter for testing "Less" condition.
- LessFilter(String, E) - Constructor for class com.tangosol.util.filter.LessFilter
- 
Construct a LessFilter for testing "Less" condition.
- LessOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the logical less than or equal to operator.
- LessOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.LessOperator
- 
Construct a LessOperator.
- LICENSE_MODE_DEVELOPMENT - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Development license.
- LICENSE_MODE_EVALUATION - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Evaluation license.
- LICENSE_MODE_PRODUCTION - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Production license.
- LifecycleAwareEvent<S extends Enum<S>> - Interface in com.tangosol.util.fsm
- 
ALifecycleAwareEventis a specializedEventthat receives callbacks during the processing of theEventby aFiniteStateMachine.
- LifecycleContext() - Constructor for class com.tangosol.net.DefaultCacheServer.LifecycleContext
- LifecycleEvent - Interface in com.tangosol.net.events.application
- 
A LifecycleEvent encapsulates a lifecycle action that has occurred on aConfigurableCacheFactory.
- LifecycleEvent.Type - Enum in com.tangosol.net.events.application
- 
TheLifecycleEventtypes.
- LifecycleEventHandler(EventObserverSupport.EventObserver<LifecycleEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.LifecycleEventHandler
- LifecycleEvents - Annotation Type in com.tangosol.net.events.annotation
- 
LifecycleEventInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveLifecycleEvents.
- like(ValueExtractor<T, E>, String) - Static method in class com.tangosol.util.Filters
- 
Return a LikeFilter for pattern match.
- like(ValueExtractor<T, E>, String, boolean) - Static method in class com.tangosol.util.Filters
- 
Return a LikeFilter for pattern match.
- like(ValueExtractor<T, E>, String, char) - Static method in class com.tangosol.util.Filters
- 
Return a LikeFilter for pattern match.
- like(ValueExtractor<T, E>, String, char, boolean) - Static method in class com.tangosol.util.Filters
- 
Return a LikeFilter for pattern match.
- LikeFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value for pattern match.
- LikeFilter() - Constructor for class com.tangosol.util.filter.LikeFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- LikeFilter(ValueExtractor<? super T, ? extends E>, String) - Constructor for class com.tangosol.util.filter.LikeFilter
- 
Construct a LikeFilter for pattern match.
- LikeFilter(ValueExtractor<? super T, ? extends E>, String, char, boolean) - Constructor for class com.tangosol.util.filter.LikeFilter
- 
Construct a LikeFilter for pattern match.
- LikeFilter(String, String) - Constructor for class com.tangosol.util.filter.LikeFilter
- 
Construct a LikeFilter for pattern match.
- LikeFilter(String, String, boolean) - Constructor for class com.tangosol.util.filter.LikeFilter
- 
Construct a LikeFilter for pattern match.
- LikeFilter(String, String, char, boolean) - Constructor for class com.tangosol.util.filter.LikeFilter
- 
Construct a LikeFilter for pattern match.
- LikeOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the "like" operator.
- LikeOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.LikeOperator
- 
Construct a LikeOperator.
- LikeOperator(String, boolean, String...) - Constructor for class com.tangosol.coherence.dslquery.operator.LikeOperator
- 
Construct a LikeOperator.
- LikeOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
LikeOPToken is used to parse a SQL like statement.
- LikeOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.LikeOPToken
- 
Construct a new LikeOPToken with the given parameters.
- LikeOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.LikeOPToken
- 
Construct a new LikeOPToken with the given parameters.
- limit(long) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the elements of this stream, truncated to be no longer thanmaxSizein length.
- limit(long) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the elements of this stream, truncated to be no longer thanmaxSizein length.
- limit(long) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the elements of this stream, truncated to be no longer thanmaxSizein length.
- limit(long) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, truncated to be no longer thanmaxSizein length.
- LimitFilter<T> - Class in com.tangosol.util.filter
- 
Filter which truncates the results of another filter.
- LimitFilter() - Constructor for class com.tangosol.util.filter.LimitFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- LimitFilter(Filter<T>, int) - Constructor for class com.tangosol.util.filter.LimitFilter
- 
Construct a limit filter.
- link() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Link this block (either an Entry or free block) into the appropriate data structures (either the hash bucket or the free list.)
- linkAfter(SafeLinkedList.Node) - Method in class com.tangosol.util.SafeLinkedList.Node
- 
Add this Node to the List following the specified Node.
- linkBefore(SafeLinkedList.Node) - Method in class com.tangosol.util.SafeLinkedList.Node
- 
Add this Node to the List preceding the specified Node.
- list() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the identifiers of the PersistentStores known to this manager.
- list() - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- list() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Return the identifiers of the PersistentStores known to this manager.
- list() - Method in interface com.tangosol.persistence.SnapshotArchiver
- 
Return the identifiers of the archived snapshots known to this archiver.
- list() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Return the identifiers of the PersistentStores known to this manager.
- LIST_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The AST node name for a List of Values Node.
- listArchivedSnapshots() - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Return a list of archived snapshots that the configured archiver knows about.
- listArchivedSnapshotStores(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Return a list of stores for a given archived snapshot.
- ListArchiverStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder.ListArchiverStatement
- 
Create a ListArchiverStatement that will list the archiver for a service.
- ListArchiverStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aListArchiverStatementBuilder.ListArchiverStatement.
- ListArchiverStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder
- ListArchiverStatementBuilder.ListArchiverStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "LIST ARCHIVER" command.
- ListBasedAddressProviderBuilder - Class in com.tangosol.coherence.config.builder
- 
This class builds an AddressProviderBuilder from a list of address and port.
- ListBasedAddressProviderBuilder() - Constructor for class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
- 
ConstructsListBasedAddressProviderBuilder
- LISTEN_ALL - Static variable in class com.tangosol.net.cache.CachingMap
- 
Invalidation strategy that instructs the CachingMap to listen to all back map events; this strategy is preferred when updates to the back map are frequent and with high probability come from the outside of this CachingMap; for example multiple CachingMap instances using the same back map with a large degree of key set overlap between front maps.
- LISTEN_AUTO - Static variable in class com.tangosol.net.cache.CachingMap
- 
Invalidation strategy that instructs the CachingMap implementation to switch automatically between LISTEN_PRESENT and LISTEN_ALL strategies based on the cache statistics.
- LISTEN_LOGICAL - Static variable in class com.tangosol.net.cache.CachingMap
- 
Invalidation strategy that instructs the CachingMap to listen to all back map events that are not synthetic deletes.
- LISTEN_NONE - Static variable in class com.tangosol.net.cache.CachingMap
- 
No invalidation strategy.
- LISTEN_PRESENT - Static variable in class com.tangosol.net.cache.CachingMap
- 
Invalidation strategy that instructs the CachingMap to listen to the back map events related only to the items currently present in the front map; this strategy serves best when the changes to the back map come mostly from the CachingMap itself.
- listener() - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Create newAbstractRepositoryBase.Listener.Builderinstance.
- listener(MapListener<? super K, ? super V>) - Method in class com.tangosol.net.MapViewBuilder
- 
TheMapListenerthat will receive all events, including those that result from the initial population of theview.
- listener(MapListener<? super K, ? super V>) - Method in class com.tangosol.net.ViewBuilder
- 
TheMapListenerthat will receive all events, including those that result from the initial population of theview.
- Listener() - Constructor for class com.oracle.coherence.grpc.proxy.GrpcServerController.Listener
- listeners() - Method in class com.tangosol.util.Listeners
- 
Get the array of event listeners.
- Listeners - Class in com.tangosol.util
- 
Provide a simple, efficient, and thread-safe implementation of a list of event listeners.
- Listeners() - Constructor for class com.tangosol.util.Listeners
- 
Default constructor.
- listInternal() - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Internal implementation to return the identifiers of the archived snapshots known to this archiver.
- listInternal() - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
- listIterator() - Method in class com.tangosol.util.ConverterCollections.ConverterList
- listIterator() - Method in class com.tangosol.util.ImmutableMultiList
- listIterator() - Method in class com.tangosol.util.InflatableList
- listIterator() - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Returns a list iterator of the elements in this list (in proper sequence).
- listIterator() - Method in class com.tangosol.util.SubList
- listIterator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- listIterator(int) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- listIterator(int) - Method in class com.tangosol.util.ImmutableMultiList
- listIterator(int) - Method in class com.tangosol.util.InflatableList
- listIterator(int) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Returns a list iterator of the elements in this list (in proper sequence), starting at the specified position in this list.
- listIterator(int) - Method in class com.tangosol.util.SubList
- listIterator(int) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- ListMap<K,V> - Class in com.tangosol.util
- 
As of Coherence 3.2, the ListMap simply extends Java's own LinkedHashMap, which became available in JDK 1.4.
- ListMap() - Constructor for class com.tangosol.util.ListMap
- 
Construct a ListMap.
- ListMap(Map<? extends K, ? extends V>) - Constructor for class com.tangosol.util.ListMap
- 
Construct a ListMap with the same mappings as the given map.
- listOpen() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return the identifiers of PersistentStores that are currently open.
- listOpen() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Return the identifiers of PersistentStores that are currently open.
- listOpen() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Return the identifiers of PersistentStores that are currently open.
- ListOpToken - Class in com.tangosol.coherence.dsltools.precedence
- 
ListOPToken is used to process expressions between bracketing characters such as are between "[" and "]" which should result in a list (e.g
- ListOpToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.ListOpToken
- 
Construct a new InfixOPToken with the given parameters.
- ListOpToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.ListOpToken
- 
Construct a new InfixOPToken with the given parameters.
- ListServicesStatement(boolean) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder.ListServicesStatement
- 
Create a ListServicesStatement that will list services and their persistence mode.
- ListServicesStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aListServicesStatementBuilder.ListServicesStatement.
- ListServicesStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder
- ListServicesStatementBuilder.ListServicesStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "LIST SERVICES" command.
- listSnapshots() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return the identifiers of the snapshots known to this environment.
- listSnapshots() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Return the identifiers of the snapshots known to this environment.
- listSnapshots() - Method in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
- 
Return the identifiers of the snapshots known to this environment.
- ListSnapshotsStatement(String, boolean) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder.ListSnapshotsStatement
- 
Create a ListSnapshotsStatement that will list snapshots for services.
- ListSnapshotsStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aListSnapshotsStatementBuilder.ListSnapshotsStatement.
- ListSnapshotsStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder
- ListSnapshotsStatementBuilder.ListSnapshotsStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "LIST SNAPSHOTS" command.
- listStores() - Method in class com.tangosol.persistence.Snapshot
- 
Return the identifiers of the PersistentStores that comprise the snapshot.
- listStoresInternal(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
List the stores for a given snapshot.
- listStoresInternal(String) - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
- ListView() - Constructor for class com.tangosol.util.ImmutableArrayList.ListView
- 
Create a ListView over this ImmutableArrayList.
- ListView() - Constructor for class com.tangosol.util.ImmutableMultiList.ListView
- 
Create a ListView over this ImmutableMultiList.
- Lite - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation that can be applied toMapListenerCDI observers to register them as lite listeners.
- LITE - Static variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Constant to indicate that the listener is registered for "lite" events.
- Lite.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theLiteannotation.
- LiteMap<K,V> - Class in com.tangosol.util
- 
An implementation of java.util.Map that is optimal (in terms of both size and speed) for very small sets of data but still works excellently with large sets of data.
- LiteMap() - Constructor for class com.tangosol.util.LiteMap
- 
Construct a LiteMap.
- LiteMap(Map<? extends K, ? extends V>) - Constructor for class com.tangosol.util.LiteMap
- 
Construct a LiteMap with the same mappings as the given map.
- Literal() - Constructor for class com.oracle.coherence.cdi.CacheAdd.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.CacheGet.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.CachePut.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.CacheRemove.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Activated.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Activating.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Arrived.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Assigned.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Committed.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Committing.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.CommittingLocal.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.CommittingRemote.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Connecting.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Created.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Deleted.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Departed.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Departing.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Destroyed.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Disconnected.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Disposing.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Error.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Executed.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Executing.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Inserted.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Inserting.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Lite.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Lost.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Recovered.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Removed.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Removing.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Replicating.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Rollback.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Started.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Starting.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Stopped.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Stopping.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Synced.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Synchronous.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Syncing.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Truncated.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Updated.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.events.Updating.Literal
- Literal() - Constructor for class com.oracle.coherence.cdi.Remote.Literal
- Literal(String, boolean) - Constructor for class com.oracle.coherence.cdi.Name.Literal
- 
ConstructName.Literalinstance.
- LITERAL_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The AST node name for a Literal Node.
- LiteralBaseToken - Class in com.tangosol.coherence.dsltools.base
- 
LiteralBaseToken is the BaseToken that represents literals such as String, Integer, Long, Float, and Double.
- LiteralBaseToken(int, String) - Constructor for class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Construct a new LiteralBaseToken with the given parameters.
- LiteralExpression<T> - Class in com.tangosol.config.expression
- 
ALiteralExpressionis a literal (aka: constant)Expression.
- LiteralExpression() - Constructor for class com.tangosol.config.expression.LiteralExpression
- 
Default constructor needed for serialization.
- LiteralExpression(T) - Constructor for class com.tangosol.config.expression.LiteralExpression
- 
Construct aLiteralExpression.
- literalFloat() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
A floating point literal has been detected so create.
- LiteralOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
LiteralOpToken is used to implement literals.
- LiteralOPToken(LiteralBaseToken) - Constructor for class com.tangosol.coherence.dsltools.precedence.LiteralOPToken
- 
Construct a new LiteralOPToken with the given parameters.
- LiteralOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.LiteralOPToken
- 
Construct a new LiteralOPToken with the given parameters.
- LiteralOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.LiteralOPToken
- 
Construct a new LiteralOPToken with the given parameters.
- LiteSet<E> - Class in com.tangosol.util
- 
An implementation of java.util.Set that is optimal (in terms of both size and speed) for very small sets of data but still works excellently with large sets of data.
- LiteSet() - Constructor for class com.tangosol.util.LiteSet
- 
Construct a LiteSet
- LiteSet(Collection<? extends E>) - Constructor for class com.tangosol.util.LiteSet
- 
Construct a LiteSet containing the elements of the passed Collection.
- load() - Method in class com.tangosol.net.ssl.AbstractCertificateLoader
- load() - Method in interface com.tangosol.net.ssl.CertificateLoader
- 
Load aCertificate.
- load(long, ReadBuffer) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(long, R) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(long, R) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- load(PasswordProvider) - Method in class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- load(PasswordProvider) - Method in interface com.tangosol.net.ssl.PrivateKeyLoader
- 
Load a namedPrivateKey.
- load(XmlElement) - Static method in class com.tangosol.net.SocketOptions
- 
Deprecated.
- load(Binary) - Method in class com.tangosol.io.AbstractBinaryStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Binary) - Method in class com.tangosol.io.AsyncBinaryStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Binary) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Binary) - Method in interface com.tangosol.io.BinaryStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Binary) - Method in class com.tangosol.io.nio.BinaryMapStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(BinaryEntry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
- load(BinaryEntry<K, V>) - Method in interface com.tangosol.net.cache.BinaryEntryStore
- 
Load the value from the underlying store and update the specified entry.
- load(BinaryEntry<K, V>, StoreObserver<K, V>) - Method in interface com.tangosol.net.cache.NonBlockingEntryStore
- 
Load the value from the underlying store, update the provided entry and call theonNextmethod of the providedStoreObserverobject, oronErrorif the store operation failed.
- load(Object) - Method in class com.tangosol.net.cache.LocalCache
- 
Indicates to the cache that the specified key should be loaded into the cache, if it is not already in the cache.
- load(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheLoaderCacheStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Return the entry associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(Object) - Method in class com.tangosol.util.NullImplementation.NullCacheStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(String, PasswordProvider) - Method in class com.tangosol.net.ssl.AbstractKeyStoreLoader
- load(String, PasswordProvider) - Method in class com.tangosol.net.ssl.EmptyKeyStoreLoader
- load(String, PasswordProvider) - Method in interface com.tangosol.net.ssl.KeyStoreLoader
- 
Load a namedKeyStore.
- load(String, PasswordProvider, Certificate[]) - Method in interface com.tangosol.net.ssl.KeyStoreLoader
- load(String, PasswordProvider, PrivateKey, PasswordProvider, Certificate[]) - Method in interface com.tangosol.net.ssl.KeyStoreLoader
- load(K) - Method in class com.tangosol.net.cache.AbstractCacheLoader
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(K) - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(K) - Method in interface com.tangosol.net.cache.CacheLoader
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(K) - Method in class com.tangosol.net.cache.CacheLoaderCacheStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- load(K) - Method in class com.tangosol.net.cache.MapCacheStore
- 
Return the value associated with the specified key, or null if the key does not have an associated value in the underlying store.
- loadAll() - Method in class com.tangosol.net.cache.LocalCache
- 
Indicates to the cache that it should load data from its loader to fill the cache; this is sometimes referred to as "pre-loading" or "warming" a cache.
- loadAll(Collection) - Method in class com.tangosol.net.cache.LocalCache
- 
Indicates to the cache that the specified keys should be loaded into the cache, if they are not already in the cache.
- loadAll(Collection) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheLoaderCacheStore
- 
Return the values associated with each the specified keys in the passed collection.
- loadAll(Collection) - Method in class com.tangosol.util.NullImplementation.NullCacheStore
- 
Return the values associated with each the specified keys in the passed collection.
- loadAll(Collection<? extends K>) - Method in interface com.tangosol.net.cache.CacheLoader
- 
Return the values associated with each the specified keys in the passed collection.
- loadAll(Collection<? extends K>) - Method in class com.tangosol.net.cache.CacheLoaderCacheStore
- 
Return the values associated with each the specified keys in the passed collection.
- loadAll(Set) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
- loadAll(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Return the entry set associated with the specified keys in the passed collection.
- loadAll(Set<? extends BinaryEntry<K, V>>) - Method in interface com.tangosol.net.cache.BinaryEntryStore
- 
Load the values from the underlying store and update the specified entries.
- loadAll(Set<? extends BinaryEntry<K, V>>, StoreObserver<K, V>) - Method in interface com.tangosol.net.cache.NonBlockingEntryStore
- 
Load the values from the underlying store and update the specified entries by calling the onNext method of the providedStoreObserverobject, or onError if the store operation failed.
- loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- loadAll(Set<? extends K>, boolean, CompletionListener) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- loadAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Load the entries associated with each of the specified binary keys from the underlying store.
- loadAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Load the entries associated with each of the specified binary keys from the underlying store.
- loadAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Load the entries associated with each of the specified binary keys from the underlying store.
- loadAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Load the entries associated with each of the specified binary keys from the underlying store.
- LoadBalancer - Class in com.tangosol.net
- 
A non-sticky HTTP load-balancer.
- LoadBalancer(LoadBalancer.AddressPort, LoadBalancer.AddressPort[], Properties) - Constructor for class com.tangosol.net.LoadBalancer
- 
Instantiate a LoadBalancer object that will listen on a host address/port and redirect requests to destination addresses/ports.
- LoadBalancer.AddressPort - Class in com.tangosol.net
- 
An AddressPort is an immutable combination of an IP address and a port number.
- LoadBalancer.Queue - Class in com.tangosol.net
- 
A Queue is used to effeciently queue up items for daemon threads to work on.
- LoadBalancer.RequestHandler - Class in com.tangosol.net
- 
A RequestHandler is a daemon thread that processes a request from a queue.
- LoadBalancer.ResponseHandler - Class in com.tangosol.net
- 
A ResponseHandler is a daemon thread that processes an outgoing response from a destination server.
- LoadBalancer.SocketHandler - Class in com.tangosol.net
- 
A SocketHandler is an abstract daemon thread.
- loadClass(String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Find the specified class, return a Java Class object for it.
- loadClass(String, ClassLoader, ClassLoader) - Static method in class com.oracle.coherence.common.base.Classes
- 
Attempt to load the specified class using sequentionally all of the specified loaders, the ContextClassLoader and the current class loader.
- loadClass(String, ClassLoader, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Attempt to load the specified class using sequentionally all of the specified loaders, the ContextClassLoader and the current class loader.
- LoadComparator(boolean) - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.LoadComparator
- 
Construct a LoadComparator.
- loadConfig(String) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Load the configuration from a file or resource.
- loadConfig(String, ClassLoader) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Load the configuration from a file or resource.
- loadConfigAsResource(String, ClassLoader) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Load the configuration as a resource.
- loadConfigFromFile(File) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Load the configuration from a file or directory.
- loadConfigFromURI(String, ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Load the XML configuration from the specified URI.
- loadExtentIdsInternal(Set<Long>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Populate the given set with the identifiers of extents in the underlying persistent storage.
- loadFileOrResource(String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from a file or resource.
- loadFileOrResource(String, String, ClassLoader) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from a file or resource.
- loadFileOrResource(String, String, ClassLoader, boolean) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from a file or resource.
- loadFileOrResourceOrDefault(String, String, ClassLoader) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from a file or resource.
- loadInternal(long, ReadBuffer) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Load and return the value associated with the specified key from the underlying persistent storage.
- loadInternal(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Load the entry associated with the specified key from the underlying store.
- loadInternal(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Load the entry associated with the specified key from the underlying store.
- loadInternal(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Load the entry associated with the specified key from the underlying store.
- loadInternal(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Load the entry associated with the specified key from the underlying store.
- loadNamespaceHandlers(XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Load all the customNamespaceHandlerinstances for the specifiedXmlElement.
- loadNamespaceHandlers(XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Load all the customNamespaceHandlerinstances for the specifiedXmlElement.
- LoadOperationObserver() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.LoadOperationObserver
- 
Default constructor
- LoadOperationObserver(int) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.LoadOperationObserver
- 
Constructor for loadAll() code path.
- loadResource(String, ClassLoader, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Attempt to find a valid, resolvable URL for the specified resource, first by using each of the specified ClassLoaders, then using the ContextClassLoader.
- loadResource(String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from a resource.
- loadResource(String, String, ClassLoader) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from resource.
- loadResource(URL, String, ClassLoader) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from a URL resource.
- loadResourceInternal(String, String, ClassLoader, boolean, boolean, boolean) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from a file or resource.
- loadResourceInternal(URL, String, boolean) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the configuration from a URL.
- loadXml(InputStream) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load XML from a stream.
- loadXml(InputStream, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load XML from a stream using the specified charset.
- loadXml(Class) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load XML from a file for a class.
- loadXml(Class, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load XML from a file for a class using a given charset.
- loadXml(Class, String, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load XML from a file that is collocated with the specified class with a given charset.
- loadXml(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load XML from a string.
- loadXml(String, XmlDocument) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load XML from a String into the specified XmlElement.
- loadXml(String, XmlDocument, boolean) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load XML from a String into the specified XmlElement.
- loadXml(URL) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the XML from the specified url using the default character set.
- loadXml(URL, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Load the XML from the specified url using the specified character set.
- local() - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Return a local onlyMBeanServerProxy.
- local() - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- LocalAddressProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat parses a <local-address> to produce anInetSocketAddress.
- LocalAddressProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.LocalAddressProcessor
- LocalAddressProviderBuilder - Class in com.tangosol.coherence.config.builder
- 
This class builds an AddressProviderBuilder from a local address.
- LocalAddressProviderBuilder(String, int, int) - Constructor for class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
ConstructsLocalAddressProviderBuilderdeferring address resolution until realized.
- LocalAddressProviderBuilder(String, int, int, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
ConstructsLocalAddressProviderBuilderdeferring address resolution until realized.
- LocalAddressProviderBuilder(InetAddress, int, int) - Constructor for class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
ConstructsLocalAddressProviderBuilderwith a resolved address.
- localAtomicBoolean(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicBooleaninstance for the specified name.
- localAtomicBoolean(String, boolean) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicBooleaninstance for the specified name and initial value.
- LocalAtomicBoolean - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAtomicBooleaninterface, that simply wrapsjava.util.concurrent.atomic.AtomicBooleaninstance.
- LocalAtomicBoolean(boolean) - Constructor for class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- 
ConstructLocalAtomicBooleaninstance.
- LocalAtomicBoolean(AtomicBoolean) - Constructor for class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- 
ConstructLocalAtomicBooleaninstance.
- localAtomicInteger(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicIntegerinstance for the specified name.
- localAtomicInteger(String, int) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicIntegerinstance for the specified name and initial value.
- LocalAtomicInteger - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAtomicIntegerinterface, that simply wrapsjava.util.concurrent.atomic.AtomicIntegerinstance.
- localAtomicLong(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicLonginstance for the specified name.
- localAtomicLong(String, long) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicLonginstance for the specified name and initial value.
- LocalAtomicLong - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAtomicLonginterface, that simply wrapsjava.util.concurrent.atomic.AtomicLonginstance.
- localAtomicMarkableReference(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicMarkableReferenceinstance for the specified name.
- localAtomicMarkableReference(String, V, boolean) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicMarkableReferenceinstance for the specified name and initial value and mark.
- LocalAtomicMarkableReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAtomicMarkableReferenceinterface, that simply wrapsjava.util.concurrent.atomic.AtomicMarkableReferenceinstance.
- LocalAtomicMarkableReference(AtomicMarkableReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- 
ConstructLocalAtomicMarkableReference<V>instance.
- LocalAtomicMarkableReference(V, boolean) - Constructor for class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- 
ConstructLocalAtomicMarkableReference<V>instance.
- localAtomicReference(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicReferenceinstance for the specified name.
- localAtomicReference(String, V) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicReferenceinstance for the specified name and initial value.
- LocalAtomicReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAtomicReferenceinterface, that simply wrapsjava.util.concurrent.atomic.AtomicReferenceinstance.
- LocalAtomicReference(AtomicReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- 
ConstructLocalAtomicReference<V>instance.
- LocalAtomicReference(V) - Constructor for class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- 
ConstructLocalAtomicReference<V>instance.
- localAtomicStampedReference(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicStampedReferenceinstance for the specified name.
- localAtomicStampedReference(String, V, int) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnLocalAtomicStampedReferenceinstance for the specified name and initial value and stamp.
- LocalAtomicStampedReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
Local implementation ofAtomicStampedReferenceinterface, that simply wrapsjava.util.concurrent.atomic.AtomicStampedReferenceinstance.
- LocalAtomicStampedReference(AtomicStampedReference<V>) - Constructor for class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- 
ConstructLocalAtomicStampedReference<V>instance.
- LocalAtomicStampedReference(V, int) - Constructor for class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- 
ConstructLocalAtomicStampedReference<V>instance.
- LocalCache<K,V> - Class in com.tangosol.coherence.jcache.localcache
- 
An in-process local cache implementation of aCachebased on a Coherence <local-cache>.
- LocalCache - Class in com.tangosol.net.cache
- 
A LocalCache implementation that supports the JCache API, CacheLoader and CacheStore objects.
- LocalCache() - Constructor for class com.tangosol.net.cache.LocalCache
- 
Construct the cache manager.
- LocalCache(int) - Constructor for class com.tangosol.net.cache.LocalCache
- 
Construct the cache manager.
- LocalCache(int, int) - Constructor for class com.tangosol.net.cache.LocalCache
- 
Construct the cache manager.
- LocalCache(int, int, CacheLoader) - Constructor for class com.tangosol.net.cache.LocalCache
- 
Construct the cache manager.
- LocalCache(CoherenceBasedCacheManager, String, LocalCacheConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Constructs aLocalCacheconfigured byLocalCacheConfiguration.
- LocalCache.Entry - Class in com.tangosol.net.cache
- 
A holder for a cached value.
- LocalCache.EntryIterator<K,V> - Class in com.tangosol.coherence.jcache.localcache
- 
JCache Entry iterator
- LocalCache.InternalListener - Class in com.tangosol.net.cache
- 
An internal MapListener that listens to this cache and reports changes to the CacheStore.
- LocalCache.KeyMask - Class in com.tangosol.net.cache
- 
A class that masks certain changes so that they are not reported back to the CacheStore.
- LocalCacheAsynchronousMapListener<K,V> - Class in com.tangosol.coherence.jcache.localcache
- 
MapListener for Coherence-based JCache adapter implementation to generate JCacheCoherenceCacheEntryEvent.
- LocalCacheAsynchronousMapListener.NonSyntheticEntryFilter - Class in com.tangosol.coherence.jcache.localcache
- 
Server side filter to filter out both coherence and jcache synthetic events.
- LocalCacheConfiguration<K,V> - Class in com.tangosol.coherence.jcache.localcache
- 
AConfigurationfor aCachebased on a Coherence <local-scheme>, or more specifically an in-processNamedCache.
- LocalCacheConfiguration() - Constructor for class com.tangosol.coherence.jcache.localcache.LocalCacheConfiguration
- 
Constructs a defaultLocalCacheConfiguration.
- LocalCacheConfiguration(CompleteConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.localcache.LocalCacheConfiguration
- 
Constructs aLocalCacheConfigurationbased on aCompleteConfiguration.
- LocalCacheSynchronousMapListener<K,V> - Class in com.tangosol.coherence.jcache.localcache
- 
Synchronous version of LocalCacheAsynchronousMapListener.
- LocalCacheValue - Class in com.tangosol.coherence.jcache.localcache
- 
Represents the internal Cache Entry Value with in anLocalCache.
- LocalCacheValue(LocalCacheValue) - Constructor for class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Copy constructor
- LocalCacheValue.JCacheSyntheticKind - Enum in com.tangosol.coherence.jcache.localcache
- 
Synthetic Update
- localCountDownLatch(String, int) - Static method in class com.oracle.coherence.concurrent.Latches
- 
Return a singleton instance of aLocalCountDownLatchwith a specified name and initial count.
- LocalCountDownLatch - Class in com.oracle.coherence.concurrent
- 
Local implementation ofCountDownLatchinterface, that simply wrapsjava.util.concurrent.CountDownLatchinstance.
- localLock(String) - Static method in class com.oracle.coherence.concurrent.locks.Locks
- 
Return a singleton instance of a localReentrantLockwith a specified name.
- LocalPermission - Class in com.tangosol.net.security
- 
This class is for local (non-clustered) permissions.
- LocalPermission(String) - Constructor for class com.tangosol.net.security.LocalPermission
- 
Create a new LocalPermission with the specified target name.
- localReadWriteLock(String) - Static method in class com.oracle.coherence.concurrent.locks.Locks
- 
Return a singleton instance of a localReentrantReadWriteLockwith a specified name.
- LocalScheme - Class in com.tangosol.coherence.config.scheme
- 
TheLocalSchemeclass is responsible for building a fully configured instance of a LocalCache.
- LocalScheme() - Constructor for class com.tangosol.coherence.config.scheme.LocalScheme
- localSemaphore(String, int) - Static method in class com.oracle.coherence.concurrent.Semaphores
- 
Return a singleton instance of aLocalSemaphorewith a specified name and number of permits.
- LocalSemaphore - Class in com.oracle.coherence.concurrent
- 
Local implementation ofSemaphoreinterface, that simply wrapsjava.util.concurrent.Semaphoreinstance.
- lock() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Acquires the lock.
- lock() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.ReadLock
- 
Acquires the read lock.
- lock() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Acquires the write lock.
- lock(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- lock(Object) - Method in class com.tangosol.net.cache.NearCache
- 
Attempt to lock the specified item and return immediately.
- lock(Object) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- lock(Object) - Method in interface com.tangosol.util.ConcurrentMap
- 
Attempt to lock the specified item and return immediately.
- lock(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterConcurrentMap
- 
Attempt to lock the specified item and return immediately.
- lock(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Attempt to lock the specified item and return immediately.
- lock(Object) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Attempt to lock the specified item and return immediately.
- lock(Object) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Lock this entry for the specified lock holder.
- lock(Object) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Attempt to lock the specified item and return immediately.
- lock(Object, long) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- lock(Object, long) - Method in class com.tangosol.net.cache.NearCache
- 
Attempt to lock the specified item within the specified period of time.
- lock(Object, long) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- lock(Object, long) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Attempt to lock the specified item within the specified period of time.
- lock(Object, long) - Method in interface com.tangosol.util.ConcurrentMap
- 
Attempt to lock the specified item within the specified period of time.
- lock(Object, long) - Method in class com.tangosol.util.ConverterCollections.ConverterConcurrentMap
- 
Attempt to lock the specified item within the specified period of time.
- lock(Object, long) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Attempt to lock the specified item within the specified period of time.
- lock(Object, long) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Attempt to lock the specified item within the specified period of time.
- lock(Object, long) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Attempt to lock the specified item within the specified period of time.
- Lock() - Constructor for class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Construct a new Lock object.
- LOCK_ALL - Static variable in class com.tangosol.io.AsyncBinaryStore
- 
Special key to indicate that all keys should be locked.
- LOCK_ALL - Static variable in interface com.tangosol.util.ConcurrentMap
- 
Special key value indicating an intent to lock the entire map.
- LOCK_ALL_PENDING - Static variable in class com.tangosol.util.SegmentedHashMap
- 
The bit-mask used to indicate that a lock-all is pending.
- LOCK_ALL_PENDING_IDX - Static variable in class com.tangosol.util.SegmentedHashMap
- 
The mutex number used to indicate that a lock-all is pending.
- LOCK_COUNT - Static variable in class com.tangosol.util.SegmentedHashMap
- 
The number of segment-locks.
- LOCK_FILE_NAME - Static variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
Name of warning file.
- Lockable - Interface in com.oracle.coherence.common.base
- 
The Lockable interface is used for managing exclusive access to thread-safe classes.
- Lockable.Unlockable - Interface in com.oracle.coherence.common.base
- 
The Unlockable interface is used for releasing the exclusive access to this Lockable.
- LockableEntry(Object, Object, int) - Constructor for class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Construct a LockableEntry for the given entry.
- LockAction() - Constructor for class com.tangosol.util.SegmentedConcurrentMap.LockAction
- lockAll(ConcurrentMap, Collection, long) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Attempt to lock all the specified keys within a specified period of time.
- lockAllBuckets() - Method in class com.tangosol.util.SegmentedHashMap
- 
Lock everything.
- lockAllBuckets(int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Lock everything, assuming that the segment for the specified bucket has already been locked.
- lockAllSegments(long) - Method in class com.tangosol.util.SegmentedHashMap
- 
Lock all segments except for the specified segments that have already been locked by the calling thread.
- lockBucket(int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Attempt to lock the segment corresponding to the specified bucket.
- lockFile(File) - Static method in class com.tangosol.io.FileHelper
- 
Obtain an exclusive lock on the specified file.
- lockInternal(Object) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Obtain a lock for the specified key.
- lockInternalNoWait(Object) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Obtain a lock for the specified key, but only if no other thread has the lock at the point in time that this method is invoked.
- lockInterruptibly() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Acquires the lock unless the current thread is interrupted.
- lockInterruptibly() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.ReadLock
- 
Acquires the read lock unless the current thread is interrupted.
- lockInterruptibly() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Acquires the write lock unless the current thread is interrupted.
- lockInterruptibly(Lock) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Acquire a lock while still respecting the calling thread'stimeout.
- LockOwner - Class in com.oracle.coherence.concurrent.locks
- 
The identity of a lock owner, represented by the UID of the member, and the ID of a thread holding or attempting to acquire the lock.
- LockOwner() - Constructor for class com.oracle.coherence.concurrent.locks.LockOwner
- 
Default constructor for serialization interfaces
- LockOwner(Member, long) - Constructor for class com.oracle.coherence.concurrent.locks.LockOwner
- 
ConstructLockOwnerinstance.
- lockRead() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Acquire a read lock on this persistent store.
- Locks - Class in com.oracle.coherence.concurrent.locks
- 
Factory methods for various local and remote lock implementations.
- Locks() - Constructor for class com.oracle.coherence.concurrent.locks.Locks
- LOCKS_ALL - Static variable in class com.tangosol.util.SegmentedHashMap
- 
The lock representation used to indicate that all mutexes are locked.
- LOCKS_NONE - Static variable in class com.tangosol.util.SegmentedHashMap
- 
The lock representation used to indicate that no locks are set.
- lockSegment(int, boolean) - Method in class com.tangosol.util.SegmentedHashMap
- 
Attempt to lock the specified segment.
- lockStorage() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Acquire an exclusive lock on the data directory underlying this persistent store.
- lockWrite() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Acquire a write lock on this persistent store.
- log() - Static method in class com.tangosol.util.Base
- 
Prints a blank line to the log.
- log(Class<?>) - Static method in class com.tangosol.util.Base
- 
Prints the passed class information to the log.
- log(Exception) - Static method in class com.tangosol.coherence.rest.util.RestHelper
- 
Log server side message for handled exceptions that return a http response ofBAD REQUEST, status 400.
- log(Object) - Static method in class com.tangosol.util.Base
- 
Prints the passed Object to the log.
- log(String) - Static method in class com.tangosol.util.Base
- 
Prints the passed String value to the log.
- log(String, int) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message at the specified severity level.
- log(String, int) - Static method in class com.tangosol.net.CacheFactory
- 
Deprecated.since Coherence 14.1.2, and may be removed in a future version; use one ofLoggermethods instead.
- log(String, Throwable, int) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace at the specified severity level.
- log(Throwable) - Static method in class com.tangosol.util.Base
- 
Prints the passed exception information to the log.
- log(Throwable, int) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) at the specified severity level.
- log(Supplier<String>, int) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message at the specified severity level.
- log(Supplier<String>, Throwable, int) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace at the specified severity level.
- LOG_ALWAYS - Static variable in class com.tangosol.util.Base
- 
It is expected that items with a log level of 0 will always be logged.
- LOG_CONFIG - Static variable in class com.tangosol.util.Base
- 
Log level 4 indicates configuration related log message.
- LOG_DEBUG - Static variable in class com.tangosol.util.Base
- 
As of Coherence 3.2, the default logging level is 5, so using the level of 5 will show up in the logs by default as a debug message.
- LOG_ERR - Static variable in class com.tangosol.util.Base
- 
Log level 1 indicates an error.
- LOG_INFO - Static variable in class com.tangosol.util.Base
- 
Log level 3 indicates information that should likely be logged.
- LOG_MAX - Static variable in class com.tangosol.util.Base
- 
The maximum logging level indicator.
- LOG_MIN - Static variable in class com.tangosol.util.Base
- 
The minimum logging level indicator.
- LOG_QUIET - Static variable in class com.tangosol.util.Base
- 
As of Coherence 3.2, the default logging level is 5, so using a level higher than 5 will be "quiet" by default, meaning that it will not show up in the logs unless the configured logging level is increased.
- LOG_WARN - Static variable in class com.tangosol.util.Base
- 
Log level 2 indicates a warning.
- logEntryRequest(BinaryEntry, Subject, boolean, int) - Method in class com.tangosol.net.security.AuditingAuthorizer
- 
Log the entry level authorization request.
- logException(Throwable, String) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Helper to log ignored exceptions.
- logException(SocketAddress, IOException) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Log an exception which is handled internally by the TcpDatagramSocket.
- Logger - Class in com.oracle.coherence.common.base
- 
Logging API.
- Logger() - Constructor for class com.oracle.coherence.common.base.Logger
- LoggingPofHandler - Class in com.tangosol.io.pof
- 
An implementation of PofHandler that logs all of the stream contents for debugging / testing purposes.
- LoggingPofHandler() - Constructor for class com.tangosol.io.pof.LoggingPofHandler
- 
Default constructor: Construct a Logging POF Handler that sends all logging output to standard output.
- LoggingPofHandler(PrintWriter) - Constructor for class com.tangosol.io.pof.LoggingPofHandler
- 
Construct a Logging POF Handler that sends all logging output to the specified PrintWriter.
- LoggingWriter(int) - Constructor for class com.tangosol.util.Base.LoggingWriter
- 
Construct a PrintWriter that logs using theCacheFactory.log(java.lang.String, int)method.
- login(String, char[]) - Static method in class com.tangosol.net.security.Security
- 
Perform the authentication.
- login(CallbackHandler) - Static method in class com.tangosol.net.security.Security
- 
Perform the authentication.
- logMapRequest(BackingMapContext, Subject, boolean, int) - Method in class com.tangosol.net.security.AuditingAuthorizer
- 
Log the backing map level authorization request.
- logMissingIdx(Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Log messages for missing inverse index.
- logPermissionRequest(ClusterPermission, Subject, boolean) - Method in class com.tangosol.net.security.DefaultController
- 
Log the authorization request.
- logProtocolWarning(SocketAddress, TcpDatagramSocket.Impl.ConnectionStatus, int) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Periodically log a warning when connections are made using an unrecognized protocol.
- logSerializationErrors(Map<Serializer, Exception>, String) - Method in class com.tangosol.io.MultiplexingSerializer
- 
Given the provided mappings between aSerializerand theExceptionit threw, log each mapping for diagnostic purposes.
- logStackTraces() - Static method in class com.tangosol.net.GuardSupport
- 
Collect stack traces and synchronization information for all running threads and write them to the error log.
- LONG_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
- 
An empty array of longs.
- LONG_CONVERTER_DOWN - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
A converter that converts from a Long to a ReadBuffer.
- LONG_CONVERTER_UP - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
A converter that converts from a ReadBuffer to a Long.
- LONG_MAX_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theLongMaxaggregator.
- LONG_MIN_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theLongMinaggregator.
- LONG_SUM_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theLongSumaggregator.
- LongAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.LongAdapter
- 
Construct a SimpleAdapter.
- LongArray<V> - Interface in com.tangosol.util
- 
An interface, similar in its methods to List, and similar in its purpose to a Java array, designed for sparse storage and indexed by long values.
- LongArray.Iterator<V> - Interface in com.tangosol.util
- 
An Iterator that adds a "current element" concept, similar to theMap.Entryinterface.
- LongArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Construct a LongArrayAdapter.
- LongArrayCodec(Class<LongArray<Object>>) - Constructor for class com.tangosol.io.pof.reflect.Codecs.LongArrayCodec
- 
Construct a LongArrayCodec.
- longBinaryOperator(Remote.LongBinaryOperator) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable LongBinaryOperator.
- longConsumer(Remote.LongConsumer) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable LongConsumer.
- longFunction(Remote.LongFunction<R>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable LongFunction.
- LONGLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
The numberic code for a long literal
- LONGLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
The numberic code for a long literal
- longMax(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.
- longMax(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.
- LongMax<T> - Class in com.tangosol.util.aggregator
- 
Calculates a maximum of numeric values extracted from a set of entries in a Map.
- LongMax() - Constructor for class com.tangosol.util.aggregator.LongMax
- 
Default constructor (necessary for the ExternalizableLite interface).
- LongMax(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.LongMax
- 
Construct a LongMax aggregator.
- LongMax(String) - Constructor for class com.tangosol.util.aggregator.LongMax
- 
Construct a LongMax aggregator.
- longMin(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.
- longMin(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.
- LongMin<T> - Class in com.tangosol.util.aggregator
- 
Calculates a minimum of numeric values extracted from a set of entries in a Map.
- LongMin() - Constructor for class com.tangosol.util.aggregator.LongMin
- 
Default constructor (necessary for the ExternalizableLite interface).
- LongMin(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.LongMin
- 
Construct a LongMin aggregator.
- LongMin(String) - Constructor for class com.tangosol.util.aggregator.LongMin
- 
Construct a LongMin aggregator.
- longPredicate(Remote.LongPredicate) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable LongPredicate.
- longSum(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.
- longSum(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.
- LongSum<T> - Class in com.tangosol.util.aggregator
- 
Sums up numeric values extracted from a set of entries in a Map.
- LongSum() - Constructor for class com.tangosol.util.aggregator.LongSum
- 
Default constructor (necessary for the ExternalizableLite interface).
- LongSum(ValueExtractor<? super T, ? extends Number>) - Constructor for class com.tangosol.util.aggregator.LongSum
- 
Construct a LongSum aggregator.
- LongSum(String) - Constructor for class com.tangosol.util.aggregator.LongSum
- 
Construct a LongSum aggregator.
- longSupplier(Remote.LongSupplier) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable LongSupplier.
- longToDoubleFunction(Remote.LongToDoubleFunction) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable LongToDoubleFunction.
- longToIntFunction(Remote.LongToIntFunction) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable LongToIntFunction.
- longUnaryOperator(Remote.LongUnaryOperator) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable LongUnaryOperator.
- longValue() - Method in class com.oracle.coherence.common.base.MutableLong
- longValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Returns the current value of thisAsyncAtomicIntegeras alongafter a widening primitive conversion.
- longValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Returns the current value of thisDistributedAtomicLongas along.
- longValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- longValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- longValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- longValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- longValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Returns the current value of thisAtomicIntegeras alongafter a widening primitive conversion.
- longValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Returns the current value of thisAtomicLongas along.
- longValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- longValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- longValue() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- longValue() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- longValue() - Method in class com.tangosol.io.pof.RawQuad
- 
Returns the value of the specified number as along.
- lookup(String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Lookup an OPToken by name
- lookup(String) - Method in interface com.tangosol.net.NameService
- 
Retrieves the named object.
- lookup(String, Cluster, NameService.RequestContext) - Method in interface com.tangosol.net.NameService.LookupCallback
- 
Retrieve the named object.
- lookupIdentity(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Look up the specified identity and return the object to which it refers.
- lookupIdentity(int) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Look up the specified identity and return the PofValue to which it refers.
- Lost - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any LOST event.
- LOST - com.tangosol.net.events.partition.TransferEvent.Type
- 
ThisTransferEventis dispatched when a partition has been orphaned (data loss may have occurred), and the ownership is assumed by thelocal member.
- Lost.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theLostannotation.
- LOW - com.tangosol.net.events.annotation.Interceptor.Order
- 
Indicates that theEventInterceptoris not concerned with where in the chain it resides.
- lower(Object) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- lowerEntry(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- lowerKey(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
M
- m_aabArray - Variable in class com.tangosol.io.MultiByteArrayInputStream
- 
The array of byte arrays.
- m_aAdapter - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
The property adapters for the XML bean.
- m_aAddrPortDest - Variable in class com.tangosol.net.LoadBalancer
- 
The AddressPort combinations that the load balancer will balance to.
- m_aAggregator - Variable in class com.tangosol.util.aggregator.CompositeAggregator
- 
The underlying EntryAggregator array.
- m_ab - Variable in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
The byte array that holds the binary data.
- m_ab - Variable in class com.tangosol.io.ByteArrayWriteBuffer
- 
The byte array that holds the binary data.
- m_ab - Variable in class com.tangosol.io.MultiByteArrayInputStream
- 
The current byte array.
- m_ab - Variable in class com.tangosol.io.MultiByteArrayOutputStream
- 
The current block of output.
- m_abAccum - Variable in class com.tangosol.io.Base64OutputStream
- 
Accumulated bytes.
- m_abBuf - Variable in class com.tangosol.net.LoadBalancer.SocketHandler
- 
The buffer to use for reading from a stream.
- m_abGroup - Variable in class com.tangosol.io.Base64InputStream
- 
Group of bytes (stored as ints 0..255).
- m_acache - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
A cached array of the backing ConfigurableCacheMap instances.
- m_achBuf - Variable in class com.tangosol.io.AbstractWriteBuffer
- 
A lazily instantiated temp buffer used to avoid allocations fromString.toCharArray()and repeated calls toString.charAt(int).
- m_achGroup - Variable in class com.tangosol.io.Base64OutputStream
- 
An array that is used to send 4 characters at a time to the underlying Writer object.
- m_aClzByTypeId - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
An array of WeakReferences to user type classes, indexed by type identifier.
- m_aComparator - Variable in class com.tangosol.util.comparator.ChainedComparator
- 
The Comparator array.
- m_actionConditionalRemove - Variable in class com.tangosol.util.SegmentedConcurrentMap
- 
The singleton action for conditional remove.
- m_actionContainsValue - Variable in class com.tangosol.util.SegmentedHashMap
- 
The singleton action for containsValue support.
- m_actionDumpHeldLocks - Variable in class com.tangosol.util.SegmentedConcurrentMap
- 
The singleton action dump held locks.
- m_actionGetEntry - Variable in class com.tangosol.util.SegmentedHashMap
- 
The singleton action for getEntryInternal support.
- m_actionInsert - Variable in class com.tangosol.util.SegmentedHashMap
- 
The singleton action for insert support.
- m_actionLock - Variable in class com.tangosol.util.SegmentedConcurrentMap
- 
The action for lock() support.
- m_actionRemove - Variable in class com.tangosol.util.SegmentedHashMap
- 
The singleton action for remove support.
- m_actionSize - Variable in class com.tangosol.util.SegmentedConcurrentMap
- 
The singleton action for size support.
- m_actionTruncate - Variable in class com.tangosol.util.SegmentedConcurrentMap
- 
The singleton action for truncate.
- m_actionUnlock - Variable in class com.tangosol.util.SegmentedConcurrentMap
- 
The action for unlock() support.
- m_address - Variable in class com.tangosol.net.CompositeAddressProvider.SingleProvider
- 
The single address that this AddressProvider represents.
- m_addrportHost - Variable in class com.tangosol.net.LoadBalancer
- 
The AddressPort combination that the load balancer will listen on.
- m_advancer - Variable in class com.tangosol.util.PagedIterator
- 
The underlying Advancer.
- m_aeBucket - Variable in class com.tangosol.util.SafeHashMap
- 
The array of hash buckets.
- m_aeBucket - Variable in class com.tangosol.util.SegmentedHashMap
- 
The array of hash buckets.
- m_aExtractor - Variable in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
The ValueExtractor array.
- m_aggregator - Variable in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
- 
The underlying aggregator.
- m_aggregator - Variable in class com.tangosol.util.aggregator.GroupAggregator
- 
The underlying EntryAggregator.
- m_aggregatorRegistry - Variable in class com.tangosol.coherence.rest.CacheResource
- 
Aggregator registry that is used to map the given aggregator name to an EntryAggregator instance.
- m_aggregatorRegistry - Variable in class com.tangosol.coherence.rest.EntrySetResource
- 
Aggregator registry that is used to map the given aggregator name to an EntryAggregator instance.
- m_aggregatorRegistry - Variable in class com.tangosol.coherence.rest.NamedQueryResource
- 
Aggregator registry that is used to map the given aggregator name to an EntryAggregator instance.
- m_aGuardContext - Variable in class com.tangosol.net.GuardSupport
- 
Array of GuardContexts for the registered Guardables.
- m_aiOwner - Variable in class com.tangosol.net.partition.Ownership
- 
An array of member ids representing the partition ownership.
- m_anodeRecycled - Variable in class com.tangosol.util.RecyclingLinkedList
- 
The Nodes to recycle.
- m_aoArgs - Variable in class com.tangosol.util.AbstractScript
- 
The arguments to be passed to the script during evaluation.
- m_aoArgs - Variable in class com.tangosol.util.processor.MethodInvocationProcessor
- 
Method arguments.
- m_aoData - Variable in class com.tangosol.util.CircularArrayList
- 
The array into which the elements of the list are stored.
- m_aoItem - Variable in class com.tangosol.util.SimpleEnumerator
- 
Array of items to enumerate.
- m_aoKey - Variable in class com.tangosol.util.KeyValueArrayMap
- 
The array containing map keys.
- m_aoParam - Variable in class com.tangosol.util.extractor.ReflectionExtractor
- 
The parameter array.
- m_aoParam - Variable in class com.tangosol.util.extractor.UniversalExtractor
- 
The parameter array.
- m_aoValue - Variable in class com.tangosol.util.KeyValueArrayMap
- 
The array containing map values.
- m_aOwners - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The ownership array for this analysis context.
- m_aOwnershipMembers - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
An array of the ownership members to include in the distribution, arranged in arbitrary order.
- m_aParallelResults - Variable in class com.tangosol.util.aggregator.CompositeAggregator
- 
An array of partial results for each aggregator.
- m_apprvrEvict - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The EvictionApprover.
- m_apprvrEvict - Variable in class com.tangosol.net.cache.SerializationCache
- 
The EvictionApprover.
- m_apprvrEvict - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
An optional EvictionApprover registered with this cache.
- m_apRecovery - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
The recovery address-provider.
- m_apRefresh - Variable in class com.tangosol.net.RefreshableAddressProvider
- 
The address provider to be refreshed.
- m_aProcessor - Variable in class com.tangosol.util.processor.CompositeProcessor
- 
The underlying entry processor array.
- m_arguments - Variable in class com.tangosol.net.management.MBeanAccessor.Invoke
- 
The arguments to the operation.
- m_arrayExpiry - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.Array of set of keys, indexed by the time of expiry.
- m_arrayRefs - Variable in class com.tangosol.io.pof.PofBufferReader
- 
Lazily-constructed mapping of identities to references.
- m_arrayRefs - Variable in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Lazily-constructed mapping of identities to references.
- m_aRules - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
The array of quorum rules.
- m_aSegment - Variable in class com.tangosol.util.SegmentedHashMap
- 
An array of the control-structures for the Map's segments.
- m_aSerByTypeId - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
An array of PofSerializer objects, indexed by type identifier.
- m_asGUIDNewest - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
The resolved list of the newest GUIDs, indexed by partition-id.
- m_asStackRemote - Variable in exception com.tangosol.io.pof.PortableException
- 
A raw representation of the remote stack trace for this exception.
- m_atomicLocks - Variable in class com.tangosol.util.SegmentedHashMap
- 
The "segment-locks".
- m_atomicNonce - Variable in class com.tangosol.util.SortedBag
- 
The nonce used to increment the unique element ids.
- m_atomicUpdaterValue - Static variable in class com.tangosol.util.SegmentedConcurrentMap
- 
AtomicUpdater for the entry value.
- m_binContent - Variable in class com.tangosol.coherence.rest.util.StaticContent
- m_binFutureData - Variable in class com.tangosol.io.SimpleEvolvable
- 
Future data.
- m_binKey - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
The Binary key.
- m_binValue - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
The Binary value.
- m_binValueOrig - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
The original Binary value.
- m_bldr - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
AParameterizedBuilderthat creates aPersistenceEnvironment.
- m_bldrExtractor - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
TheExtractorBuilderthat will be used to realizeValueExtractors to be used by CohQL.
- m_buf - Variable in class com.tangosol.io.DelegatingWriteBuffer
- 
The WriteBuffer to delegate to; the "containing" WriteBuffer.
- m_buf - Variable in class com.tangosol.io.nio.ByteBufferInputStream
- 
The ByteBuffer object from which data is read.
- m_buf - Variable in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
The ByteBuffer object from which data is read.
- m_bufUnsafe - Variable in class com.tangosol.io.ByteArrayWriteBuffer
- 
Cached ReadBuffer to quickly provide an answer toByteArrayWriteBuffer.getUnsafeReadBuffer().
- m_bufValue - Variable in class com.tangosol.util.ExternalizableHelper.DecoratedMultiBufferReadBuffer
- 
The undecorated value.
- m_builder - Variable in class com.tangosol.coherence.config.builder.ServiceLoadBalancerBuilder
- 
Customized ServiceLoadBalancerBuilder.
- m_cAccum - Variable in class com.tangosol.io.Base64OutputStream
- 
The number of bytes accumulated (0, 1, 2 or 3).
- m_cache - Variable in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
- 
Listener for this JCache.
- m_cache - Variable in class com.tangosol.coherence.rest.CacheResource
- 
NamedCache wrapped by this resource.
- m_cache - Variable in class com.tangosol.coherence.rest.EntryResource
- 
NamedCache which stores the referenced entry.
- m_cache - Variable in class com.tangosol.coherence.rest.EntrySetResource
- 
Cache which stores the referenced entries.
- m_cache - Variable in class com.tangosol.coherence.rest.NamedQueryResource
- 
NamedCache wrapped by this resource.
- m_cache - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
The cache to query from.
- m_cacheFactory - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
TheConfigurableCacheFactoryto use to access caches.
- m_cacheSource - Variable in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
- m_calculator - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The external unit calculator.
- m_calculator - Variable in class com.tangosol.net.cache.SerializationCache
- 
The unit calculator to use to limit size of the cache.
- m_calculator - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The unit calculator.
- m_calculator - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
TheConfigurableCacheMap.UnitCalculatorused to calculate the size ofSimpleMapIndex.IndexCalculator.CalculatorState.CONFIGUREDtypes. intoBinaryto approximate the size.
- m_calculator - Variable in class com.tangosol.util.SimpleMapIndex
- 
UnitCalculator used to estimate the cost of a value.
- m_calculatorBackup - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The backup LoadCalculator.
- m_calculatorPrimary - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The primary LoadCalculator.
- m_cAverageBundleSize - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
An average bundle size for this Bundler.
- m_cAverageBurstDuration - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
An average time for bundled request processing (burst).
- m_cAverageThreadWaitDuration - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
An average thread waiting time caused by under-filled bundle.
- m_cAvgTouch - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.For a prune cycle, this value is the average number of touches that an entry should have.
- m_cb - Variable in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Number of bytes in the byte array that belong to this ReadBuffer object.
- m_cb - Variable in class com.tangosol.io.ByteArrayWriteBuffer.Allocator
- 
The capacity of the ByteArrayWriteBuffer instances to allocate.
- m_cb - Variable in class com.tangosol.io.ByteArrayWriteBuffer
- 
Number of bytes in the byte array that have been written by this WriteBuffer.
- m_cb - Variable in class com.tangosol.io.DelegatingWriteBuffer
- 
Length in bytes of this WriteBuffer.
- m_cb - Variable in class com.tangosol.io.SizeEstimatingBufferOutput
- 
The byte count.
- m_cBackupActual - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The number of backup storages to maintain.
- m_cBarred - Variable in class com.tangosol.util.ThreadGateLite.Bar
- m_cbAveragePartition - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
The average partition storage size in bytes.
- m_cbAverageStorage - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
The average node storage size in bytes.
- m_cbBlock - Variable in class com.tangosol.io.MultiByteArrayOutputStream
- 
The max size of each block.
- m_cbFixed - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
If the state isSimpleMapIndex.IndexCalculator.CalculatorState.FIXED, contains a cached cost per instance.
- m_cBlocks - Variable in class com.tangosol.io.MultiByteArrayOutputStream
- 
The number of flushed blocks.
- m_cbMax - Variable in class com.tangosol.io.ByteArrayWriteBuffer
- 
Number of bytes that the byte array can be grown to.
- m_cbMax - Variable in class com.tangosol.io.DelegatingWriteBuffer
- 
Maximum number of bytes in this WriteBuffer.
- m_cbMaxPartition - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
The maximum partition storage size in bytes.
- m_cbMaxStorage - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
The maximum node storage size in bytes.
- m_cbPadBack - Variable in class com.tangosol.io.MultiByteArrayOutputStream
- 
The number of additional bytes to allocate and leave free at the back (end) of each block
- m_cbPadFront - Variable in class com.tangosol.io.MultiByteArrayOutputStream
- 
The number of additional bytes to allocate and leave free at the front (start) of each block
- m_cbStorageDirect - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The portion of the partition size that is obtained directly frompartitionedmaps (in bytes).
- m_cbStorageIndirect - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The portion of the partition size that cannot be obtained directly and has to be adjusted upon each cache entry update (in bytes).
- m_cBundleCountSnapshot - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
Snapshot for a total number of processed bundled.
- m_cBundleSizeSnapshot - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
Snapshot for a total size of processed bundled.
- m_cBurstDurationSnapshot - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
Snapshot for a burst duration.
- m_cCacheHits - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
- 
The rough (ie unsynchronized) number of calls that could be answered from the front or the back and were answered by data in the front map.
- m_cCacheMisses - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
- 
The rough (ie unsynchronized) number of calls that could be answered from the front or the back and were answered by data in the back map.
- m_cCachePrunes - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Total number of evictions triggered based on the size of the cache since the last statistics reset.
- m_cCachePrunesMillis - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Total number of milliseconds used for prune operations since the last statistics reset.
- m_cCachePuts - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Total number of put operations since the last statistics reset.
- m_cCapacity - Variable in class com.tangosol.util.SafeHashMap
- 
The capacity of the hash map (the point at which it must resize), 1 <= n.
- m_ccf - Variable in class com.tangosol.net.SimpleServiceMonitor
- 
AConfigurableCacheFactoryinstance used to start the service.
- m_ccfSingleton - Variable in class com.tangosol.net.SingletonCacheFactoryBuilder
- 
SingletonConfigurableCacheFactoryinstance for the default URI.
- m_cContend - Variable in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
The number of threads that are waiting to lock this Entry.
- m_cCurUnits - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The current number of units in the cache.
- m_cCurUnits - Variable in class com.tangosol.net.cache.SerializationCache
- 
Current number of units to in the cache.
- m_cDbId - Variable in class com.tangosol.io.bdb.DatabaseFactory
- 
Counter used to generate unique Database names for this Environment.
- m_cDefaultSoftTimeoutMillis - Variable in class com.tangosol.net.GuardSupport.Context
- 
The default soft-timeout interval to use for the represented Guardable.
- m_cDefaultTimeoutMillis - Variable in class com.tangosol.net.GuardSupport.Context
- 
The default timeout interval to use for the represented Guardable.
- m_cDelay - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
An explicit delay to be used in favor of a determined delay inSimpleAssignmentStrategy.AnalysisContext.calculateAnalysisDelay().
- m_cElements - Variable in class com.tangosol.util.CircularArrayList
- 
The size of the list (the number of elements it contains).
- m_cEntries - Variable in class com.tangosol.util.SafeHashMap
- 
The number of entries stored in the hash map, 0 <= n.
- m_cEraseFailures - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The number of Erase failures.
- m_cEraseMillis - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The cumulative time spent on Erase operations.
- m_cEraseOps - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The number of Erase operations.
- m_cExecutionTime - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The total amount of time (in ms) that tasks/requests were executing.
- m_cExpiryDelay - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The number of milliseconds that a value will live in the cache.
- m_cExpiryDelayMillis - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The expiry delay.
- m_cFairShare - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
- 
The cached fair-share load.
- m_cFairShareBackup - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The fair-share backup partition load.
- m_cFairSharePrimary - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The fair-share primary partition load.
- m_cGuardable - Variable in class com.tangosol.net.GuardSupport
- 
The number of registered Guardables.
- m_chCurrent - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The current working char.
- m_cHighUnitFairShare - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The fair share of high units for each partition map.
- m_cHighUnits - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
High units is the number of units that triggers eviction.
- m_cHighUnitsCalibrated - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The high units adjusted based on thepartition unit factor.
- m_cHitsMillis - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Total number of milliseconds used for get operations that were hits since the last statistics reset.
- m_client - Variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The http client used to access http or https URLs.
- m_cLimitMillis - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
The amount of time after being in an endangered state after which the quorum policy makes a maximal effort to hold client requests.
- m_cLineGroups - Variable in class com.tangosol.io.Base64OutputStream
- 
The number of groups left to write in the current line.
- m_cLock - Variable in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
The lock count (number of times the "lock()" was called by the locking thread).
- m_cLogMissingIdx - Variable in class com.tangosol.util.SimpleMapIndex
- 
The number of "missing inverse index" messages that have been logged.
- m_cLowUnitFairShare - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The fair share of low units for each partition map.
- m_cLowUnits - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Low units is the number of units to evict down to.
- m_cLowUnitsCalibrated - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The low units adjusted based on thepartition unit factor.
- m_cluster - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
TheClusterto use to access services.
- m_clz - Variable in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
The class of Objects stored in the Collection.
- m_clz - Variable in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
The class of Objects stored in the ListIterator.
- m_clzBean - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
The class of the specific XML bean.
- m_clzKey - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
The type of keys forCaches.
- m_clzKey - Variable in class com.tangosol.coherence.rest.CacheResource
- 
Key class for the entries stored in the wrapped cache.
- m_clzKey - Variable in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Key class.
- m_clzKey - Variable in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
The class of key stored in the Map.
- m_clzPartialClass - Variable in class com.tangosol.coherence.rest.util.PropertySpec
- 
Property class (only for partial properties).
- m_clzPartitionMap - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- m_clzType - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The type of the property.
- m_clzVal - Variable in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
The class of value stored in the Map.
- m_clzVal - Variable in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
The class of value stored in the Map.
- m_clzValue - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
The type of values forCaches.
- m_clzValue - Variable in class com.tangosol.coherence.rest.CacheResource
- 
Value class for the entries stored in the wrapped cache.
- m_clzValue - Variable in class com.tangosol.coherence.rest.EntryResource
- 
Class of the referenced entry's value.
- m_clzValue - Variable in class com.tangosol.coherence.rest.EntrySetResource
- 
Class of the referenced entries' values.
- m_cMaxDelayMillis - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
The maximum amount of time (in ms) that a request could be delayed by this quorum policy.
- m_cMaxResults - Variable in class com.tangosol.coherence.rest.CacheResource
- 
Size of the result set this resource is allowed to return.
- m_cMaxResults - Variable in class com.tangosol.coherence.rest.NamedQueryResource
- 
Maximum size of the result set this resource is allowed to return.
- m_cMaxSize - Variable in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- 
The maximum size of this partial result.
- m_cMaxUnits - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The number of units to allow the cache to grow to before pruning.
- m_cMaxUnits - Variable in class com.tangosol.net.cache.SerializationCache
- 
Maximum number of units to manage in the cache.
- m_cMillis - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
The execution time in milliseconds.
- m_cMillisLastStart - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
The start time of the last operation.
- m_cMillisMax - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
The maxiumum time in millis to archive or retrieve a snapshot store.
- m_cMillisMin - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
The minimum time in millis to archive or retrieve a snapshot store.
- m_cMillisTotal - Variable in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
The total time in millis taken to archive or retrieve snapshot stores.
- m_cMissesMillis - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Total number of milliseconds used for get operations that were misses since the last statistics reset.
- m_cNameSuffix - Variable in class com.tangosol.util.DaemonThreadFactory
- 
The thread name counter.
- m_cNodes - Variable in class com.tangosol.util.SafeLinkedList
- 
The size of the List.
- m_coffset - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Offset of the current character.
- m_col - Variable in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
The underlying Collection.
- m_col - Variable in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
The underlying Collection.
- m_colDelegate - Variable in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- 
The Collection to which this wrapper delegates.
- m_colDelegate - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- 
The Collection to which this wrapper delegates.
- m_collValues - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
The values collection.
- m_colRegisteredDbs - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Databases to close prior to deleting the Environment.
- m_colValues - Variable in class com.tangosol.io.nio.BinaryMap
- 
The collection of values backed by this map.
- m_colValues - Variable in class com.tangosol.util.SafeHashMap
- 
The collection of values backed by this map.
- m_colValues - Variable in class com.tangosol.util.SegmentedHashMap
- 
The collection of values backed by this map.
- m_comparator - Variable in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
The comparator to use for comparing extracted values.
- m_comparator - Variable in class com.tangosol.util.aggregator.TopNAggregator
- 
The Comparator used to order the extracted values.
- m_comparator - Variable in class com.tangosol.util.comparator.SafeComparator
- 
The wrapped Comparator.
- m_comparator - Variable in class com.tangosol.util.extractor.ComparisonValueExtractor
- 
An underlying Comparator object (optional).
- m_comparator - Variable in class com.tangosol.util.SimpleMapIndex
- 
Comparator used to sort the index.
- m_comparator - Variable in class com.tangosol.util.SortedBag
- 
The comparator used to compare logical elements.
- m_comparator_copy - Variable in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- 
The comparator used to compare logical elements.
- m_complex - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
The Complex value that corresponds to the user type that is being written.
- m_compressor - Variable in class com.tangosol.util.ExternalizableHelper.FormatAwareCompressor
- 
The wrapped DeltaCompressor.
- m_config - Variable in class com.tangosol.coherence.rest.DefaultRootResource
- 
REST configuration.
- m_configuration - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
TheConfigurationfor theCoherenceBasedCache.
- m_contentionObserver - Variable in class com.tangosol.util.SegmentedConcurrentMap
- 
The ContentionObserver; may be null.
- m_context - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.The BackingMapManagerContext to pass to the enclosed backing maps.
- m_context - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
The BackingMapManagerContext to use for extracting binary values.
- m_control - Variable in class com.tangosol.util.AsynchronousAgent
- 
The underlying FlowControl; could be null if the "automatic flow control" is turned on.
- m_conv - Variable in class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Converter to convert each item.
- m_convDown - Variable in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
The Converter from this Collection to the underlying Collection.
- m_convDown - Variable in class com.tangosol.util.ConverterCollections.ConverterListIterator
- 
The Converter from this ListIterator to the underlying ListIterator.
- m_converter - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
TheConverterused to convertSimpleMapIndex.IndexCalculator.CalculatorState.UNKNOWNtypes intoBinaryto approximate the size.
- m_converterDown - Variable in class com.oracle.coherence.grpc.RequestHolder
- m_converterFromBinary - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- m_converterKeyDown - Variable in class com.oracle.coherence.grpc.CacheRequestHolder
- m_converterToBinary - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- m_converterUp - Variable in class com.oracle.coherence.grpc.RequestHolder
- m_convKey - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
The Converter to view the underlying MapEvent's key.
- m_convKey - Variable in class com.tangosol.util.ConverterCollections.ConverterMapListener
- 
The Converter to view an underlying CacheEvent's key.
- m_convKeyDown - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
The Converter used to pass keys down to the Entry Set.
- m_convKeyDown - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
- 
The Converter used to pass keys down to the Map.
- m_convKeyUp - Variable in class com.tangosol.util.ConverterCollections.ConverterEntry
- 
The Converter used to view the Entry's key.
- m_convKeyUp - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
The Converter used to view keys stored in the Entry Set.
- m_convKeyUp - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
- 
The Converter used to view keys stored in the Map.
- m_convUp - Variable in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
The Converter from the underlying Collection to this Collection.
- m_convUp - Variable in class com.tangosol.util.ConverterCollections.ConverterListIterator
- 
The Converter from the underlying ListIterator to this ListIterator.
- m_convVal - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
The Converter to view the underlying MapEvent's value.
- m_convVal - Variable in class com.tangosol.util.ConverterCollections.ConverterMapListener
- 
The Converter to view an underlying CacheEvent's value.
- m_convValDown - Variable in class com.tangosol.util.ConverterCollections.ConverterEntry
- 
The Converter used to store the Entry's value.
- m_convValDown - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
The Converter used to pass values down to the Entry Set.
- m_convValDown - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
- 
The Converter used to pass keys down to the Map.
- m_convValUp - Variable in class com.tangosol.util.ConverterCollections.ConverterEntry
- 
The Converter used to view the Entry's value.
- m_convValUp - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
The Converter used to view values stored in the Entry Set.
- m_convValUp - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
- 
The Converter used to view values stored in the Map.
- m_count - Variable in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
The count of processed entries.
- m_count - Variable in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
The count of processed entries.
- m_count - Variable in class com.tangosol.util.aggregator.AbstractDoubleAggregator
- 
The count of processed entries.
- m_count - Variable in class com.tangosol.util.aggregator.AbstractLongAggregator
- 
The count of processed entries.
- m_countThreads - Variable in class com.tangosol.net.cache.AbstractBundler
- 
A counter for the total number of threads that have started any bundle related execution.
- m_cPartitions - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
The partition-count.
- m_cPlanCompletionDelay - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The amount of time in ms to delay the analysis after a distribution suggestion has been made and before it is carried out.
- m_cPruneUnits - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The number of units to prune the cache down to.
- m_cPruneUnits - Variable in class com.tangosol.net.cache.SerializationCache
- 
The number of units to prune the cache down to.
- m_cPutsMillis - Variable in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Total number of milliseconds used for put operations since the last statistics reset.
- m_cReads - Variable in class com.tangosol.util.ReadHeavyLongArray
- 
The (dirty) total number of reads.
- m_cReadTrigger - Variable in class com.tangosol.util.ReadHeavyLongArray
- 
The read count at which to trigger a switch to a lock-free delegate.
- m_cReconnectMillis - Variable in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- 
The reconnect interval to pass to theContinuousQueryCache.
- m_cReconnectMillis - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The interval (in milliseconds) that indicates how often theContinuousQueryCacheshould attempt to synchronize its content with the underlying cache in case the connection is severed.
- m_cRecoveryMillis - Variable in class com.tangosol.net.GuardSupport.Context
- 
The amount of time to allow for recovery
- m_cRecycleMax - Variable in class com.tangosol.util.RecyclingLinkedList
- 
The maximum number of Nodes to recycle.
- m_cRecycleNodes - Variable in class com.tangosol.util.RecyclingLinkedList
- 
The current number of Nodes being recycle.
- m_cRequests - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The number of requests on this partition during the sampling period.
- m_cResults - Variable in class com.tangosol.util.aggregator.TopNAggregator
- 
The maximum number of results to include in the aggregation result.
- m_cSampleMillis - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The sample duration (in ms).
- m_cSegmentCapacity - Variable in class com.tangosol.util.SegmentedHashMap
- 
The capacity of each segment (the point at which we should resize).
- m_cSize - Variable in class com.tangosol.util.KeyValueArrayMap
- 
The number of map entries.
- m_cThreadWaitSnapshot - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
Snapshot for a combined thread waiting time.
- m_cThresholdMillis - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
The amount of time after being in an endangered state before the quorum policy should start to hold client requests.
- m_cTimeoutMillis - Variable in class com.tangosol.net.GuardSupport.Context
- 
The timeout interval to use for the represented Guardable.
- m_ctorFromString - Variable in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Constructor to use for conversion from string.
- m_ctx - Variable in class com.tangosol.io.pof.PofBufferReader
- 
The PofContext to use to realize user data types as Java objects.
- m_ctx - Variable in class com.tangosol.io.pof.PofBufferWriter
- 
The PofContext used by this PofBufferWriter to serialize user types.
- m_ctx - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
The backing map context.
- m_ctx - Variable in class com.tangosol.util.SimpleMapIndex
- 
Thecontextassociated with this index.
- m_ctxLast - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The last analysis context.
- m_cUnits - Variable in class com.tangosol.util.SimpleMapIndex
- 
The size footprint of the index, in units (as defined by the UnitCalculator).
- m_current - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
The current BaseTokens from data
- m_current - Variable in class com.tangosol.util.SafeLinkedList
- 
The Node at the "cached position" in the List.
- m_currentToken - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
The current OPToken translated from current
- m_cWaitMillis - Variable in class com.tangosol.net.SimpleServiceMonitor
- 
The number of milliseconds between checking the status of the services.
- m_cWaitMillis - Variable in class com.tangosol.util.WrapperConcurrentMap
- 
The number of milliseconds to continue trying to obtain a lock in case when the locking is enforced.
- m_cWaitTime - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The total amount of time (in ms) that tasks/requests spent waiting.
- m_daemonRequest - Variable in class com.tangosol.net.LoadBalancer.ResponseHandler
- 
The RequestHandler that this ResponseHandler belongs to.
- m_daemonResponse - Variable in class com.tangosol.net.LoadBalancer.RequestHandler
- 
The ResponseHandler that handles the server-to-client response routing corresponding to requests routed client-to-server by this daemon.
- m_data - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
The source of BaseTokens to process
- m_db - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
The underlying Database Handle.
- m_db - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
The Database handle.
- m_dbConfig - Variable in class com.tangosol.io.bdb.DatabaseFactory
- 
Configuration to use when creating new Databases.
- m_decResult - Variable in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
The running result value.
- m_delegateSocketProvider - Variable in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Underlying TCP socket provider
- m_dependencies - Variable in class com.tangosol.net.TcpDatagramSocketProvider
- 
TcpDatagramSocketProvider Dependencies
- m_dependencies - Variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The cluster dependencies.
- m_Dependencies - Variable in class com.tangosol.net.SocketProviderFactory
- 
Dependencies
- m_dflPruneLevel - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The percentage of the total number of units that will remain after the cache manager prunes the cache (i.e. this is the "low water mark" value); this value is in the range 0.0 to 1.0.
- m_dflResult - Variable in class com.tangosol.util.aggregator.AbstractDoubleAggregator
- 
The running result value.
- m_dir - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
Directory to lock.
- m_dirEnv - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Environment directory.
- m_dirLock - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Lock held on the directory associated with the Environment.
- m_dirParent - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Parent directory for creating Environments.
- m_dirParent - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Configuration setting for parent directory.
- m_dPreviousSizeThreshold - Variable in class com.tangosol.net.cache.AbstractBundler
- 
The previous bundle size threshold value.
- m_element - Variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
- m_eNext - Variable in class com.tangosol.util.SafeHashMap.Entry
- 
The next entry in the linked list (an open hashing implementation).
- m_eNext - Variable in class com.tangosol.util.SegmentedHashMap.Entry
- 
The next entry in the linked list (an open hashing implementation).
- m_entry - Variable in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- 
The underlying entry.
- m_entry - Variable in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- 
The underlying entry.
- m_entry - Variable in class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- 
The result of entry processor invocation.
- m_entry - Variable in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
- m_entryNew - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Cached new entry.
- m_entryOld - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Cached old entry.
- m_env - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Berkeley DB Environment for managing Databases.
- m_env - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The environment that created this AbstractPersistenceManager.
- m_envConfig - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Berkeley DB Environment Configuration.
- m_envHolder - Variable in class com.tangosol.io.bdb.DatabaseFactory
- 
Holder for Environment used to create Databases.
- m_eraseBundler - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The bundler for erase() operations.
- m_eReason - Variable in class com.tangosol.util.aggregator.AsynchronousAggregator
- 
Reason for the failed operation.
- m_eReason - Variable in class com.tangosol.util.processor.AsynchronousProcessor
- 
Reason for the failed operation.
- m_eReason - Variable in class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- 
Reason for the failed operation.
- m_event - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
The underlying MapEvent.
- m_eventQueue - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The event queue for thisContinuousQueryCache.
- m_executor - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
TheStatementExecutorto use to execute statements.
- m_executor - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
TheStatementExecutorto use to execute statements.
- m_extractor - Variable in class com.tangosol.coherence.rest.util.MvelManipulator
- 
The underlying ValueExtractor.
- m_extractor - Variable in class com.tangosol.coherence.rest.util.PropertySpec
- 
An extractor that can extract value of this property from a target object.
- m_extractor - Variable in class com.tangosol.util.aggregator.GroupAggregator
- 
The underlying ValueExtractor.
- m_extractor - Variable in class com.tangosol.util.aggregator.TopNAggregator
- 
The ValueExtractor used by this aggregator.
- m_extractor - Variable in class com.tangosol.util.extractor.CompositeUpdater
- 
The ValueExtractor part.
- m_extractor - Variable in class com.tangosol.util.extractor.ConditionalExtractor
- 
The underlying extractor.
- m_extractor - Variable in class com.tangosol.util.extractor.DeserializationAccelerator
- 
The underlying extractor.
- m_extractor - Variable in class com.tangosol.util.extractor.KeyExtractor
- 
The underlying ValueExtractor.
- m_extractor - Variable in class com.tangosol.util.filter.ExtractorFilter
- 
The ValueExtractor used by this filter.
- m_extractor - Variable in class com.tangosol.util.filter.ValueChangeEventFilter
- m_extractor - Variable in class com.tangosol.util.processor.ExtractorProcessor
- 
The underlying value extractor.
- m_extractor - Variable in class com.tangosol.util.processor.PropertyManipulator
- 
The underlying ValueExtractor.
- m_extractor - Variable in class com.tangosol.util.SimpleMapIndex
- 
ValueExtractor object that this MapIndex uses to extract an indexable property value from a [converted] value stored in the resource map.
- m_fActivated - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Indicates whether this factory has been activated.
- m_fActive - Variable in class com.tangosol.util.AbstractKeyBasedMap.DeferredCacheEvent
- 
Whether the DeferredCacheEvent is in an active or inactive state.
- m_factory - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Factory used to create this Database.
- m_factoryCacheLoader - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
TheFactoryfor theCacheLoader.
- m_factoryCacheWriter - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
TheFactoryfor theCacheWriter.
- m_factoryExpiryPolicy - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
TheFactoryfor theExpiryPolicy.
- m_fAddStorageMBeanAttributes - Variable in class com.tangosol.net.management.MBeanAccessor.GetAttributes
- 
Provide a way to disable management over rest assumption that we want storage mbean attributes when processing a back tier cache.
- m_fAttribute - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
True if the property is stored in an attribute instead of an XML element.
- m_fBlind - Variable in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
True means that put() and remove() can return null, regardless of the presence of an old value.
- m_fBlocking - Variable in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Specifies if the provider is to produce blocking datagram sockets.
- m_fBreakLines - Variable in class com.tangosol.io.Base64OutputStream
- 
True if lines are to be broken by BASE64_LF;
- m_fByMember - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
Differentiates between by-member and by-partition iteration.
- m_fCacheValues - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The option of whether or not to locally cache values.
- m_fCacheValues - Variable in class com.tangosol.net.MapViewBuilder
- 
Flag controlling if theviewwill store both keys and values or only keys.
- m_fCircular - Variable in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
- 
Whether this Iterator is currently in a circular mode.
- m_fClosed - Variable in class com.tangosol.io.Base64InputStream
- 
True after close is invoked.
- m_fClosed - Variable in class com.tangosol.io.Base64OutputStream
- 
True after close is invoked.
- m_fClosed - Variable in class com.tangosol.io.MultiByteArrayOutputStream
- 
True after close is invoked.
- m_fCompleted - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- m_fContainer - Variable in class com.tangosol.coherence.rest.server.InjectionBinder
- 
The flag specifying whether REST API is run inside the container (true) or standalone (false).
- m_fDeepClone - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Specifies whether the XML bean requires a deep clone.
- m_fDeferredEvent - Variable in class com.tangosol.util.WrapperObservableMap
- 
Specifies whether or not fabricated events could be deferred.
- m_fDestroyed - Variable in class com.tangosol.net.cache.NearCache
- 
True if {#link destroy()} has been called on this cache.
- m_fDestructive - Variable in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
True if the BufferInput set to self-destruct.
- m_fDestructive - Variable in class com.tangosol.io.MultiByteArrayInputStream
- 
True iff the array will be null'd out as it is traversed.
- m_fDisposed - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Indicates whether this factory has been disposed.
- m_fDisposed - Variable in class com.tangosol.net.SimpleServiceMonitor
- 
Indicates that thisServiceMonitorhas been disposed.
- m_fDynamic - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
If set to true, indicates a dynamic active recovery strategy.
- m_fEmptyIsNull - Variable in class com.tangosol.run.xml.IterableAdapter
- 
Empty-is-null option: Empty iterable values are not stored in the serialized form of the XmlBean nor in the XML form of the XmlBean.
- m_fEnableConfigDiscovery - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
A flag to enable POF config discovery.
- m_fEnableTypeDiscovery - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
True iff discovery of PortableTypes is enabled.
- m_fEnforceLocking - Variable in class com.tangosol.util.WrapperConcurrentMap
- 
Flag indicating whether or not the locking is enforced for put, remove and clear operations.
- m_fEOF - Variable in class com.tangosol.io.Base64InputStream
- 
True after eof is determined.
- m_fEOF - Variable in class com.tangosol.io.MultiByteArrayInputStream
- 
True after eof is determined.
- m_fEraseAllSupported - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Flag that determines whether or not EraseAll operations are supported by the wrapped store.
- m_fEraseSupported - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Flag that determines whether or not Erase operations are supported by the wrapped store.
- m_fEraseUnsupported - Variable in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
True means that a call to the CacheStore erase() method is assumed to be unsupported.
- m_fEvolvable - Variable in class com.tangosol.io.pof.PofBufferWriter
- 
Indicate if the object to be written is either Evolvable or part of an Evolvable object.
- m_fExact - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Whether to construct a query without a wildcard suffix (exact) or with.
- m_fExhausted - Variable in class com.tangosol.net.CompositeAddressProvider.SingleProvider
- 
Is this AddressProvider exhausted?
- m_fExitWhenProcessingComplete - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
A flag indicating whether a CohQL session should be exited when the list of statements has been executed.
- m_fExtended - Variable in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageQueryPlusStatement
- 
Flag indicating whether this command turns trace on or off.
- m_fExtendedLanguage - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Flag that controls whether we except Map, and List as literals.
- m_fExtendedLanguage - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Flag that controls whether we except Map, and List as literals.
- m_fFederated - Variable in class com.tangosol.coherence.config.CacheMapping
- 
The flag to indicate if thisCacheMappingis federated.
- m_fForward - Variable in class com.tangosol.util.SimpleEnumerator
- 
Iterator direction.
- m_fForwardIndex - Variable in class com.tangosol.util.extractor.ConditionalExtractor
- 
Specifies whether or not this extractor will create aConditionalIndexthat supports a forward index.
- m_fForwardIndex - Variable in class com.tangosol.util.SimpleMapIndex
- 
Specifies whether or not this MapIndex supports a forward index.
- m_filter - Variable in class com.tangosol.net.cache.CachingMap.FrontMapListener
- 
The filter associated with this listener.
- m_filter - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The filter that represents the subset of information from the underlyingNamedCachethat thisContinuousQueryCacherepresents.
- m_filter - Variable in class com.tangosol.net.management.MBeanAccessor.GetAttributes
- 
MBean Attribute filter.
- m_filter - Variable in class com.tangosol.net.management.ObjectNameExcludeFilter
- 
The underlying filter.
- m_filter - Variable in class com.tangosol.net.MapViewBuilder
- 
TheFilterthat will be used to define the entries maintained in this view.
- m_filter - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
The filter to query with.
- m_filter - Variable in class com.tangosol.util.aggregator.GroupAggregator
- 
The Filter object representing the "having" clause of this "group by" aggregator.
- m_filter - Variable in class com.tangosol.util.extractor.ConditionalExtractor
- 
The filter used by this extractor.
- m_filter - Variable in class com.tangosol.util.filter.FilterTrigger
- 
The underlying filter.
- m_filter - Variable in class com.tangosol.util.filter.MapEventFilter
- 
The event value(s) filter.
- m_filter - Variable in class com.tangosol.util.processor.ConditionalProcessor
- 
The underlying filter.
- m_filter - Variable in class com.tangosol.util.processor.ConditionalPut
- 
The underlying filter.
- m_filter - Variable in class com.tangosol.util.processor.ConditionalPutAll
- 
The underlying filter.
- m_filter - Variable in class com.tangosol.util.processor.ConditionalRemove
- 
The underlying filter.
- m_filterAdd - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
TheMapEventFilterthat uses theContinuousQueryCache'sfilter to select events that would add elements to this cache's contents.
- m_filterRemove - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
TheMapEventFilterthat uses theContinuousQueryCache'sfilter to select events that would remove elements from this cache's contents.
- m_fImmutableValues - Variable in class com.tangosol.util.SimpleMapIndex
- 
Specifies whether or not the index is based on the immutable values (e.g. keys).
- m_fIncrementalEvict - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specifies whether or not this cache will incrementally evict.
- m_fInit - Variable in class com.tangosol.util.aggregator.CompositeAggregator
- 
Flag specifying whether this aggregator has been initialized.
- m_fInit - Variable in class com.tangosol.util.aggregator.GroupAggregator
- 
Flag specifying whether this aggregator has been initialized.
- m_fInsert - Variable in class com.tangosol.util.processor.VersionedPut
- 
Specifies whether or not an insert is allowed.
- m_fInsert - Variable in class com.tangosol.util.processor.VersionedPutAll
- 
Specifies whether or not an insert is allowed.
- m_fInterfaceAllowed - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
True iff an interface name is acceptable in the configuration as the class of a user type.
- m_fIsEnd - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The flag set when end of file is detected.
- m_fKeysOnly - Variable in class com.tangosol.net.partition.PartitionedIterator
- 
Differentiates between a key iterator (true) and an entry iterator (false).
- m_fLazy - Variable in class com.tangosol.util.extractor.DeserializationAccelerator
- 
The "lazy" flag.
- m_flGrowthRate - Variable in class com.tangosol.util.SafeHashMap
- 
The rate of growth as a fraction of the current number of buckets, 0 < n, such that the hash map grows to bucketCount * (1 + growthRate)
- m_flGrowthRate - Variable in class com.tangosol.util.SegmentedHashMap
- 
The rate of growth as a fraction of the current number of buckets, 0 < n, such that the hash map grows to bucketcount * (1 + growth-rate).
- m_fListeners - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
Keeps track of whether theContinuousQueryCachehas listeners that require this cache to cache values.
- m_flLoadFactor - Variable in class com.tangosol.util.SafeHashMap
- 
The determining factor for the hash map capacity given a certain number of buckets, such that capacity = bucketCount * loadFactor.
- m_flLoadFactor - Variable in class com.tangosol.util.SegmentedHashMap
- 
The determining factor for the hash map capacity given a certain number of buckets, such that capacity = bucketcount * loadfactor.
- m_flPctRecover - Variable in class com.tangosol.net.GuardSupport.Context
- 
Percentage of the timeout after which to attempt recovery of the Guardable.
- m_flThresholdPct - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
- 
Action policy threshold in percentage.
- m_fManagementEnabled - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
Is JMX management enabled?
- m_fMutator - Variable in class com.tangosol.util.processor.MethodInvocationProcessor
- 
A flag specifying whether the method mutates the state of a target object.
- m_fNewValue - Variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- 
Determines whether this entry represents the old or new value.
- m_fNext - Variable in class com.tangosol.util.FilterEnumerator
- 
Is there a next item which passed the test?
- m_fNullFirst - Variable in class com.tangosol.util.comparator.SafeComparator
- 
Flag specifying if nulls should be sorted as less (first) or greater (last) than all non-null elements.
- m_fOptimizeGetTime - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specifies whether or not this cache is used in the environment, where theBase.getSafeTimeMillis()is used very frequently and as a result, theBase.getLastSafeTimeMillis()could be used without sacrificing the clock precision.
- m_fOptimizeMV - Variable in class com.tangosol.util.extractor.ConditionalExtractor
- 
For an indexed value that is a multi-value (Collection or array) this flag specifies whether an attempt should be made to search the forward map for an existing reference that is "equal" to the specified multi-value and use it instead (if available) to reduce the index memory footprint.
- m_fOrdered - Variable in class com.tangosol.util.SimpleMapIndex
- 
Specifies whether or not this MapIndex orders the contents of the indexed information.
- m_fParallel - Variable in class com.tangosol.util.aggregator.AbstractAggregator
- 
Set to true if this aggregator realizes that it is going to be used in parallel.
- m_fParallel - Variable in class com.tangosol.util.aggregator.CompositeAggregator
- 
Flag specifying whether parallel optimizations can be used.
- m_fParallel - Variable in class com.tangosol.util.aggregator.GroupAggregator
- 
Flag specifying whether parallel optimizations can be used.
- m_fParallel - Variable in class com.tangosol.util.aggregator.TopNAggregator
- 
True iff this aggregator is to be used in parallel.
- m_fPreferJavaTime - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
True if Java 8 date/time types (java.time.*) should be preferred over legacy types.
- m_fPreferJavaTime - Variable in class com.tangosol.io.pof.SimplePofContext
- 
True if Java 8 date/time types (java.time.*) should be preferred over legacy types.
- m_fPrefixAllowed - Variable in class com.tangosol.coherence.dsltools.precedence.InfixOPToken
- 
Flag that control whether the operator can be used as a prefix.
- m_fPrev - Variable in class com.tangosol.util.FilterEnumerator
- 
Is there a previous item which passed the test and can be removed?
- m_fPrimary - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.LoadComparator
- 
Flag for primary or backup load comparison.
- m_fPrimary - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
- 
True iff this filter represents primary partition load.
- m_fRandom - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
An option to randomize the order of iteration to avoid harmonics in a clustered environment.
- m_fReadOnly - Variable in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- 
The read-only flag to pass to theContinuousQueryCache.
- m_fReadOnly - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The option to disallow modifications through thisContinuousQueryCacheinterface.
- m_fReadThrough - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
Is "read-through" enabled?
- m_fReferenceEnabled - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
True iff POF Identity/Reference type support is enabled.
- m_fReferenceEnabled - Variable in class com.tangosol.io.pof.SimplePofContext
- 
True if POF Identity/Reference type support is enabled.
- m_fRefresh - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
True if JMXPartitionStats should be updated.
- m_fRefreshContext - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.ReadThread
- 
Field used to tell theReadWriteBackingMap.ReadThreadto refresh itsGuardian.GuardContext.
- m_fRefreshContext - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.WriteThread
- 
Field used to tell theReadWriteBackingMap.WriteThreadto refresh itsGuardian.GuardContext.
- m_fReleased - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
Whether this PersistenceManager has been released.
- m_fResolve - Variable in class com.tangosol.net.ConfigurableAddressProvider
- 
Deprecated.
- m_fRetained - Variable in class com.tangosol.util.SubSet
- 
Toggles between whether the modifications are removed or retained.
- m_fReturn - Variable in class com.tangosol.util.processor.ConditionalPut
- 
Specifies whether or not a return value is required.
- m_fReturn - Variable in class com.tangosol.util.processor.ConditionalRemove
- 
Specifies whether or not a return value is required.
- m_fReturn - Variable in class com.tangosol.util.processor.VersionedPut
- 
Specifies whether or not a return value is required.
- m_fReturn - Variable in class com.tangosol.util.processor.VersionedPutAll
- 
Specifies whether or not a return value is required.
- m_fRoundRobin - Variable in class com.tangosol.net.LoadBalancer
- 
Toggles between random and round-robin load balancing.
- m_fSafe - Variable in class com.tangosol.net.ConfigurableAddressProvider
- 
Specifies if the provider is only to return resolved addresses.
- m_fSanity - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
A flag that enables sanity checking.
- m_fSanity - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
A flag that enables sanity checking.
- m_fServicesStarted - Variable in class com.tangosol.net.DefaultCacheServer
- 
Flag that indicates whether this instance of DefaultCacheServer has called start on the associated services.
- m_fSharedStorage - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Specifies whether or not the storage is shared.
- m_fShutdown - Variable in class com.tangosol.net.DefaultCacheServer
- 
Flag that indicates whether of not the shutdown was initiated.
- m_fSilent - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
A flag indicating whether the query session is running in silent mode.
- m_fSilent - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
A flag indicating whether the query session is running in silent mode.
- m_fSparse - Variable in class com.tangosol.run.xml.IterableAdapter
- 
Sparse array storage option.
- m_fSplitCollection - Variable in class com.tangosol.util.SimpleMapIndex
- 
If a value extracted by the ValueExtractor is a Collection, this property specifies whether or not it should be treated as a Collection of contained attributes or indexed as a single composite attribute.
- m_fStarted - Variable in class com.tangosol.net.SimpleServiceMonitor
- 
Indicates that theServiceMonitorhas started.
- m_fStatisticsEnabled - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
Are statistics enabled?
- m_fStopOnError - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
A flag indicating when true that CohQL should stop processing multiple statements if an error occurs (for example when processing a file), or when false that errors will be logged and statement processing will continue.
- m_fStopOnError - Variable in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder.WheneverQueryPlusStatement
- 
The QueryPlus error action.
- m_fStoreAllSupported - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Flag that determines whether or not StoreAll operations are supported by the wrapped store.
- m_fStoreByValue - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
Is store-by-reference enabled?
- m_fStoreSupported - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Flag that determines whether or not Store operations are supported by the wrapped store.
- m_fStoreUnsupported - Variable in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
True means that a call to the CacheStore store() method is assumed to be unsupported.
- m_fStreaming - Variable in class com.tangosol.util.aggregator.CompositeAggregator
- 
Flag specifying whether streaming optimizations can be used.
- m_fStreaming - Variable in class com.tangosol.util.aggregator.GroupAggregator
- 
Flag specifying whether streaming optimizations can be used.
- m_fstreamLocked - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
The FileStream which the actual lock is held on.
- m_fStrict - Variable in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Specifies whether or not the "read-only" nature of this NamedCache is strictly enforced.
- m_fStrict - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntrySet
- 
Determines whether or not all of the Entry methods are protected; if set to true, then all Entry methods are protected.
- m_fStrict - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
Determines whether or not all of the Entry methods are protected; if set to true, then all Entry methods are protected.
- m_fStripTrailingZeros - Variable in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Shall trailing zeros be removed from the aggregation result?
- m_fSubclassAllowed - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
True iff serialization of sub-classes is explicitly enabled.
- m_fSynthetic - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Whether this update is synthetic.
- m_fTemporary - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
Flag indicating if the database is temporary.
- m_fTemporary - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Flag indicating if this store manages temporary data.
- m_fTemporary - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Flag indicating if this is a temporary environment.
- m_fTrace - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Flag that indicates tracing mode.
- m_fTrace - Variable in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder.TraceQueryPlusStatement
- 
Flag indicating whether this command turns trace on or off.
- m_fTraceEnabled - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Flag that indicates tracing mode.
- m_fTranslateEvents - Variable in class com.tangosol.util.WrapperObservableMap
- 
Specifies whether or not events are translated by this wrapper.
- m_fUseIs - Variable in class com.tangosol.util.processor.PropertyManipulator
- 
The getter prefix flag.
- m_fUserTypeBegin - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
True iff the type and version identifier of the user type was written to the POF stream.
- m_fUserTypeEnd - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
True iff the user type was written to the POF stream.
- m_fValidate - Variable in class com.tangosol.run.xml.SimpleParser
- 
If true, validate XML if it contains an XSD reference
- m_fWriteThrough - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
Is "write-through" enabled?
- m_gateLockAll - Variable in class com.tangosol.util.SegmentedConcurrentMap
- 
The Gate controlling LOCK_ALL access for this map.
- m_gateMap - Variable in class com.tangosol.util.WrapperConcurrentMap
- 
The ThreadGate object for the entire map.
- m_guardian - Variable in class com.tangosol.net.GuardSupport
- 
The Guardian that is managing this GuardSupport.
- m_handler - Variable in class com.tangosol.io.pof.PofBufferWriter
- 
The WritingPofHandler used to write a POF stream.
- m_head - Variable in class com.tangosol.util.AbstractSparseArray
- 
The first node of the tree (or null if the tree is empty).
- m_head - Variable in class com.tangosol.util.SafeLinkedList
- 
The first Node in the List (or null if empty).
- m_holder - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
TheCacheRequestHolderto hold theMapListenerRequestthat can convert between different serialization formats.
- m_iArray - Variable in class com.tangosol.io.MultiByteArrayInputStream
- 
The index of the current byte array.
- m_iArrayMarked - Variable in class com.tangosol.io.MultiByteArrayInputStream
- 
The index of the marked byte array.
- m_iFirst - Variable in class com.tangosol.util.CircularArrayList
- 
The offset to the first element.
- m_iItem - Variable in class com.tangosol.util.SimpleEnumerator
- 
Iterator position: next item to return.
- m_iKey - Variable in class com.tangosol.util.KeyValueArrayMap
- 
The index into the key array of the first key.
- m_iLast - Variable in class com.tangosol.net.ConfigurableAddressProvider
- 
Index of the last returned address.
- m_iLast - Variable in class com.tangosol.util.CircularArrayList
- 
The offset to one past the last element.
- m_impl - Variable in class com.tangosol.net.TcpDatagramSocket
- m_in - Variable in class com.tangosol.io.pof.PofBufferReader
- 
The BufferInput containing the POF stream.
- m_in - Variable in class com.tangosol.io.WrapperDataInputStream
- 
The underlying DataInput object to use.
- m_index - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
The container index.
- m_iNextDestination - Variable in class com.tangosol.net.LoadBalancer
- 
Round-robin index.
- m_iNextIter - Variable in class com.tangosol.util.ChainedEnumerator
- 
The next Iterator (index into the m_listIter) to iterate.
- m_info - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.The CacheInfo for the enclosed backing maps.
- m_infoBean - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The BeanInfo object that contains this PropertyAdapter.
- m_infoQuorum - Variable in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
- 
The "last good" service membership.
- m_iOrderId - Variable in class com.tangosol.util.AsynchronousAgent
- 
A unit-of-order id associated with this agent.
- m_iPos - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The current position in the underlying Reader.
- m_iPos - Variable in class com.tangosol.util.SafeLinkedList
- 
The "cached position" in the List.
- m_iPrevProp - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
The index of the last property written to the POF stream or -1 if the first property has yet to be written.
- m_iProp - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
The index of the user type being written.
- m_iStartPos - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The saved start position for a token.
- m_iStore - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
- 
The storage index at which to evaluate members for safety.
- m_iter - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
- 
The underlying Iterator.
- m_iter - Variable in class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Iterator of Objects to convert.
- m_iter - Variable in class com.tangosol.util.ConverterCollections.ConverterListIterator
- 
The underlying ListIterator.
- m_iter - Variable in class com.tangosol.util.FilterEnumerator
- 
Objects to filter/enumerate.
- m_iter - Variable in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
- m_iter - Variable in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
The underlying ListIterator.
- m_iterAddr - Variable in class com.tangosol.net.ConfigurableAddressProvider
- 
An address iterator for the previously resolved address.
- m_iterAddress - Variable in class com.tangosol.net.CompositeAddressProvider.AddressIterator
- 
The iterator of Addresses from the current provider.
- m_iterator - Variable in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
- 
The iterator used to implement the AddressProvider interface.
- m_iterator - Variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
- m_iteratorInternal - Variable in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
The internal Iterator
- m_iterCurrent - Variable in class com.tangosol.util.ChainedEnumerator
- 
The current Iterator.
- m_iterEvict - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.For deferred eviction, iterator of entries to evict.
- m_iterInternal - Variable in class com.tangosol.net.CompositeAddressProvider
- 
The default iterator used to implement the AddressProvider interface.
- m_iterKeys - Variable in class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
- 
Key iterator.
- m_iterKeys - Variable in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.EntrySetIterator
- 
Key iterator.
- m_iterKeys - Variable in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection.ValuesIterator
- 
A key iterator.
- m_iterPage - Variable in class com.tangosol.util.PagedIterator
- 
An Iterator for the current page.
- m_iterProvider - Variable in class com.tangosol.net.CompositeAddressProvider.AddressIterator
- 
The iterator of AddressProviders.
- m_iValue - Variable in class com.tangosol.util.KeyValueArrayMap
- 
The index into the value array of the first value.
- m_key - Variable in class com.tangosol.util.MapEvent
- 
A key.
- m_keyConverter - Variable in class com.tangosol.coherence.rest.CacheResource
- 
Key converter.
- m_laClass - Variable in class com.tangosol.io.pof.SimplePofContext
- 
A LongArray of user types, indexed by type identifier.
- m_language - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
TheCoherenceQueryLanguageto use.
- m_laSerializer - Variable in class com.tangosol.io.pof.SimplePofContext
- 
A LongArray of PofSerializer objects, indexed by type identifier.
- m_laVersions - Variable in class com.tangosol.net.partition.DefaultVersionedPartitions
- 
A data structure for holding partition -> version mapping.
- m_ldtCompleted - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The timestamp of when the analysis represented by this context was completed, or 0 if it is not yet complete.
- m_ldtConnectionTimestamp - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The timestamp when the synchronization was last attempted.
- m_ldtEndangered - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
The time at which the service most recently became endangered (or 0 if the service is in the "safe" state).
- m_ldtExpiry - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
The expiry timestamp for this entry; orCacheMap.EXPIRY_DEFAULTif the entry uses the default expiry setting; orCacheMap.EXPIRY_NEVERif the entry never expires
- m_ldtLastMissedSoftTimeout - Variable in class com.tangosol.net.GuardSupport.Context
- 
The soft-timeout stamp that was violated, resulting in a recovery attempt.
- m_ldtLastRefresh - Variable in class com.tangosol.net.RefreshableAddressProvider
- 
The last timestamp when the address list was refreshed.
- m_ldtLastReport - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
The last time disallowed actions were reported.
- m_ldtLastTransfer - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The time at this this partition was last transferred.
- m_ldtLogMissingIdx - Variable in class com.tangosol.util.SimpleMapIndex
- 
The time at which the most recent logging of "missing inverse index" messages started.
- m_ldtNextCheck - Variable in class com.tangosol.net.GuardSupport
- 
The next time at which the Guardables should be checked.
- m_ldtSampleStart - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The sample start time.
- m_ldtSoftTimeout - Variable in class com.tangosol.net.GuardSupport.Context
- 
The next soft-timeout for the Guardable
- m_ldtTimeout - Variable in class com.tangosol.net.GuardSupport.Context
- 
The next timeout for the Guardable.
- m_lIndexLast - Variable in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- 
The index associated with the last returned value
- m_lineNumber - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The current line number.
- m_list - Variable in class com.tangosol.net.LoadBalancer.Queue
- 
A list of items that have been queued.
- m_listBlock - Variable in class com.tangosol.io.MultiByteArrayOutputStream
- 
The list of blocks.
- m_listBundle - Variable in class com.tangosol.net.cache.AbstractBundler
- 
A pool of Bundle objects.
- m_listCache - Variable in class com.tangosol.net.RefreshableAddressProvider
- 
The cached addresses.
- m_listener - Variable in class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
- 
The MapListener to route to.
- m_listener - Variable in class com.tangosol.net.MapViewBuilder
- 
TheMapListenerthat will receive all the events from theview, including those corresponding to its initial population.
- m_listenerAdd - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
Thelistenerthat gets information about what should be in this cache.
- m_listenerDeactivation - Variable in class com.tangosol.net.cache.CachingMap
- 
The NamedCache deactivation listener.
- m_listenerDeactivation - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
TheNamedCacheDeactivationListener.
- m_listenerInternal - Variable in class com.tangosol.util.WrapperObservableMap
- 
The MapListener used to listen to the wrapped ObservableMap.
- m_listenerRemove - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
Thelistenerthat gets information about what should be thrown out of this cache.
- m_listenersCached - Variable in class com.tangosol.util.MapListenerSupport
- 
A cached set of Listeners.
- m_listenerService - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The cache serviceMemberListenerfor the underlyingNamedCache.
- m_listenerSupport - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
Locallistener supportto allow theContinuousQueryCacheto intercept all events dispatched by the internalObservableMap.
- m_listenerSupport - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The MapListenerSupport object.
- m_listenerSupport - Variable in class com.tangosol.net.cache.ReadWriteBackingMap
- 
MapListenerSupport object.
- m_listenerSupport - Variable in class com.tangosol.util.ObservableHashMap
- 
The MapListenerSupport object.
- m_listenerSupport - Variable in class com.tangosol.util.WrapperObservableMap
- 
The event listeners.
- m_listFiles - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
A list of statement script files to execute when the CohQL session starts.
- m_listHandler - Variable in class com.tangosol.net.LoadBalancer
- 
The list of RequestHandler daemons.
- m_listHolders - Variable in class com.tangosol.net.ConfigurableAddressProvider
- 
A read-only list of ProvidedAddress objects.
- m_listIter - Variable in class com.tangosol.util.ChainedEnumerator
- 
The Iterators.
- m_listLifecycleListener - Variable in class com.tangosol.net.DefaultCacheServer
- 
TheLifecycleListeners to be notified of lifecycle events for thisDefaultCacheServer.
- m_listListenerConfigurations - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- 
TheCacheEntryListenerConfigurations.
- m_listResultEntries - Variable in class com.tangosol.util.processor.AsynchronousProcessor
- 
List of result value entries.
- m_listStatements - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
A list of statements to execute when the CohQL session starts.
- m_listSteps - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
The map of steps.
- m_listSubSteps - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
The list of child steps.
- m_lLastPrune - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The last time that a prune was run.
- m_lNextFlush - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The time before which a expired-entries flush will not be performed.
- m_loadBundler - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The bundler for load() operations.
- m_loader - Variable in class com.tangosol.io.WrapperDataInputStream
- 
The class loader used to resolve deserialized classes.
- m_loader - Variable in class com.tangosol.net.cache.CacheLoaderCacheStore
- 
The CacheLoader to delegate to.
- m_loader - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
TheClassLoaderto use when de-serializing/serializing keys and values.
- m_loader - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.The ClassLoader to pass to the enclosed backing maps.
- m_loader - Variable in class com.tangosol.net.MapViewBuilder
- 
The View'sClassLoader.
- m_loadLocal - Variable in class com.tangosol.net.proxy.DefaultProxyServiceLoadBalancer
- 
The ServiceLoad associated with the "local" Member.
- m_lock - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- 
The read/write lock for concurrency control.
- m_lock - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- 
The read/write lock for concurrency control.
- m_lock - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
The read/write lock for concurrency control.
- m_lockDir - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
The actual FileLock.
- m_lockExclusive - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- 
The exclusive lock for performing read/write operations.
- m_lockExclusive - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- 
The exclusive lock for performing read/write operations.
- m_lockExclusive - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
The exclusive lock for performing read/write operations.
- m_lockFile - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The FileLock used to prevent concurrent access to the data directory underlying this persistent store.
- m_lockRead - Variable in class com.tangosol.util.ReadHeavyLongArray
- 
The mutable read lock.
- m_lockShared - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- 
The shared lock for performing read operations.
- m_lockShared - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- 
The shared lock for performing read operations.
- m_lockShared - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
The shared lock for performing read operations.
- m_lResult - Variable in class com.tangosol.util.aggregator.AbstractLongAggregator
- 
The running result value.
- m_lValue - Variable in class com.oracle.coherence.common.base.MutableLong
- 
The value.
- m_lValue - Variable in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
- 
The Node's value.
- m_manager - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
TheCoherenceBasedCacheManagerthat owns theCache.
- m_manager - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The DistributionManager.
- m_managerActive - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
This singleton active manager.
- m_managerBackup - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
This singleton backup manager.
- m_managerEvents - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
This singleton events manager.
- m_manipulator - Variable in class com.tangosol.util.processor.PropertyProcessor
- 
The property value manipulator.
- m_map - Variable in class com.tangosol.util.aggregator.ReducerAggregator
- 
The resulting map of reduced values.
- m_map - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
- 
The underlying Map.
- m_map - Variable in class com.tangosol.util.ConverterCollections.ConverterMapListener
- 
The converting Map the will be the source of converted events.
- m_map - Variable in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
The map.
- m_map - Variable in class com.tangosol.util.MapSet
- 
The underlying Map.
- m_map - Variable in class com.tangosol.util.processor.ConditionalPutAll
- 
Specifies the map of new values.
- m_map - Variable in class com.tangosol.util.processor.VersionedPutAll
- 
Specifies the map of new values.
- m_map - Variable in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
The underlying Map.
- m_map - Variable in class com.tangosol.util.SortedBag
- 
The internal sorted map holding the bag contents.
- m_map - Variable in class com.tangosol.util.WrapperObservableMap
- 
The (wrapped) map containing all the resources.
- m_mapAttribute - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.Map of scheme attributes.
- m_mapAttributes - Variable in class com.tangosol.net.management.MBeanAccessor.SetAttributes
- 
The AttributeList to be updated.
- m_mapBack - Variable in class com.tangosol.net.cache.SimpleOverflowMap
- 
The "back" map, which the front overflows to.
- m_mapBackingMap - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.The map of backing maps keyed by corresponding cache names.
- m_mapBackingMapListeners - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.The map of backing map listeners keyed by the corresponding backing map references.
- m_mapByLoader - Variable in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Mapping used to associate class loaders with the cache factories that are configured on them.
- m_mapClassNameByTypeId - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
Once initialized, this references a thread-safe Map that contains mappings from POF type identifiers (wrapped as Integer objects) to Java class names.
- m_mapConcurrent - Variable in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
A Converter ConcurrentMap around the underlying NamedCache.
- m_mapConfigByLoader - Variable in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Mapping used to associate class loaders with specific configuration elements.
- m_mapDatagramSocketProvider - Variable in class com.tangosol.net.SocketProviderFactory
- 
A map of instantiated datagram socket providers, keyed by id.
- m_mapDelegate - Variable in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- 
The Map to which this wrapper delegates.
- m_mapDelegate - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
The Map to which this wrapper delegates.
- m_mapEvolvable - Variable in class com.tangosol.io.pof.EvolvableHolder
- 
Map of Evolvable objects, keyed by type id.
- m_mapFactories - Variable in class com.tangosol.io.bdb.DatabaseFactoryManager
- 
Map of DatabaseFactory objects keyed by XmlElement configuration.
- m_mapFilters - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
A map of ObjectName key to Filter.
- m_mapFilters - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
- 
A map of ObjectName key to Filter.
- m_mapFirst - Variable in class com.tangosol.util.ChainedMap
- 
The first map.
- m_mapForward - Variable in class com.tangosol.util.SimpleMapIndex
- 
Map that contains the index values (forward index).
- m_mapFront - Variable in class com.tangosol.net.cache.SimpleOverflowMap
- 
The "front" map, which is size-limited.
- m_mapFunctions - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
The map of CohQL functions.
- m_mapIdentities - Variable in class com.tangosol.io.pof.PofBufferWriter.ReferenceLibrary
- 
A map from objects that can be referenced to their Integer identities.
- m_mapIndex - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The map of indexes maintained by this cache.
- m_mapInverse - Variable in class com.tangosol.util.SimpleMapIndex
- 
Map that contains the index contents (inverse index).
- m_mapInvocable - Variable in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
A Converter InvocableMap around the underlying NamedCache.
- m_mapKeyListeners - Variable in class com.tangosol.util.MapListenerSupport
- 
The collections of MapListener objects that have signed up for key based notifications from an ObservableMap implementation keyed by the corresponding key objects.
- m_mapListener - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The optionalMapListenerthat may be provided duringContinuousQueryCacheconstruction.
- m_mapListeners - Variable in class com.tangosol.util.MapListenerSupport
- 
The collections of MapListener objects that have signed up for notifications from an ObservableMap implementation keyed by the corresponding Filter objects.
- m_mapLoad - Variable in class com.tangosol.net.SimpleServiceLoadBalancer
- 
A Map of ServiceLoad objects keyed by their associated Member.
- m_mapLocal - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The keys that are in thisContinuousQueryCache, and (ifContinuousQueryCache.m_fCacheValuesis true) the corresponding values as well.
- m_mapLock - Variable in class com.tangosol.util.WrapperConcurrentMap
- 
The map containing all the locks.
- m_mapMember - Variable in class com.tangosol.net.SimpleServiceLoadBalancer
- 
A SortedMap of List of Member objects keyed by their associated ServiceLoad.
- m_mapMiss - Variable in class com.tangosol.net.cache.SimpleOverflowMap
- 
The miss cache; may be null.
- m_mapNamedQueries - Variable in class com.tangosol.coherence.rest.config.QueryConfig
- 
Named query mappings.
- m_mapOperators - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
The map of CohQL operators.
- m_mapOuter - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache.CapacityAwareMap
- 
The ObservableSplittingBackingMap used to call prepareUpdate.
- m_mapOwnedPartitions - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The map of member ownership information for this analysis context.
- m_mapParsedQuery - Variable in class com.tangosol.coherence.rest.query.AbstractQueryEngine
- 
Map of cached ParsedQuery instances, keyed by their corresponding final query string.
- m_mapper - Variable in class com.tangosol.net.MapViewBuilder
- 
TheValueExtractorthat will be used to transform values retrieved from the underlying map before storing them locally; if specified, thisviewwill becomeread-only.
- m_mapPortableTypes - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
Discovered list of types that are annotated withPortableType.
- m_mapProperties - Variable in class com.tangosol.coherence.rest.util.PartialObject
- 
Property values for this object.
- m_mapProvider - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
A map of provider types, keyed by id.
- m_mapQuery - Variable in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
A Converter QueryMap around the underlying NamedCache.
- m_mapQueryEngines - Variable in class com.tangosol.coherence.rest.query.QueryEngineRegistry
- 
A map of registered QueryEngines, keyed by engine names.
- m_mapQuorumByRole - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
The cluster membership quorum map, keyed by role name.
- m_mapResolved - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
The resolved map of members to the associated set of partitions.
- m_mapResults - Variable in class com.tangosol.util.aggregator.GroupAggregator
- 
A map of partial results to aggregate.
- m_mapSecond - Variable in class com.tangosol.util.ChainedMap
- 
The second map.
- m_mapServices - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Map used to hold references to services that are ensured by this factory where values are non-scoped service names.
- m_mapServices - Variable in class com.tangosol.net.SimpleServiceMonitor
- 
A map ofServices to be monitored with values being non-scoped service names.
- m_mapSocketProvider - Variable in class com.tangosol.net.SocketProviderFactory
- 
A map of instantiated socket providers, keyed by id.
- m_mapSSLDependencies - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
A map of SSL provider dependencies, keyed by id.
- m_mapSSLDependenciesBuilder - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
A map of SSL provider dependencies builder, keyed by id.
- m_mapStandardKeyListeners - Variable in class com.tangosol.util.MapListenerSupport
- 
The subset of standard (not lite) key listeners.
- m_mapStandardListeners - Variable in class com.tangosol.util.MapListenerSupport
- 
The subset of standard (not lite) global listeners.
- m_mapStatementBuilders - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
The map of CohQL query builders.
- m_mapSteps - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.AbstractRecordableStep
- 
The Map of child steps.
- m_mapSuggestLast - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The Map containing the last distribution suggested by this strategy.
- m_mapSyncReq - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
While theContinuousQueryCacheis configuring or re-configuring its listeners and content, any events that are received must be logged to ensure that the corresponding content is in sync.
- m_mapTCPDatagramDependencies - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
A map of TCP Datagram provider dependencies, keyed by id.
- m_mapTemp - Variable in class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
- 
Map to use with getInternal() in order to determine differences between null values and non-present values.
- m_mapTypeId - Variable in class com.tangosol.io.pof.SimplePofContext
- 
A Map that contains mappings from a registered user type into type identifier.
- m_mapTypeIdByClass - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
Once initialized, this references a thread-safe Map that contains mappings from Java classes to POF type identifiers (wrapped as Integer objects).
- m_mapTypeIdByClassName - Variable in class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- 
Once initialized, this references a thread-safe Map that contains mappings from Java class names to POF type identifiers (wrapped as Integer objects).
- m_mapVersion - Variable in class com.tangosol.run.jca.SimpleValidator
- 
The map that holds version objects for enlisted resources.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.CacheResource
- 
Marshaller registry to obtain marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.EntryResource
- 
Marshaller registry to obtain marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.providers.JsonCollectionWriter
- 
Marshaller registry to obtain element marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.providers.XmlCollectionWriter
- 
Marshaller registry to obtain element marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.providers.XmlKeysWriter
- 
Marshaller registry to obtain element marshallers from.
- m_marshallerRegistry - Variable in class com.tangosol.coherence.rest.providers.XmlMapWriter
- 
Marshaller registry to obtain element marshallers from.
- m_mathContext - Variable in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
TheMathContextto provide the precision.
- m_memberFrom - Variable in class com.tangosol.net.partition.PartitionEvent
- 
The "from" member for events that represent transfer from a member.
- m_memberTo - Variable in class com.tangosol.net.partition.PartitionEvent
- 
The "to" member for events that represent transfer to a member.
- m_methFromString - Variable in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Static method to use for conversion from string.
- m_methodClone - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The "public Object clone()" method for the property type, if available.
- m_methodFactory - Variable in class com.tangosol.run.xml.RestrictedStringAdapter
- 
The factory method.
- m_methodGet - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The property "accessor" method.
- m_methodSet - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The property "mutator" method.
- m_nAction - Variable in class com.tangosol.util.filter.FilterTrigger
- 
The action code.
- m_nAdvanceFrequency - Variable in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
The TcpDatagramSocket advance frequency.
- m_namedCache - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
The underlyingNamedCachethat holds then entries for theCoherenceBasedCache.
- m_nAverageThroughput - Variable in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
An average bundled request throughput in size units per millisecond (total bundle size over total processing time)
- m_nBeanId - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Serialization ID for the XmlBean class.
- m_nBindingPower - Variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The power that this token binds, typically to the left.
- m_nCalculatorType - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The type of unit calculator employed by the cache; one of the UNIT_CALCULATOR_* enumerated values.
- m_nDataVersion - Variable in class com.tangosol.io.SimpleEvolvable
- 
Data version.
- m_nEfficiency - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
The estimated cost.
- m_nEvictionType - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The type of eviction policy employed by the cache; one of the EVICTION_POLICY_* enumerated values.
- m_nFlags - Variable in class com.tangosol.net.cache.CacheEvent
- 
Flags holder for event details such as whether the event is synthetic
- m_nHash - Variable in class com.tangosol.util.SafeHashMap.Entry
- 
The key's hash code.
- m_nHash - Variable in class com.tangosol.util.SegmentedHashMap.Entry
- 
The key's hash code.
- m_nId - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
The identity of the object to encode, or -1 if the identity shouldn't be encoded in the POF stream
- m_nId - Variable in class com.tangosol.net.partition.PartitionEvent
- 
The event's id.
- m_nId - Variable in class com.tangosol.util.MapEvent
- 
The event's id.
- m_nImplVersion - Variable in class com.tangosol.io.SimpleEvolvable
- 
Implementation version.
- m_nLastSentTime - Variable in class com.tangosol.util.transformer.SamplingEventTransformer
- 
The last time an event was sent.
- m_nMask - Variable in class com.tangosol.util.filter.MapEventFilter
- 
The event mask.
- m_nMaskSynthetic - Variable in class com.tangosol.util.filter.CacheEventFilter
- 
Bitmask that selects whether to include synthetic, natural, or all events.
- m_nMaxLoadId - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.JMXPartitionStats
- 
The node ID with maximum node storage size in bytes.
- m_nodeNext - Variable in class com.tangosol.util.SafeLinkedList.Node
- 
The next Node in the List.
- m_nodePrev - Variable in class com.tangosol.util.SafeLinkedList.Node
- 
The previous Node in the List.
- m_nOptimizationPlan - Variable in class com.tangosol.util.MapListenerSupport
- 
The optimization plan which indicates the fastest way to put together a set of listeners.
- m_nPartition - Variable in class com.tangosol.net.partition.PartitionStatistics
- 
The partition ID.
- m_nPartition - Variable in class com.tangosol.net.partition.SimplePartitionKey
- 
The partition id.
- m_nPartition - Variable in class com.tangosol.util.MapEvent
- 
The partition this MapEvent was emitted from.
- m_nPort - Variable in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
The configured port.
- m_nRuleMask - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
- 
Action policy rule mask.
- m_nSamplingInterval - Variable in class com.tangosol.util.transformer.SamplingEventTransformer
- 
The sampling interval to use.
- m_nSizeIn - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
The pre-execution key set size.
- m_nSizeOut - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
The post-execution key set size.
- m_nState - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
State of theContinuousQueryCache.
- m_nState - Variable in class com.tangosol.net.GuardSupport.Context
- 
The current state of the Context.
- m_nState - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
One of the STATE_* constants representing the current quorum state.
- m_nState - Variable in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
The state of the PersistenceStore.
- m_nState - Variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
- m_nStrategyCurrent - Variable in class com.tangosol.net.cache.CachingMap
- 
The current invalidation strategy, which at times could be different from the target strategy.
- m_nStrategyTarget - Variable in class com.tangosol.net.cache.CachingMap
- 
The invalidation strategy that this map is to use.
- m_nStrength - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
The strength (one of the *_SAFE constants).
- m_nStyle - Variable in class com.tangosol.util.comparator.EntryComparator
- 
Comparison style utilized by this EntryComparator.
- m_nTarget - Variable in class com.tangosol.util.extractor.AbstractExtractor
- 
Specifies which part of the entry should be used by theAbstractExtractor.extractFromEntry(java.util.Map.Entry)operation.
- m_nThreshold - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
- 
Action policy threshold which is always non-negative.
- m_nType - Variable in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
POF type identifer of this value.
- m_nTypeId - Variable in class com.tangosol.io.pof.ExternalizableLitePofSerializer
- 
The type identifier of the user type to serialize and deserialize.
- m_nTypeId - Variable in class com.tangosol.io.pof.ExternalizablePofSerializer
- 
The type identifier of the user type to serialize and deserialize.
- m_nTypeId - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
The type identifier of the user type that is being written.
- m_nTypeId - Variable in class com.tangosol.io.pof.PortableObjectSerializer
- 
The type identifier of the user type to serialize and deserialize.
- m_nTypeId - Variable in class com.tangosol.io.pof.PortableTypeSerializer
- 
The type identifier of the user type to serialize and deserialize.
- m_nTypeId - Variable in class com.tangosol.io.pof.XmlSerializablePofSerializer
- 
The type identifier of the user type to serialize and deserialize.
- m_nUnitFactor - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The unit factor.
- m_nUnitFactor - Variable in class com.tangosol.net.cache.SerializationCache
- 
The unit factor.
- m_nUnitFactor - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The unit factor.
- m_nVersion - Variable in class com.tangosol.io.pof.reflect.PofUserType
- 
The data version of this value.
- m_nVersion - Variable in class com.tangosol.net.partition.VersionedOwnership
- 
The ownership version.
- m_nVersion - Variable in class com.tangosol.util.MapEvent
- 
The partition version of this MapEvent.
- m_nVersionId - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
The version identifier of the user type that is being written.
- m_object - Variable in class com.tangosol.util.SafeLinkedList.Node
- 
The value stored in the Node.
- m_observer - Variable in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
The observer method to delegate events to.
- m_oCurr - Variable in class com.tangosol.util.PagedIterator
- 
Currently "Active" object.
- m_oExpr - Variable in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Compiled expression.
- m_oExpr - Variable in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Compiled expression.
- m_of - Variable in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Offset into the byte array at which the binary data is located.
- m_of - Variable in class com.tangosol.io.MultiByteArrayInputStream
- 
The current offset in the current byte array.
- m_of - Variable in class com.tangosol.io.MultiByteArrayOutputStream
- 
The offset into the current block of output.
- m_ofbGroup - Variable in class com.tangosol.io.Base64InputStream
- 
The offset in the group of bytes.
- m_ofLimit - Variable in class com.tangosol.util.SimpleEnumerator
- 
Iterator end position (beyond last).
- m_ofMarked - Variable in class com.tangosol.io.MultiByteArrayInputStream
- 
The marked offset in the marked byte array.
- m_ofStart - Variable in class com.tangosol.io.DelegatingWriteBuffer
- 
Offset into the containing WriteBuffer where this WriteBuffer starts.
- m_ofWrite - Variable in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Current write offset within the containing WriteBuffer.
- m_oIterActive - Variable in class com.tangosol.util.SafeHashMap
- 
A holder for active Iterator(s): either WeakReference(<Iterator>) or WeakHashMap(<Iterator>, null)
- m_oIterActive - Variable in class com.tangosol.util.SegmentedHashMap
- 
A holder for active Iterator(s): either WeakReference(<Iterator>) or WeakHashMap(<Iterator> null)
- m_oKey - Variable in class com.tangosol.coherence.rest.EntryResource
- 
Referenced entry's key.
- m_oKey - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Lazily converted key in Object format.
- m_oKey - Variable in class com.tangosol.util.SafeHashMap.Entry
- 
The key.
- m_oKey - Variable in class com.tangosol.util.SegmentedHashMap.Entry
- 
The key.
- m_oKey - Variable in class com.tangosol.util.SimpleMapEntry
- 
The key.
- m_oKeyUp - Variable in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- 
Cached converted key.
- m_oLockHolder - Variable in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
The lock holder object.
- m_oNext - Variable in class com.tangosol.util.FilterEnumerator
- 
The next item which passed the test.
- m_oOrigValue - Variable in class com.tangosol.util.SimpleMapEntry
- 
The original value.
- m_orderIdFunction - Variable in class com.tangosol.net.topic.Publisher.OrderByValue
- 
A function used to compute the unit-of-order from the value type V.
- m_oResult - Variable in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
The running result value.
- m_oState - Variable in class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
- 
The signaling state, null for unsignaled, this for signaled, or a thread for the single awaiting thread
- m_out - Variable in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
The BufferOutput to delegate to.
- m_out - Variable in class com.tangosol.io.pof.PofBufferWriter
- 
The BufferOutput object that the PofBufferWriter writes to.
- m_out - Variable in class com.tangosol.io.WrapperOutputStream
- 
The underlying OutputStream object to use.
- m_oValue - Variable in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Deserialized representation of this value.
- m_oValue - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Lazily converted value in Object format.
- m_oValue - Variable in class com.tangosol.util.InflatableCollection
- 
Holds NO_VALUE, a single value, or an InflatedCollection of values.
- m_oValue - Variable in class com.tangosol.util.processor.VersionedPut
- 
Specifies the new value to update an entry with.
- m_oValue - Variable in class com.tangosol.util.SafeHashMap.Entry
- 
The value.
- m_oValue - Variable in class com.tangosol.util.SegmentedHashMap.Entry
- 
The value.
- m_oValue - Variable in class com.tangosol.util.SimpleMapEntry
- 
The value.
- m_oValue - Variable in class com.tangosol.util.SparseArray.ObjectNode
- 
The Node's value.
- m_oValueLatestOld - Variable in class com.tangosol.net.cache.OverflowMap.HistoricCacheEvent
- 
A previous value, but the most recent of the previous values.
- m_oValueOrig - Variable in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Lazily converted original value in Object format.
- m_oValueUp - Variable in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- 
Cached converted value.
- m_oWaitHead - Variable in class com.oracle.coherence.common.base.ConcurrentNotifier
- 
The head of a stack of waiting threads.
- m_owners - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter
- 
The ownership
- m_owners - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
- 
The ownership.
- m_owners - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
- 
The ownership.
- m_partsOrphan - Variable in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
- 
The set of orphaned partitions.
- m_partsOrphaned - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The set of partitions that were determined to be orphaned in the call toPartitionAssignmentStrategy.analyzeOrphans(Map).
- m_partsUnresolved - Variable in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
The PartitionSet containing partitions that don't have corresponding GUIDs.
- m_partsUpdated - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The set of partitions that have been updated in this analysis context; may be null.
- m_policy - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The eviction policy; for eviction type EVICTION_POLICY_EXTERNAL.
- m_policy - Variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The eviction policy.
- m_pool - Variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
An optional DaemonPool used to execute tasks.
- m_pool - Variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
An optional DaemonPool used to execute tasks.
- m_predicate - Variable in class com.tangosol.util.filter.PredicateFilter
- 
ThePredicatefor filtering extracted values.
- m_primingListener - Variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Wrapper map event listener.
- m_processor - Variable in class com.tangosol.util.processor.ConditionalProcessor
- 
The underlying entry processor.
- m_processorRegistry - Variable in class com.tangosol.coherence.rest.CacheResource
- 
a processor registry that is used to map the given processor name to an EntryProcessor instance.
- m_processorRegistry - Variable in class com.tangosol.coherence.rest.EntryResource
- 
a processor registry that is used to map the given processor name to an EntryProcessor instance.
- m_processorRegistry - Variable in class com.tangosol.coherence.rest.EntrySetResource
- 
a processor registry that is used to map the given processor name to an EntryProcessor instance.
- m_processorRegistry - Variable in class com.tangosol.coherence.rest.NamedQueryResource
- 
a processor registry that is used to map the given processor name to an EntryProcessor instance.
- m_propertySet - Variable in class com.tangosol.coherence.rest.util.PropertySpec
- 
A set of nested properties.
- m_propOptions - Variable in class com.tangosol.net.LoadBalancer
- 
The optional settings that the load balancer will use.
- m_providerCurrent - Variable in class com.tangosol.net.CompositeAddressProvider.AddressIterator
- 
The current AddressProvider.
- m_providerFactory - Variable in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
SocketProviderFactory referencing this Dependency object.
- m_query - Variable in class com.tangosol.coherence.rest.NamedQueryResource
- 
Named query responsible to filter cache entries.
- m_query - Variable in class com.tangosol.net.management.MBeanAccessor.GetAttributes
- 
The query used to reduce the MBeans.
- m_query - Variable in class com.tangosol.net.management.MBeanAccessor.Invoke
- 
The query used to reduce the MBeans.
- m_query - Variable in class com.tangosol.net.management.MBeanAccessor.SetAttributes
- 
The ParsedQuery to be used to query the MBeans.
- m_queryConfig - Variable in class com.tangosol.coherence.rest.CacheResource
- 
Query configuration for this resource.
- m_queryEngineRegistry - Variable in class com.tangosol.coherence.rest.CacheResource
- 
Query engine registry to obtain query engines from.
- m_queue - Variable in class com.tangosol.net.LoadBalancer
- 
The queue of pending requests.
- m_queue - Variable in class com.tangosol.net.LoadBalancer.RequestHandler
- 
The Queue that this RequestHandler listens to connections (Socket) on.
- m_random - Variable in class com.tangosol.net.LoadBalancer
- 
Random number generator.
- m_reader - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
The reader to use to get user input.
- m_reader - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
TheBufferedReaderto use to obtain user input.
- m_reader - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The underlying Reader holding the characters being tokenized.
- m_reader - Variable in class com.tangosol.io.Base64InputStream
- 
The Reader object from which the Base64 encoded data is read.
- m_recordType - Variable in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
- 
The type of query recorder that this builder builds.
- m_refLoader - Variable in class com.tangosol.io.MultiplexingSerializer
- 
The optionalClassLoader.
- m_refs - Variable in class com.tangosol.io.pof.PofBufferWriter
- 
If references are used, then this is the ReferenceLibrary.
- m_registry - Variable in class com.tangosol.coherence.rest.NamedQueryResource
- 
Query engine registry.
- m_registry - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.TheResourceRegistryfor configuration.
- m_resolver - Variable in class com.tangosol.net.PartitionedService.PartitionRecoveryAction
- 
The GUID resolver.
- m_result - Variable in class com.oracle.coherence.grpc.RequestHolder
- 
A result value.
- m_roundingMode - Variable in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
TheRoundingModeused for the aggregated calculation.
- m_ruleCurrent - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
The current state.
- m_sActive - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
The active directory used by persistence.
- m_sApplicationName - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
An optional application name to use.
- m_sBackup - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
The backup directory used by persistence.
- m_sBaseQuery - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
The base MBean query to be used in the query.
- m_sCacheName - Variable in class com.tangosol.coherence.dslquery.FilterBuilder
- 
The cache name this FilterBuilder is buildingFilters to query against.
- m_sCacheName - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.The cache name.
- m_scale - Variable in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
The scale used for the aggregated calculation.
- m_sCluster - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
The cluster name to be used in the query.
- m_sDbName - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
The name of the underlying Database.
- m_sDbName - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Database name, used for persistent stores.
- m_sDomainPartitions - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
A comma delimited list of domain partition names.
- m_sElement - Variable in class com.tangosol.run.xml.IterableAdapter
- 
Name used for each element of the array when formatted into XML.
- m_sElementName - Variable in class com.tangosol.coherence.config.xml.processor.BackingMapSchemeProcessor
- 
The name of theXmlElementto process.
- m_service - Variable in class com.tangosol.net.AbstractServiceLoadBalancer
- 
The containing Service.
- m_service - Variable in class com.tangosol.net.cache.WrapperNamedCache
- 
The CacheService this NamedCache is a part of.
- m_service - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
The cluster service.
- m_service - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
The Service that this policy applies to.
- m_service - Variable in class com.tangosol.net.partition.DefaultKeyAssociator
- 
The PartitionedService that this DefaultKeyAssociator is bound to.
- m_service - Variable in class com.tangosol.net.partition.DefaultKeyPartitioningStrategy
- 
The PartitionedService that this strategy is bound to.
- m_service - Variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
The PartitionedService that this quorum policy is bound to.
- m_service - Variable in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
The associated service that this strategy attempts to co-locate partitions with.
- m_service - Variable in class com.tangosol.net.WrapperService
- 
The (wrapped) Service.
- m_serviceDependencies - Variable in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
TheServiceDependenciesto be used to configure the services produced by this scheme.
- m_serviceLocator - Variable in class com.tangosol.coherence.rest.CacheResource
- 
The ServiceLocator for this resource.
- m_serviceLocator - Variable in class com.tangosol.coherence.rest.DefaultRootResource
- m_serviceMon - Variable in class com.tangosol.net.DefaultCacheServer
- 
The ServiceMonitor used to monitor services.
- m_serviceName - Variable in class com.oracle.coherence.cdi.events.EventObserverSupport.ServiceEventHandler
- m_session - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
TheSessionto use for cache access.
- m_session - Variable in class com.tangosol.coherence.rest.DefaultRootResource
- 
Coherence session.
- m_session - Variable in class com.tangosol.net.CoherenceSession
- 
The underlyingSessionto which this implementation will delegate requests.
- m_set - Variable in class com.tangosol.io.nio.BinaryMap
- 
The set of entries backed by this map.
- m_set - Variable in class com.tangosol.util.aggregator.DistinctValues
- 
The resulting set of distinct values.
- m_set - Variable in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
The underlying Entry Set (or Collection of Map Entry objects).
- m_set - Variable in class com.tangosol.util.ConverterCollections.ConverterMap
- 
The Entry Set.
- m_set - Variable in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
The underlying Entry Set.
- m_set - Variable in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
The Entry Set.
- m_setEntries - Variable in class com.tangosol.util.aggregator.CompositeAggregator
- 
A set of accumulated entries to aggregate.
- m_setEntries - Variable in class com.tangosol.util.ChainedMap
- 
The entry set.
- m_setEntries - Variable in class com.tangosol.util.EntrySetMap
- 
The underlying set of Entry objects.
- m_setEntries - Variable in class com.tangosol.util.SafeHashMap
- 
The set of entries backed by this map.
- m_setEntries - Variable in class com.tangosol.util.SegmentedHashMap
- 
The set of entries backed by this map.
- m_setEntries - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
The entry set.
- m_setIndexLookupRecords - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
The set of index lookup records.
- m_setKeyExcluded - Variable in class com.tangosol.util.SimpleMapIndex
- 
A set of keys for the entries, which could not be included in the index.
- m_setKeys - Variable in class com.tangosol.coherence.rest.EntrySetResource
- 
Referenced entries' keys.
- m_setKeys - Variable in class com.tangosol.io.nio.BinaryMap
- 
The set of keys backed by this map.
- m_setKeys - Variable in class com.tangosol.util.filter.KeyFilter
- 
The keys that are evaluated to true by this filter.
- m_setKeys - Variable in class com.tangosol.util.SafeHashMap
- 
The set of keys backed by this map.
- m_setKeys - Variable in class com.tangosol.util.SegmentedHashMap
- 
The set of keys backed by this map.
- m_setKeys - Variable in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- 
The key set.
- m_setLeaving - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
The set of leaving members.
- m_setMachines - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
The set of machine names.
- m_setManager - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.A Set of BackingMapManager instances registered by this factory.
- m_setManager - Variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
A Set of BackingMapManager instances registered by this factory.
- m_setMod - Variable in class com.tangosol.util.SubSet
- 
The removed or retained items.
- m_setOperators - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
The set of valid operators used by this scanner
- m_setOrig - Variable in class com.tangosol.util.SubSet
- 
The underlying set (assumed immutable).
- m_setOwenersLeaving - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The set of ownership members that are leaving.
- m_setOwnershipMembers - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The set of ownership members to include in the distribution.
- m_setOwnersLast - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The Set of ownership-enabled members at the time of the last analysis.
- m_setPartitions - Variable in class com.tangosol.net.partition.PartitionEvent
- 
The set of affected partitions.
- m_setPids - Variable in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
The remaining set of partitions to iterate.
- m_setProperties - Variable in class com.tangosol.coherence.rest.util.PropertySet
- 
Property set.
- m_setRacks - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
The set of rack names.
- m_setSites - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
The set of site names.
- m_setTypes - Variable in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
A set of event types the observer is interested in.
- m_sEvents - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
The events directory used by persistence.
- m_sExpr - Variable in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
The MVEL expression to evaluate.
- m_sExpr - Variable in class com.tangosol.coherence.rest.util.MvelManipulator
- 
The MVEL expression to evaluate.
- m_sExpr - Variable in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
The MVEL expression to evaluate.
- m_sFilter - Variable in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
The filter description.
- m_sGarFileName - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
The name of an optional GAR file to load.
- m_sHost - Variable in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
The configured address, either hostname or IP address.
- m_signature - Variable in class com.tangosol.net.management.MBeanAccessor.Invoke
- 
The signature of the operation.
- m_size - Variable in class com.tangosol.util.AbstractSparseArray
- 
The number of nodes in the tree.
- m_sJCacheName - Variable in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
TheCachename of theCoherenceBasedCache.
- m_sLanguage - Variable in class com.tangosol.util.AbstractScript
- 
The language the script is written.
- m_sLedASTName - Variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
A functor for building ast for led method.
- m_sLockText - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
Text to include in the lock file.
- m_sMBeanDomainName - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
The MBean domain name to be used in the query.
- m_sMediaType - Variable in class com.tangosol.coherence.rest.util.StaticContent
- m_sMemberKey - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
The member key to be used in the query.
- m_sMessage - Variable in exception com.tangosol.io.pof.PortableException
- 
The exception's message.
- m_sMethod - Variable in class com.tangosol.util.extractor.ReflectionExtractor
- 
The name of the method to invoke.
- m_sMethod - Variable in class com.tangosol.util.extractor.ReflectionUpdater
- 
The name of the method to invoke.
- m_sMethodName - Variable in class com.tangosol.util.processor.MethodInvocationProcessor
- 
The name of the method to invoke.
- m_sMode - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
The mode used by persistence; either active, active-backup, active-async or on-demand.
- m_sName - Variable in class com.tangosol.coherence.rest.util.PropertySpec
- 
Property name.
- m_sName - Variable in class com.tangosol.io.pof.PofPrincipal
- 
The name of the identity represented by this Principal.
- m_sName - Variable in exception com.tangosol.io.pof.PortableException
- 
The exception's name.
- m_sName - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The name of the underlyingNamedCache.
- m_sName - Variable in class com.tangosol.net.cache.WrapperNamedCache
- 
The name of the cache.
- m_sName - Variable in class com.tangosol.net.ssl.AbstractCertificateLoader
- 
The name of the certificate to load.
- m_sName - Variable in class com.tangosol.net.ssl.AbstractKeyStoreLoader
- 
The name of the keystore to load.
- m_sName - Variable in class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- 
The name of the private key to load.
- m_sName - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The property name.
- m_sName - Variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
- m_sName - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
The XML element name for the XML bean.
- m_sName - Variable in class com.tangosol.util.AbstractScript
- 
The name of the script object to execute.
- m_sName - Variable in class com.tangosol.util.extractor.UniversalExtractor
- 
A method or property name.
- m_sName - Variable in class com.tangosol.util.extractor.UniversalUpdater
- 
A method name, or a property name.
- m_sName - Variable in class com.tangosol.util.processor.PropertyManipulator
- 
The property name, never null.
- m_sNameCanon - Variable in class com.tangosol.util.extractor.AbstractExtractor
- 
Canonical name for this extractor.
- m_sNameCanon - Variable in class com.tangosol.util.extractor.UniversalExtractor
- 
Canonical name for this extractor.
- m_sNamePrefix - Variable in class com.tangosol.util.DaemonThreadFactory
- 
The prefix to use for unnammed threads produced by the factory.
- m_sNests - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The characters used to begin nesting.
- m_sNmsPrefix - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The namespace prefix for this property.
- m_sNmsPrefix - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Namespace prefix.
- m_sNmsUri - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The namespace URI for this property.
- m_sNmsUri - Variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Namespace URI.
- m_sNudASTName - Variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
A functor for building ast for nud method.
- m_socketClient - Variable in class com.tangosol.net.LoadBalancer.ResponseHandler
- 
The Socket to write the response to.
- m_socketServer - Variable in class com.tangosol.net.LoadBalancer.ResponseHandler
- 
The Socket to read the response from.
- m_sOperationName - Variable in class com.tangosol.net.management.MBeanAccessor.Invoke
- 
The the name of the operation to be invoked.
- m_sPunctuation - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The characters used for punctuation.
- m_sQuery - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
- 
A query that can be passed to the MBeanServer to reduce the MBeans.
- m_sRuleElementName - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
- 
A rule element name to be used to construct ConfigurationException description if it throws at instantiation time.
- m_sSchemeName - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.The corresponding scheme name.
- m_sService - Variable in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
The service name to be used in the query.
- m_sService - Variable in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
The name of the associated service.
- m_sSnapshot - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
The snapshot directory used by persistence.
- m_state - Variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
TheSimpleMapIndex.IndexCalculator.CalculatorStateof this calculator.
- m_stats - Variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.The CacheStatistics object maintained by this cache.
- m_stats - Variable in class com.tangosol.net.cache.SimpleOverflowMap
- 
The CacheStatistics object maintained by this cache.
- m_stats - Variable in class com.tangosol.util.WrapperObservableMap
- 
The CacheStatistics object maintained by this wrapper.
- m_statsPartition - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The JMXPartitionStats that hold the last updated jmx attributes.
- m_sTitle - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
String to use for Title that heads each result displayed.
- m_sTitle - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
String to use for Title that heads each result displayed.
- m_store - Variable in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
The CacheStore to delegate all Map operations to.
- m_store - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Store that holds cache references scoped by class loader and optionally, if configured, Subject.
- m_storeBundler - Variable in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
The bundler for store() operations.
- m_sTrash - Variable in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
The trash directory used by persistence.
- m_strength - Variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
The backup strength for the resiliency of the resulting distribution.
- m_sUnnests - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The characters used to end nesting.
- m_supplier - Variable in class com.tangosol.util.processor.MethodInvocationProcessor
- 
The supplier that should be used to create the entry value if this processor is invoked on an entry that is not present in the cache.
- m_supplierOrderId - Variable in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
A function that should be used to determine order id.
- m_sValue - Variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The string value of the literal.
- m_sXml - Variable in class com.tangosol.run.xml.PropertyAdapter
- 
The XML element name used to store this property.
- m_tail - Variable in class com.tangosol.util.SafeLinkedList
- 
The last Node in the List (or null if empty).
- m_term - Variable in class com.tangosol.coherence.dslquery.FilterBuilder
- 
The Term that is the AST that encodes the Filter to be made.
- m_test - Variable in class com.tangosol.util.FilterEnumerator
- 
Test to perform on each item.
- m_thread - Variable in class com.tangosol.net.SimpleServiceMonitor
- 
TheThreadwe are using for monitoring the services periodically.
- m_threadAwait - Variable in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- 
The waiting thread, or null.
- m_threadRunning - Variable in class com.tangosol.net.LoadBalancer
- 
The Thread that the load balancer is started on.
- m_threadShutdown - Variable in class com.tangosol.net.DefaultCacheServer
- 
Shutdown hook thread.
- m_threadShutdownHook - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Shutdown hook for closing environment.
- m_timeout - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
The number of milli-seconds to wait for aStatementto execute before timing out.
- m_timeout - Variable in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
The timeout value to use for CohQL statement execution.
- m_tlContext - Static variable in class com.tangosol.net.GuardSupport
- 
ThreadLocal containing the GuardContext associated with the current thread.
- m_token - Variable in class com.tangosol.run.xml.SimpleParser
- 
The "current" token being evaluated.
- m_tokenBuffer - Variable in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
The temporary buffer used to build the String representing a token.
- m_tokenTable - Variable in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
The TokenTable that defines the translation from BaseTokens to OPTokens
- m_tokenTableExtendedSQL - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
The extended TokenTable for the full language that resembles SQL.
- m_tokenTableForFilter - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
The TokenTable for Filters.
- m_tokenTableSQL - Variable in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
The TokenTable for the full language that resembles SQL.
- m_toker - Variable in class com.tangosol.run.xml.SimpleParser
- 
The lexical tokenizer.
- m_transformer - Variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
The transformer that should be used to convert values from the underlying cache.
- m_transformState - Variable in class com.tangosol.net.cache.CacheEvent
- 
The transformation state for this event.
- m_tree - Variable in class com.tangosol.util.Tree
- 
The delgate tree.
- m_updater - Variable in class com.tangosol.coherence.rest.util.MvelManipulator
- 
The underlying ValueUpdater.
- m_updater - Variable in class com.tangosol.util.extractor.CompositeUpdater
- 
The ValueUpdater part.
- m_updater - Variable in class com.tangosol.util.processor.PropertyManipulator
- 
The underlying ValueUpdater.
- m_updater - Variable in class com.tangosol.util.processor.UpdaterProcessor
- 
The underlying ValueUpdater.
- m_value - Variable in class com.oracle.coherence.common.base.SimpleHolder
- 
The held value.
- m_value - Variable in class com.oracle.coherence.common.base.VolatileHolder
- 
The held value.
- m_value - Variable in class com.tangosol.util.filter.ComparisonFilter
- 
The value to compare to.
- m_value - Variable in class com.tangosol.util.processor.ConditionalPut
- 
Specifies the new value to update an entry with.
- m_value - Variable in class com.tangosol.util.processor.UpdaterProcessor
- 
A value to update the entry's value with.
- m_valueLast - Variable in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- 
The last value returned from the iterator.
- m_valueNew - Variable in class com.tangosol.util.MapEvent
- 
A new value.
- m_valueOld - Variable in class com.tangosol.util.MapEvent
- 
A previous value.
- m_writer - Variable in class com.tangosol.coherence.dslquery.ExecutionContext
- 
ThePrintWriterthat can be used by commands to display output.
- m_writer - Variable in class com.tangosol.io.Base64OutputStream
- 
The Writer object to which the Base64 encoded data is written.
- m_writerNested - Variable in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
The currently open nested writer, if any.
- m_xml - Variable in class com.tangosol.net.SocketOptions
- 
The configuration.
- m_xmlConfig - Variable in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Stored configuration for this Manager.
- m_xmlConfig - Variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Configuration.
- m_xmlElement - Variable in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
- 
An optional xml configuration element to be used in ConfigurationException.
- m_xmlScheme - Variable in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.The xml configuration for the enclosed backing maps.
- MACHINE_SAFE - com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
The cluster nodes running on a machine can be stopped simultaneously without any data loss.
- MACHINE_SAFE - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Machine-safety (members are on different machines).
- MACHINES - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
The role prefix to use for the "timeout-machine-quorum".
- MacroExpansionProcessor() - Constructor for class com.tangosol.config.expression.ValueMacroExpression.MacroExpansionProcessor
- main(String[]) - Static method in class com.oracle.coherence.cdi.server.Server
- 
Main method that creates and startsCdiCacheServer.
- main(String[]) - Static method in class com.tangosol.coherence.dslquery.QueryPlus
- 
The main application for CohQL statement processing.
- main(String[]) - Static method in class com.tangosol.io.DebugDataOutputStream
- 
Command line test.
- main(String[]) - Static method in class com.tangosol.io.nio.BinaryMap
- 
Debugging support: Command line test.
- main(String[]) - Static method in class com.tangosol.io.pof.PofBufferWriter
- main(String[]) - Static method in class com.tangosol.io.pof.PofParser
- 
Unit test:
- main(String[]) - Static method in class com.tangosol.net.cache.BinaryMemoryCalculator
- 
Unit test.
- main(String[]) - Static method in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
Unit test.
- main(String[]) - Static method in class com.tangosol.net.CacheFactory
- 
Invoke the Coherence command line tool.
- main(String[]) - Static method in class com.tangosol.net.ClusterPermission
- 
Unit test allows to compare the specified permissions.
- main(String[]) - Static method in class com.tangosol.net.Coherence
- 
Start a Coherence server.
- main(String[]) - Static method in class com.tangosol.net.DefaultCacheServer
- 
Entry point: start the cache server under two possible contexts: With a "coherence-cache-config.xsd" compliant configuration file. With a GAR file or a directory containing the contents of a GAR file and optionally an application name and comma-delimited list of tenant names. If both are provided the latter takes precedence.
- main(String[]) - Static method in class com.tangosol.net.LoadBalancer
- 
Command-line capability to start the load balancer.
- main(String[]) - Static method in class com.tangosol.net.management.MBeanConnector
- 
Start a Coherence cluster node that enables JMX agents such as a web browser or JConsole to connect to the in-process JMX MBeanServer and manage Coherence MBeans.
- main(String[]) - Static method in class com.tangosol.net.Ping
- 
Check if the specified address is reachable.
- main(String[]) - Static method in class com.tangosol.net.security.DefaultController
- 
Standalone permission check utility.
- main(String[]) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Utility that outputs information about a given GUID.
- main(String[]) - Static method in class com.tangosol.run.xml.SaxParser
- 
Unit test: create a simple parser, parse and output the result.
- main(String[]) - Static method in class com.tangosol.run.xml.SimpleParser
- 
Unit test.
- main(String[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Parse a hex string representing a serialized object.
- main(String[]) - Static method in class com.tangosol.util.HealthCheckClient
- 
Run the health check.
- main(String[]) - Static method in class com.tangosol.util.SafeLinkedList
- 
Self-test for SafeLinkedList.
- main(String[]) - Static method in class com.tangosol.util.UID
- 
Allow UID identifiers to be generated or parsed at the command line.
- main(String[]) - Static method in class com.tangosol.util.UUID
- 
Allow UUID identifiers to be generated or parsed at the command line.
- makeAdapter(Class, String, String, XmlElement) - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Generate a property adapter instance that will work on this bean class and will adapt for a property of the specified class and of the specified name.
- makeByteArrayPrivate() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Make sure that the underlying byte[] will be treated as private data.
- makeConnection(SocketAddress) - Method in class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
- 
Produce a new Connection for the specified destination address.
- makeConnection(SocketAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Produce a new Connection for the specified destination address.
- makeConnection(SocketChannel) - Method in class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
- 
Make a connection from an existing channel.
- makeEntry(Map<K, V>, K) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Create a SimpleEntry object for the specified map and the key.
- makeEntrySet(Collection<? extends Map.Entry<K, V>>) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Create a set of read-only SimpleEntry objects for the specified collection of Map.Entry objects.
- makeEntrySet(Map<K, V>, Collection<? extends K>, boolean) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Create a set of SimpleEntry objects for the specified map and the key collection.
- makeExtractor(NodeTerm) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- 
Process the AST Tree using the given Term that represents getter.
- makeExtractor(Term, Term, TermWalker) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- makeExtractor(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
Create aValueExtractorfor thisBaseOperatorusing the specified left and right values.
- makeFilter() - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- 
Make a new Filter from the set AST.
- makeFilter(Term) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- 
Make a new Filter from the given AST.
- makeFilter(Term, Term, TermWalker) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- makeFilter(Term, Term, TermWalker) - Method in class com.tangosol.coherence.dslquery.operator.ComparisonOperator
- makeFilter(Term, Term, TermWalker) - Method in class com.tangosol.coherence.dslquery.operator.EqualsOperator
- makeFilter(Term, Object[]) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- 
Make a new Filter from the given AST using given array for Bind vars.
- makeFilter(Term, Object[], Map) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- 
Make a new Filter from the given AST using the given bind variables.
- makeFilter(Term, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- 
Make a new Filter from the given AST using the given bind variables.
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.AndOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
Create aFilterfor thisBaseOperatorusing the specified left and right values.
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.BetweenOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.ContainsAllOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.ContainsAnyOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.ContainsOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.EqualsOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.GreaterEqualsOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.GreaterOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.InOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.LessEqualsOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.LessOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.LikeOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.NotEqualsOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.OrOperator
- makeFilter(Object, Object) - Method in class com.tangosol.coherence.dslquery.operator.XorOperator
- makeFilterForCache(String, Term, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.FilterBuilder
- 
Make a new Filter from the given AST using given array for Bind vars.
- makeInteger(int) - Static method in class com.tangosol.util.Base
- 
Deprecated.
- makeLong(long) - Static method in class com.tangosol.util.Base
- 
Deprecated.
- makeMBeanName(PartitionedService) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Create a name for the MBean representing this strategy.
- makeName(String, int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Format a synthetic name for a partition-specific backing map.
- makeProvider(XmlElement) - Static method in class com.tangosol.net.ConfigurableAddressProvider
- 
Deprecated.
- makeSelfLink(Thread, long, Object) - Method in class com.oracle.coherence.common.base.ConcurrentNotifier
- 
Make a link for the calling thread, checking if one already exists for this notifier.
- makeThread(ThreadGroup, Runnable, String) - Static method in class com.tangosol.util.Base
- 
Create a Thread with the specified group, runnable, and name, using the configured ThreadFactory, as specified by the tangosol.coherence.threadfactory system property.
- makeThread(ThreadGroup, Runnable, String) - Method in class com.tangosol.util.DaemonThreadFactory
- 
Create a Thread with the specified group, runnable, and name.
- makeThread(ThreadGroup, Runnable, String) - Method in interface com.tangosol.util.ThreadFactory
- 
Create a Thread with the specified group, runnable, and name.
- makeTrint(long) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Convert a long integer to a trint.
- MANAGEMENT_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the ManagementMBean.
- Manager() - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.
- Manager(ExtensibleConfigurableCacheFactory) - Constructor for class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Construct the backing map manager.
- manipulate(String) - Static method in class com.tangosol.util.Processors
- 
Construct a property manipulate processor for the specified property name.
- manipulate(String, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct a property manipulate processor for the specified property name.
- map(Remote.DoubleUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the results of applying the given function to the elements of this stream.
- map(Remote.Function<? super T, ? extends R>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the results of applying the given function to the elements of this stream.
- map(Remote.IntUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the results of applying the given function to the elements of this stream.
- map(Remote.LongUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the results of applying the given function to the elements of this stream.
- map(ValueExtractor<? super T, ? extends R>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the results of applying the given extractor to the elements of this stream.
- map(ValueExtractor<? super V, ? extends U>) - Method in class com.tangosol.net.MapViewBuilder
- 
TheValueExtractorthat thisviewwill use to transform the results from the underlying map prior to storing them locally.
- map(ValueExtractor<? super V, ? extends U>) - Method in class com.tangosol.net.ViewBuilder
- 
TheValueExtractorthat thisviewwill use to transform the results from the underlying cache prior to storing them locally.
- map(DoubleUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the results of applying the given function to the elements of this stream.
- map(Function<? super T, ? extends R>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the results of applying the given function to the elements of this stream.
- map(IntUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the results of applying the given function to the elements of this stream.
- map(LongUnaryOperator) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the results of applying the given function to the elements of this stream.
- MAP_FIXED_SIZES - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
An immutable map of fixed-sized classes to instance size (in bytes).
- MAP_OVERHEAD - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
The memory cost of a NullableConcurrentMap used as the Forward Index.
- MAP_PRIMITIVE_SIZES - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
An immutable map of primitive types to their size (in bytes).
- MAP_SCHEMETYPE_BY_SCHEMENAME - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The mappings from scheme name to scheme type.
- MapAdapter - Class in com.tangosol.run.xml
- 
A MapAdapter supports properties whose types implement the java.util.Map interface.
- MapAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.MapAdapter
- 
Construct a MapAdapter.
- MapArray(int) - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
- 
Construct an empty MapArray for a given partition count.
- MapBuilder - Interface in com.tangosol.coherence.config.builder
- 
TheMapBuilderinterface is used by a builder to create an instance of aMapthat is a local to a Java process.
- MapBuilder.Dependencies - Class in com.tangosol.coherence.config.builder
- MapCacheStore<K,V> - Class in com.tangosol.net.cache
- 
A CacheStore that sits directly on top of a Map.
- MapCacheStore(Map<K, V>) - Constructor for class com.tangosol.net.cache.MapCacheStore
- 
Create a CacheStore that delegates to a Map.
- MapCodec(Class<? extends Map<Object, Object>>) - Constructor for class com.tangosol.io.pof.reflect.Codecs.MapCodec
- 
Construct a MapCodec.
- MapEntryIteratorToCacheEntryIteratorAdapter<K,V> - Class in com.tangosol.coherence.jcache.common
- MapEntryIteratorToCacheEntryIteratorAdapter(Iterator<Map.Entry<K, V>>) - Constructor for class com.tangosol.coherence.jcache.common.MapEntryIteratorToCacheEntryIteratorAdapter
- 
Constructs aMapEntryIteratorToCacheEntryIteratorAdapterthat lazily adapts anIteratoroverMapentries in to anIteratoroverCacheentries.
- MapEvent<K,V> - Class in com.tangosol.util
- 
An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.
- MapEvent() - Constructor for class com.tangosol.util.MapEvent
- 
Default constructor for serialization.
- MapEvent(ObservableMap<K, V>, int, K, V, V) - Constructor for class com.tangosol.util.MapEvent
- 
Constructs a new MapEvent.
- MapEventFilter<K,V> - Class in com.tangosol.util.filter
- 
Filter which evaluates the content of a MapEvent object according to the specified criteria.
- MapEventFilter() - Constructor for class com.tangosol.util.filter.MapEventFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- MapEventFilter(int) - Constructor for class com.tangosol.util.filter.MapEventFilter
- 
Construct a MapEventFilter that evaluates MapEvent objects based on the specified combination of event types.
- MapEventFilter(int, Filter<V>) - Constructor for class com.tangosol.util.filter.MapEventFilter
- 
Construct a MapEventFilter that evaluates MapEvent objects based on the specified combination of event types.
- MapEventFilter(Filter<V>) - Constructor for class com.tangosol.util.filter.MapEventFilter
- 
Construct a MapEventFilter that evaluates MapEvent objects that would affect the results of a keySet filter issued by a previous call toQueryMap.keySet(com.tangosol.util.Filter).
- MapEventOutput<K,V> - Class in com.tangosol.coherence.rest.events
- 
MapListenerimplementation that converts CoherenceMapEventsinto Jersey Server Sent Events (SSE).
- MapEventOutput(NamedCache<K, V>, boolean) - Constructor for class com.tangosol.coherence.rest.events.MapEventOutput
- 
Construct MapEventOutput instance.
- MapEventTransformer<K,V,U> - Interface in com.tangosol.util
- 
MapEventTransformer interface is used to allow an event consumer to change the content of aMapEventdestined for the correspondingMapListener.
- MapEventTransformerBinding - Annotation Type in com.oracle.coherence.cdi
- 
Specifies that an annotation type is aMapEventTransformerbinding type.
- MapEventTransformerFactory<A extends Annotation,K,V,U> - Interface in com.oracle.coherence.cdi
- 
A factory that produces instances ofMapEventTransformerfor a givenAnnotation.
- MapEventTransformerFilter<T> - Class in com.tangosol.util.filter
- 
MapEventTransformerFilter is a generic multiplexing wrapper that combines two implementations: a Filter (most commonly aMapEventFilter) and a MapEventTransformer and is used to register event listeners that allow to change the content of a MapEvent.
- MapEventTransformerFilter() - Constructor for class com.tangosol.util.filter.MapEventTransformerFilter
- 
No-argument constructor for lite deserialization.
- MapEventTransformerFilter(Filter<T>, MapEventTransformer) - Constructor for class com.tangosol.util.filter.MapEventTransformerFilter
- 
Construct a MapEventTransformerFilter based on the specified Filter and MapEventTransformer.
- MapEventTransformerProducer - Class in com.oracle.coherence.cdi
- 
A CDI bean that producesMapEventTransformerinstances usingMapEventTransformerFactorybeans annotated withMapEventTransformerBindingannotations.
- MapIndex<K,V,E> - Interface in com.tangosol.util
- 
MapIndex is used to correlate values stored in an indexed Map (or attributes of those values) to the corresponding keys in the indexed Map.
- MapJsonBodyHandler - Interface in com.tangosol.net.management
- 
A class that can serialize and deserializeMapsto and from json.
- MapListener<K,V> - Interface in com.tangosol.util
- 
The listener interface for receiving MapEvents.
- MapListenerProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AMapListenerProcessoris responsible for processing a listenerXmlElements to produce aParameterizedBuilderfor aMapListener.
- MapListenerProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MapListenerProcessor
- MapListenerProxy - Class in com.oracle.coherence.grpc.proxy
- 
A class to encapsulate bidirectional streaming of map events for a single cache.
- MapListenerProxy(NamedCacheService, StreamObserver<MapListenerResponse>) - Constructor for class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Create aMapListenerProxyto handle aMapListenersubscription to a cache.
- MapListenerProxy.DeactivationListener - Class in com.oracle.coherence.grpc.proxy
- 
NamedCacheDeactivationListenerthat will communicate cache truncation and destruction events over the proxy.
- MapListenerProxy.FilterInfo - Class in com.oracle.coherence.grpc.proxy
- 
A holder for filter information.
- MapListenerProxy.KeyConverter - Class in com.oracle.coherence.grpc.proxy
- 
Converter for cache key instances.
- MapListenerProxy.WrapperPrimingListener - Class in com.oracle.coherence.grpc.proxy
- 
MapListenerSupport.PrimingListenerthat delegates calls to the wrappedMapListener.
- MapListenerSupport - Class in com.tangosol.util
- 
This class provides support for advanced MapListener functionality.
- MapListenerSupport() - Constructor for class com.tangosol.util.MapListenerSupport
- 
Constructs a new MapListenerSupport object.
- MapListenerSupport.FilterEvent - Class in com.tangosol.util
- 
An extension of the CacheEvent which may carry no values (old or new), but instead holds on an array of Filter objects being the "cause" of the event.
- MapListenerSupport.PrimingListener<K,V> - Interface in com.tangosol.util
- 
A tag interface indicating that this listener is registered as a synchronous listener for lite events (carrying only a key) and generates a "priming" event when registered.
- MapListenerSupport.SynchronousListener<K,V> - Interface in com.tangosol.util
- 
A tag interface indicating that tagged MapListener implementation has to receive the MapEvent notifications in a synchronous manner.
- MapListenerSupport.WrapperListener<K,V> - Class in com.tangosol.util
- 
A base class for various wrapper listener classes.
- MapListenerSupport.WrapperPrimingListener - Class in com.tangosol.util
- 
A wrapper class that turns the specified MapListener into a priming listener.
- MapListenerSupport.WrapperSynchronousListener<K,V> - Class in com.tangosol.util
- 
A wrapper class that turns the specified MapListener into a synchronous listener.
- mapMerger(Remote.BinaryOperator<V>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
- 
BinaryOperator<Map>that merges the contents of its right argument into its left argument, using the provided merge function to handle duplicate keys.
- mapMerger(BinaryOperator<V>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
- 
BinaryOperator<Map>that merges the contents of its right argument into its left argument, using the provided merge function to handle duplicate keys.
- MapName - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used to indicate a specific map name.
- MapName.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theMapNameannotation.
- MapNotFoundException - Exception in com.tangosol.util
- 
An exception to indicate that a required map does not exist.
- MapNotFoundException(String) - Constructor for exception com.tangosol.util.MapNotFoundException
- 
Create aMapNotFoundException.
- MappedBufferManager - Class in com.tangosol.io.nio
- 
Manages a ByteBuffer on a file.
- MappedBufferManager() - Constructor for class com.tangosol.io.nio.MappedBufferManager
- 
Construct a MappedBufferManager using defaults.
- MappedBufferManager(int, int, File) - Constructor for class com.tangosol.io.nio.MappedBufferManager
- 
Construct a MappedBufferManager that supports a buffer of a certain initial and maximum size.
- MappedStoreManager - Class in com.tangosol.io.nio
- 
An implementation of BinaryStoreManager interface that usesBinaryMapobjects built on theMappedBufferManagerto provideBinaryStoreobjects.
- MappedStoreManager(int, int, File) - Constructor for class com.tangosol.io.nio.MappedStoreManager
- 
Construct a DirectStoreManager that uses BinaryMap objests built on the MappedBufferManager(s) with certain initial and maximum size.
- mapping(Remote.Function<? super T, ? extends U>, RemoteCollector<? super U, A, R>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Adapts aCollectoraccepting elements of typeUto one accepting elements of typeTby applying a mapping function to each input element before accumulation.
- MapSet - Class in com.tangosol.util
- 
An ExternalizableLite implementation of java.util.Set that uses an underlying Map object to store its data in, just as the Java HashSet implementation uses an underlying HashMap for its element storage.
- MapSet() - Constructor for class com.tangosol.util.MapSet
- 
Default constructor.
- MapSet(Map) - Constructor for class com.tangosol.util.MapSet
- 
Construct a MapSet that uses the given Map for its underlying storage.
- mapToDouble(Remote.IntToDoubleFunction) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns aDoubleStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToDouble(Remote.LongToDoubleFunction) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns aDoubleStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToDouble(Remote.ToDoubleFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns aDoubleStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToDouble(ValueExtractor<? super T, ? extends Number>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anDoubleStreamconsisting of the results of applying the given extractor to the elements of this stream.
- mapToDouble(IntToDoubleFunction) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns aDoubleStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToDouble(LongToDoubleFunction) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns aDoubleStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToDouble(ToDoubleFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns aDoubleStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToInt(Remote.DoubleToIntFunction) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns anIntStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToInt(Remote.LongToIntFunction) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns anIntStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToInt(Remote.ToIntFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anIntStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToInt(ValueExtractor<? super T, ? extends Number>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anIntStreamconsisting of the results of applying the given extractor to the elements of this stream.
- mapToInt(DoubleToIntFunction) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns anIntStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToInt(LongToIntFunction) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns anIntStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToInt(ToIntFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anIntStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToLong(Remote.DoubleToLongFunction) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns aLongStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToLong(Remote.IntToLongFunction) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns aLongStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToLong(Remote.ToLongFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns aLongStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToLong(ValueExtractor<? super T, ? extends Number>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns anLongStreamconsisting of the results of applying the given extractor to the elements of this stream.
- mapToLong(DoubleToLongFunction) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns aLongStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToLong(IntToLongFunction) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns aLongStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToLong(ToLongFunction<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns aLongStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToObj(Remote.DoubleFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns an object-valuedStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToObj(Remote.IntFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns an object-valuedStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToObj(Remote.LongFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns an object-valuedStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToObj(DoubleFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns an object-valuedStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToObj(IntFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns an object-valuedStreamconsisting of the results of applying the given function to the elements of this stream.
- mapToObj(LongFunction<? extends U>) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns an object-valuedStreamconsisting of the results of applying the given function to the elements of this stream.
- MapTrigger<K,V> - Interface in com.tangosol.util
- 
MapTrigger represents a functional agent that allows to validate, reject or modify mutating operations against an underlying map.
- MapTrigger.Entry<K,V> - Interface in com.tangosol.util
- 
A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.
- MapTriggerListener - Class in com.tangosol.util
- 
MapTriggerListener is a special purpose MapListener implementation that is used to register aMapTriggeron a corresponding ObservableMap.
- MapTriggerListener(MapTrigger) - Constructor for class com.tangosol.util.MapTriggerListener
- 
Construct a MapTriggerListener that can be used to register the specified MapTrigger.
- MapViewBuilder<K,V> - Class in com.tangosol.net
- 
TheViewBuilderprovides a means toMapViewBuilder.build()amap viewusing a fluent pattern / style.
- MapViewBuilder(Supplier<NamedCache<K, V>>) - Constructor for class com.tangosol.net.MapViewBuilder
- 
Construct a newViewBuilderfor the providedSupplier.
- mark() - Method in class com.tangosol.run.xml.SimpleParser
- 
Marks the current position and returns it as a token.
- mark(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Marks the current read position in the InputStream in order to support the stream to be later "rewound" (using theInputStreaming.reset()method) to the current position.
- mark(int) - Method in class com.tangosol.io.MultiByteArrayInputStream
- 
Marks the current position in this input stream.
- mark(int) - Method in class com.tangosol.io.nio.ByteBufferInputStream
- 
Marks the current position in this input stream.
- mark(int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Marks the current read position in the InputStream in order to support the stream to be later "rewound" (using theInputStreaming.reset()method) to the current position.
- mark(int) - Method in class com.tangosol.io.pof.PofInputStream
- 
Marks the current read position in the InputStream in order to support the stream to be later "rewound" (using thePofInputStream.reset()method) to the current position.
- mark(int) - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Marks the current read position in the InputStream in order to support the stream to be later "rewound" (using theInputStreaming.reset()method) to the current position.
- mark(int) - Method in class com.tangosol.io.Utf8Reader
- 
Mark the present position in the stream.
- mark(int) - Method in class com.tangosol.io.WrapperDataInputStream
- 
Marks the current read position in the InputStream in order to support the stream to be later "rewound" (using theWrapperDataInputStream.reset()method) to the current position.
- mark(int) - Method in class com.tangosol.io.WrapperInputStream
- 
Marks the current read position in the InputStream in order to support the stream to be later "rewound" (using theWrapperInputStream.reset()method) to the current position.
- mark(int) - Method in class com.tangosol.util.NullImplementation.NullReader
- MARK_UNSET - Static variable in class com.tangosol.io.MultiByteArrayInputStream
- 
Marker position indicating that stream is not marked.
- markConverted() - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Mark the underlying keys set as converted.
- MARKED_ALL - Static variable in class com.tangosol.net.partition.PartitionSet
- 
Serialization format indicator: Indicates that all partitions are marked; MARKED_ALL requires no additional data.
- MARKED_FEW - Static variable in class com.tangosol.net.partition.PartitionSet
- 
Serialization format indicator: Indicates that a small number of partitions are marked; followed by stream of packed integers indicating gaps between each marked partition, terminated with a -1.
- MARKED_MANY - Static variable in class com.tangosol.net.partition.PartitionSet
- 
Serialization format indicator: Indicates that a large number of partitions are marked; followed by a sequence of 64-bit values sufficient to represent the cardinality of the PartitionSet.
- MARKED_NONE - Static variable in class com.tangosol.net.partition.PartitionSet
- 
Serialization format indicator: Indicates that no partitions are marked; MARKED_NONE requires no additional data.
- markError() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- 
Update the failed request meter.
- markPosition(int, SafeLinkedList.Node) - Method in class com.tangosol.util.SafeLinkedList
- 
Remember that a certain Node occurs at a certain index.
- markReceived() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- 
Update the messages received meter.
- markSent() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- 
Update the messages sent meter.
- markServicesStarted() - Method in class com.tangosol.net.DefaultCacheServer
- 
Set the "services started" flag.
- markStarted() - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Mark the server as started.
- markSuccess() - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- 
Update the successful request meter.
- markSupported() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Determine if this InputStream supports theReadBuffer.BufferInput.mark(int)andInputStreaming.reset()methods.
- markSupported() - Method in class com.tangosol.io.MultiByteArrayInputStream
- 
Tests if this input stream supports themarkandresetmethods.
- markSupported() - Method in class com.tangosol.io.nio.ByteBufferInputStream
- 
Tests if this input stream supports themarkandresetmethods.
- markSupported() - Method in class com.tangosol.io.pof.PofInputStream
- 
Determine if this InputStream supports thePofInputStream.mark(int)andPofInputStream.reset()methods.
- markSupported() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Determine if this InputStream supports theReadBuffer.BufferInput.mark(int)andInputStreaming.reset()methods.
- markSupported() - Method in class com.tangosol.io.Utf8Reader
- 
Tell whether this stream supports the mark() operation.
- markSupported() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Determine if this InputStream supports theWrapperDataInputStream.mark(int)andWrapperDataInputStream.reset()methods.
- markSupported() - Method in class com.tangosol.io.WrapperInputStream
- 
Determine if this InputStream supports theWrapperInputStream.mark(int)andWrapperInputStream.reset()methods.
- markSupported() - Method in class com.tangosol.util.NullImplementation.NullReader
- marshal(StaticContent, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.StaticContentMarshaller
- marshal(Binary, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.BinaryMarshaller
- marshal(Object, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.KeyConverterAdapter
- marshal(String, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.StringMarshaller
- marshal(T, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.JacksonJsonMarshaller
- marshal(T, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
- marshal(T, OutputStream, MultivaluedMap<String, Object>) - Method in interface com.tangosol.coherence.rest.io.Marshaller
- 
Write the specified object into the given stream.
- marshalAsFragment(T, OutputStream, MultivaluedMap<String, Object>) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
- marshalAsFragment(T, OutputStream, MultivaluedMap<String, Object>) - Method in interface com.tangosol.coherence.rest.io.Marshaller
- 
Write the specified object into the given stream as a fragment.
- Marshaller<T> - Interface in com.tangosol.coherence.rest.io
- 
An interface that must be implemented by REST marshallers.
- MarshallerRegistry - Class in com.tangosol.coherence.rest.io
- 
Registry for marshaller instances.
- MarshallerRegistry() - Constructor for class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Construct a MarshallerRegistry instance.
- MASK_CONNECT - Static variable in class com.tangosol.coherence.config.builder.ProxyQuorumPolicyBuilder
- 
Connect quorum mask.
- MASK_CONNECT - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.ProxyQuorumPolicy
- 
Bitmask used to encode a client connection action.
- MASK_DISTRIBUTION - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Bitmask used to encode a distribution action.
- MASK_LAST - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
The highest used bitmask value.
- MASK_READ - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Bitmask used to encode a read action.
- MASK_RECOVER - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Bitmask used to encode a recover action.
- MASK_RESTORE - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Bitmask used to encode a partition restore action.
- MASK_WRITE - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Bitmask used to encode a write action.
- MaskedPartitionMap(PartitionSet) - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
- 
Construct MaskedPartitionMap based on the specified PartitionSet.
- match(int) - Method in class com.tangosol.run.xml.SimpleParser
- 
Verifies that the current token matches the passed token id and, if so, advances to the next token.
- match(String) - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token matches the given string.
- match(String) - Method in class com.tangosol.run.xml.SimpleParser
- 
Verifies that the current token is a name token whose name matches the passed String and, if so, advances to the next token.
- match(String, boolean) - Method in class com.tangosol.coherence.dsltools.base.BaseToken
- 
Answer whether this token matches the given string.
- match(String, boolean) - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
- 
Answer whether this token matches the given string.
- match(String, boolean) - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
- 
Answer whether this token matches the given string.
- matches(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Test to see if the current BaseToken's string matches the given string.
- matches(String, boolean) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Test to see if the current BaseToken's string matches the given string.
- max() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns anOptionalDoubledescribing the maximum element of this stream, or an empty OptionalDouble if this stream is empty.
- max() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns anOptionalIntdescribing the maximum element of this stream, or an empty optional if this stream is empty.
- max() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns anOptionalLongdescribing the maximum element of this stream, or an empty optional if this stream is empty.
- max(Filter<?>, Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToComparableFunction<? super T, R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToComparableFunction<? super T, R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Filter<?>, Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Remote.Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns the maximum element of this stream according to the providedComparator.
- max(Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToBigDecimalFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of the BigDecimal values extracted from a set of entries in a Map.
- max(Remote.ToComparableFunction<? super T, ? extends R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of the Comparable values extracted from a set of entries in a Map.
- max(Remote.ToComparableFunction<? super T, R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToComparableFunction<? super T, R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToDoubleFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of the double values extracted from a set of entries in a Map.
- max(Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToIntFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of the int values extracted from a set of entries in a Map.
- max(Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the maximum value of the specified function.
- max(Remote.ToLongFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a maximum of the long values extracted from a set of entries in a Map.
- max(ValueExtractor<? super U, ? extends Comparable>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns the maximum element of this stream according to the attribute extracted by the providedValueExtractor.
- max(Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns the maximum element of this stream according to the providedComparator.
- MAX - Static variable in class com.tangosol.util.SimpleLongArray
- 
Maximum index value.
- MAX_DECIMAL128_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Maximum scale for the IEEE-754r 128-bit decimal format.
- MAX_DECIMAL128_UNSCALED - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Maximum unscaled value for the IEEE-754r 128-bit decimal format.
- MAX_DECIMAL32_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Maximum scale for the IEEE-754r 32-bit decimal format.
- MAX_DECIMAL32_UNSCALED - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Maximum unscaled value for the IEEE-754r 32-bit decimal format.
- MAX_DECIMAL64_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Maximum scale for the IEEE-754r 64-bit decimal format.
- MAX_DECIMAL64_UNSCALED - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Maximum unscaled value for the IEEE-754r 64-bit decimal format.
- MAX_DECO_HEADER_BYTES - Static variable in class com.tangosol.util.ExternalizableHelper
- 
The maximum number of bytes the header of the binary-decorated value may contain.
- MAX_LOCK_WAIT - Static variable in class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.The length of time (in millis) to wait on a lock; keep this value low to avoid causing timing problems since some calls will be on the distributed cache thread.
- MAX_MACRO_EXPANSIONS - Static variable in class com.tangosol.config.expression.ValueMacroExpression
- 
Avoid recursive macro expansions that never return.
- MAX_OPEN_BLOCKS - Static variable in class com.tangosol.io.nio.BinaryMap
- 
Maximum number of simultaneously open blocks to support.
- MAX_PACKED_INT_SIZE - Static variable in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Maximum encoding length for a packed int value.
- MAX_PACKED_LONG_SIZE - Static variable in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Maximum encoding length for a packed long value.
- MAX_PARTITION_MAP_UNIT_FACTOR - Static variable in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
The maximum unit factor for partition maps.
- MAX_PORT - Static variable in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- MAX_SIZE_CODES - Static variable in class com.tangosol.io.nio.BinaryMap
- 
Number of size codes for free blocks.
- maxBy(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the entity with the maximum value of the specified function.
- maxBy(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the entity with the maximum value of the specified function.
- maxBy(Remote.Comparator<? super T>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
- 
Returns aRemote.BinaryOperatorwhich returns the greater of two elements according to the specifiedComparator.
- maxBy(Remote.Comparator<? super T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat produces the maximal element according to a givenComparator, described as anOptional<T>.
- maxBy(ValueExtractor<? super T, ? extends E>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
- 
Returns aRemote.BinaryOperatorwhich returns the greater of two elements according to the specifiedComparablevalue.
- maxBy(ValueExtractor<? super T, ? extends E>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat produces the maximal element according to a givenComparableattribute, described as anOptional<T>.
- maxBy(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the entity with the maximum value of the specified function.
- maxBy(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the entity with the maximum value of the specified function.
- maxBy(Comparator<? super T>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
- 
Returns aRemote.BinaryOperatorwhich returns the greater of two elements according to the specifiedComparator.
- MBEAN_NAME - Static variable in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
The name to use for the management MBean.
- MBEAN_PREFIX - Static variable in class com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics
- 
The connection MBean ObjectName prefix.
- MBEAN_TYPE - Static variable in class com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics
- 
The connection MBean type.
- MBeanAccessor - Class in com.tangosol.net.management
- 
MBeanAccessor provides a means to access JMX MBeans via the Coherence Management Server (a single MBeanServer with an aggregated view of MBeans for the entire cluster).
- MBeanAccessor() - Constructor for class com.tangosol.net.management.MBeanAccessor
- 
Default Constructor.
- MBeanAccessor(MBeanServerProxy) - Constructor for class com.tangosol.net.management.MBeanAccessor
- 
Create an instance of MBeanAccessor.
- MBeanAccessor.GetAttributes - Class in com.tangosol.net.management
- 
The Remote.Function for theMBeanServerConnection.getAttributes method.
- MBeanAccessor.Invoke - Class in com.tangosol.net.management
- 
The Remote.Function for theMBeanServerConnection.invoke method.
- MBeanAccessor.QueryBuilder - Class in com.tangosol.net.management
- 
The Query Builder for generating Coherence MBean queries.
- MBeanAccessor.QueryBuilder.ParsedQuery - Class in com.tangosol.net.management
- 
A ParsedQuery represents the result of a call toMBeanAccessor.QueryBuilder.build().
- MBeanAccessor.SetAttributes - Class in com.tangosol.net.management
- 
The Remote.Function for theMBeanServerConnection.setAttributes method.
- MBeanConnector - Class in com.tangosol.net.management
- 
Utility class to expose Coherence JMX MBeans via the Sun JMX reference implementation HtmlAdaptorServer or a JMX RemoteJMXConnectorServer.
- MBeanConnector() - Constructor for class com.tangosol.net.management.MBeanConnector
- MBeanHelper - Class in com.tangosol.net.management
- 
Helper class providing various functionality related to aggregation of attributes and methods exposed by Coherence JMX framework MBeans.
- MBeanHelper() - Constructor for class com.tangosol.net.management.MBeanHelper
- MBeanHelper.QueryExpFilter - Class in com.tangosol.net.management
- MBeanReference - Class in com.tangosol.net.management
- 
MBeanReference holds all necessary information to uniquely identify an MBean.
- MBeanReference(ObjectName, MBeanServer) - Constructor for class com.tangosol.net.management.MBeanReference
- 
Construct an instance of MBeanReference.
- MBeanServerFinder - Interface in com.tangosol.net.management
- 
MBeanServerFinder represents a facility that allows a pluggable run-time selection of an MBeanServer to be used by the Coherence JMX framework.
- MBeanServerProxy - Interface in com.tangosol.net.management
- 
MBeanServerProxy allows any cluster node that runs the Management service to obtain and set attributes or invoke methods on registered MBeans.
- MBeanServerRegistrationUtility - Class in com.tangosol.coherence.jcache.common
- 
A convenience class for registering CacheStatisticsMBeans with an MBeanServer.
- MBeanServerRegistrationUtility.ObjectNameType - Enum in com.tangosol.coherence.jcache.common
- 
The type of registered Object
- Megabytes - Class in com.tangosol.coherence.config.unit
- 
Megabytesis a specializedMemorySizewhose default constructor assumes that the specified units (when a they are not specified) are measured in megabytes.
- Megabytes(int) - Constructor for class com.tangosol.coherence.config.unit.Megabytes
- 
Constructs aMegabytesrepresenting aMemorySizemeasured in megabytes.
- Megabytes(MemorySize) - Constructor for class com.tangosol.coherence.config.unit.Megabytes
- 
Constructs aMegabytesbased on anotherMemorySize.
- Megabytes(String) - Constructor for class com.tangosol.coherence.config.unit.Megabytes
- 
Constructs aMegabytesrepresenting aMemorySizemeasured in megabytes.
- Member - Interface in com.tangosol.net
- 
The Member interface represents a cluster member.
- MEMBER - Static variable in class com.tangosol.net.management.MBeanAccessor
- 
The "member" key in the ObjectName.
- MEMBER_IDENTITY_LIMIT - Static variable in interface com.tangosol.net.MemberIdentity
- 
The member identity limit used to restrict the size of various fields.
- MEMBER_JOINED - Static variable in class com.tangosol.net.MemberEvent
- 
This event indicates that a Member has joined.
- MEMBER_LEAVING - Static variable in class com.tangosol.net.MemberEvent
- 
This event indicates that a Member is leaving.
- MEMBER_LEFT - Static variable in class com.tangosol.net.MemberEvent
- 
This event indicates that a Member has left.
- memberCompleted(Member, Object) - Method in interface com.tangosol.net.InvocationObserver
- 
This method is called by theInvocationServiceto inform the InvocationObserver that a member has finished running theInvocableobject; the result of the invocation, if any, is provided to the InvocationObserver.
- MemberEvent - Class in com.tangosol.net
- 
An event which indicates that membership has changed: a Member has joined a Member is leaving a Member has left A MemberEvent object is sent as an argument to the MemberListener interface methods.
- MemberEvent(Object, int, Member) - Constructor for class com.tangosol.net.MemberEvent
- 
Constructs a new MemberEvent.
- memberFailed(Member, Throwable) - Method in interface com.tangosol.net.InvocationObserver
- 
This method is called by theInvocationServiceto inform the InvocationObserver that a member has thrown an exception while running theInvocableobject.
- MEMBERID_COMPARATOR - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Comparator used to provide arbitrary (equals-compatible) comparisons between members.
- MemberIdentity - Interface in com.tangosol.net
- 
The MemberIdentity interface represents the identity of a cluster member.
- MemberIdentityProvider - Interface in com.tangosol.net
- 
A provider of values for a member's identity.
- memberJoined(MemberEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ServiceListener
- memberJoined(MemberEvent) - Method in class com.tangosol.net.cache.NearCache.BackServiceListener
- 
Invoked when a Member has joined the service.
- memberJoined(MemberEvent) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener
- 
Invoked when a Member has joined the service.
- memberJoined(MemberEvent) - Method in interface com.tangosol.net.MemberListener
- 
Invoked when a Member has joined the service.
- memberJoined(MemberEvent) - Method in class com.tangosol.net.partition.FailoverAccessPolicy.MembershipListener
- 
Invoked when a Member has joined the service.
- memberLeaving(MemberEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ServiceListener
- memberLeaving(MemberEvent) - Method in class com.tangosol.net.cache.NearCache.BackServiceListener
- 
Invoked when a Member is leaving the service.
- memberLeaving(MemberEvent) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener
- 
Invoked when a Member is leaving the service.
- memberLeaving(MemberEvent) - Method in interface com.tangosol.net.MemberListener
- 
Invoked when a Member is leaving the service.
- memberLeaving(MemberEvent) - Method in class com.tangosol.net.partition.FailoverAccessPolicy.MembershipListener
- 
Invoked when a Member is leaving the service.
- memberLeft(Member) - Method in interface com.tangosol.net.InvocationObserver
- 
This method is called by theInvocationServiceto inform the InvocationObserver that a member that theInvocableobject was intended for execution upon has left the service (or the cluster).
- memberLeft(MemberEvent) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ServiceListener
- memberLeft(MemberEvent) - Method in class com.tangosol.net.cache.NearCache.BackServiceListener
- 
Invoked when a Member has left the service.
- memberLeft(MemberEvent) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener
- 
Invoked when a Member has left the service.
- memberLeft(MemberEvent) - Method in interface com.tangosol.net.MemberListener
- 
Invoked when a Member has left the service.
- memberLeft(MemberEvent) - Method in class com.tangosol.net.partition.FailoverAccessPolicy.MembershipListener
- 
Invoked when a Member has left the service.
- MemberListener - Interface in com.tangosol.net
- 
The listener interface for receiving MemberEvents.
- MemberListenerProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
An ElementProcessor to process a <member-listener> to produce a List containing a single MemberListener.
- MemberListenerProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MemberListenerProcessor
- 
Constructs aMemberListenerProcessor.
- MembershipListener() - Constructor for class com.tangosol.net.partition.FailoverAccessPolicy.MembershipListener
- MembershipQuorumPolicy() - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Create a MembershipQuorumPolicy.
- memchr(byte[], int, int, byte) - Static method in class com.tangosol.util.Binary
- 
Find the specified byte (a "needle") in the specified binary region ("the haystack").
- memchr(byte[], int, int, byte, boolean) - Static method in class com.tangosol.util.Binary
- 
Find the specified byte (a "needle") in the specified binary region ("the haystack").
- memcmp(byte[], int, int, byte[], int, int) - Static method in class com.tangosol.util.Binary
- 
Compare two binary regions.
- memcpy(byte[], int, byte[], int, int) - Static method in class com.tangosol.util.Binary
- 
Copy binary data from one binary region to another.
- memmem(byte[], int, int, byte[], int, int) - Static method in class com.tangosol.util.Binary
- 
Find the second binary region (a "needle") in the first binary region ("the haystack").
- memmem(byte[], int, int, byte[], int, int, boolean) - Static method in class com.tangosol.util.Binary
- 
Find the second binary region (a "needle") in the first binary region ("the haystack").
- MemorySizeProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AMemorySizeProcessoris responsible for processing Coherence memory sizes and returning them in bytes.
- MemorySizeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MemorySizeProcessor
- 
Constructs aMemorySizeProcessor.
- merge() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Merge a free block with any free blocks that it borders.
- merge(TopNAggregator.PartialResult<E>) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- 
Merge single PartialResult into this PartialResult.
- merge(QueryRecord.PartialResult) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Merge the given result with this one.
- merge(QueryRecord.PartialResult.Step) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Merge the given step with this one.
- merge(ValueExtractor[], ValueExtractor[]) - Static method in class com.tangosol.util.extractor.ChainedExtractor
- 
Return aValueExtractorarray with the provided arrays merged into a single array.
- merge(Object, Object, BiFunction) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- merge(Object, Object, BiFunction) - Method in class com.tangosol.util.SafeSortedMap
- merge(Object, Object, BiFunction) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- merge(K, V, Remote.BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
If the specified key is not already associated with a value or is associated with null, associates it with the given non-null value.
- merge(K, V, Remote.BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- 
If the specified key is not already associated with a value or is associated with null, associates it with the given non-null value.
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.tangosol.util.SafeHashMap
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- merge(TK, TV, Remote.BiFunction<? super TV, ? super TV, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- merge(TK, TV, Remote.BiFunction<? super TV, ? super TV, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- merge(TK, TV, BiFunction<? super TV, ? super TV, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- merge(TK, TV, BiFunction<? super TV, ? super TV, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- mergeArray(T[], T[]) - Static method in class com.tangosol.util.Base
- 
Merge two array with type T elements.
- mergeBooleanArray(boolean[], boolean[]) - Static method in class com.tangosol.util.Base
- 
Merge two boolean arrays.
- mergeByteArray(byte[], byte[]) - Static method in class com.tangosol.util.Base
- 
Merge two byte arrays.
- mergeCharArray(char[], char[]) - Static method in class com.tangosol.util.Base
- 
Merge two char arrays.
- mergeDoubleArray(double[], double[]) - Static method in class com.tangosol.util.Base
- 
Merge two double arrays.
- mergeEvents(MapEvent, MapEvent) - Static method in class com.tangosol.net.cache.OverflowMap
- 
Merge two events that have been raised in sequence from a given map.
- mergeEvents(MapEvent, MapEvent) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Merge two events that have been raised in sequence from a given map.
- mergeFilter(Filter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- mergeFloatArray(float[], float[]) - Static method in class com.tangosol.util.Base
- 
Merge two float arrays.
- mergeIncludes(String, XmlElement, ClassLoader) - Static method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Merge all included POF configuration files into the given xml configuration.
- mergeIntArray(int[], int[]) - Static method in class com.tangosol.util.Base
- 
Merge two int arrays.
- mergeLongArray(long[], long[]) - Static method in class com.tangosol.util.Base
- 
Merge two long arrays.
- mergeResults(Collection) - Method in class com.tangosol.util.SimpleQueryRecord
- 
Merge the partial results from the associated record.
- mergeSchema(XmlElement, XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Merge thexmlnsschema attributes andxsi:schemaLocationattribute of the targetXmlElementinto the sourceXmlElement.
- Message - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.Notification
- MessageDeliveryModeProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor JMS <message-delivery-mode> configurations.
- MessageDeliveryModeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MessageDeliveryModeProcessor
- META_EXTENT - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
The extent-id used to store cache metadata.
- META_FILENAME - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Persistence metadata filename.
- META_IMPL_VERSION - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Persistence metadata property: implementation version.
- META_PARTITION_COUNT - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Persistence metadata property: partition count.
- META_SERVICE_VERSION - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Persistence metadata property: service version.
- META_STORAGE_FORMAT - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Persistence metadata property: storage format.
- META_STORAGE_VERSION - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Persistence metadata property: storage version.
- METHOD_CALL_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of aReflectionExtractorthat will call a specific method.
- METHOD_SUFFIX - Static variable in class com.tangosol.util.extractor.UniversalExtractor
- 
IfUniversalExtractor.m_sNameends with this suffix, it represents a method name.
- METHOD_SUFFIX - Static variable in class com.tangosol.util.extractor.UniversalUpdater
- 
IfUniversalUpdater.m_sNameends with this suffix, it represents a method name.
- MethodInvocationProcessor<K,V,R> - Class in com.tangosol.util.processor
- 
An entry processor that invokes specified method on a value of a cache entry and optionally updates the entry with a modified value.
- MethodInvocationProcessor() - Constructor for class com.tangosol.util.processor.MethodInvocationProcessor
- 
Deserialization constructor.
- MethodInvocationProcessor(Remote.Supplier<V>, String, boolean, Object...) - Constructor for class com.tangosol.util.processor.MethodInvocationProcessor
- 
Construct MethodInvocationProcessor instance.
- MethodInvocationProcessor(String, boolean, Object...) - Constructor for class com.tangosol.util.processor.MethodInvocationProcessor
- 
Construct MethodInvocationProcessor instance.
- METHODS - Static variable in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Method names that should be tried in order when looking for a method that can be used for conversion from string.
- MetricsLabels - Annotation Type in com.tangosol.net.management.annotation
- 
The MetricsLabels descriptor annotation adds ametrics.labelsfield and its value to thedescriptorfor a method on an MBean.
- MetricsScope - Annotation Type in com.tangosol.net.management.annotation
- 
The MetricsScope descriptor annotation adds a metrics.scope field and its value to thedescriptorfor an MBean.
- MetricsTag - Annotation Type in com.tangosol.net.management.annotation
- 
The MetricsTag descriptor annotation adds ametrics.tagfield and its value to thedescriptorfor a method on an MBean.
- MetricsValue - Annotation Type in com.tangosol.net.management.annotation
- 
The MetricsValue descriptor annotation adds a metrics.value field and its value to thedescriptorfor a method on an MBean.
- MGR_CONTEXT - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The name of the replaceable parameter representing the backing map manager context.
- MGR_CONTEXT - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The name of the replaceable parameter representing the backing map manager context.
- Millis - Class in com.tangosol.coherence.config.unit
- 
Millisis a specializedDurationwhose default constructor assumes that the specified units of time (when the unit magnitude is not specified) are milliseconds.
- Millis(Duration) - Constructor for class com.tangosol.coherence.config.unit.Millis
- 
Constructs aMillisbased on anotherDuration.
- Millis(String) - Constructor for class com.tangosol.coherence.config.unit.Millis
- 
Constructs aMillisrepresenting aDurationmeasured in milliseconds.
- MillisProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AMillisProcessoris responsible for processing Coherence time values and returning them in milliseconds.
- MillisProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.MillisProcessor
- 
Constructs aMillisProcessor.
- min() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns anOptionalDoubledescribing the minimum element of this stream, or an empty OptionalDouble if this stream is empty.
- min() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns anOptionalIntdescribing the minimum element of this stream, or an empty optional if this stream is empty.
- min() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns anOptionalLongdescribing the minimum element of this stream, or an empty optional if this stream is empty.
- min(VersionedPartitions, VersionedPartitions) - Static method in class com.tangosol.util.MapListenerSupport
- 
Return the minimum versions for the provided two partition versioned data structures.
- min(Filter<?>, Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToComparableFunction<? super T, R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToComparableFunction<? super T, R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Filter<?>, Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Remote.Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns the minimum element of this stream according to the providedComparator.
- min(Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToBigDecimalFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of the BigDecimal values extracted from a set of entries in a Map.
- min(Remote.ToComparableFunction<? super T, ? extends R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of the Comparable values extracted from a set of entries in a Map.
- min(Remote.ToComparableFunction<? super T, R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToComparableFunction<? super T, R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToDoubleFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of the double values extracted from a set of entries in a Map.
- min(Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToIntFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of the int values extracted from a set of entries in a Map.
- min(Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the minimum value of the specified function.
- min(Remote.ToLongFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a minimum of the long values extracted from a set of entries in a Map.
- min(ValueExtractor<? super U, ? extends Comparable>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns the minimum element of this stream according to the attribute extracted by the providedValueExtractor.
- min(Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns the minimum element of this stream according to the providedComparator.
- MIN_BLOCK - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
Minimum length of an "extract" block to encode.
- MIN_DECIMAL128_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Minimum scale for the IEEE-754r 128-bit decimal format.
- MIN_DECIMAL32_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Minimum scale for the IEEE-754r 32-bit decimal format.
- MIN_DECIMAL64_SCALE - Static variable in interface com.tangosol.io.pof.PofConstants
- 
Minimum scale for the IEEE-754r 64-bit decimal format.
- MIN_ENTRY - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
Minimum size of an Entry block.
- MIN_FREE - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
Minimum size of a free block.
- MIN_PORT - Static variable in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- MIN_REQUEUE_DELAY - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
- 
The minimum "retry after requeue" time interval.
- MIN_SEGMENT_CAPACITY - Static variable in class com.tangosol.util.SegmentedHashMap
- 
The minimum segment capacity.
- MIN_SNAPSHOT_REFRESH - Static variable in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- 
The minimum amount of time between request duration histogram snapshots.
- MIN_SPLIT - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
Minimum size of a block to split off a free block.
- minBy(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the entity with the minimum value of the specified function.
- minBy(Filter<?>, ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the entity with the minimum value of the specified function.
- minBy(Remote.Comparator<? super T>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
- 
Returns aRemote.BinaryOperatorwhich returns the lesser of two elements according to the specifiedComparator.
- minBy(Remote.Comparator<? super T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat produces the minimal element according to a givenComparator, described as anOptional<T>.
- minBy(ValueExtractor<? super T, ? extends E>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
- 
Returns aRemote.BinaryOperatorwhich returns the lesser of two elements according to the specifiedComparablevalue.
- minBy(ValueExtractor<? super T, ? extends E>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat produces the minimal element according to a givenComparableattribute, described as anOptional<T>.
- minBy(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the entity with the minimum value of the specified function.
- minBy(ValueExtractor<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the entity with the minimum value of the specified function.
- minBy(Comparator<? super T>) - Static method in interface com.tangosol.util.function.Remote.BinaryOperator
- 
Returns aRemote.BinaryOperatorwhich returns the lesser of two elements according to the specifiedComparator.
- MirroringAssignmentStrategy - Class in com.tangosol.net.partition
- 
A PartitionAssignmentStrategy used by a service to attempt to co-locate the primary ownership of partitions on the same members as another service.
- MirroringAssignmentStrategy(String) - Constructor for class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Construct a MirroringAssignmentStrategy to be associated the specified service.
- mod(int, int) - Static method in interface com.oracle.coherence.common.base.Hasher
- 
Calculate a modulo of two integer numbers.
- mod(int, int) - Static method in class com.tangosol.util.Base
- 
Calculate a modulo of two integer numbers.
- mod(long, long) - Static method in interface com.oracle.coherence.common.base.Hasher
- 
Calculate a modulo of two long numbers.
- mod(long, long) - Static method in class com.tangosol.util.Base
- 
Calculate a modulo of two long numbers.
- MODE_DEBUG - Static variable in class com.tangosol.io.nio.BinaryMap
- 
True to enable debug mode.
- Model<S extends Enum<S>> - Interface in com.tangosol.util.fsm
- 
AModelrepresents the definition of aFiniteStateMachine, the set of known states,Transitions between said states andStateEntryActions /StateExitActions to be performed when said states are changed.
- modified(long, ExpiryPolicy) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Update theJCacheEntryMetaInfbased on the associated entry being modified at the specified time.
- monitorServices(long) - Method in class com.tangosol.net.DefaultCacheServer
- 
Check the ServiceMonitor status ensuring it is monitoring services.
- monitorServices(long) - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Check the service status periodically (keep alive interval), restarting any stopped services.
- MONTH_NAME - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Format month name.
- MOST_RECENT - com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent.Process
- 
MOST_RECENT indicates that the most recently submittedEventfor a specified discriminator will be processed.
- moveDir(File, File) - Static method in class com.tangosol.io.FileHelper
- 
Move the specified directory to the specified destination path.
- moveExtent(long, long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Move the specified extent from the old extent id to the new extent id.
- moveExtent(long, long) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Move the specified extent from the old extent id to the new extent id.
- moveExtent(long, long) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- moveExtentInternal(long, long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Move the specified extent from the old extent id to the new extent id.
- moveExtents(PersistentStore, long, long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Move the old extent to the new extent in the specifiedstoreincluding all associated extents (meta extents).
- moveFile(File, File) - Static method in class com.tangosol.io.FileHelper
- 
Move the specified file to the specified destination path.
- moveOffset(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Move the offset within the stream forward.
- moveOffset(int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Move the offset within the stream forward.
- MpMetricsRegistryAdapter - Class in com.oracle.coherence.mp.metrics
- 
An implementation ofMetricsRegistryAdapterregisters Coherence metrics with Helidon's vendor or application registry.
- MpMetricsRegistryAdapter(MetricRegistry, MetricRegistry) - Constructor for class com.oracle.coherence.mp.metrics.MpMetricsRegistryAdapter
- 
Construct aMpMetricsRegistryAdapter.
- MSG_NO_PENDING - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The message returned by SimpleStrategyMBean when all suggested distributions have completed and none are in-progress or scheduled.
- MSG_NO_RESULT - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
The message returned by SimpleStrategyMBean when the distribution coordinator has not done its first analysis yet.
- multi(ValueExtractor<T, ?>...) - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that extracts values using the specifiedValueExtractors and returns the extracted values in aList.
- multi(String...) - Static method in class com.tangosol.util.Extractors
- 
Returns an extractor that extracts the specified fields and returns the extracted values in aList.
- MultiBufferInput() - Constructor for class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Default constructor.
- MultiBufferInput(boolean) - Constructor for class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Default constructor.
- MultiBufferOutput(int) - Constructor for class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Construct an AbstractBufferOutput that will begin writing at the specified offset within the containing WriteBuffer.
- MultiBufferReadBuffer - Class in com.tangosol.io
- 
The MultiBufferReadBuffer is a ReadBuffer implementation that presents a view across any number of underlying ReadBuffer objects, as if they were appended end-to-end into a single ReadBuffer.
- MultiBufferReadBuffer(ReadBuffer[]) - Constructor for class com.tangosol.io.MultiBufferReadBuffer
- 
Construct a MultiBufferReadBuffer from an array of underlying ReadBuffer objects.
- MultiBufferReadBuffer.MultiBufferInput - Class in com.tangosol.io
- 
An implementation of the BufferInput interface that is backed by a series of the underlying ReadBuffer BufferInput objects.
- MultiBufferWriteBuffer - Class in com.tangosol.io
- 
The MultiBufferWriteBuffer is used to present a single WriteBuffer that collects together a sequence of underlying WriteBuffer objects, and which grows by allocating additional WriteBuffer objects as necessary.
- MultiBufferWriteBuffer(MultiBufferWriteBuffer.WriteBufferPool) - Constructor for class com.tangosol.io.MultiBufferWriteBuffer
- 
Construct a MultiBufferWriteBuffer that will use the passed WriteBufferPool to allocate WriteBuffer objects from.
- MultiBufferWriteBuffer(MultiBufferWriteBuffer.WriteBufferPool, int) - Constructor for class com.tangosol.io.MultiBufferWriteBuffer
- 
Construct a MultiBufferWriteBuffer that will use the passed WriteBufferPool to allocate WriteBuffer objects from.
- MultiBufferWriteBuffer.MultiBufferOutput - Class in com.tangosol.io
- 
The MultiBufferOutput implementation extends the AbstractBufferOutput to provide "pass through" operations to the underlying buffer if the operation is guaranteed to fit in the underlying buffer; otherwise, it virtualizes the operation onto the MultiBufferWriteBuffer itself so that the over-run of one underlying WriteBuffer will end up being written to the next underlying WriteBuffer.
- MultiBufferWriteBuffer.WriteBufferPool - Interface in com.tangosol.io
- 
A WriteBufferPool is used to dynamically allocate WriteBuffer objects as the MultiBufferWriteBuffer requires them.
- MultiByteArrayInputStream - Class in com.tangosol.io
- 
Reads binary data from a series of byte arrays.
- MultiByteArrayInputStream(byte[][]) - Constructor for class com.tangosol.io.MultiByteArrayInputStream
- 
Construct a MultiByteArrayInputStream.
- MultiByteArrayInputStream(byte[][], boolean) - Constructor for class com.tangosol.io.MultiByteArrayInputStream
- 
Construct a MultiByteArrayInputStream.
- MultiByteArrayOutputStream - Class in com.tangosol.io
- 
An OutputStream that accumulates the written data to a series of byte arrays that do not exceed a specified size.
- MultiByteArrayOutputStream(int) - Constructor for class com.tangosol.io.MultiByteArrayOutputStream
- 
Construct a MultiByteArrayOutputStream to write to byte arrays of the specified length.
- MultiByteArrayOutputStream(int, int, int) - Constructor for class com.tangosol.io.MultiByteArrayOutputStream
- 
Construct a MultiByteArrayOutputStream to write to byte arrays of the specified length, leaving the specified amount of padding at the front and back of each byte array.
- MultiExtractor - Class in com.tangosol.util.extractor
- 
Composite ValueExtractor implementation based on an array of extractors.
- MultiExtractor() - Constructor for class com.tangosol.util.extractor.MultiExtractor
- 
Default constructor (necessary for the ExternalizableLite interface).
- MultiExtractor(ValueExtractor[]) - Constructor for class com.tangosol.util.extractor.MultiExtractor
- 
Construct a MultiExtractor.
- MultiExtractor(String) - Constructor for class com.tangosol.util.extractor.MultiExtractor
- 
Construct a MultiExtractor for a specified method name list.
- MultiIterator(int) - Constructor for class com.tangosol.util.ImmutableMultiList.MultiIterator
- MultiplexingMapListener<K,V> - Class in com.tangosol.util
- 
A base class that simplifies the implementation of a MapListener by multiplexing all events into a single listener method.
- MultiplexingMapListener() - Constructor for class com.tangosol.util.MultiplexingMapListener
- MultiplexingSerializer - Class in com.tangosol.io
- 
ASerializerimplementation that multiplexes serialization/deserialization requests across multipleSerializerimplementations.
- MultiplexingSerializer(Serializer...) - Constructor for class com.tangosol.io.MultiplexingSerializer
- 
Construct a newSerializerthat will multiplex serialization operations across the provided list ofSerializers.
- MultiplexingSerializer.SerializationHeader - Class in com.tangosol.io
- 
Simple wrapper class to hold decorated info added by the serialization process.
- MultiplicationOperator - Class in com.tangosol.coherence.dslquery.operator
- 
An operator representing the mathematical multiplication operation.
- MultiplicationOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.MultiplicationOperator
- 
Construct a MultiplicationOperator.
- multiply(PropertyManipulator<V, N>, N, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct a multiply processor that will multiply a property value by a specified factor, returning either the old or the new value as specified.
- multiply(String, N, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct a multiply processor that will multiply a property value by a specified factor, returning either the old or the new value as specified.
- MutableLong - Class in com.oracle.coherence.common.base
- 
A Long like class which supports mutation.
- MutableLong() - Constructor for class com.oracle.coherence.common.base.MutableLong
- 
Construct a MutableLong with a zero initial value.
- MutableLong(long) - Constructor for class com.oracle.coherence.common.base.MutableLong
- 
Construct a MutableLong with the specified value.
- MVEL_EXTRACTOR_BUILDER - Static variable in class com.tangosol.coherence.rest.query.CoherenceQueryLanguageEngine
- 
ExtractorBuilder to use if optionalorg.mvel.Mvel2module is on path.
- MvelExtractor - Class in com.tangosol.coherence.rest.util.extractor
- 
MVEL-based ValueExtractor implementation.
- MvelExtractor() - Constructor for class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Default constructor (necessary for the ExternalizableLite and PortableObject interfaces).
- MvelExtractor(String) - Constructor for class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Construct a MvelExtractor based on an MVEL expression.
- MvelExtractor(String, int) - Constructor for class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Construct a MvelExtractor based on an MVEL expression and an entry extraction target.
- MvelHelper - Class in com.tangosol.coherence.rest.util
- 
Enable Mvel to be optional by only accessing module via reflection with implementation provided on classpath.
- MvelHelper() - Constructor for class com.tangosol.coherence.rest.util.MvelHelper
- MvelManipulator - Class in com.tangosol.coherence.rest.util
- 
MVEL-based ValueManipulator implementation.
- MvelManipulator() - Constructor for class com.tangosol.coherence.rest.util.MvelManipulator
- 
Default constructor (necessary for the ExternalizableLite and PortableObject interfaces).
- MvelManipulator(String) - Constructor for class com.tangosol.coherence.rest.util.MvelManipulator
- 
Construct a MvelManipulator based on an MVEL expression.
- MvelUpdater - Class in com.tangosol.coherence.rest.util.updater
- 
MVEL-based ValueUpdater implementation.
- MvelUpdater() - Constructor for class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Default constructor (necessary for the ExternalizableLite and PortableObject interfaces).
- MvelUpdater(String) - Constructor for class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Construct a MvelUpdater based on an MVEL expression.
- myValueOf(String) - Static method in enum com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
N
- Name - Annotation Type in com.oracle.coherence.cdi
- 
A qualifier annotation used when injecting Coherence resource to indicate a specific resource name.
- Name() - Constructor for class com.tangosol.net.topic.Subscriber.Name
- 
Default constructor for serialization.
- Name(String) - Constructor for class com.tangosol.net.topic.Subscriber.Name
- 
Construct a new group name.
- NAME - Static variable in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
The name of the Coherence provider.
- NAME - Static variable in class com.tangosol.io.DefaultSerializer
- 
The name of this serializer.
- NAME - Static variable in class com.tangosol.net.management.MBeanAccessor
- 
The "name" key in the ObjectName.
- NAME - Static variable in class com.tangosol.net.security.SecurityProvider
- 
The name of this provider.
- NAME_DEFAULT - Static variable in interface com.tangosol.net.NameService
- 
Default service name for the NameService.
- Name.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theNameannotation.
- named(String) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Set the name of theCoherenceinstance.
- named(String) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set the name for the session to be created.
- NamedCache<K,V> - Interface in com.tangosol.net
- 
A Map-based data-structure that manages entries across one or more processes.
- NamedCacheBuilder - Interface in com.tangosol.coherence.config.builder
- 
ANamedCacheBuilderrealizesNamedCaches.
- NamedCacheProducer - Class in com.oracle.coherence.cdi
- NamedCacheService - Interface in com.oracle.coherence.grpc.proxy
- 
A NamedCache service.
- NamedCacheService.DefaultDependencies - Class in com.oracle.coherence.grpc.proxy
- 
The defaultNamedCacheService.Dependenciesimplementation.
- NamedCacheService.Dependencies - Interface in com.oracle.coherence.grpc.proxy
- 
The dependencies to configure aNamedCacheServiceImpl.
- NamedCacheServiceGrpcImpl - Class in com.oracle.coherence.grpc.proxy
- 
A plain gRPC implementation of NamedCache service.
- NamedCacheServiceGrpcImpl() - Constructor for class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- 
Create aNamedCacheServiceGrpcImplthat wraps a default implementation ofNamedCacheService.
- NamedCacheServiceGrpcImpl(NamedCacheService) - Constructor for class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- 
Create aNamedCacheServiceGrpcImplwith default configuration.
- NamedCacheServiceGrpcImpl(NamedCacheService.Dependencies) - Constructor for class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- 
Create aNamedCacheServiceGrpcImplthat wraps a default implementation ofNamedCacheService.
- NamedCacheServiceImpl - Class in com.oracle.coherence.grpc.proxy
- 
A gRPC NamedCache service.
- NamedCacheServiceImpl(NamedCacheService.Dependencies) - Constructor for class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Create aNamedCacheServiceImpl.
- NamedCollection - Interface in com.tangosol.net
- 
NamedCollection defines a common base interface for various named collection types.
- NamedCollection.Option - Interface in com.tangosol.net
- 
The Option interface defines the root interface of all NamedCollection Options.
- NamedCollectionBuilder<C extends NamedCollection> - Interface in com.tangosol.coherence.config.builder
- 
ANamedCollectionBuilderrealizesNamedCollections.
- NamedEventInterceptor<E extends Event<?>> - Class in com.tangosol.net.events
- 
A wrapper forEventInterceptors allowing additional metadata to be associated with the interceptor without augmenting the interceptor contract.
- NamedEventInterceptor(EventInterceptor<E>) - Constructor for class com.tangosol.net.events.NamedEventInterceptor
- 
Construct a NamedEventInterceptor for the specified interceptor.
- NamedEventInterceptor(EventInterceptor<E>, NamedEventInterceptor<E>) - Constructor for class com.tangosol.net.events.NamedEventInterceptor
- 
Construct a NamedEventInterceptor for the specified interceptor using the provided NamedEventInterceptor as the source to clone from.
- NamedEventInterceptor(String, EventInterceptor<E>) - Constructor for class com.tangosol.net.events.NamedEventInterceptor
- 
Construct a NamedEventInterceptor for the specified interceptor and unique identifier.
- NamedEventInterceptor(String, EventInterceptor<E>, RegistrationBehavior) - Constructor for class com.tangosol.net.events.NamedEventInterceptor
- 
Construct a NamedEventInterceptor for the specified interceptor and unique identifier.
- NamedEventInterceptor(String, EventInterceptor<E>, String, String, Interceptor.Order, RegistrationBehavior) - Constructor for class com.tangosol.net.events.NamedEventInterceptor
- 
Construct a NamedEventInterceptor for the specified interceptor.
- NamedEventInterceptor(String, EventInterceptor<E>, String, String, Interceptor.Order, RegistrationBehavior, Set<Enum>) - Constructor for class com.tangosol.net.events.NamedEventInterceptor
- 
Construct a NamedEventInterceptor for the specified interceptor.
- NamedEventInterceptorBuilder - Class in com.tangosol.coherence.config.builder
- 
An NamedEventInterceptorBuilder facilitates the construction of aNamedEventInterceptor, which wraps anEventInterceptor.
- NamedEventInterceptorBuilder() - Constructor for class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- NamedMap<K,V> - Interface in com.tangosol.net
- 
A Map-based data-structure that manages entries across one or more processes.
- NamedMap.Option - Interface in com.tangosol.net
- 
An immutable option for requesting and configuringNamedMaps.
- NamedQuery - Class in com.tangosol.coherence.rest.config
- 
Holder for configured named query data.
- NamedQuery(String, String, String, int) - Constructor for class com.tangosol.coherence.rest.config.NamedQuery
- 
Construct an instance of NamedQuery.
- NamedQueryResource - Class in com.tangosol.coherence.rest
- 
REST resource representing a set of filtered cache entries.
- NamedQueryResource(NamedCache, NamedQuery, int) - Constructor for class com.tangosol.coherence.rest.NamedQueryResource
- 
Create a instance of NamedQueryResource.
- NamedResourceBuilder<T> - Class in com.tangosol.coherence.config.builder
- NamedResourceBuilder(ParameterizedBuilder<T>, String) - Constructor for class com.tangosol.coherence.config.builder.NamedResourceBuilder
- NamedSerializerFactory - Interface in com.tangosol.io
- 
A factory that producesSerializerinstances for a given name.
- NamedTopic<V> - Interface in com.tangosol.net.topic
- 
NamedTopic represents a topic entity for publish/subscribe messaging.
- NamedTopic.ElementCalculator - Interface in com.tangosol.net.topic
- 
A unit calculator is an object that can calculate the cost of storing an element in a topic.
- NamedTopicProducer - Class in com.oracle.coherence.cdi
- NamedTopicProducer(BeanManager) - Constructor for class com.oracle.coherence.cdi.NamedTopicProducer
- 
Create the {2link NamedTopicProducer}.
- NamedTopicScheme - Interface in com.tangosol.coherence.config.scheme
- 
TheTopicSchemeclass is responsible for building a fully configured instance of aNamedTopic.
- NameListDependencies(String) - Constructor for class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
- NameService - Interface in com.tangosol.net
- 
A NameService is a service that accepts connections from external clients (e.g.
- NameService.LookupCallback - Interface in com.tangosol.net
- 
An object which implementsNameService.LookupCallbackcan be registered with aNameServiceviaNameService.addLookupCallback(com.tangosol.net.NameService.LookupCallback)to perform a lookup on names that were not found in the NameService's directory.
- NameService.RequestContext - Interface in com.tangosol.net
- 
An object which implementsNameService.RequestContextstores information about the NameService request.
- NameService.Resolvable - Interface in com.tangosol.net
- 
During thelookupcall, if the retrieved object isNameService.Resolvable, then the result of theresolvecall is returned.
- NamespaceHandler - Interface in com.tangosol.config.xml
- 
ANamespaceHandleris responsible for defining theDocumentPreprocessor,ElementProcessors andAttributeProcessors required for processing xml content belonging to a specific xml namespace used in an xml document.
- NaturalAssociator - Class in com.oracle.coherence.common.base
- 
NaturalAssociator provides an Associator implementation for objects that implement theAssociatedinterface.
- NaturalAssociator() - Constructor for class com.oracle.coherence.common.base.NaturalAssociator
- NaturalCloner - Class in com.oracle.coherence.common.base
- 
A Cloner that clonesCloneableobjects.
- NaturalCloner() - Constructor for class com.oracle.coherence.common.base.NaturalCloner
- NaturalComparator<T extends Comparable<T>> - Class in com.oracle.coherence.common.base
- 
NaturalComparator is a comparator which simply delegates to a Comparable object's compare implementation.
- NaturalComparator() - Constructor for class com.oracle.coherence.common.base.NaturalComparator
- NaturalHasher<V> - Class in com.oracle.coherence.common.base
- NaturalHasher() - Constructor for class com.oracle.coherence.common.base.NaturalHasher
- naturalOrder() - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a comparator that comparesComparableobjects in natural order.
- navigableKeySet() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- navigate(PofValue) - Method in class com.tangosol.io.pof.reflect.AbstractPofPath
- 
Locate thePofValueidentified by this PofNavigator within the passed PofValue.
- navigate(PofValue) - Method in interface com.tangosol.io.pof.reflect.PofNavigator
- 
Locate thePofValueidentified by this PofNavigator within the passed PofValue.
- NearCache<K,V> - Class in com.tangosol.net.cache
- 
A "near cache" is a CachingMap whose front map is a size-limited and/or auto-expiring local cache, and whose back map is a distributed cache.
- NearCache(Map<K, V>, NamedCache<K, V>) - Constructor for class com.tangosol.net.cache.NearCache
- 
Construct a NearCache, using a mapBack NamedCache as the complete (back) storage and mapFront Map as a near (front) storage using theCachingMap.LISTEN_AUTOinvalidation strategy.
- NearCache(Map<K, V>, NamedCache<K, V>, int) - Constructor for class com.tangosol.net.cache.NearCache
- 
Construct a NearCache, using a mapBack NamedCache as the complete (back) storage and mapFront Map as a near (front) storage.
- NearCache.BackServiceListener - Class in com.tangosol.net.cache
- 
MemberListener for the back cache's service.
- NearScheme - Class in com.tangosol.coherence.config.scheme
- 
TheNearSchemeis used to realize (create) an instance of a NearCache.
- NearScheme() - Constructor for class com.tangosol.coherence.config.scheme.NearScheme
- negate() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Make negavite the representation of this node.
- negate() - Method in interface com.tangosol.util.function.Remote.BiPredicate
- 
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.tangosol.util.function.Remote.DoublePredicate
- 
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.tangosol.util.function.Remote.IntPredicate
- 
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.tangosol.util.function.Remote.LongPredicate
- 
Returns a predicate that represents the logical negation of this predicate.
- negate() - Method in interface com.tangosol.util.function.Remote.Predicate
- 
Returns a predicate that represents the logical negation of this predicate.
- negativeNumber(Number) - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Make negative the given number that supposedly came from this node.
- NestedBaseTokens - Class in com.tangosol.coherence.dsltools.base
- 
NestedBaseTokens is a token that holds a sequence of tokens as well as the two bracketing characters.
- NestedBaseTokens(char, char, BaseToken[]) - Constructor for class com.tangosol.coherence.dsltools.base.NestedBaseTokens
- 
Construct a new NestedBaseTokens with the given parameters.
- NestingOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
NestingOPToken is an abstract classused to implement parsing situation where some nesting is implied.
- NestingOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.NestingOPToken
- 
Construct a new NestingOPToken with the given parameters.
- NestingOPToken(String, int, String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.NestingOPToken
- 
Construct a new NestingOPToken with the given parameters.
- never() - Static method in class com.tangosol.util.Filters
- 
Return a filter that always evaluates to false.
- NeverFilter<T> - Class in com.tangosol.util.filter
- 
Filter which always evaluates to false.
- NeverFilter() - Constructor for class com.tangosol.util.filter.NeverFilter
- 
Construct a NeverFilter.
- newAST(String, Term) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Create an Abstract Syntax Node for the given arguments.
- newAST(String, String) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Create an Abstract Syntax Node for the given arguments.
- newAST(String, String, Term) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Create an Abstract Syntax Node for the given arguments.
- newAST(String, String, Term, Term) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Create an Abstract Syntax Node for the given arguments.
- newAST(String, String, Term, Term, Term) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Create an Abstract Syntax Node for the given arguments.
- newBinary(byte[], int, int) - Method in class com.tangosol.util.Unsafe
- 
Return a newBinaryinstance backed by the specified byte[] beginning at the specified offset and of the specified length.
- newCondition() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- newCondition() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.ReadLock
- 
ThrowsUnsupportedOperationExceptionbecauseReadLocksdo not support conditions.
- newCondition() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- newEngine(ByteBufAllocator) - Method in class com.oracle.coherence.grpc.RefreshableSslContext
- newEngine(ByteBufAllocator, String, int) - Method in class com.oracle.coherence.grpc.RefreshableSslContext
- newHashMap(int) - Static method in class com.tangosol.util.Base
- 
Construct an instance ofHashMapwith a desired number of entries and a default load factor (0.75).
- newHashMap(int, float) - Static method in class com.tangosol.util.Base
- 
Construct an instance ofHashMapwith a desired number of entries and a load factor.
- newHashSet(int) - Static method in class com.tangosol.util.Base
- 
Construct an instance ofHashSetwith a desired number of elements and a default load factor.
- newHashSet(int, float) - Static method in class com.tangosol.util.Base
- 
Construct an instance ofHashSetwith a desired number of elements and a load factor.
- newIdentifier(String) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Construct a new identifier OPToken instance with the given id.
- newInstance() - Static method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Create an instance ofNamedCacheServiceImplusing the default dependencies configuration.
- newInstance() - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on Coherence defaults.
- newInstance(NamedCacheService.Dependencies) - Static method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Create an instance ofNamedCacheServiceImplusing the default dependencies configuration.
- newInstance(DefaultDaemonPoolDependencies) - Static method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor
- 
Create aDaemonPoolExecutor.
- newInstance(XmlElement) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on the information defined byXmlElementthat of which is compliant with the "coherence-cache-config.xsd".
- newInstance(XmlElement, ClassLoader) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on the information defined byXmlElementthat of which is compliant with the "coherence-cache-config.xsd".
- newInstance(XmlElement, ClassLoader, String) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on the information defined byXmlElementthat of which is compliant with the "coherence-cache-config.xsd".
- newInstance(XmlElement, ClassLoader, String, String) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on the information defined byXmlElementthat of which is compliant with the "coherence-cache-config.xsd".
- newInstance(XmlElement, ClassLoader, String, String, Context) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on the information defined byXmlElementthat of which is compliant with the "coherence-cache-config.xsd".
- newInstance(XmlElement, ClassLoader, String, String, Context, ParameterResolver) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on the information defined byXmlElementthat of which is compliant with the "coherence-cache-config.xsd".
- newInstance(PrintWriter, InputStream, CoherenceQueryLanguage, String[]) - Static method in class com.tangosol.coherence.dslquery.QueryPlus.DependenciesHelper
- 
Create a new instance ofQueryPlus.Dependencies.
- newInstance(Class<T>) - Static method in class com.tangosol.io.pof.reflect.Codecs.AbstractCodec
- 
Return a new instance of T based on the provided Class<T>, or throw a RuntimeException.
- newInstance(Class, Object[]) - Static method in class com.oracle.coherence.common.base.Classes
- 
Instantiate the specified class using the specified parameters.
- newInstance(Class, Object[]) - Static method in class com.tangosol.util.ClassHelper
- 
Instantiate the specified class using the specified parameters.
- newInstance(String) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on the information defined by the specified cache configuration file/resource that of which is compliant with the "coherence-cache-config.xsd".
- newInstance(String, ClassLoader) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.DependenciesHelper
- 
Construct anExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory.Dependenciesinstance based on the information defined by the specified cache configuration file/resource that of which is compliant with the "coherence-cache-config.xsd".
- newLiteral(String, int) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Construct a new literal OPToken instance with the given parameters.
- newLocalAddressProviderBuilder(XmlElement) - Static method in class com.tangosol.coherence.config.xml.processor.AddressProviderBuilderProcessor
- 
Build a new AddressProviderBuilder for the local-address.
- newParameterListFromMap(Map<?, ?>) - Static method in class com.tangosol.coherence.dslquery.FilterBuilder
- 
Convert the givenMapinto aParameterList.
- newSpan(String) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Return aSpan.Builderfor the specified operation.
- newSpan(String, ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Return aSpan.Builderfor a given operation on an entry.
- newSpan(String, Set<ReadWriteBackingMap.Entry>) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Return aSpan.Builderfor a given operation on a set of entries.
- newTerm(String) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Construct a new TermNode with the given functor.
- newTerm(String, Term) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Construct a new TermNode with the given functor and given Terms.
- newTerm(String, Term[]) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Construct a new TermNode with the given functor and given Terms.
- newTerm(String, Term, Term) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Construct a new TermNode with the given functor and given Terms.
- newTerm(String, Term, Term, Term) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Construct a new TermNode with the given functor and given Terms.
- newTerm(String, Term, Term, Term, Term) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Construct a new TermNode with the given functor and given Terms.
- newTerm(String, Term, Term, Term, Term, Term) - Static method in class com.tangosol.coherence.dsltools.termtrees.Terms
- 
Construct a new TermNode with the given functor and given Terms.
- newThread(Runnable) - Method in class com.tangosol.util.DaemonThreadFactory
- next() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Answer the next token from the underlying reader.
- next() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
- 
Answer the next token in the stream or null if at end.
- next() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Move to the next token in the stream and return it.
- next() - Method in class com.tangosol.coherence.dsltools.termtrees.Term.TermIterator
- next() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterator
- next() - Method in class com.tangosol.coherence.jcache.common.MapEntryIteratorToCacheEntryIteratorAdapter
- next() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache.EntryIterator
- next() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache.EntryIterator
- next() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
- 
Returns the next element in the iteration.
- next() - Method in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
- next() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet.EntrySetIterator
- next() - Method in class com.tangosol.run.xml.SimpleElement.ElementIterator
- next() - Method in class com.tangosol.run.xml.SimpleParser
- 
Advances to and returns the next token.
- next() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.EntrySetIterator
- 
Returns the next element in the iteration.
- next() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection.ValuesIterator
- 
Returns the next element in the iteration.
- next() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- next() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Returns the next element in the iteration.
- next() - Method in class com.tangosol.util.ChainedEnumerator
- 
Returns the next element of this Iterator.
- next() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
- next() - Method in class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Returns the next element of this Iterator.
- next() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- next() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
Returns the next element in the iteration.
- next() - Method in class com.tangosol.util.DeltaSet.DeltaIterator
- 
Returns the next element in the interation.
- next() - Method in class com.tangosol.util.Dequeue
- 
Returns the next element of this Iterator.
- next() - Method in class com.tangosol.util.EnumerationIterator
- 
Returns the next element of this Iterator.
- next() - Method in class com.tangosol.util.FilterEnumerator
- 
Returns the next element of this Iterator.
- next() - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
- next() - Method in class com.tangosol.util.IteratorEnumerator
- 
Returns the next element of this Iterator.
- next() - Method in interface com.tangosol.util.LongArray.Iterator
- 
Returns the next element in the iteration.
- next() - Method in class com.tangosol.util.NullImplementation.NullEnumerator
- 
Returns the next element in the interation.
- next() - Method in class com.tangosol.util.OpenHashMap.EntrySet.EntrySetIterator
- 
Returns the next element in the iteration.
- next() - Method in class com.tangosol.util.PagedIterator
- 
Return the next element in the iteration.
- next() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
- 
Returns the next element in the interation.
- next() - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Returns the next element in the list.
- next() - Method in class com.tangosol.util.SimpleEnumerator
- 
Returns the next element of this Iterator.
- next() - Method in class com.tangosol.util.SimpleLongArray.Iterator
- 
Returns the next element in the iteration.
- next() - Method in class com.tangosol.util.SimpleStreamer
- next() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- next(int) - Method in class com.tangosol.net.partition.PartitionSet
- 
Return an index of the first marked partition that is greater than or equal to the specified partition.
- next(int) - Method in class com.tangosol.util.Dequeue
- 
Determines the index following the passed index for storing or accessing an item from the m_ao storage.
- nextChar() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Advance to the next character and return it.
- nextElement() - Method in class com.tangosol.util.ChainedEnumerator
- 
Returns the next element of this enumeration.
- nextElement() - Method in class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Get the next element in the enumeration.
- nextElement() - Method in class com.tangosol.util.Dequeue
- 
Returns the next element from the Dequeue.
- nextElement() - Method in class com.tangosol.util.FilterEnumerator
- 
Get the next element in the enumeration.
- nextElement() - Method in class com.tangosol.util.IteratorEnumerator
- 
Returns the next element of this enumeration.
- nextElement() - Method in class com.tangosol.util.NullImplementation.NullEnumerator
- 
Returns the next element of this enumeration if this enumeration object has at least one more element to provide.
- nextElement() - Method in class com.tangosol.util.SimpleEnumerator
- 
Returns the next element of this enumeration.
- nextEntry() - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Get the next non-synthetic entry in the linked list (open hash)
- nextEntry(boolean) - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Get the next entry in the linked list (open hash).
- nextEntrySetPage(PageRequest, StreamObserver<EntryResult>) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Obtain the next page of a paged entry set request.
- nextEntrySetPage(PageRequest, StreamObserver<EntryResult>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- nextEntrySetPage(PageRequest, StreamObserver<EntryResult>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- nextIndex() - Method in class com.tangosol.io.pof.PofInputStream
- 
Determine the next property index to read from.
- nextIndex() - Method in class com.tangosol.io.pof.PofOutputStream
- 
Determine the next property index to write to.
- nextIndex() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- nextIndex() - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
- nextIndex() - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Returns the index of the element that would be returned by a subsequent call to next.
- nextIndex() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
- nextInterceptor() - Method in interface com.tangosol.net.events.Event
- 
Dispatch this event to the nextEventInterceptorin the chain if one exists.
- nextIterable(PartitionedFilter) - Method in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
Obtain the next Iterable for a given filter.
- nextIterable(PartitionedFilter) - Method in class com.tangosol.net.partition.PartitionedIterator
- nextKey(ByteBuffer) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Perform a blocking read, waiting for a complete packet.
- nextKeySetPage(PageRequest, StreamObserver<BytesValue>) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Obtain the next page of a paged key set request.
- nextKeySetPage(PageRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- nextKeySetPage(PageRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- nextNode() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Returns the next Node in the iteration.
- nextPage() - Method in class com.tangosol.util.filter.LimitFilter
- 
Switch to the next page.
- nextPage() - Method in interface com.tangosol.util.PagedIterator.Advancer
- 
Obtain a new page of objects to be used by the enclosing PagedIterator.
- nextPartition() - Method in interface com.tangosol.net.partition.VersionedPartitions.Iterator
- 
Return and progress this Iterator to the next partition.
- nextPrimitive() - Method in class com.tangosol.util.PrimitiveSparseArray.Iterator
- 
Returns the next element (as a long) in the iteration.
- nextVersion() - Method in interface com.tangosol.net.partition.VersionedPartitions.VersionedIterator
- 
Return the next version by progressing this iterator to the next element in this Iterator.
- NIL - Static variable in class com.tangosol.io.nio.BinaryMap
- 
Offset reserved for the "does-not-exist" block.
- NilPofValue(PofValue, PofContext, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.PofSparseArray.NilPofValue
- 
Construct a NilPofValue instance.
- NioFileManagerBuilder - Class in com.tangosol.coherence.config.builder.storemanager
- 
The NioFileManagerBuilder class builds an instance of a MappedStoreManager.
- NioFileManagerBuilder() - Constructor for class com.tangosol.coherence.config.builder.storemanager.NioFileManagerBuilder
- NO_BINARY - Static variable in class com.tangosol.io.AbstractReadBuffer
- 
An empty Binary object.
- NO_BINARY - Static variable in class com.tangosol.io.AbstractWriteBuffer
- 
An empty Binary object.
- NO_BINARY - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
An empty Binary object.
- NO_BYTES - Static variable in class com.tangosol.io.AbstractReadBuffer
- 
An empty byte array (by definition immutable).
- NO_BYTES - Static variable in class com.tangosol.io.AbstractWriteBuffer
- 
An empty byte array (by definition immutable).
- NO_LISTENERS - Variable in class com.tangosol.util.MapListenerSupport
- 
An empty set of Listeners.
- NO_LONGS - Static variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
An empty long array (by definition immutable).
- NO_REFRESH - Static variable in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
The default auto-refresh period - no refresh.
- NO_STRINGS - Static variable in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
An empty String array (by definition immutable).
- NO_STRINGS - Static variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
An empty String array (by definition immutable).
- NO_VALUE - Static variable in class com.tangosol.util.AbstractSafeLongArray
- 
A value guaranteed to never be in the array.
- NO_VALUE - Static variable in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Tag object indicating that a corresponding value has not been converted.
- NO_VALUE - Static variable in class com.tangosol.util.InflatableCollection
- 
A marker value indicating that the single value has not been initialized.
- NO_VALUE - Static variable in interface com.tangosol.util.MapIndex
- 
Constant used to indicate that the index does not contain requested value.
- NO_VALUE - Static variable in class com.tangosol.util.MapSet
- 
A no-value object.
- NO_VALUE - Static variable in class com.tangosol.util.SegmentedHashMap
- 
Object to be used as a value representing that the Entry object is "synthetic" and while logically associated with a key, does not represent a key-value mapping in the Map.
- NO_VALUE - Static variable in class com.tangosol.util.SimpleMapEntry
- 
Constant used to indicate that the original value does not exist.
- NO_VALUE - Static variable in class com.tangosol.util.SortedBag
- 
Marker value object.
- Node() - Constructor for class com.tangosol.util.AbstractSparseArray.Node
- Node() - Constructor for class com.tangosol.util.RecyclingLinkedList.Node
- 
Construct a blank Node.
- Node() - Constructor for class com.tangosol.util.SafeLinkedList.Node
- 
Construct a blank Node.
- Node(Object) - Constructor for class com.tangosol.util.RecyclingLinkedList.Node
- 
Construct a Node with a value.
- Node(Object) - Constructor for class com.tangosol.util.SafeLinkedList.Node
- 
Construct a Node with a value.
- NODE_ID - Static variable in class com.tangosol.net.management.MBeanAccessor
- 
The "nodeId" key in the ObjectName.
- NODE_SAFE - com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
Any cluster member could be stopped without data loss.
- NODE_SAFE - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Node-safety (members are different).
- NODE_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the ClusterNodeMBean.
- nodeList() - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Parse a comma separated sequence of expressions to the of the tokens.
- nodeList(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Parse a comma separated sequence of expressions upto the given end marker.
- nodeList(String, boolean) - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Parse a comma separated sequence of expressions upto the given end marker.
- NodeTerm - Class in com.tangosol.coherence.dsltools.termtrees
- 
NodeTerm is the class used to represent trees of Terms that can have children.
- NodeTerm(String) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor.
- NodeTerm(String, Term) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor and given Terms.
- NodeTerm(String, Term[]) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor and given Terms.
- NodeTerm(String, Term[], Term) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor and given Terms.
- NodeTerm(String, Term, Term) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor and given Terms.
- NodeTerm(String, Term, Term[]) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor and given Terms.
- NodeTerm(String, Term, Term, Term) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor and given Terms.
- NodeTerm(String, Term, Term, Term, Term) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor and given Terms.
- NodeTerm(String, Term, Term, Term, Term, Term) - Constructor for class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Construct a new TermNode with the given functor and given Terms.
- NON_TRANSFORMABLE - com.tangosol.net.cache.CacheEvent.TransformationState
- 
Value used to indicate that an event is non-transformable and should not be passed to any transformer-based listeners.
- NonBlocking - Class in com.oracle.coherence.common.base
- 
NonBlocking allows a thread to mark itself as non-blocking and should be exempt from things such as flow-control pauses using a try-with-resource pattern.
- NonBlocking() - Constructor for class com.oracle.coherence.common.base.NonBlocking
- NonBlockingEntryStore<K,V> - Interface in com.tangosol.net.cache
- 
NonBlockingEntryStore provides a means to integrate Coherence with an underlying data source that offers a non-blocking API.
- NonBlockingEntryStoreWrapper(NonBlockingEntryStore) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Construct a NonBlockingEntryStoreWrapper.
- NonBlockingFiniteStateMachine<S extends Enum<S>> - Class in com.tangosol.util.fsm
- 
AnNonBlockingFiniteStateMachineis a specializedFiniteStateMachineimplementation that performs transitions asynchronously to the threads that request state changes.
- NonBlockingFiniteStateMachine(String, Model<S>, S, DaemonPoolDependencies, boolean, NonBlockingFiniteStateMachine.TaskDependencies) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Construct anNonBlockingFiniteStateMachinegiven aModel.
- NonBlockingFiniteStateMachine.CoalescedEvent<S extends Enum<S>> - Class in com.tangosol.util.fsm
- 
ANonBlockingFiniteStateMachine.CoalescedEventis aLifecycleAwareEventthat coalesces other (wrapped)Events with the same discriminator so that only oneEventactually executes.
- NonBlockingFiniteStateMachine.CoalescedEvent.Discriminator - Class in com.tangosol.util.fsm
- 
ANonBlockingFiniteStateMachine.CoalescedEvent.Discriminatoris an object that is used to uniquely differentiate events to be coalesced, scoped by aNonBlockingFiniteStateMachine.
- NonBlockingFiniteStateMachine.CoalescedEvent.Process - Enum in com.tangosol.util.fsm
- 
TheNonBlockingFiniteStateMachine.CoalescedEventto process.
- NonBlockingFiniteStateMachine.DefaultTaskDependencies - Class in com.tangosol.util.fsm
- 
Implementation of Dependencies for Task
- NonBlockingFiniteStateMachine.DelayedTransitionTo<S extends Enum<S>> - Class in com.tangosol.util.fsm
- 
ANonBlockingFiniteStateMachine.DelayedTransitionTois a specializedInstructionforNonBlockingFiniteStateMachines that enables aStateEntryActionto request a delayed transition to another state, unlike aInstruction.TransitionToInstructionwhich occurs immediately.
- NonBlockingFiniteStateMachine.ProcessEventLater<S extends Enum<S>> - Class in com.tangosol.util.fsm
- 
A specializedInstructionforNonBlockingFiniteStateMachines that enables aStateEntryActionto request anEventto be processed at some point in the future.
- NonBlockingFiniteStateMachine.SubsequentEvent<S extends Enum<S>> - Class in com.tangosol.util.fsm
- 
ANonBlockingFiniteStateMachine.SubsequentEventis anEventthat ensures that another (wrapped)Eventto occur if an only if theFiniteStateMachineis at a certain transition count.
- NonBlockingFiniteStateMachine.Task - Class in com.tangosol.util.fsm
- 
A PriorityTask implementation to process a requested event.
- NonBlockingFiniteStateMachine.TaskDependencies - Interface in com.tangosol.util.fsm
- 
Dependencies for Task.
- NonBlockingInvocable - Interface in com.tangosol.net
- 
NonBlockingInvocable is anInvocablethat can be executed asynchronously.
- NonBlockingTcpDatagramSocket - Class in com.tangosol.net
- 
TCP based non-blocking datagram socket implementation.
- NonBlockingTcpDatagramSocket() - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket
- 
Create a new NonBlockingTcpDatagramSocket that with a wildcard address bound to an ephemeral port.
- NonBlockingTcpDatagramSocket(int) - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket
- 
Creates a new NonBlockingTcpDatagramSocket using the wildcard address and the specified port number.
- NonBlockingTcpDatagramSocket(int, InetAddress) - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket
- 
Creates a new NonBlockingTcpDatagramSocket using anaddressand a port number.
- NonBlockingTcpDatagramSocket(SocketProvider) - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket
- 
Creates a new NonBlockingTcpDatagramSocket using theprovider.
- NonBlockingTcpDatagramSocket(NonBlockingTcpDatagramSocket.Impl) - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket
- 
Creates a new NonBlockingTcpDatagramSocket around anNonBlockingTcpDatagramSocket.Impl.
- NonBlockingTcpDatagramSocket(SocketAddress) - Constructor for class com.tangosol.net.NonBlockingTcpDatagramSocket
- 
Creates a new NonBlockingTcpDatagramSocket which will be bound to the specifiedaddress.
- NonBlockingTcpDatagramSocket.Impl - Class in com.tangosol.net
- 
A specialization ofTcpDatagramSocket.Implwhich provides non-blocking functionality, seeNonBlockingTcpDatagramSocket.Impl.send(DatagramPacket).
- none() - Static method in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
Return the order that will allow the server to parallelize the execution of async operations across multiple threads, regardless of whether they were invoked from the same client thread or not.
- none() - Static method in class com.tangosol.net.topic.Publisher.OrderBy
- 
Return an OrderBy that will enforce no specific ordering betweensent valuesallowing for the greatest level of parallelism.
- none() - Static method in class com.tangosol.net.topic.Subscriber.ChannelOwnershipListeners
- 
Create aSubscriber.ChannelOwnershipListenersoption with zerolisteners.
- NONE - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
Initial state, also state of an allocated block that has not been linked.
- NONE - Static variable in interface com.tangosol.net.AsyncNamedMap.Option
- 
An empty option array.
- NONE - Static variable in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
The none-order singleton.
- NONE - Static variable in class com.tangosol.net.ClusterPermission
- 
No actions.
- NONE_ALLOWED - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
A QuorumRule that rejects all actions.
- noneMatch(Remote.DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns whether no elements of this stream match the provided predicate.
- noneMatch(Remote.IntPredicate) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns whether no elements of this stream match the provided predicate.
- noneMatch(Remote.LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns whether no elements of this stream match the provided predicate.
- noneMatch(Remote.Predicate<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns whether no elements of this stream match the provided predicate.
- noneMatch(DoublePredicate) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns whether no elements of this stream match the provided predicate.
- noneMatch(IntPredicate) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns whether no elements of this stream match the provided predicate.
- noneMatch(LongPredicate) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns whether no elements of this stream match the provided predicate.
- noneMatch(Predicate<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns whether no elements of this stream match the provided predicate.
- NonSyntheticEntryFilter<T> - Class in com.tangosol.coherence.jcache.common
- 
Server side filter to filter out both coherence and jcache synthetic events.
- NonSyntheticEntryFilter() - Constructor for class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
- NonSyntheticEntryFilter() - Constructor for class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener.NonSyntheticEntryFilter
- NonSyntheticEntryFilter() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener.NonSyntheticEntryFilter
- NoOpElementProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat does nothing.
- NOPARAMS - Static variable in class com.tangosol.run.xml.PropertyAdapter
- 
Parameters for finding no-parameter methods.
- NOPARAMS - Static variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Parameters for finding no-parameter methods.
- NORMAL - com.oracle.coherence.cdi.events.Backlog.Type
- 
Indicates that a participant was previously backlogged but is no longer so.
- not(Filter<T>) - Static method in class com.tangosol.util.Filters
- 
Return a filter that represents the logical negation of the specified filter.
- NOT_FOUND - Static variable in interface com.tangosol.util.LongArray
- 
This index is used to indicate that an element was not found.
- notePos() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Note the offset within the underlying Reader
- notEqual(ValueExtractor<T, ? extends E>, E) - Static method in class com.tangosol.util.Filters
- 
Return a filter that tests for non-equality.
- NotEqualsFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which compares the result of a method invocation with a value for inequality.
- NotEqualsFilter() - Constructor for class com.tangosol.util.filter.NotEqualsFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- NotEqualsFilter(ValueExtractor<? super T, ? extends E>, E) - Constructor for class com.tangosol.util.filter.NotEqualsFilter
- 
Construct a NotEqualsFilter for testing inequality.
- NotEqualsFilter(String, E) - Constructor for class com.tangosol.util.filter.NotEqualsFilter
- 
Construct a NotEqualsFilter for testing inequality.
- NotEqualsOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the not equals operator.
- NotEqualsOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.NotEqualsOperator
- 
Construct a NotEqualsOperator.
- NotFilter<T> - Class in com.tangosol.util.filter
- 
Filter which negates the results of another filter.
- NotFilter() - Constructor for class com.tangosol.util.filter.NotFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- NotFilter(Filter<T>) - Constructor for class com.tangosol.util.filter.NotFilter
- 
Construct a negation filter.
- NOTHING - Static variable in interface com.tangosol.util.fsm.Instruction
- 
TheInstructionfor aFiniteStateMachineto do nothing.
- NOTHING_TO_COMMIT - Static variable in class com.tangosol.net.topic.Subscriber.CommitResult
- 
A result indicating there was nothing to be committed.
- NothingToCommit - com.tangosol.net.topic.Subscriber.CommitResultStatus
- 
A commit request was made, but there was no position to be committed.
- Notification - Annotation Type in com.tangosol.net.management.annotation
- 
The Notification annotation provides a means for an MBean interface to describe the notification it emits.
- Notification(String, String) - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.Notification
- NotificationManager - Interface in com.tangosol.net.management
- 
A NotificationManager is responsible for JMX notification delivery from a managed node to a set of subscribing managing nodes.
- Notifier - Interface in com.oracle.coherence.common.base
- 
A Condition-like object, used to block thread(s) for a notification.
- notify(MapEvent<K, V>) - Method in class com.oracle.coherence.cdi.CdiMapEventObserver
- notify(MapEvent<K, V>) - Method in interface com.oracle.coherence.cdi.events.AnnotatedMapListener.MapEventObserver
- 
Process an event.
- notify(E) - Method in class com.oracle.coherence.cdi.CdiEventObserver
- notify(E) - Method in interface com.oracle.coherence.cdi.events.EventObserverSupport.EventObserver
- 
Process an event.
- NOTIFY_LOST - Static variable in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Notification type for a "partitions are lost and needs to be recovered" event.
- notifyCanceled(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
Notify the task that it has been canceled.
- notifyCanceled(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceManager.Task
- 
Notify the task that it has been canceled.
- notifyCollector(Object, boolean) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
Add the given object to the configured collector (if any).
- notifyShutdown() - Method in class com.tangosol.net.DefaultCacheServer
- 
Ensure the DCS instance has shutdown.
- notifyStopping() - Method in class com.tangosol.util.Daemon.DaemonWorker
- NotOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
NotOPToken is used to implement not operators.
- NotOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.NotOPToken
- 
Construct a new NotOPToken with the given parameters.
- NotOPToken(String, int, String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.NotOPToken
- 
Construct a new NotOPToken with the given parameters.
- NotOwnedFilter(Ownership) - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter
- 
Construct a NotOwnedFilter with the specified ownership.
- nPort - Variable in class com.tangosol.net.LoadBalancer.AddressPort
- 
The port.
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder.CommandsOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder.ExtendedLanguageCommandOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder.HelpCommandOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder.SanityCheckCommandOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder.ServicesCommandOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder.SetTimeoutOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder.TraceCommandOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder.WheneverCommandOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLArchiveSnapshotOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLCreateSnapshotOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLForceRecoveryOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLListArchivedSnapshotsOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLListArchiverOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLListServicesOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLListSnapshotsOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLRecoverSnapshotOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLRemoveSnapshotOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLResumeServiceOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLRetrieveSnapshotOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLSuspendServiceOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.persistence.SQLValidateSnapshotOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLBackupOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLCreateCacheOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLCreateIndexOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLDeleteOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLDropCacheOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLDropIndexOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLExplainOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLInsertOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLRestoreOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLSelectOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLSourceOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLTruncateCacheOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dslquery.token.SQLUpdateOPToken
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.IdentifierOPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.InfixOPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.KeywordOPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.ListOpToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.LiteralOPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.NotOPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.ParenOPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.precedence.PrefixOPToken
- 
Process this token in the context of parser p with the null denotation.
- nud(OPParser) - Method in class com.tangosol.coherence.dsltools.termlanguage.CurlyToken
- 
Process this token in the context of parser p with the null denotation.
- Null() - Constructor for class com.tangosol.util.SafeSortedMap.Null
- NULL - Static variable in class com.tangosol.util.SafeSortedMap
- 
Placeholder for anullkey or value.
- NULL_IMPLEMENTATION - Static variable in interface com.tangosol.net.ClusterDependencies.ServiceProvider
- NULL_OPTION - Static variable in interface com.tangosol.net.topic.Subscriber.Option
- NULL_RESULT - Static variable in interface com.tangosol.coherence.dslquery.StatementResult
- 
A StatementResult with a null result value.
- NULL_TYPE - Static variable in class com.tangosol.io.MultiplexingSerializer
- 
Symbolic reference fornull.
- Nullable<T> - Interface in com.oracle.coherence.common.base
- 
An interface that any class can implement to mark itself as "nullable", which allows it to be used in a more optimal way with collections that support "nullable" keys and/or values.
- NullActionPolicy() - Constructor for class com.tangosol.util.NullImplementation.NullActionPolicy
- NullAddressProvider() - Constructor for class com.tangosol.util.NullImplementation.NullAddressProvider
- NullCacheStore() - Constructor for class com.tangosol.util.NullImplementation.NullCacheStore
- NullCollector() - Constructor for class com.tangosol.util.NullImplementation.NullCollector
- NullContinuation() - Constructor for class com.tangosol.util.NullImplementation.NullContinuation
- NullDeltaCompressor() - Constructor for class com.tangosol.util.NullImplementation.NullDeltaCompressor
- NullEntryProcessor() - Constructor for class com.tangosol.util.NullImplementation.NullEntryProcessor
- NullFilter - Class in com.tangosol.util
- 
Filter which discards null references.
- NullFilter() - Constructor for class com.tangosol.util.NullFilter
- 
Default constructor (for ExternalizableLite and PortableObject).
- NullImplementation - Class in com.tangosol.util
- 
A collection of classes that do nothing.
- NullImplementation - Static variable in interface com.tangosol.net.PasswordProvider
- 
A singleton implementation of aPasswordProviderthat always returns an empty array.
- NullImplementation.NullActionPolicy - Class in com.tangosol.util
- 
An implementation of an ActionPolicy that allows all actions.
- NullImplementation.NullAddressProvider - Class in com.tangosol.util
- 
Null implementation ofAddressProvider.
- NullImplementation.NullBackingMapManagerContext - Class in com.tangosol.util
- 
An implementation of BackingMapManagerContext that does nothing.
- NullImplementation.NullCacheStore - Class in com.tangosol.util
- 
An implementation of an CacheStore that does nothing.
- NullImplementation.NullCollector<V> - Class in com.tangosol.util
- 
ACollectorimplementation that does nothing.
- NullImplementation.NullContinuation<R> - Class in com.tangosol.util
- 
A Continuation that does nothing.
- NullImplementation.NullConverter - Class in com.tangosol.util
- 
A Converter that does nothing.
- NullImplementation.NullDeltaCompressor - Class in com.tangosol.util
- 
An implementation of a DeltaCompressor that does nothing and always returns the new stream.
- NullImplementation.NullEntryProcessor - Class in com.tangosol.util
- 
An implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.
- NullImplementation.NullEnumerator - Class in com.tangosol.util
- 
An empty enumerator.
- NullImplementation.NullLongArray<V> - Class in com.tangosol.util
- 
An immutable emptyLongArray
- NullImplementation.NullMap - Class in com.tangosol.util
- 
A Map that contains nothing and does nothing.
- NullImplementation.NullMemberIdentityProvider - Class in com.tangosol.util
- 
An implementation of aMemberIdentityProviderthat returnsnullfor all its methods.
- NullImplementation.NullObservableMap - Class in com.tangosol.util
- 
An immutable ObservableMap which contains nothing.
- NullImplementation.NullOutputStream - Class in com.tangosol.util
- 
An OutputStream that does basically nothing.
- NullImplementation.NullPartitionAssignmentStrategy - Class in com.tangosol.util
- 
An implementation ofPartitionAssignmentStrategythat does nothing.
- NullImplementation.NullPersistenceEnvironment<R> - Class in com.tangosol.util
- 
APersistenceEnvironmentthat does nothing.
- NullImplementation.NullPersistenceManager<R> - Class in com.tangosol.util
- 
APersistenceManagerthat does nothing.
- NullImplementation.NullPersistentStore<R> - Class in com.tangosol.util
- 
APersistentStorethat does as little as possible.
- NullImplementation.NullPersistentStore.Token - Class in com.tangosol.util
- 
Token returned byNullImplementation.NullPersistentStore.begin(Collector, Object).
- NullImplementation.NullPofContext - Class in com.tangosol.util
- 
An implementation of PofContext that does nothing.
- NullImplementation.NullPofHandler - Class in com.tangosol.util
- 
An implementation of PofHandler that does nothing.
- NullImplementation.NullReader - Class in com.tangosol.util
- 
A reader that does basically nothing.
- NullImplementation.NullResourceRegistry - Class in com.tangosol.util
- 
AResourceRegistryimplementation that does nothing.
- NullImplementation.NullSet - Class in com.tangosol.util
- 
An immutable set which contains nothing.
- NullImplementation.NullValueExtractor - Class in com.tangosol.util
- 
A ValueExtractor that always results in the passed-in value.
- NullImplementation.NullWriter - Class in com.tangosol.util
- 
A writer that does basically nothing.
- NullImplementationBuilder() - Constructor for class com.tangosol.coherence.config.builder.ActionPolicyBuilder.NullImplementationBuilder
- NULLLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
The numberic code for a boolean literal
- NULLLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
The numberic code for a boolean literal
- NullLongArray() - Constructor for class com.tangosol.util.NullImplementation.NullLongArray
- 
Create an immutable emptyLongArray.
- NullMap() - Constructor for class com.tangosol.util.NullImplementation.NullMap
- 
Default constructor (for ExternalizableLite and PortableObject).
- NullMemberIdentityProvider() - Constructor for class com.tangosol.util.NullImplementation.NullMemberIdentityProvider
- NullObservableMap() - Constructor for class com.tangosol.util.NullImplementation.NullObservableMap
- 
Default constructor (for ExternalizableLite and PortableObject).
- nullOption() - Static method in interface com.tangosol.net.topic.Subscriber.Option
- 
A null implementation of anSubscriber.Option.
- NullParameterResolver - Class in com.tangosol.config.expression
- NullParameterResolver() - Constructor for class com.tangosol.config.expression.NullParameterResolver
- 
Default constructor needed for serialization.
- NullPartitionAssignmentStrategy() - Constructor for class com.tangosol.util.NullImplementation.NullPartitionAssignmentStrategy
- NullPersistenceEnvironment() - Constructor for class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
- NullPersistenceManager() - Constructor for class com.tangosol.util.NullImplementation.NullPersistenceManager
- NullPersistentStore() - Constructor for class com.tangosol.util.NullImplementation.NullPersistentStore
- NullResourceRegistry() - Constructor for class com.tangosol.util.NullImplementation.NullResourceRegistry
- NullSet() - Constructor for class com.tangosol.util.NullImplementation.NullSet
- 
Default constructor (for ExternalizableLite and PortableObject).
- nullsFirst(Remote.Comparator<T>) - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a null-friendly comparator that considersnullto be less than non-null.
- nullsLast(Remote.Comparator<T>) - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a null-friendly comparator that considersnullto be greater than non-null.
- NullValueExtractor() - Constructor for class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Default constructor (for ExternalizableLite and PortableObject).
- NumberIncrementor<K,V,N extends Number> - Class in com.tangosol.util.processor
- 
The NumberIncrementor entry processor is used to increment a property value of aNumbertype.
- NumberIncrementor() - Constructor for class com.tangosol.util.processor.NumberIncrementor
- 
Default constructor (necessary for the ExternalizableLite interface).
- NumberIncrementor(ValueManipulator, N, boolean) - Constructor for class com.tangosol.util.processor.NumberIncrementor
- 
Construct an NumberIncrementor processor that will increment a property value by a specified amount, returning either the old or the new value as specified.
- NumberIncrementor(String, N, boolean) - Constructor for class com.tangosol.util.processor.NumberIncrementor
- 
Construct an NumberIncrementor processor that will increment a property value by a specified amount, returning either the old or the new value as specified.
- NumberIncrementorFactory - Class in com.tangosol.coherence.rest.util.processor
- 
ProcessorFactorythat can be used to create aNumberIncrementor.
- NumberIncrementorFactory(boolean) - Constructor for class com.tangosol.coherence.rest.util.processor.NumberIncrementorFactory
- 
Construct an instance of NumberIncrementorFactory.
- NumberMultiplier<K,V,N extends Number> - Class in com.tangosol.util.processor
- 
The NumberMultiplier entry processor is used to multiply a property value of aNumbertype.
- NumberMultiplier() - Constructor for class com.tangosol.util.processor.NumberMultiplier
- 
Default constructor (necessary for the ExternalizableLite interface).
- NumberMultiplier(ValueManipulator<V, N>, N, boolean) - Constructor for class com.tangosol.util.processor.NumberMultiplier
- 
Construct an NumberMultiplier processor that will multiply a property value by a specified factor, returning either the old or the new value as specified.
- NumberMultiplier(String, N, boolean) - Constructor for class com.tangosol.util.processor.NumberMultiplier
- 
Construct an NumberMultiplier processor that will multiply a property value by a specified factor, returning either the old or the new value as specified.
- NumberMultiplierFactory - Class in com.tangosol.coherence.rest.util.processor
- 
ProcessorFactorythat can be used to create aNumberMultiplier.
- NumberMultiplierFactory(boolean) - Constructor for class com.tangosol.coherence.rest.util.processor.NumberMultiplierFactory
- 
Construct an instance of NumberMultiplierFactory.
O
- objDoubleConsumer(Remote.ObjDoubleConsumer<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ObjDoubleConsumer.
- OBJECT_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
- 
An empty array of objects.
- ObjectNameExcludeFilter - Class in com.tangosol.net.management
- 
Filter used to prevent registering MBeans that match the specified pattern.
- ObjectNameExcludeFilter(String) - Constructor for class com.tangosol.net.management.ObjectNameExcludeFilter
- 
Construct an ObjectNameExcludeFilter based on one or more regular expressions.
- ObjectNameExcludeFilter(String[]) - Constructor for class com.tangosol.net.management.ObjectNameExcludeFilter
- 
Construct an ObjectNameExcludeFilter based on one or more regular expressions.
- ObjectNode(long, V) - Constructor for class com.tangosol.util.SparseArray.ObjectNode
- Objects - Class in com.oracle.coherence.common.base
- 
Class for providing comparison functionality.
- Objects() - Constructor for class com.oracle.coherence.common.base.Objects
- ObjectStreamFactory - Interface in com.tangosol.io
- 
Provides the means to create ObjectInput and ObjectOutput streams based on primitive data streams in a layered, pluggable fashion.
- ObjectWriter - Class in com.tangosol.coherence.rest.providers
- 
Provider responsible for marshalling Java objects.
- ObjectWriter() - Constructor for class com.tangosol.coherence.rest.providers.ObjectWriter
- 
Default constructor.
- ObjectWriter(MarshallerRegistry) - Constructor for class com.tangosol.coherence.rest.providers.ObjectWriter
- 
Construct an ObjectWriter instance.
- objIntConsumer(Remote.ObjIntConsumer<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ObjIntConsumer.
- objLongConsumer(Remote.ObjLongConsumer<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ObjLongConsumer.
- ObservableCachingScheme - Interface in com.tangosol.coherence.config.scheme
- 
AnObservableCachingSchemeis aCachingSchemethat supports defining and addingMapListeners to realizedMaps andNamedCaches.
- ObservableHashMap<K,V> - Class in com.tangosol.util
- 
An ObservableMap implementation that extends the SafeHashMap.
- ObservableHashMap() - Constructor for class com.tangosol.util.ObservableHashMap
- 
Construct the ObservableHashMap.
- ObservableHashMap(int, float, float) - Constructor for class com.tangosol.util.ObservableHashMap
- 
Construct an ObservableHashMap using the specified settings.
- ObservableHashMap.Entry<K,V> - Class in com.tangosol.util
- 
A holder for a cached value.
- ObservableMap<K,V> - Interface in com.tangosol.util
- 
ObservableMap interface represents an object with a model being a Map that allows for pluggable notifications for occurring changes.
- ObservableSplittingBackingCache - Class in com.tangosol.net.partition
- 
The ObservableSplittingBackingCache is an implementation of the ConfigurableCacheMap interface that works as an observable backing map in a partitioned system.
- ObservableSplittingBackingCache(BackingMapManager, String) - Constructor for class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Create a ObservableSplittingBackingCache that adds ConfigurableCacheMap functionality to an ObservableSplittingBackingMap.
- ObservableSplittingBackingCache.CapacityAwareMap - Class in com.tangosol.net.partition
- 
A subclass of PartitionSplittingBackingMap which allows an injected instance ofObservableSplittingBackingMapto be called immediately before inserting a value(s) in a partition map.
- ObservableSplittingBackingCache.EntrySet - Class in com.tangosol.net.partition
- 
A set of ConfigurableCacheMap entries backed by this map.
- ObservableSplittingBackingCache.EntrySet.Entry - Class in com.tangosol.net.partition
- 
A Cache Entry implementation.
- ObservableSplittingBackingMap - Class in com.tangosol.net.partition
- 
An observable, cache-aware PartitionAwareBackingMap implementation.
- ObservableSplittingBackingMap(BackingMapManager, String) - Constructor for class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Create a ObservableSplittingBackingMap that will delegate each partition's data and operations to a separate backing map.
- ObservableSplittingBackingMap(PartitionAwareBackingMap) - Constructor for class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Create a ObservableSplittingBackingMap that will delegate each partition's data and operations to a separate backing map.
- octalValue(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Returns the integer value of an octal digit.
- octalValue(char) - Static method in class com.tangosol.util.Base
- 
Returns the integer value of an octal digit.
- of(boolean) - Static method in class com.oracle.coherence.cdi.View.Literal
- 
Create aView.Literal.
- of(boolean) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedbooleanvalue.
- of(byte) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedbytevalue.
- of(double) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifieddoublevalue.
- of(float) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedfloatvalue.
- of(int) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedintvalue.
- of(int) - Static method in class com.oracle.coherence.concurrent.cdi.Count.Literal
- 
Create aCount.Literal.
- of(int) - Static method in class com.oracle.coherence.concurrent.cdi.Permits.Literal
- 
Create aPermits.Literal.
- of(int...) - Static method in class com.oracle.coherence.cdi.PofExtractor.Literal
- 
Create aPofExtractor.Literal.
- of(long) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedlongvalue.
- of(short) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedshortvalue.
- of(ChainedExtractor...) - Static method in class com.oracle.coherence.cdi.ChainedExtractor.Extractors.Literal
- 
Create anChainedExtractor.Extractors.Literal.
- of(Backlog.Type) - Static method in class com.oracle.coherence.cdi.events.Backlog.Literal
- 
Create aBacklog.Literal.
- of(PofExtractor...) - Static method in class com.oracle.coherence.cdi.PofExtractor.Extractors.Literal
- 
Create anPofExtractor.Extractors.Literal.
- of(PropertyExtractor...) - Static method in class com.oracle.coherence.cdi.PropertyExtractor.Extractors.Literal
- 
Create anPropertyExtractor.Extractors.Literal.
- of(Subscriber.ChannelOwnershipListener...) - Static method in class com.tangosol.net.topic.Subscriber.ChannelOwnershipListeners
- 
Create aSubscriber.ChannelOwnershipListenersoption with one or morelisteners.
- of(Remote.Supplier<A>, Remote.BiConsumer<A, T>, Remote.BinaryOperator<A>, Remote.Function<A, R>, Collector.Characteristics...) - Static method in interface com.tangosol.util.stream.RemoteCollector
- 
Returns a newCollectordescribed by the givensupplier,accumulator,combiner, andfinisherfunctions.
- of(Remote.Supplier<R>, Remote.BiConsumer<R, T>, Remote.BinaryOperator<R>, Collector.Characteristics...) - Static method in interface com.tangosol.util.stream.RemoteCollector
- 
Returns a newCollectordescribed by the givensupplier,accumulator, andcombinerfunctions.
- of(ValueExtractor<T, E>) - Static method in class com.tangosol.util.extractor.KeyExtractor
- 
Factory method for key extractor.
- of(ValueExtractor<T, E>) - Static method in interface com.tangosol.util.ValueExtractor
- 
Helper method to allow composition/chaining of extractors.
- of(Boolean) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedBooleanvalue.
- of(Byte) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedBytevalue.
- of(Class<?>, int...) - Static method in class com.oracle.coherence.cdi.PofExtractor.Literal
- 
Create aPofExtractor.Literal.
- of(Class<?>, String) - Static method in class com.oracle.coherence.cdi.PofExtractor.Literal
- 
Create aPofExtractor.Literal.
- of(Class<? extends InvocableMap.EntryProcessor>) - Static method in class com.oracle.coherence.cdi.events.Processor.Literal
- 
Create aProcessor.Literal.
- of(Double) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedDoublevalue.
- of(Float) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedFloatvalue.
- of(Integer) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedIntegervalue.
- of(Long) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedLongvalue.
- of(Short) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specifiedShortvalue.
- of(String) - Static method in class com.oracle.coherence.cdi.ConfigUri.Literal
- 
Create aConfigUri.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.events.CacheName.Literal
- 
Create aCacheName.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.events.MapName.Literal
- 
Create aMapName.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.events.ParticipantName.Literal
- 
Create aParticipantName.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.events.ScopeName.Literal
- 
Create aScopeName.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.events.ServiceName.Literal
- 
Create aServiceName.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.Name.Literal
- 
Create aName.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.PropertyExtractor.Literal
- 
Create aPropertyExtractor.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.Scope.Literal
- 
Create aScope.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.SerializerFormat.Literal
- 
Create aSerializerFormat.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.SessionName.Literal
- 
Create aSessionName.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.SubscriberGroup.Literal
- 
Create aSubscriberGroup.Literal.
- of(String) - Static method in class com.oracle.coherence.cdi.WhereFilter.Literal
- 
Create aWhereFilter.Literal.
- of(String) - Static method in class com.tangosol.net.topic.Subscriber.Name
- 
Obtain aSubscriber.Optionthat specifies a group name for aSubscriber.
- of(String...) - Static method in class com.oracle.coherence.cdi.ChainedExtractor.Literal
- 
Create aChainedExtractor.Literal.
- of(Supplier<A>, BiConsumer<A, T>, BinaryOperator<A>, Function<A, R>, Collector.Characteristics...) - Static method in interface com.tangosol.util.stream.RemoteCollector
- 
Returns a newCollectordescribed by the givensupplier,accumulator,combiner, andfinisherfunctions.
- of(Supplier<R>, BiConsumer<R, T>, BinaryOperator<R>, Collector.Characteristics...) - Static method in interface com.tangosol.util.stream.RemoteCollector
- 
Returns a newCollectordescribed by the givensupplier,accumulator, andcombinerfunctions.
- of(T) - Static method in interface com.oracle.coherence.common.base.Nullable
- 
Create aNullablerepresentation of the specified reference value.
- OFF_HEAP - Static variable in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
An off-heap backup storage.
- OFFSET_HASH - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
Offset of the key's hash within an Entry block.
- OFFSET_KEY - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
Offset of the key data within an Entry block.
- OFFSET_VALUE - Static variable in class com.tangosol.io.nio.BinaryMap.Block
- 
Offset (not counting key length) of the value data within an Entry block.
- OffsetLengthSubstringExpansionProcessor() - Constructor for class com.tangosol.config.expression.ValueMacroExpression.OffsetLengthSubstringExpansionProcessor
- OldCache - Class in com.tangosol.net.cache
- 
Deprecated.As of Coherence 3.1, useLocalCacheinstead
- OldCache() - Constructor for class com.tangosol.net.cache.OldCache
- 
Deprecated.Construct the cache manager.
- OldCache(int) - Constructor for class com.tangosol.net.cache.OldCache
- 
Deprecated.Construct the cache manager.
- OldCache(int, int) - Constructor for class com.tangosol.net.cache.OldCache
- 
Deprecated.Construct the cache manager.
- OldCache(int, int, double) - Constructor for class com.tangosol.net.cache.OldCache
- 
Deprecated.Construct the cache manager.
- OldCache.Entry - Class in com.tangosol.net.cache
- 
Deprecated.A holder for a cached value.
- OldCache.EntrySet - Class in com.tangosol.net.cache
- 
Deprecated.A set of entries backed by this map.
- OldCache.EvictionPolicy - Interface in com.tangosol.net.cache
- 
Deprecated.An eviction policy is an object that the cache provides with access information, and when requested, the eviction policy selects and evicts entries from the cache.
- OldCache.InternalEvictionPolicy - Class in com.tangosol.net.cache
- 
Deprecated.The InternalEvictionPolicy represents a pluggable eviction policy for the non-pluggable built-in (internal) eviction policies supported by this cache implementation.
- OldCache.InternalUnitCalculator - Class in com.tangosol.net.cache
- 
Deprecated.The InternalUnitCalculator represents a pluggable UnitCalculator for the non-pluggable built-in (internal) UnitCalculator implementation provided by this cache implementation.
- OldCache.KeySet - Class in com.tangosol.net.cache
- 
Deprecated.A set of entries backed by this map.
- OldCache.UnitCalculator - Interface in com.tangosol.net.cache
- 
Deprecated.A unit calculator is an object that can calculate the cost of caching an object.
- OldCache.ValuesCollection - Class in com.tangosol.net.cache
- 
Deprecated.A collection of values backed by this map.
- OldDateAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
- 
Construct a SimpleAdapter.
- ON_HEAP - Static variable in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
An on-heap backup storage.
- onAccept(ExecutionContext) - Method in interface com.tangosol.util.fsm.LifecycleAwareEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventis initially about to be accepted for processing.
- onAccept(ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventis initially about to be accepted for processing.
- onAccept(ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.SubsequentEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventis initially about to be accepted for processing.
- onAccept(SelectionKey) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Called when a channel is identified as have a new connection to accept.
- onAdd() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.This method is invoked when the containing Map has actually added this Entry to itself.
- onAdd() - Method in class com.tangosol.util.ObservableHashMap.Entry
- 
This method is invoked when the containing Map has actually added this Entry to itself.
- onAdd() - Method in class com.tangosol.util.SafeHashMap.Entry
- 
This method is invoked when the containing Map has actually added this Entry to itself.
- onBackEvent(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap
- 
Handle an event occuring against the "back" map.
- onBeforeClosing() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Closes aCoherenceBasedCacheat the request of a call toCache.close().
- onBeforeClosing() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- onBeforeClosing() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- onBeforeClosing() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- onBeforeClosing() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- onBoolean(int, boolean) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a boolean value has been encountered in the POF stream.
- onBoolean(int, boolean) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a boolean value has been encountered in the POF stream.
- onBoolean(int, boolean) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a boolean value has been encountered in the POF stream.
- onBoolean(int, boolean) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a boolean value has been encountered in the POF stream.
- onBoolean(int, boolean) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a boolean value has been encountered in the POF stream.
- onBoolean(int, boolean) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a boolean value has been encountered in the POF stream.
- onBoolean(int, boolean) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a boolean value has been encountered in the POF stream.
- onChannelsAssigned(Set<Integer>) - Method in interface com.tangosol.net.topic.Subscriber.ChannelOwnershipListener
- 
The channels owned by a subscriber have changed.
- onChannelsLost(Set<Integer>) - Method in interface com.tangosol.net.topic.Subscriber.ChannelOwnershipListener
- 
Channels previously owned by a subscriber have been lost, this is typically as a result of the subscriber being timed out or disconnection from the cluster.
- onChannelsRevoked(Set<Integer>) - Method in interface com.tangosol.net.topic.Subscriber.ChannelOwnershipListener
- 
Channels previously owned by a subscriber have been revoked.
- onChar(int, char) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a character value has been encountered in the POF stream.
- onChar(int, char) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a character value has been encountered in the POF stream.
- onChar(int, char) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a character value has been encountered in the POF stream.
- onChar(int, char) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a character value has been encountered in the POF stream.
- onChar(int, char) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a character value has been encountered in the POF stream.
- onChar(int, char) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a character value has been encountered in the POF stream.
- onChar(int, char) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a character value has been encountered in the POF stream.
- onCharString(int, String) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a character string value has been encountered in the POF stream.
- onCharString(int, String) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a character string value has been encountered in the POF stream.
- onCharString(int, String) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a character string value has been encountered in the POF stream.
- onCharString(int, String) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a character string value has been encountered in the POF stream.
- onCharString(int, String) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a character string value has been encountered in the POF stream.
- onCharString(int, String) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a character string value has been encountered in the POF stream.
- onCharString(int, String) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a character string value has been encountered in the POF stream.
- onClose(Runnable) - Method in interface com.tangosol.net.topic.Publisher
- 
Add an action to be executed when thisPublisheris closed.
- onClose(Runnable) - Method in interface com.tangosol.net.topic.Subscriber
- 
Add an action to be executed when thisSubscriberis closed.
- onComplete() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- onComplete() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.LoadOperationObserver
- 
Complete the current operation.
- onComplete() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.StoreOperationObserver
- 
Complete the current operation.
- onComplete() - Method in interface com.tangosol.net.cache.StoreObserver
- 
Complete the current operation.
- onComplete() - Method in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
- 
Called after this asynchronous aggregator has been notified about all possible partial results or failures and no more are forthcoming.
- onComplete() - Method in class com.tangosol.util.aggregator.AsynchronousAggregator
- onComplete() - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
Called after the processor has been notified about all possible partial results or failures and no more are forthcoming.
- onComplete() - Method in class com.tangosol.util.processor.AsynchronousProcessor
- onComplete() - Method in class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- onComplete() - Method in class com.tangosol.util.processor.StreamingAsynchronousProcessor
- onCompleted() - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- onCompleted() - Method in class com.oracle.coherence.grpc.SafeStreamObserver
- onConnectionHeader(TcpDatagramSocket.Impl.ConnectionStatus, SocketChannel) - Method in class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
- 
Process a pending connection header.
- onConnectionHeader(TcpDatagramSocket.Impl.ConnectionStatus, SocketChannel) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Process a pending connection header.
- onContend(Object, SegmentedConcurrentMap.LockableEntry) - Method in interface com.tangosol.util.SegmentedConcurrentMap.ContentionObserver
- 
Called when the specified lock holder begins contending for the specified LockableEntry.
- onDate(int, int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a date value has been encountered in the POF stream.
- onDate(int, int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a date value has been encountered in the POF stream.
- onDate(int, int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a date value has been encountered in the POF stream.
- onDate(int, int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a date value has been encountered in the POF stream.
- onDate(int, int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a date value has been encountered in the POF stream.
- onDate(int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a date value has been encountered in the POF stream.
- onDate(int, int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a date value has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a date-time value has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a date-time value has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a date-time value has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, boolean) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a date-time value has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a date-time value has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a date-time value has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, boolean) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a date-time value has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a date-time value (with a timezone offset) has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a date-time value (with a timezone offset) has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a date-time value (with a timezone offset) has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a date-time value (with a timezone offset) has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a date-time value (with a timezone offset) has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a date-time value (with a timezone offset) has been encountered in the POF stream.
- onDateTime(int, int, int, int, int, int, int, int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a date-time value (with a timezone offset) has been encountered in the POF stream.
- onDayTimeInterval(int, int, int, int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a day-time interval value has been encountered in the POF stream.
- onDayTimeInterval(int, int, int, int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a day-time interval value has been encountered in the POF stream.
- onDayTimeInterval(int, int, int, int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a day-time interval value has been encountered in the POF stream.
- onDayTimeInterval(int, int, int, int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a day-time interval value has been encountered in the POF stream.
- onDayTimeInterval(int, int, int, int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a day-time interval value has been encountered in the POF stream.
- onDayTimeInterval(int, int, int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a day-time interval value has been encountered in the POF stream.
- onDayTimeInterval(int, int, int, int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a day-time interval value has been encountered in the POF stream.
- onDecimal128(int, BigDecimal) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a quad-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal128(int, BigDecimal) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a quad-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal128(int, BigDecimal) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a quad-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal128(int, BigDecimal) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a quad-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal128(int, BigDecimal) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a quad-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal128(int, BigDecimal) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a quad-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal128(int, BigDecimal) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a quad-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal32(int, BigDecimal) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a single-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal32(int, BigDecimal) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a single-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal32(int, BigDecimal) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a single-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal32(int, BigDecimal) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a single-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal32(int, BigDecimal) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a single-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal32(int, BigDecimal) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a single-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal32(int, BigDecimal) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a single-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal64(int, BigDecimal) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a double-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal64(int, BigDecimal) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a double-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal64(int, BigDecimal) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a double-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal64(int, BigDecimal) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a double-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal64(int, BigDecimal) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a double-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal64(int, BigDecimal) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a double-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onDecimal64(int, BigDecimal) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a double-precision decimal value (a base-10 floating point) has been encountered in the POF stream.
- onEndNamespace(ProcessingContext, XmlElement, String, URI) - Method in class com.tangosol.coherence.jcache.JCacheExtendNamespace
- 
<!-- Generated by JCacheExtendNamespace --> <caching-scheme-mapping> <cache-mapping> <cache-name>jcache-partitioned-*</cache-name> <scheme-name>jcache-extend-tcp</scheme-name> </cache-mapping> <cache-mapping> <cache-name>jcache-configurations</cache-name> <scheme-name>jcache-extend-tcp</scheme-name> </cache-mapping> </caching-scheme-mapping> <caching-schemes> <remote-cache-scheme> <scheme-name>jcache-extend-tcp</scheme-name> <!-- TODO: scope-name probably needed within container context. --> <!-- <scope-name>jcache-extend</scope-name> --> <service-name>JCacheTCPProxyService</service-name> <proxy-service-name>TCPProxyService</proxy-service-name> <initiator-config> <tcp-initiator> <name-service-addresses> <socket-address> <address system-property="coherence.remote.address">127.0.0.1</address> <port system-property="coherence.clusterport">7574</port> </socket-address> </name-service-addresses> </tcp-initiator> </initiator-config> </remote-cache-scheme> </caching-schemes>
- onEndNamespace(ProcessingContext, XmlElement, String, URI) - Method in class com.tangosol.coherence.jcache.JCacheNamespace
- onEndNamespace(ProcessingContext, XmlElement, String, URI) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Called when the xml namespace associated with theNamespaceHandleris last encountered in an xml document.
- onEndNamespace(ProcessingContext, XmlElement, String, URI) - Method in interface com.tangosol.config.xml.NamespaceHandler
- 
Called when the xml namespace associated with theNamespaceHandleris last encountered in an xml document.
- onEnterState(S, S, Event<S>, ExecutionContext) - Method in interface com.tangosol.util.fsm.StateEntryAction
- 
Performs the necessary actions when aFiniteStateMachineenters a particular state.
- onEraseAllFailure(Set, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store eraseAll() failure.
- onEraseFailure(ReadWriteBackingMap.Entry, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store erase() failure.
- onEraseFailure(Object, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store erase() failure.
- onError(SSLContextDependencies, Throwable) - Method in class com.oracle.coherence.grpc.RefreshableSslContext
- onError(BinaryEntry<K, V>, Exception) - Method in interface com.tangosol.net.cache.StoreObserver
- 
Indicate that the corresponding entry is in error, due to the given exception.
- onError(BinaryEntry, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.LoadOperationObserver
- 
Indicate that the corresponding entry is in error, due to the given exception.
- onError(BinaryEntry, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.StoreOperationObserver
- 
Indicate that the corresponding entry is in error, due to the given exception.
- onError(Throwable) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- onError(Throwable) - Method in class com.oracle.coherence.grpc.SafeStreamObserver
- onEvent(LifecycleEvent) - Method in class com.tangosol.coherence.jcache.common.ContainerHelper.JCacheLifecycleInterceptor
- onEvent(CoherenceLifecycleEvent) - Method in interface com.tangosol.net.Coherence.LifecycleListener
- onEvent(CacheLifecycleEvent) - Method in class com.oracle.coherence.mp.config.CoherenceConfigSource
- onEvent(E) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- onEvent(E) - Method in interface com.tangosol.net.events.EventInterceptor
- 
Perform necessary processing of the specifiedEvent.
- onEvent(E) - Method in class com.tangosol.net.events.NamedEventInterceptor
- 
Perform necessary processing of the specifiedEvent.
- onEvent(Consumer<T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.Listener.Builder
- 
Add the event handler for all events.
- onException(Exception) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Called when an unexpected exception is caught while writing to the POF stream.
- onException(Exception) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Called when an unexpected exception is caught while writing to the POF stream.
- onException(Throwable) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- onException(Throwable) - Method in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
- 
Called if the operation failed for any reason.
- onException(Throwable) - Method in class com.tangosol.util.aggregator.AsynchronousAggregator
- 
Called if the operation failed for any reason.
- onException(Throwable) - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
Called if any part of the operation failed for any reason.
- onException(Throwable) - Method in class com.tangosol.util.processor.AsynchronousProcessor
- onException(Throwable) - Method in class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- onException(Throwable) - Method in class com.tangosol.util.processor.StreamingAsynchronousProcessor
- onException(Throwable, Runnable) - Method in class com.tangosol.util.TaskDaemon
- 
Process an exception that is thrown during a task execution.
- onException(T) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Called to handle an unexpected exception.
- onException(T) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Called to handle an unexpected exception.
- onException(T) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Called to handle an unexpected exception.
- onExitState(S, Event<S>, ExecutionContext) - Method in interface com.tangosol.util.fsm.StateExitAction
- 
Performs the necessary actions when aFiniteStateMachineexits a particular state.
- onFilterRequest(MapListenerRequest, MapTrigger<Binary, Binary>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Invoked whenMapListenerRequest.RequestTypeisKEY.
- onFloat128(int, RawQuad) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a base-2 quad-precision floating point value has been encountered in the POF stream.
- onFloat128(int, RawQuad) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a base-2 quad-precision floating point value has been encountered in the POF stream.
- onFloat128(int, RawQuad) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a base-2 quad-precision floating point value has been encountered in the POF stream.
- onFloat128(int, RawQuad) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a base-2 quad-precision floating point value has been encountered in the POF stream.
- onFloat128(int, RawQuad) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a base-2 quad-precision floating point value has been encountered in the POF stream.
- onFloat128(int, RawQuad) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a base-2 quad-precision floating point value has been encountered in the POF stream.
- onFloat128(int, RawQuad) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a base-2 quad-precision floating point value has been encountered in the POF stream.
- onFloat32(int, float) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a base-2 single-precision floating point value has been encountered in the POF stream.
- onFloat32(int, float) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a base-2 single-precision floating point value has been encountered in the POF stream.
- onFloat32(int, float) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a base-2 single-precision floating point value has been encountered in the POF stream.
- onFloat32(int, float) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a base-2 single-precision floating point value has been encountered in the POF stream.
- onFloat32(int, float) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a base-2 single-precision floating point value has been encountered in the POF stream.
- onFloat32(int, float) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a base-2 single-precision floating point value has been encountered in the POF stream.
- onFloat32(int, float) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a base-2 single-precision floating point value has been encountered in the POF stream.
- onFloat64(int, double) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a base-2 double-precision floating point value has been encountered in the POF stream.
- onFloat64(int, double) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a base-2 double-precision floating point value has been encountered in the POF stream.
- onFloat64(int, double) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a base-2 double-precision floating point value has been encountered in the POF stream.
- onFloat64(int, double) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a base-2 double-precision floating point value has been encountered in the POF stream.
- onFloat64(int, double) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a base-2 double-precision floating point value has been encountered in the POF stream.
- onFloat64(int, double) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a base-2 double-precision floating point value has been encountered in the POF stream.
- onFloat64(int, double) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a base-2 double-precision floating point value has been encountered in the POF stream.
- onFrontEvent(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap
- 
Either handle an event by turning it over to another thread that is processing the key specified by the event, or take responsibility on this thread for deferring the event and registering its immediate side-effects.
- onFrontEvent(MapEvent) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Either handle an event by turning it over to another thread that is processing the key specified by the event, or take responsibility on this thread for deferring the event and registering its immediate side-effects.
- onGuardableRecovery(Guardable, Service) - Method in interface com.tangosol.net.ServiceFailurePolicy
- 
Take appropriate action after the specified guardable (associated with the specified service) has missed a "soft-timeout" and has entered the "RECOVERY" state.
- onGuardableTerminate(Guardable, Service) - Method in interface com.tangosol.net.ServiceFailurePolicy
- 
Take appropriate action after the specified guardable (associated with the specified service) has missed a "hard-timeout" and has entered the "TERMINATING" state.
- onIdentityReference(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Specifies that a reference to a previously-identified value has been encountered in the POF stream.
- onIdentityReference(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Specifies that a reference to a previously-identified value has been encountered in the POF stream.
- onIdentityReference(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Specifies that a reference to a previously-identified value has been encountered in the POF stream.
- onIdentityReference(int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Specifies that a reference to a previously-identified value has been encountered in the POF stream.
- onIdentityReference(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Specifies that a reference to a previously-identified value has been encountered in the POF stream.
- onIdentityReference(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Specifies that a reference to a previously-identified value has been encountered in the POF stream.
- onIdentityReference(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Specifies that a reference to a previously-identified value has been encountered in the POF stream.
- onInsert(Consumer<T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.Listener.Builder
- 
Add the event handler for INSERT events.
- onInserted(T) - Method in interface com.oracle.coherence.repository.AbstractRepositoryBase.Listener
- 
An event callback that will be called when a new entity is inserted into the repository.
- onInt128(int, BigInteger) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a 128-bit integer value has been encountered in the POF stream.
- onInt128(int, BigInteger) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a 128-bit integer value has been encountered in the POF stream.
- onInt128(int, BigInteger) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a 128-bit integer value has been encountered in the POF stream.
- onInt128(int, BigInteger) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a 128-bit integer value has been encountered in the POF stream.
- onInt128(int, BigInteger) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a 128-bit integer value has been encountered in the POF stream.
- onInt128(int, BigInteger) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a 128-bit integer value has been encountered in the POF stream.
- onInt128(int, BigInteger) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a 128-bit integer value has been encountered in the POF stream.
- onInt16(int, short) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a short integer value has been encountered in the POF stream.
- onInt16(int, short) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a short integer value has been encountered in the POF stream.
- onInt16(int, short) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a short integer value has been encountered in the POF stream.
- onInt16(int, short) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a short integer value has been encountered in the POF stream.
- onInt16(int, short) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a short integer value has been encountered in the POF stream.
- onInt16(int, short) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a short integer value has been encountered in the POF stream.
- onInt16(int, short) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a short integer value has been encountered in the POF stream.
- onInt32(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that an integer value has been encountered in the POF stream.
- onInt32(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that an integer value has been encountered in the POF stream.
- onInt32(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that an integer value has been encountered in the POF stream.
- onInt32(int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that an integer value has been encountered in the POF stream.
- onInt32(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that an integer value has been encountered in the POF stream.
- onInt32(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that an integer value has been encountered in the POF stream.
- onInt32(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that an integer value has been encountered in the POF stream.
- onInt64(int, long) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a long integer value has been encountered in the POF stream.
- onInt64(int, long) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a long integer value has been encountered in the POF stream.
- onInt64(int, long) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a long integer value has been encountered in the POF stream.
- onInt64(int, long) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a long integer value has been encountered in the POF stream.
- onInt64(int, long) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a long integer value has been encountered in the POF stream.
- onInt64(int, long) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a long integer value has been encountered in the POF stream.
- onInt64(int, long) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a long integer value has been encountered in the POF stream.
- onKeyRequest(MapListenerRequest, MapTrigger<?, ?>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Invoked whenMapListenerRequest.RequestTypeisKEY.
- onLoadAllFailure(Collection, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store loadAll() failure.
- onLoadAllFailure(Collection, Exception, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store loadAll() failure.
- onLoadFailure(Object, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store load() failure.
- onLoadFailure(Object, Exception, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store load() failure.
- onMapEvent(MapEvent) - Method in class com.tangosol.net.cache.CachingMap.PrimingListener
- onMapEvent(MapEvent) - Method in class com.tangosol.net.cache.CachingMap.SimpleListener
- onMapEvent(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap.BackMapListener
- 
Invoked when a map entry has been inserted, updated or deleted.
- onMapEvent(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap.FrontMapListener
- 
Invoked when a map entry has been inserted, updated or deleted.
- onMapEvent(MapEvent) - Method in class com.tangosol.net.cache.SimpleOverflowMap.FrontMapListener
- 
Invoked when a map entry has been inserted, updated or deleted.
- onMapEvent(MapEvent) - Method in class com.tangosol.util.MapListenerSupport.WrapperPrimingListener
- 
Invoked when a map entry has been inserted, updated or deleted.
- onMapEvent(MapEvent) - Method in class com.tangosol.util.MapTriggerListener
- 
Invoked when a map entry has been inserted, updated or deleted.
- onMapEvent(MapEvent<?, ?>) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- onMapEvent(MapEvent<K, V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache.AddListener
- onMapEvent(MapEvent<K, V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache.InternalMapListener
- 
Dispatch events received from the internal map to theMapListenerSupport's registeredMapListeners.
- onMapEvent(MapEvent<K, V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache.RemoveListener
- onMapEvent(MapEvent<K, V>) - Method in class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
- onMapEvent(MapEvent<K, V>) - Method in class com.tangosol.util.ConverterCollections.ConverterCacheListener
- onMapEvent(MapEvent<K, V>) - Method in class com.tangosol.util.ConverterCollections.ConverterMapListener
- onMapEvent(MapEvent<K, V>) - Method in class com.tangosol.util.MapListenerSupport.WrapperListener
- 
Invoked when a map entry has been inserted, updated or deleted.
- onMapEvent(MapEvent<K, V>) - Method in class com.tangosol.util.MultiplexingMapListener
- 
Invoked when a map entry has been inserted, updated or deleted.
- onMapEvent(MapEvent<K, V>) - Method in class com.tangosol.util.WrapperObservableMap.InternalListener
- 
Invoked when a map entry has been inserted, updated or deleted.
- onMappingAdded() - Method in class com.tangosol.util.SimpleMapIndex
- 
Increase the size of the index by the size of an index map entry.
- onMappingAdded(Object, int) - Method in class com.tangosol.util.SimpleMapIndex
- 
Increase the size of the index by the estimated size of the specified added value.
- onMappingRemoved() - Method in class com.tangosol.util.SimpleMapIndex
- 
Decrease the size of the index by the size of an index map entry.
- onMappingRemoved(Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Decrease the size of the index by the estimated size of the specified removed value.
- onModify(MapEvent) - Method in class com.tangosol.net.cache.LocalCache.InternalListener
- 
A value modification event (insert or update) has occurred.
- onNext(MapListenerRequest) - Method in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- onNext(BinaryEntry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.LoadOperationObserver
- 
Indicates the associated operation (load or store) has completed successfully and applied to the provided BinaryEntry.
- onNext(BinaryEntry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.StoreOperationObserver
- 
Indicates the associated operation (load or store) has completed successfully and applied to the provided BinaryEntry.
- onNext(BinaryEntry<K, V>) - Method in interface com.tangosol.net.cache.StoreObserver
- 
Indicates the associated operation (load or store) has completed successfully and applied to the provided BinaryEntry.
- onNext(T) - Method in class com.oracle.coherence.grpc.SafeStreamObserver
- onNullReference(int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Specifies that a null value has been encountered in the POF stream.
- onNullReference(int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Specifies that a null value has been encountered in the POF stream.
- onNullReference(int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Specifies that a null value has been encountered in the POF stream.
- onNullReference(int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Specifies that a null value has been encountered in the POF stream.
- onNullReference(int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Specifies that a null value has been encountered in the POF stream.
- onNullReference(int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Specifies that a null value has been encountered in the POF stream.
- onNullReference(int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Specifies that a null value has been encountered in the POF stream.
- onOctet(int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that an octet value (a byte) has been encountered in the POF stream.
- onOctet(int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that an octet value (a byte) has been encountered in the POF stream.
- onOctet(int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that an octet value (a byte) has been encountered in the POF stream.
- onOctet(int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that an octet value (a byte) has been encountered in the POF stream.
- onOctet(int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that an octet value (a byte) has been encountered in the POF stream.
- onOctet(int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that an octet value (a byte) has been encountered in the POF stream.
- onOctet(int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that an octet value (a byte) has been encountered in the POF stream.
- onOctetString(int, Binary) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a octet string value has been encountered in the POF stream.
- onOctetString(int, Binary) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a octet string value has been encountered in the POF stream.
- onOctetString(int, Binary) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a octet string value has been encountered in the POF stream.
- onOctetString(int, Binary) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a octet string value has been encountered in the POF stream.
- onOctetString(int, Binary) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a octet string value has been encountered in the POF stream.
- onOctetString(int, Binary) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a octet string value has been encountered in the POF stream.
- onOctetString(int, Binary) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a octet string value has been encountered in the POF stream.
- onPartitionEvent(PartitionEvent) - Method in interface com.tangosol.net.partition.PartitionListener
- 
Invoked when a partition event has occurred.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.EnumProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.MemberListenerProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.MemorySizeProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.MillisProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PartitionListenerProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PersistenceEnvironmentsProcessor.PersistenceEnvironmentProcessor
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PersistenceProcessor
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ResourceBuilderProcessor
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SerializerBuilderProcessor
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SerializerFactoryProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ServiceFailurePolicyProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SimpleBuilderProcessor
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SpecificInstanceProcessor
- 
Process anXmlElementto return a specific type of value.
- onProcess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.StorageAccessAuthorizerBuilderProcessor
- onProcessed(ExecutionContext) - Method in interface com.tangosol.util.fsm.LifecycleAwareEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventhas been processed.
- onProcessed(ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventhas been processed.
- onProcessed(ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.SubsequentEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventhas been processed.
- onProcessing(ExecutionContext) - Method in interface com.tangosol.util.fsm.LifecycleAwareEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventis about to be processed.
- onProcessing(ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventis about to be processed.
- onProcessing(ExecutionContext) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.SubsequentEvent
- 
Called by aFiniteStateMachinewhen theLifecycleAwareEventis about to be processed.
- onRead(SelectionKey, ByteBuffer) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Called when a channel is detected as readable.
- onRecovery() - Method in class com.tangosol.net.GuardSupport.Context
- 
Called when the guardable enters the "RECOVERY" state.
- onRelease(R) - Method in interface com.tangosol.util.ResourceRegistry.ResourceLifecycleObserver
- 
Called by aResourceRegistrywhen a resource is being released.
- onReleased(AbstractPersistenceManager) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Called by the specified manager when it has been released.
- onRemove() - Method in class com.tangosol.util.ObservableHashMap.Entry
- 
Called to inform the Entry that it has been removed.
- onRemove(Consumer<T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.Listener.Builder
- 
Add the event handler for REMOVE events.
- onRemoved(T) - Method in interface com.oracle.coherence.repository.AbstractRepositoryBase.Listener
- 
An event callback that will be called when an entity is removed from the repository.
- onResult(Map.Entry) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- onResult(Map.Entry<K, R>) - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
Called when there is a partial result of the asynchronous execution.
- onResult(Map.Entry<K, R>) - Method in class com.tangosol.util.processor.AsynchronousProcessor
- onResult(Map.Entry<K, R>) - Method in class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- onResult(Map.Entry<K, R>) - Method in class com.tangosol.util.processor.StreamingAsynchronousProcessor
- onResult(P) - Method in class com.tangosol.util.aggregator.AbstractAsynchronousAggregator
- 
Called when there is a partial result of the asynchronous execution.
- onResult(P) - Method in class com.tangosol.util.aggregator.AsynchronousAggregator
- 
Called when the aggregation result is available.
- onServiceFailed(Cluster) - Method in interface com.tangosol.net.ServiceFailurePolicy
- 
Take appropriate action after some service failed to stop.
- onStartNamespace(ProcessingContext, XmlElement, String, URI) - Method in class com.tangosol.coherence.config.xml.CacheConfigNamespaceHandler
- 
Called when the xml namespace associated with theNamespaceHandleris first encountered in an xml document.
- onStartNamespace(ProcessingContext, XmlElement, String, URI) - Method in class com.tangosol.coherence.config.xml.OperationalConfigNamespaceHandler
- 
Called when the xml namespace associated with theNamespaceHandleris first encountered in an xml document.
- onStartNamespace(ProcessingContext, XmlElement, String, URI) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Called when the xml namespace associated with theNamespaceHandleris first encountered in an xml document.
- onStartNamespace(ProcessingContext, XmlElement, String, URI) - Method in interface com.tangosol.config.xml.NamespaceHandler
- 
Called when the xml namespace associated with theNamespaceHandleris first encountered in an xml document.
- onStoreAllFailure(Set, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store storeAll() failure.
- onStoreAllFailure(Set, Exception, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store storeAll() failure.
- onStoreFailure(ReadWriteBackingMap.Entry, Exception) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store store() failure.
- onStoreFailure(ReadWriteBackingMap.Entry, Exception, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Logs a store store() failure.
- onTerminate() - Method in class com.tangosol.net.GuardSupport.Context
- 
Called when the guardable enters the "TERMINATING" state.
- onTime(int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a time value has been encountered in the POF stream.
- onTime(int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a time value has been encountered in the POF stream.
- onTime(int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a time value has been encountered in the POF stream.
- onTime(int, int, int, int, int, boolean) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a time value has been encountered in the POF stream.
- onTime(int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a time value has been encountered in the POF stream.
- onTime(int, int, int, int, int, boolean) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a time value has been encountered in the POF stream.
- onTime(int, int, int, int, int, boolean) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a time value has been encountered in the POF stream.
- onTime(int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a time value (with a timezone offset) has been encountered in the POF stream.
- onTime(int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a time value (with a timezone offset) has been encountered in the POF stream.
- onTime(int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a time value (with a timezone offset) has been encountered in the POF stream.
- onTime(int, int, int, int, int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a time value (with a timezone offset) has been encountered in the POF stream.
- onTime(int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a time value (with a timezone offset) has been encountered in the POF stream.
- onTime(int, int, int, int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a time value (with a timezone offset) has been encountered in the POF stream.
- onTime(int, int, int, int, int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a time value (with a timezone offset) has been encountered in the POF stream.
- onTimeInterval(int, int, int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a time interval value has been encountered in the POF stream.
- onTimeInterval(int, int, int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a time interval value has been encountered in the POF stream.
- onTimeInterval(int, int, int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a time interval value has been encountered in the POF stream.
- onTimeInterval(int, int, int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a time interval value has been encountered in the POF stream.
- onTimeInterval(int, int, int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a time interval value has been encountered in the POF stream.
- onTimeInterval(int, int, int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a time interval value has been encountered in the POF stream.
- onTimeInterval(int, int, int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a time interval value has been encountered in the POF stream.
- onTransition(String, S, S, Event<S>, ExecutionContext) - Method in interface com.tangosol.util.fsm.TransitionAction
- 
Performs the necessary actions as part of aTransitionfrom one state to another, triggered by a specifiedEvent.
- onTransition(S, S) - Method in interface com.tangosol.util.fsm.FiniteStateMachineListener
- 
Called during a state transition immediately before aFiniteStateMachineenters a particular state.
- onUncontend(Object, SegmentedConcurrentMap.LockableEntry) - Method in interface com.tangosol.util.SegmentedConcurrentMap.ContentionObserver
- 
Called when the specified lock holder stops contending for the specified LockableEntry.
- onUnknownAttribute(XmlAttribute) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
A call-back to handle when anXmlAttributeis unknown to theNamespaceHandler.
- onUnknownElement(XmlElement) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
A call-back to handle when anXmlElementis unknown to theNamespaceHandler.
- onUpdate(SSLContextDependencies) - Method in class com.oracle.coherence.grpc.RefreshableSslContext
- onUpdate(BiConsumer<T, T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.Listener.Builder
- 
Add the event handler for UPDATE events.
- onUpdate(Consumer<T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase.Listener.Builder
- 
Add the event handler for UPDATE events.
- onUpdated(T, T) - Method in interface com.oracle.coherence.repository.AbstractRepositoryBase.Listener
- 
An event callback that will be called when an entity is updated.
- onValue(int) - Method in class com.tangosol.io.pof.WritingPofHandler.Complex
- 
Notify the Complex object that a value has been encountered.
- onValue(int) - Method in class com.tangosol.io.pof.WritingPofHandler.ComplexMap
- 
Notify the Complex object that a value has been encountered.
- onYearMonthInterval(int, int, int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
Report that a year-month interval value has been encountered in the POF stream.
- onYearMonthInterval(int, int, int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
Report that a year-month interval value has been encountered in the POF stream.
- onYearMonthInterval(int, int, int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Report that a year-month interval value has been encountered in the POF stream.
- onYearMonthInterval(int, int, int) - Method in interface com.tangosol.io.pof.PofHandler
- 
Report that a year-month interval value has been encountered in the POF stream.
- onYearMonthInterval(int, int, int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report that a year-month interval value has been encountered in the POF stream.
- onYearMonthInterval(int, int, int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
Report that a year-month interval value has been encountered in the POF stream.
- onYearMonthInterval(int, int, int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
Report that a year-month interval value has been encountered in the POF stream.
- OP_APPEND - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
A binary delta operator that instructs theBinaryDeltaCompressor.applyDelta(com.tangosol.io.ReadBuffer, com.tangosol.io.ReadBuffer)method to copy the following bytes from the delta value and append them to the new value.
- OP_EXTRACT - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
A binary delta operator that instructs theBinaryDeltaCompressor.applyDelta(com.tangosol.io.ReadBuffer, com.tangosol.io.ReadBuffer)method to extract bytes from the old value and append them to the new value.
- OP_TERM - Static variable in class com.tangosol.io.BinaryDeltaCompressor
- 
A binary delta operator that instructs theBinaryDeltaCompressor.applyDelta(com.tangosol.io.ReadBuffer, com.tangosol.io.ReadBuffer)method that the delta has been fully applied.
- open() - Method in class com.tangosol.util.ThreadGateLite
- 
Re-open the closed gate.
- open() - Method in class com.tangosol.util.WrapperReentrantGate
- 
Re-open the closed gate.
- open(PersistentStore<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Open this persistent store.
- open(String, PersistentStore<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Open or create aPersistentStoreassociated with the specified identifier and based on the providedstore.
- open(String, PersistentStore<ReadBuffer>, Collector<Object>) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Open or create aPersistentStoreassociated with the specified identifier and based on the providedstore.
- open(String, PersistentStore<R>) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Open or create aPersistentStoreassociated with the specified identifier and based on the providedstore.
- open(String, PersistentStore<R>) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Open or create aPersistentStoreassociated with the specified identifier and based on the providedstore.
- open(String, PersistentStore<R>, Collector<Object>) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Open or create aPersistentStoreassociated with the specified identifier and based on the providedstore.
- open(String, PersistentStore<R>, Collector<Object>) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Open or create aPersistentStoreassociated with the specified identifier and based on the providedstore.
- openActive() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Open and return the singleton active PersistenceManager.
- openActive() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Open and return the singleton active PersistenceManager.
- openActive() - Method in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
- 
Open and return the singleton active PersistenceManager.
- openActiveInternal() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Open the active manager.
- openBackup() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Open and return a singleton PersistenceManager to store backup data.
- openBackup() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Open and return a singleton PersistenceManager to store backup data.
- openBackupInternal() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Open the backup manager.
- openBlock(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Obtain a Block object for the block located at the specified offset in the ByteBuffer.
- openDatagramChannel() - Method in interface com.tangosol.net.SocketProvider
- 
Return a new DatagramChannel.
- openDatagramSocket() - Method in interface com.tangosol.net.DatagramSocketProvider
- 
Return a new DatagramSocket.
- openDatagramSocket() - Method in interface com.tangosol.net.SocketProvider
- 
Return a new DatagramSocket.
- openDatagramSocket() - Method in class com.tangosol.net.SystemDatagramSocketProvider
- openDatagramSocket() - Method in class com.tangosol.net.TcpDatagramSocketProvider
- 
Return a new DatagramSocket.
- openEvents() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Open and return a singleton PersistenceManager to store MapEvents.
- openEvents() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Open and return a singleton PersistenceManager to store MapEvents.
- openEventsInternal() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Open the events manager.
- OpenHashMap<K,V> - Class in com.tangosol.util
- 
An implementation ofMapthat is optimized for memory footprint.
- OpenHashMap() - Constructor for class com.tangosol.util.OpenHashMap
- 
Default constructor.
- OpenHashMap(int) - Constructor for class com.tangosol.util.OpenHashMap
- 
Create a OpenHashMap pre-sized to hold the specified number of entries.
- OpenHashMap(Map) - Constructor for class com.tangosol.util.OpenHashMap
- 
Create a OpenHashMap that will initially contain the contents of the passed Map.
- OpenHashMap.EntrySet - Class in com.tangosol.util
- 
A set of entries backed by this map.
- OpenHashMap.EntrySet.Entry - Class in com.tangosol.util
- 
An Entry implementation that is augmented to allow an Entry instance to be re-used, which means that the same Entry instance can represent different map entries over time.
- OpenHashMap.EntrySet.EntrySetIterator - Class in com.tangosol.util
- 
An Iterator over the EntrySet that is backed by the Map.
- OpenHashMap.KeySet - Class in com.tangosol.util
- 
A set of keys backed by this map.
- OpenHashSet<E> - Class in com.tangosol.util
- 
An implementation ofSetthat is optimized for memory footprint.
- OpenHashSet() - Constructor for class com.tangosol.util.OpenHashSet
- 
Default constructor.
- OpenHashSet(int) - Constructor for class com.tangosol.util.OpenHashSet
- 
Create a OpenHashSet pre-sized to hold the specified number of elements.
- OpenHashSet(Collection<? extends E>) - Constructor for class com.tangosol.util.OpenHashSet
- 
Create a OpenHashSet that will initially contain the contents of the passed Collection.
- openInternal() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Open the underlying persistent storage.
- OpenMBeanHelper - Class in com.tangosol.net.management
- 
A set of utility method for dealing with OpenMBean APIs because they stupidly have constructors that throw exceptions.
- OpenMBeanHelper() - Constructor for class com.tangosol.net.management.OpenMBeanHelper
- openMulticastSocket() - Method in interface com.tangosol.net.DatagramSocketProvider
- 
Return a new MulticastSocket.
- openMulticastSocket() - Method in interface com.tangosol.net.SocketProvider
- 
Return a new MulticastSocket.
- openMulticastSocket() - Method in class com.tangosol.net.SystemDatagramSocketProvider
- openMulticastSocket() - Method in class com.tangosol.net.TcpDatagramSocketProvider
- 
Return a new MulticastSocket.
- openServerSocket() - Method in interface com.tangosol.net.SocketProvider
- 
Return a new ServerSocket.
- openServerSocketChannel() - Method in interface com.tangosol.net.SocketProvider
- 
Return a new ServerSocketChannel.
- openSnapshot(String) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Open a PersistenceManager used to access the snapshot with the specified identifier.
- openSnapshot(String) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Open a PersistenceManager used to access the snapshot with the specified identifier.
- openSnapshot(String) - Method in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
- 
Open a PersistenceManager used to access the snapshot with the specified identifier.
- openSnapshotInternal(File, String) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Open the snapshot with the specified identifier.
- openSocket() - Method in interface com.tangosol.net.SocketProvider
- 
Return a new Socket.
- openSocketChannel() - Method in interface com.tangosol.net.SocketProvider
- 
Return a new SocketChannel.
- OpenTask(PersistentStore<ReadBuffer>, Collector<Object>) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.OpenTask
- 
Construct an OpenTask.
- Operation(long, ReadBuffer) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.Operation
- 
Create a new Operation.
- OperationalConfigNamespaceHandler - Class in com.tangosol.coherence.config.xml
- 
TheOperationalConfigNamespaceHandleris responsible for capturing and creating the Coherence operational configuration when processing a Coherence operational configuration file.
- OperationalConfigNamespaceHandler() - Constructor for class com.tangosol.coherence.config.xml.OperationalConfigNamespaceHandler
- 
Standard Constructor.
- OperationalConfigNamespaceHandler.Extension - Interface in com.tangosol.coherence.config.xml
- 
Implementations ofOperationalConfigNamespaceHandler.Extensionare able to modify theOperationalConfigNamespaceHandlerbefore it is used.
- OperationalContext - Interface in com.tangosol.net
- 
OperationalContext is an interface for providing Oracle Coherence operational configuration.
- OperationalDefaultsPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
AOperationalDefaultsPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat introduces (via cloning) default xml content for xml elements where the said content is missing.
- OperationalDefaultsPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.OperationalDefaultsPreprocessor
- 
Constructs aOperationalDefaultsPreprocessor.
- OperationBundlingProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AOperationBundlingProcessoris responsible for processing an operation-bundlingXmlElementto produce anBundleManager.
- OperationBundlingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.OperationBundlingProcessor
- OperatorBaseToken - Class in com.tangosol.coherence.dsltools.base
- 
OperatorBaseToken is a token that represents a known operator.
- OperatorBaseToken(String) - Constructor for class com.tangosol.coherence.dsltools.base.OperatorBaseToken
- 
Construct a new OperatorBaseToken with the given operator value.
- OPException - Exception in com.tangosol.coherence.dsltools.precedence
- 
OPExpression is the RuntimeException thrown by the OPParser and OPScanner when problems are detected.
- OPException() - Constructor for exception com.tangosol.coherence.dsltools.precedence.OPException
- 
Construct a new OPException.
- OPException(String) - Constructor for exception com.tangosol.coherence.dsltools.precedence.OPException
- 
Construct a new OPException with the given message string.
- OPParser - Class in com.tangosol.coherence.dsltools.precedence
- 
OPParser is the parser class for the Top Down Operator Presidence Parsing framework.
- OPParser(OPScanner) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Construct a new OPParser initialized to gthe given Scanner
- OPParser(Reader, TokenTable, Set<CharSequence>) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Construct a new OPParser that parses the given Reader in the language defined by the given TokenTable.
- OPParser(String, TokenTable, Set<CharSequence>) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Construct a new OPParser that parses the given expression in the language defined by the given TokenTable.
- OPScanner - Class in com.tangosol.coherence.dsltools.precedence
- 
OPScanner gives clients a streaming api that returns a next OPToken by processing a java.lang.String using a TokenTable to convert lower level BaseTokens into the high functionality OPTokens.
- OPScanner(TokenTable, Set<CharSequence>) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Construct a new OPScanner using the given TokenTable.
- OPT_BY_MEMBER - Static variable in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
An option to iterate one member at a time.
- OPT_BY_PARTITION - Static variable in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
An option to iterate one partition at a time.
- OPT_ENTRIES - Static variable in class com.tangosol.net.partition.PartitionedIterator
- 
An option to iterate Map Entry objects.
- OPT_KEYS - Static variable in class com.tangosol.net.partition.PartitionedIterator
- 
An option to iterate the Map keys.
- OPT_RANDOMIZED - Static variable in class com.tangosol.net.partition.AbstractPartitionedIterator
- 
An option to iterate the members or partitions in a randomized order.
- OptimisticScheme - Class in com.tangosol.coherence.config.scheme
- 
TheOptimisticSchemeclass builds an optimistic cache.
- OptimisticScheme() - Constructor for class com.tangosol.coherence.config.scheme.OptimisticScheme
- optimizeFilterOrder(Map, Set) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Sort all the participating filters according to their effectiveness.
- optimizeFilterOrder(Map, Set) - Method in class com.tangosol.util.filter.BetweenFilter
- OptionalDoubleSerializer - Class in com.tangosol.io.pof
- 
POF serializer forjava.util.OptionalDouble.
- OptionalDoubleSerializer() - Constructor for class com.tangosol.io.pof.OptionalDoubleSerializer
- OptionalIntSerializer - Class in com.tangosol.io.pof
- 
POF serializer forjava.util.OptionalInt.
- OptionalIntSerializer() - Constructor for class com.tangosol.io.pof.OptionalIntSerializer
- OptionalLongSerializer - Class in com.tangosol.io.pof
- 
POF serializer forjava.util.OptionalLong.
- OptionalLongSerializer() - Constructor for class com.tangosol.io.pof.OptionalLongSerializer
- OptionalSerializer - Class in com.tangosol.io.pof
- 
POF serializer forjava.util.Optional.
- OptionalSerializer() - Constructor for class com.tangosol.io.pof.OptionalSerializer
- OPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
OPToken is the root class for the Top Down Operator Precedence Parsing framework's tokens.
- OPToken() - Constructor for class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Construct a new OPToken.
- OPToken(String) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Construct a new OPToken with the given parameters.
- OPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Construct a new OPToken with the given parameters.
- OPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Construct a new OPToken with the given parameters.
- OPToken(String, int, String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Construct a new OPToken with the given parameters.
- OPToken(String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Construct a new OPToken with the given parameters.
- or(Filter) - Method in interface com.tangosol.util.Filter
- 
Return a composed predicate that represents a short-circuiting logical OR of this predicate and another.
- or(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 OR of this predicate and another.
- or(Remote.DoublePredicate) - Method in interface com.tangosol.util.function.Remote.DoublePredicate
- 
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
- or(Remote.IntPredicate) - Method in interface com.tangosol.util.function.Remote.IntPredicate
- 
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
- or(Remote.LongPredicate) - Method in interface com.tangosol.util.function.Remote.LongPredicate
- 
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
- or(Remote.Predicate<? super T>) - Method in interface com.tangosol.util.function.Remote.Predicate
- 
Returns a composed predicate that represents a short-circuiting logical OR of this predicate and another.
- order() - Method in annotation type com.tangosol.net.events.annotation.Interceptor
- 
Iff a value ofInterceptor.Order.HIGHis provided this interceptor will request to be the first in the chain of interceptors.
- OrderBy() - Constructor for class com.tangosol.net.topic.Publisher.OrderBy
- 
Default constructor for serialization.
- OrderBy(IntSupplier) - Constructor for class com.tangosol.net.AsyncNamedMap.OrderBy
- 
Construct OrderBy instance.
- OrderById() - Constructor for class com.tangosol.net.topic.Publisher.OrderById
- OrderById(int) - Constructor for class com.tangosol.net.topic.Publisher.OrderById
- OrderByNone() - Constructor for class com.tangosol.net.topic.Publisher.OrderByNone
- OrderByRoundRobin() - Constructor for class com.tangosol.net.topic.Publisher.OrderByRoundRobin
- OrderByThread() - Constructor for class com.tangosol.net.topic.Publisher.OrderByThread
- OrderByValue() - Constructor for class com.tangosol.net.topic.Publisher.OrderByValue
- OrderByValue(ToIntFunction<? super V>) - Constructor for class com.tangosol.net.topic.Publisher.OrderByValue
- ordered() - Method in annotation type com.oracle.coherence.repository.Indexed
- 
Determines whether the index should be ordered or not (default).
- ORDINAL_PROPERTY - Static variable in class com.oracle.coherence.mp.config.CoherenceConfigSource
- 
The name of the system property that can be used to change the ordinal for thisConfigSource.
- OrFilter - Class in com.tangosol.util.filter
- 
Filter which returns the logical "or" of two other filters.
- OrFilter() - Constructor for class com.tangosol.util.filter.OrFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- OrFilter(Filter, Filter) - Constructor for class com.tangosol.util.filter.OrFilter
- 
Construct an "or" filter.
- OrOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the logical OR operator.
- OrOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.OrOperator
- 
Construct an OrOperator.
- ORPHANED - com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
A partition is orphaned when there are no storage-enabled member of the service that holds a primary copy of that partition.
- out() - Static method in class com.tangosol.util.Base
- 
Prints a blank line.
- out(Class<?>) - Static method in class com.tangosol.util.Base
- 
Prints the passed class information.
- out(Object) - Static method in class com.tangosol.util.Base
- 
Prints the passed Object.
- out(String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.ALWAYSseverity.
- out(String) - Static method in class com.tangosol.util.Base
- 
Prints the passed String value.
- out(String, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.ALWAYSseverity.
- out(Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) withLogger.ALWAYSseverity.
- out(Throwable) - Static method in class com.tangosol.util.Base
- 
Prints the passed exception information.
- out(Supplier<String>) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.ALWAYSseverity.
- out(Supplier<String>, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.ALWAYSseverity.
- OutputStreaming - Interface in com.tangosol.io
- 
This is the interface represented by the Java OutputStream class.
- OverflowMap - Class in com.tangosol.net.cache
- 
An Observable Map implementation that wraps two maps - a front map (assumed to be fast but limited in its maximum size) and a back map (assumed to be slower but much less limited in its maximum size).
- OverflowMap(ObservableMap, Map) - Constructor for class com.tangosol.net.cache.OverflowMap
- 
Construct a OverflowMap using two specified maps: FrontMap (aka "cache" or "shallow") and BackMap (aka "file" or "deep") If the BackMap implements the ObservableMap interface a listener will be added to the BackMap to invalidate items updated [externally] in the back map.
- OverflowMap.BackMapListener - Class in com.tangosol.net.cache
- 
A listener for the back map.
- OverflowMap.EntrySet - Class in com.tangosol.net.cache
- 
A set of entries backed by this map.
- OverflowMap.EntrySet.EntrySetIterator - Class in com.tangosol.net.cache
- 
A pessimistic Iterator over the EntrySet that is backed by the OverflowMap.
- OverflowMap.ExpirableStatus - Class in com.tangosol.net.cache
- 
The ExpirableStatus adds expiry to the base Status object.
- OverflowMap.FrontMapListener - Class in com.tangosol.net.cache
- 
A listener for the front map that moves evictions to the back map.
- OverflowMap.HistoricCacheEvent - Class in com.tangosol.net.cache
- 
A CacheEvent that carries a recent value (to avoid it being lost during eviction).
- OverflowMap.InternalKeySet - Class in com.tangosol.net.cache
- 
A read-only set of keys backed by this map.
- OverflowMap.InternalKeySet.InternalKeySetIterator - Class in com.tangosol.net.cache
- 
An Iterator implementation over the keys in the OverflowMap that that is based on a concurrent Iterator over the internal status map.
- OverflowMap.Status - Class in com.tangosol.net.cache
- 
The Status object is used to manage concurrency at the key level for the key-level operations against the Map, to track all the items in the front Map, to manage the state transition for operations occurring against the Map, and to coordinate events across multiple threads.
- OverflowScheme - Class in com.tangosol.coherence.config.scheme
- OverflowScheme() - Constructor for class com.tangosol.coherence.config.scheme.OverflowScheme
- override(long) - Static method in class com.oracle.coherence.common.base.Timeout
- 
Specify a new timeout, potentially extending an already active timeout.
- overrideElement(XmlElement, XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Override the values of the specified base element with values from the specified override element.
- overrideElement(XmlElement, XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Override the values of the specified base element with values from the specified override element.
- OverrideProcessor - Interface in com.tangosol.config.xml
- 
AOverrideProcessoris responsible for processing override config elements and merging the elements with the Document root elements.
- Ownership - Class in com.tangosol.net.partition
- 
Ownership is a light-weight data structure that contains a partition ownership information.
- Ownership() - Constructor for class com.tangosol.net.partition.Ownership
- 
Default constructor (necessary for the ExternalizableLite interface).
- Ownership(int) - Constructor for class com.tangosol.net.partition.Ownership
- 
Construct an empty Ownership object with a given backup count.
- Ownership(Ownership) - Constructor for class com.tangosol.net.partition.Ownership
- 
Copy constructor.
P
- PACKED_INT_SIZE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Maximum size of a packed int.
- PACKED_LONG_SIZE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Maximum size of a packed long.
- PackedDataInputStream - Class in com.tangosol.io
- 
This is an imitation DataInputStream class that reads from streams that were produced by a correspondingPackedDataOutputStream.
- PackedDataInputStream(InputStream) - Constructor for class com.tangosol.io.PackedDataInputStream
- 
Construct a WrapperDataInputStream that will read from the specified InputStream object.
- PackedDataOutputStream - Class in com.tangosol.io
- 
This is an imitation DataOutputStream class that packs its data tighter using variable-length integers and supports UTF longer than 64KB.
- PackedDataOutputStream(OutputStream) - Constructor for class com.tangosol.io.PackedDataOutputStream
- 
Construct a PackedDataOutputStream that will output to the specified OutputStream object.
- pad(long, long) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Return the smallest value that is not less than the first argument and is a multiple of the second argument.
- pad(long, long) - Static method in class com.tangosol.util.Base
- 
Return the smallest value that is not less than the first argument and is a multiple of the second argument.
- padMemorySize(int) - Static method in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
Round the given number of bytes to the next closest integer that is divisible by 8.
- page(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aPageRequest.
- PAGED_TOPIC_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the Paged Topic MBean.
- PagedBinaryStore(int) - Constructor for class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Construct a PagedBinaryStore.
- PagedExternalScheme - Class in com.tangosol.coherence.config.scheme
- 
ThePagedExternalSchemeclass is responsible for building a fully configured instance of a PagedExternalCache.
- PagedExternalScheme() - Constructor for class com.tangosol.coherence.config.scheme.PagedExternalScheme
- PagedIterator - Class in com.tangosol.util
- 
PagedIterator is an Iterator implementation based on a concept of a page Advancer - a pluggable component that knows how to supply a next page of objects to iterate through.
- PagedIterator(PagedIterator.Advancer) - Constructor for class com.tangosol.util.PagedIterator
- 
Construct a PagedIterator based on the specified Advancer.
- PagedIterator.Advancer - Interface in com.tangosol.util
- 
Advancer is a pluggable component that knows how to load a new page (Collection) of objects to be used by the enclosing PagedIterator.
- PagedQueryHelper - Class in com.oracle.coherence.grpc.proxy
- 
A helper class for cache key set and entry set paged queries.
- PagedTopicScheme - Class in com.tangosol.coherence.config.scheme
- 
APagedTopicSchemeis responsible for building a topic.
- PagedTopicScheme() - Constructor for class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Constructs aPagedTopicScheme.
- PagedTopicSchemeProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat parses a <paged-topic-scheme> element; produces aPagedTopicScheme.
- PagedTopicSchemeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PagedTopicSchemeProcessor
- PagedTopicSchemeProcessor(Class<PagedTopicScheme>) - Constructor for class com.tangosol.coherence.config.xml.processor.PagedTopicSchemeProcessor
- PagedTopicService - Interface in com.tangosol.net
- 
ATopicServicewhich provides globally ordered topics.
- PagedTopicStorageScheme - Class in com.tangosol.coherence.config.scheme
- 
A scheme that builds the inner scheme of the backing map scheme of a topic.
- PagedTopicStorageScheme(CachingScheme, PagedTopicScheme) - Constructor for class com.tangosol.coherence.config.scheme.PagedTopicStorageScheme
- 
Create aPagedTopicStorageScheme.
- parallel() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- parallel() - Method in interface com.tangosol.util.stream.RemoteIntStream
- parallel() - Method in interface com.tangosol.util.stream.RemoteLongStream
- parallel() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns an equivalent stream that is parallel.
- parallel(InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Convert the specified aggregator to ParallelAwareAggregator.
- Parallel() - Constructor for class com.tangosol.util.aggregator.CompositeAggregator.Parallel
- 
Deprecated.Default constructor (necessary for the ExternalizableLite interface).
- Parallel() - Constructor for class com.tangosol.util.aggregator.GroupAggregator.Parallel
- 
Deprecated.Default constructor (necessary for the ExternalizableLite interface).
- Parallel(InvocableMap.EntryAggregator[]) - Constructor for class com.tangosol.util.aggregator.CompositeAggregator.Parallel
- 
Deprecated.Construct a CompositeParallelAggregator based on a specifiedEntryAggregatorarray.
- Parallel(ValueExtractor<? super T, ? extends E>, InvocableMap.EntryAggregator<? super K, ? super V, R>, Filter<?>) - Constructor for class com.tangosol.util.aggregator.GroupAggregator.Parallel
- 
Deprecated.Construct a Parallel aggregator based on a specified ValueExtractor and underlying ParallelAwareAggregator.
- PARALLEL - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A flag specifying that this aggregator should be executed in parallel.
- parallelStream() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- Parameter - Class in com.tangosol.config.expression
- 
AParameterrepresents an optionally named and optionally explicitly typedExpression.
- Parameter() - Constructor for class com.tangosol.config.expression.Parameter
- 
Default constructor needed for serialization.
- Parameter(String, Expression<?>) - Constructor for class com.tangosol.config.expression.Parameter
- 
Construct an implicitly typedParameterbased on anExpression.
- Parameter(String, Class<?>, Expression<?>) - Constructor for class com.tangosol.config.expression.Parameter
- 
Construct anParameter.
- Parameter(String, Class<?>, Object) - Constructor for class com.tangosol.config.expression.Parameter
- Parameter(String, Object) - Constructor for class com.tangosol.config.expression.Parameter
- PARAMETER_PREFIX - Static variable in class com.tangosol.config.expression.ValueMacroExpression
- 
Prefix indicating the start of a property macro.
- PARAMETER_SUFFIX - Static variable in class com.tangosol.config.expression.ValueMacroExpression
- 
Suffix indicating the close of a property macro.
- ParameterizedBuilder<T> - Interface in com.tangosol.coherence.config.builder
- 
AParameterizedBuilderis an implementation of the classic Builder Pattern that utilizes aParameterResolverto resolve any required runtimeParameters necessary for realizing an object.
- ParameterizedBuilder.ReflectionSupport - Interface in com.tangosol.coherence.config.builder
- 
Deprecated.
- ParameterizedBuilderHelper - Class in com.tangosol.coherence.config.builder
- 
TheParameterizedBuilderHelperdefines helper methods forParameterizedBuilderimplementations.
- ParameterizedBuilderHelper() - Constructor for class com.tangosol.coherence.config.builder.ParameterizedBuilderHelper
- ParameterizedBuilderRegistry - Interface in com.tangosol.coherence.config.builder
- 
A registry of strongly typed and possibly namedParameterizedBuilders.
- ParameterizedBuilderRegistry.Registration<T> - Interface in com.tangosol.coherence.config.builder
- 
Defines a singleParameterizedBuilderregistration with aParameterizedBuilderRegistry.
- ParameterList - Interface in com.tangosol.coherence.config
- ParameterMacroExpression<T> - Class in com.tangosol.coherence.config
- 
AParameterMacroExpressionis anExpressionrepresenting the use of a Coherence Parameter Macro, typically occurring with in a Coherence Cache Configuration file.
- ParameterMacroExpression() - Constructor for class com.tangosol.coherence.config.ParameterMacroExpression
- 
Default constructor needed for serialization.
- ParameterMacroExpression(String, Class<T>) - Constructor for class com.tangosol.coherence.config.ParameterMacroExpression
- 
Construct aParameterMacroExpression.
- ParameterMacroExpressionParser - Class in com.tangosol.coherence.config
- 
AParameterMacroExpressionParseris anExpressionParserfor Coherence Parameter Macros.
- ParameterMacroExpressionParser() - Constructor for class com.tangosol.coherence.config.ParameterMacroExpressionParser
- ParameterResolver - Interface in com.tangosol.config.expression
- 
AParameterResolverprovides a mechanism resolve and lookup namedParameters.
- ParamTypeProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AParamTypeProcessoris responsible for processing <param-type>XmlElements to produce a fully qualified class name.
- ParamTypeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ParamTypeProcessor
- ParenOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
ParenOPToken is used to process expressions that are between "(" and ")".
- ParenOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.ParenOPToken
- 
Construct a new ParenOpToken with the given parameters.
- ParenOPToken(String, int, String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.ParenOPToken
- 
Construct a new ParenOpToken with the given parameters.
- parent - Variable in class com.tangosol.util.AbstractSparseArray.Node
- 
The parent of this node.
- park(long) - Method in class com.oracle.coherence.common.base.ConcurrentNotifier
- 
Block the calling thread if the notifier is not ready.
- park(Object) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Invoke LockSupport.park() while still respecting the calling thread'stimeout.
- parkNanos(Object, long) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Invoke LockSupport.parkNanos() while still respecting the calling thread'stimeout.
- parse() - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Parse the next expression into an Abstract Syntax Tree.
- parse(ReadBuffer.BufferInput) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a POF value that is in the passed BufferInput.
- parse(ReadBuffer, PofContext) - Static method in class com.tangosol.io.pof.reflect.PofValueParser
- 
Parses POF-encoded binary and returns an instance of aPofValuewrapper for it.
- parse(String) - Static method in class com.tangosol.run.xml.DateTimeAdapter
- 
Return a Date represented by ISO8601 compliant string.
- parse(String) - Static method in class com.tangosol.util.QueryHelper
- 
Return theTermrepresenting the AST produced by parsing the specified CohQL query String.
- parse(String, CoherenceQueryLanguage) - Static method in class com.tangosol.util.QueryHelper
- 
Return theTermrepresenting the AST produced by parsing the specified CohQL query String.
- parse(String, Class<T>) - Method in class com.tangosol.coherence.config.ParameterMacroExpressionParser
- 
Attempts to parse the providedStringto produce anExpressionof an expected type.
- parse(String, Class<T>) - Method in interface com.tangosol.config.expression.ExpressionParser
- 
Attempts to parse the providedStringto produce anExpressionof an expected type.
- parseAction(String) - Method in class com.tangosol.net.ClusterPermission
- 
Parse the action string and set the action flag.
- parseArray(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse an Array from the POF stream.
- parseAttribute(String, int) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Return the specified (0-based) attribute from the GUID.
- parseBandwidth(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a number of bytes per second.
- parseBandwidth(String) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a number of bytes per second.
- parseBandwidth(String, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a number of bytes per second.
- parseBandwidth(String, int) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a number of bytes per second.
- parseCollection(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a Collection from the POF stream.
- parseComment(XmlElement) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse comments.
- parseComment(XmlElement, boolean) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse comments.
- parseDelimitedString(String, char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse a character-delimited String into an array of Strings.
- parseDelimitedString(String, char) - Static method in class com.tangosol.util.Base
- 
Parse a character-delimited String into an array of Strings.
- parseDoctype(XmlDocument) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse doc type.
- parseDocument(XmlDocument) - Method in class com.tangosol.run.xml.SimpleParser
- 
Factory method to instantiate an XmlDocument implementation.
- ParsedQuery() - Constructor for class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
- 
Construct a ParsedQuery instance.
- ParsedQuery(String, Map<String, Filter<String>>) - Constructor for class com.tangosol.net.management.MBeanAccessor.QueryBuilder.ParsedQuery
- 
Construct a ParsedQuery based on the given query expression and the map of key to Filter used to test against the corresponding key/value within the ObjectName.
- ParsedQuery(String, Map<String, Class>) - Constructor for class com.tangosol.coherence.rest.query.AbstractQueryEngine.ParsedQuery
- 
Construct ParsedQuery instance.
- parseElement(XmlElement) - Method in class com.tangosol.run.xml.SimpleParser
- 
Note: '<' and element name have already been parsed
- parseHex(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Return the integer value of a hexadecimal digit.
- parseHex(char) - Static method in class com.tangosol.util.Base
- 
Return the integer value of a hexadecimal digit.
- parseHex(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the passed String of hexadecimal characters into a binary value.
- parseHex(String) - Static method in class com.tangosol.util.Base
- 
Parse the passed String of hexadecimal characters into a binary value.
- parseIndexDescription(String) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Parses an index description into it's definition, footprint, and map size.
- parseInitParams(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Parse the specified "init-params" element of the following structure:
- parseInitParams(XmlElement, XmlHelper.ParameterResolver) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Parse the specified "init-params" element of the following structure:
- parseMap(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a Map from the POF stream.
- parseMemorySize(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a number of bytes.
- parseMemorySize(String) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a number of bytes.
- parseMemorySize(String, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a number of bytes.
- parseMemorySize(String, int) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a number of bytes.
- parseMisc(XmlElement) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse comments / other PIs.
- parseNumber(String) - Static method in class com.tangosol.run.xml.SimpleAdapter
- 
Parse parenthesized number string into a negative number string.
- parseParamTypes(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Parse the specified "init-params" elements and return the array of the param types.
- parsePercentage(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a percentage value and return its value as a float in the inclusive range of 0.0 and 1.0.
- parsePercentage(String) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a percentage value and return its value as a float in the inclusive range of 0.0 and 1.0.
- parsePi(XmlElement) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse <?
- parsePi(XmlElement, boolean) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse <?
- parseQueryString(String) - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine
- 
Parse a query string containing parameter type hints.
- parseSparseArray(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a Sparse Array from the POF stream.
- parseTarget(String) - Method in class com.tangosol.net.ClusterPermission
- 
Parse the target string.
- parseThreadExtension(Daemon) - Static method in class com.tangosol.net.LoadBalancer
- 
Parse the extension glued onto the end of a daemon's thread's name.
- parseTime(XmlElement, String, long) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Parse the String value of the child XmlElement with the given name as a time in milliseconds.
- parseTime(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a time duration and return its value as a number of milliseconds.
- parseTime(String) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a time duration and return its value as a number of milliseconds.
- parseTime(String, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a time duration and return its value as a number of milliseconds.
- parseTime(String, int) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a time duration and return its value as a number of milliseconds.
- parseTimeNanos(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a time duration and return its value as a number of nanoseconds.
- parseTimeNanos(String) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a time duration and return its value as a number of nanoseconds.
- parseTimeNanos(String, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Parse the given string representation of a time duration and return its value as a number of nanoseconds.
- parseTimeNanos(String, int) - Static method in class com.tangosol.util.Base
- 
Parse the given string representation of a time duration and return its value as a number of nanoseconds.
- parseUniformArray(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a Uniform Array from the POF stream.
- parseUniformCollection(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a Uniform Collection from the POF stream.
- parseUniformKeysMap(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a Uniform-Keys Map from the POF stream.
- parseUniformMap(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a Uniform Map from the POF stream.
- parseUniformSparseArray(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a Uniform Sparse Array from the POF stream.
- parseUniformValue(PofValue, int, ReadBuffer, PofContext, int) - Static method in class com.tangosol.io.pof.reflect.PofValueParser
- 
Parses a uniform POF-encoded binary and returns an instance of aPofValuewrapping the binary.
- parseUniformValue(ReadBuffer.BufferInput, int, int) - Method in class com.tangosol.io.pof.PofParser
- 
Within the POF stream, parse a POF value of the specified type that is in the passed BufferInput.
- parseUserType(ReadBuffer.BufferInput, int, int) - Method in class com.tangosol.io.pof.PofParser
- 
Parse a User Type from the POF stream.
- parseValue(PofValue, ReadBuffer, PofContext, int) - Static method in class com.tangosol.io.pof.reflect.PofValueParser
- 
Parse a POF-encoded binary and return an instance of aPofValuewrapping the binary.
- parseValue(ReadBuffer.BufferInput, int) - Method in class com.tangosol.io.pof.PofParser
- 
Within the POF stream, parse a POF value that is in the passed BufferInput.
- parseXml(InputStream) - Method in class com.tangosol.run.xml.SaxParser
- 
Parse the specified InputStream into a tree of XmlElement objects ignoring any XML nodes other than elements, text or comments (in a case of SaxParser that allows comments).
- parseXml(InputStream) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse the specified InputStream into an XmlDocument object.
- parseXml(InputStream, String) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse the specified InputStream into an XmlDocument object using the specified charset.
- parseXml(Reader) - Method in class com.tangosol.run.xml.SaxParser
- 
Parse the specified Reader into a tree of XmlElement objects ignoring any XML nodes other than elements, text or comments (in a case of SaxParser that allows comments).
- parseXml(Reader) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse the specified Reader into an XmlDocument object.
- parseXml(String) - Method in class com.tangosol.run.xml.SaxParser
- 
Parse the specified String into a tree of XmlElement objects ignoring any XML nodes other than elements, text or comments (in a case of SaxParser that allows comments).
- parseXml(String) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse the specified String into an XmlDocument object.
- parseXml(String, XmlDocument) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse the passed script.
- parseXml(String, XmlElement) - Method in class com.tangosol.run.xml.SaxParser
- 
Parse the specified String into a tree of XmlElement objects (same as above) having the specified [empty] XmlElement a root.
- parseXml(InputSource) - Method in class com.tangosol.run.xml.SaxParser
- 
Parse the specified InputSource into a tree of XmlElement objects ignoring any XML nodes other than elements, text or comments (in a case of SaxParser that allows comments).
- parseXml(InputSource, XmlElement) - Method in class com.tangosol.run.xml.SaxParser
- 
Actual implementation...
- parseXmlDecl(XmlDocument) - Method in class com.tangosol.run.xml.SimpleParser
- 
Parse XML declaration.
- PartialByteSequence(ByteSequence, int, int) - Constructor for class com.tangosol.util.AbstractByteSequence.PartialByteSequence
- 
Construct a PartialByteSequence from a ByteSequence.
- PartialClassLoader(ClassLoader) - Constructor for class com.tangosol.coherence.rest.util.PartialObject.PartialClassLoader
- 
Construct PartialClassLoader instance.
- PartialObject - Class in com.tangosol.coherence.rest.util
- 
Base class for dynamically generated partial classes.
- PartialObject() - Constructor for class com.tangosol.coherence.rest.util.PartialObject
- 
Construct a PartialObject instance.
- PartialObject(Map) - Constructor for class com.tangosol.coherence.rest.util.PartialObject
- 
Construct a PartialObject instance.
- PartialObject.PartialClassLoader - Class in com.tangosol.coherence.rest.util
- 
Class loader implementation that is used to define and load partial classes.
- PartialResult() - Constructor for class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- 
Default constructor.
- PartialResult() - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Default constructor (necessary for the ExternalizableLite interface).
- PartialResult(PartitionSet) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Construct a PartialResult.
- PartialResult(QueryContext, PartitionSet) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Construct a PartialResult.
- PartialResult(QueryRecord.PartialResult) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Copy constructor for a Result.
- PartialResult(Comparator<? super E>, int) - Constructor for class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- 
Construct a PartialResult using the specified comparator.
- ParticipantName - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used to indicate a specific participant name.
- ParticipantName.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theParticipantNameannotation.
- PARTITION_ASSIGNED - Static variable in class com.tangosol.net.partition.PartitionEvent
- 
This event indicates that the ownership of one or more partitions have been assigned to a service member.
- PARTITION_ASSIGNMENT_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the PartitionAssignmentStrategy (SimpleStrategyMBean).
- PARTITION_LOST - Static variable in class com.tangosol.net.partition.PartitionEvent
- 
This event indicates that one or more partitions have been lost.
- PARTITION_RECEIVE_BEGIN - Static variable in class com.tangosol.net.partition.PartitionEvent
- 
This event indicates that a transfer for one or more partitions is beginning and the data that belongs to partitions in the specified partition set are about to be inserted into corresponding backing maps.
- PARTITION_RECEIVE_COMMIT - Static variable in class com.tangosol.net.partition.PartitionEvent
- 
This event indicates that a transfer for one or more partitions has completed and the data that belong to these partitions have been inserted into corresponding backing maps.
- PARTITION_RECOVERED - Static variable in class com.tangosol.net.partition.PartitionEvent
- 
This event indicates that one or more partitions have been recovered by a service member.
- PARTITION_TRANSMIT_BEGIN - Static variable in class com.tangosol.net.partition.PartitionEvent
- 
This event indicates that data that belong to one or more partitions are about to be transferred to a different member.
- PARTITION_TRANSMIT_COMMIT - Static variable in class com.tangosol.net.partition.PartitionEvent
- 
This event indicates that data that belong to one or more partitions have been successfully transferred to a different member and all the data for that partition have been removed from this node.
- PARTITION_TRANSMIT_ROLLBACK - Static variable in class com.tangosol.net.partition.PartitionEvent
- 
This event indicates that a transfer for one or more partitions has been aborted (e.g. receiver's failure), and the partitions are now "owned" by this node again, and are about to be unfrozen.
- PartitionAssignmentStrategy - Interface in com.tangosol.net.partition
- 
A PartitionAssignmentStrategy is a pluggable strategy used by a PartitionedService to manage partition distribution.
- PartitionAssignmentStrategyBuilder - Class in com.tangosol.coherence.config.builder
- PartitionAssignmentStrategyBuilder(ParameterizedBuilder<?>, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.PartitionAssignmentStrategyBuilder
- 
ConstructsPartitionAssignmentStrategyBuilder
- PartitionAssignmentStrategyBuilder(String, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.PartitionAssignmentStrategyBuilder
- 
Constructs aPartitionAssignmentStrategyBuilderfor a predefined strategy.
- PartitionAssignmentStrategyProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
An ElementProcessor to process a <partition-assignment-strategy> to produce a PartitionAssignmentStrategy.
- PartitionAssignmentStrategyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PartitionAssignmentStrategyProcessor
- PartitionAwareBackingMap - Interface in com.tangosol.net.partition
- 
In a partitioned configuration, backing maps that implement the PartitionAwareBackingMap interface are able to react to the partition life-cycle (a partition showing up on a node, or moving away from a node) and manage data more efficiently as a result.
- PARTITIONED_CACHE_STATISTICS_REFRESHTIME_SYSTEM_PROPERTY - Static variable in class com.tangosol.coherence.jcache.Constants
- 
Override default refreshtime duration for partitioned cache to aggregate cache statistics over the cluster.
- PartitionedBackingMapManager(DefaultConfigurableCacheFactory.CacheInfo, XmlElement, BackingMapManagerContext, ClassLoader) - Constructor for class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.
- PartitionedBackingMapManager(ExtensibleConfigurableCacheFactory, MapBuilder.Dependencies, ParameterResolver, MapBuilder) - Constructor for class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
- 
Create a PartitionedBackingMapManager object.
- PartitionedCache<K,V> - Class in com.tangosol.coherence.jcache.partitionedcache
- 
JCache of Key, Value pairs implemented over distributed cache.
- PartitionedCache(CoherenceBasedCacheManager, String, PartitionedCacheConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Constructs aPartitionedCacheconfigured byPartitionedCacheConfigurationin context ofCoherenceBasedCacheManagerwith JCache namesJCacheName.
- PartitionedCache.EntryIterator<K,V> - Class in com.tangosol.coherence.jcache.partitionedcache
- 
JCache Entry iterator
- PartitionedCacheAsynchronousMapListener<K,V> - Class in com.tangosol.coherence.jcache.partitionedcache
- 
MapListener for coherence cache to implement jcache map events.
- PartitionedCacheAsynchronousMapListener.NonSyntheticEntryFilter - Class in com.tangosol.coherence.jcache.partitionedcache
- 
NonSyntheticEntryFilter
- PartitionedCacheBinaryEntryStore<K,V> - Class in com.tangosol.coherence.jcache.partitionedcache
- 
Generic Coherence BinaryEntryStore for Coherence JCache Adapter.
- PartitionedCacheBinaryEntryStore(String, BackingMapManagerContext, ClassLoader) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
- 
Construct a native Coherence CacheStore which implements JCache read-through and write-through semantics.
- PartitionedCacheConfiguration<K,V> - Class in com.tangosol.coherence.jcache.partitionedcache
- 
AConfigurationfor aCachebased on a Coherence <distributed-scheme> or more specifically a partitioned (aka: distributed)NamedCache.
- PartitionedCacheConfiguration() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfiguration
- 
Constructs a defaultPartitionedCacheConfiguration.
- PartitionedCacheConfiguration(CompleteConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfiguration
- 
Constructs aPartitionedCacheConfigurationbased on aCompleteConfiguration.
- PartitionedCacheConfigurationMapListener - Class in com.tangosol.coherence.jcache.partitionedcache
- 
MapListener for meta-information about JCachePartitionedCacheinstances.
- PartitionedCacheConfigurationMapListener() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfigurationMapListener
- PartitionedCacheDispatcher - Interface in com.tangosol.net.events.partition.cache
- 
A PartitionedCacheDispatcher raises the following server-sideEvents pertaining to backing-map operations:CacheLifecycleEventsEntryEventsEntryProcessorEvents
- PartitionedCacheQuorumPolicy(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[], AddressProvider) - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Construct a PartitionedCacheQuorumPolicy with the specified rule.
- PartitionedCacheQuorumPolicyBuilder - Class in com.tangosol.coherence.config.builder
- 
Defer cache configuration validation of an ActionPolicy until realized.
- PartitionedCacheQuorumPolicyBuilder(AddressProviderBuilder, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.PartitionedCacheQuorumPolicyBuilder
- 
ConstructsPartitionedCacheQuorumPolicyBuilderfrom configuration file context and xml element
- PartitionedCacheStatisticsAggregator() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- PartitionedCacheStatisticsAggregator(JCacheIdentifier, ValueExtractor) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- 
Constructs an aggregator to aggregate JCache Cache Statistics from all storage-enabled servers for a JCache implemented as a Partitioned Cache.
- PartitionedCacheStatisticsClear() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- PartitionedCacheStatisticsClear(JCacheIdentifier, ValueExtractor) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- 
Constructs an aggregator to aggregate JCache Cache Statistics from all storage-enabled servers for a JCache implemented as a Partitioned Cache.
- PartitionedCacheSynchronousMapListener<K,V> - Class in com.tangosol.coherence.jcache.partitionedcache
- 
Synchronous version of PartitionedCacheAsynchronousMapListener.
- PartitionedCacheSyntheticDeleteMapListener<K,V> - Class in com.tangosol.coherence.jcache.partitionedcache
- 
MapListener for coherence cache to generate JCache ExpiryEvents.
- PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter<T> - Class in com.tangosol.coherence.jcache.partitionedcache
- 
Server side filter for JCache ExpiryCacheEvents.
- PartitionedFilter<T> - Class in com.tangosol.util.filter
- 
Filter which limits the scope of another filter to those entries that have keys that belong to the specified partition set.
- PartitionedFilter() - Constructor for class com.tangosol.util.filter.PartitionedFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- PartitionedFilter(Filter<T>, PartitionSet) - Constructor for class com.tangosol.util.filter.PartitionedFilter
- 
Construct a PartitionedFilter.
- PartitionedIterator<T> - Class in com.tangosol.net.partition
- 
An Iterator that iterates over keys in a partition-by-partition or member-by-member manner.
- PartitionedIterator(NamedCache, Filter, PartitionSet, int) - Constructor for class com.tangosol.net.partition.PartitionedIterator
- 
Construct PartitionedIterator that will provide iteration of the keys of the specified cache using the specified filter, but will only query one partition or one member at a time.
- PartitionedIterator(Map[]) - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap.PartitionedIterator
- 
Construct PartitionedIterator based on the specified array of maps, where each map contains data for one and only one partition.
- PartitionedJCacheStatistics - Class in com.tangosol.coherence.jcache.partitionedcache
- 
compute cache statistics across all storage-enabled data members.
- PartitionedJCacheStatistics() - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- 
ConstructsPartitionedJCacheStatistics
- PartitionedJCacheStatistics(PartitionedCache) - Constructor for class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- 
Construct aPartitionedJCacheStatisticsfor a distributed cache.
- PartitionedJCacheStatistics.CacheStatisticsExtractor - Class in com.tangosol.coherence.jcache.partitionedcache
- 
Get CacheStatistics from binEntry's context for JCache id.
- PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator - Class in com.tangosol.coherence.jcache.partitionedcache
- 
Collect JCache CacheStatistics from all storage-enabled members.
- PartitionedJCacheStatistics.PartitionedCacheStatisticsClear - Class in com.tangosol.coherence.jcache.partitionedcache
- 
Clear JCache CacheStatistics from all storage-enabled members.
- partitionedPutAll(CacheRequestHolder<PutAllRequest, Void>, Map<Binary, Binary>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Perform aputAlloperation on a partitioned cache.
- PartitionedQuorumPolicyProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
An ElementProcessor that will parse a <partitioned-quorum-policy-scheme> and produce a suitableActionPolicy
- PartitionedQuorumPolicyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PartitionedQuorumPolicyProcessor
- PartitionedService - Interface in com.tangosol.net
- 
A PartitionedService is aware of a mapping of keys to partitions and of partitions to cluster members.
- PartitionedService.PartitionedAction - Interface in com.tangosol.net
- 
PartitionedAction represents a type of action taken by a PartitionedService.
- PartitionedService.PartitionRecoveryAction - Class in com.tangosol.net
- 
A PartitionedAction representing the recovery of orphaned partitions from the persistent storage, or the assignment of empty partitions if the persistent storage is unavailable or lost.
- PartitionedServiceDispatcher - Interface in com.tangosol.net.events.partition
- 
A PartitionedServiceDispatcher dispatchesEvents from aPartitionedService.
- PartitionEvent - Class in com.tangosol.net.partition
- 
The PartitionEvent carries information about an event related to one or more partitions.
- PartitionEvent(PartitionedService, int, PartitionSet, Member, Member) - Constructor for class com.tangosol.net.partition.PartitionEvent
- 
Construct a partition event.
- PartitionListener - Interface in com.tangosol.net.partition
- 
The listener interface for receiving PartitionEvents.
- PartitionListenerProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
An ElementProcessor to process a <partition-listener> to produce a List containing a single PartitionListener.
- PartitionListenerProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PartitionListenerProcessor
- 
Constructs aPartitionListenerProcessor.
- PartitionRecoveryAction(PartitionSet, GUIDHelper.GUIDResolver, QuorumInfo) - Constructor for class com.tangosol.net.PartitionedService.PartitionRecoveryAction
- 
Construct a PartitionRecoveryAction for the specified partitions, GUID resolver and the "last good" membership info.
- PartitionSet - Class in com.tangosol.net.partition
- 
PartitionSet is a light-weight data structure that represents a set of partitions that are used in parallel processing.
- PartitionSet() - Constructor for class com.tangosol.net.partition.PartitionSet
- 
Default constructor (necessary for the ExternalizableLite interface).
- PartitionSet(int) - Constructor for class com.tangosol.net.partition.PartitionSet
- 
Construct an empty partition set with a given count.
- PartitionSet(int, int...) - Constructor for class com.tangosol.net.partition.PartitionSet
- 
Construct a partition set with a given partition count and the specified partitions set.
- PartitionSet(int, Collection<? extends Integer>) - Constructor for class com.tangosol.net.partition.PartitionSet
- 
Construct a partition set with a given partition count and the specified partitions set.
- PartitionSet(PartitionSet) - Constructor for class com.tangosol.net.partition.PartitionSet
- 
Copy constructor: construct a new PartitionSet object equivalent to the specified one.
- PartitionSplittingBackingMap - Class in com.tangosol.net.partition
- 
In a partitioned configuration, the PartitionSplittingBackingMap is a "map multi-plexer" that enables multiple backing maps to be used in place of a single backing map.
- PartitionSplittingBackingMap(BackingMapManager, String) - Constructor for class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Create a PartitionSplittingBackingMap that will delegate each partition's data and operations to a separate backing map.
- PartitionSplittingBackingMap.AggregatingCacheStatistics - Class in com.tangosol.net.partition
- 
An implementation of the CacheStatics interface that aggregates across the CacheStatics objects provided by each of the backing maps corresponding to the partitions managed by this PartitionSplittingBackingMap.
- PartitionSplittingBackingMap.KeySet - Class in com.tangosol.net.partition
- 
A KeySet implementation optimized for PartitionSplittingBackingMap.
- PartitionSplittingBackingMap.MapArray - Class in com.tangosol.net.partition
- 
The MapArray is a data structure that provides a mapping between partition IDs and backing maps.
- PartitionSplittingBackingMap.MaskedPartitionMap - Class in com.tangosol.net.partition
- 
A read-only view into a subset of backing maps managed by the underlying PartitionSplittingBackingMap.
- PartitionSplittingBackingMap.PartitionedIterator - Class in com.tangosol.net.partition
- 
An Iterator designed to ensure that a stable copy of each partition's keys is available for the duration of the iteration over its keys.
- PartitionStatistics - Class in com.tangosol.net.partition
- 
PartitionStatistics encapsulates the statistics gathered for a given partition in a PartitionedService.
- PartitionStatistics() - Constructor for class com.tangosol.net.partition.PartitionStatistics
- 
Default constructor.
- PartitionStatistics(int, long) - Constructor for class com.tangosol.net.partition.PartitionStatistics
- 
Constructor for the specified partition.
- PassThroughCache<K,V> - Class in com.tangosol.coherence.jcache.passthroughcache
- 
ACachethat delegates (ie: passed-through) requests directly onto an existing CoherenceNamedCache.
- PassThroughCache(CoherenceBasedCacheManager, String, PassThroughCacheConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- 
Constructs aPassThroughCache
- PassThroughCacheConfiguration<K,V> - Class in com.tangosol.coherence.jcache.passthroughcache
- PassThroughCacheConfiguration() - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- 
Constructs aPassThroughCacheConfigurationthat defaults to using theCachename as the underlyingNamedCachename with Object-based key and value types.
- PassThroughCacheConfiguration(PassThroughCacheConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- 
Constructs aPassThroughCacheConfigurationbased on a providedPassThroughCacheConfiguration.
- PassThroughCacheConfiguration(CompleteConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- 
Constructs a PassThroughConfiguration based on a JCacheCompleteConfiguration.
- PassThroughCacheEntryEvent<K,V> - Class in com.tangosol.coherence.jcache.passthroughcache
- 
An implementation of aCacheEntryEventbased on an underlying CoherenceMapEvent.
- PassThroughCacheEntryEvent(Cache<K, V>, EventType, MapEvent) - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
- 
Constructs aPassThroughCacheEntryEvent.
- PassThroughFilterAdapter<K,V> - Class in com.tangosol.coherence.jcache.passthroughcache
- PassThroughFilterAdapter() - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
- 
Constructs aPassThroughFilterAdapter.
- PassThroughFilterAdapter(Factory<CacheEntryEventFilter<? super K, ? super V>>) - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
- 
Constructs aPassThroughFilterAdapter.
- PassThroughListenerRegistration<K,V> - Class in com.tangosol.coherence.jcache.passthroughcache
- 
Captures the Coherence-basedMapListenerandMapEventFilterinstances used for aCacheEntryListenerConfiguration
- PassThroughListenerRegistration(CacheEntryListenerConfiguration<K, V>, MapListener, MapEventFilter) - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughListenerRegistration
- 
Constructs aPassThroughListenerRegistration.
- PassThroughMapListenerAdapter<K,V> - Class in com.tangosol.coherence.jcache.passthroughcache
- PassThroughMapListenerAdapter(Cache<K, V>, CacheEntryListener<? super K, ? super V>) - Constructor for class com.tangosol.coherence.jcache.passthroughcache.PassThroughMapListenerAdapter
- 
Constructs aPassThroughMapListenerAdapter.
- PassThroughResourceConfig - Class in com.tangosol.coherence.rest.server
- 
An alternateResourceConfigimplementation that supports pass-through access to all the caches defined by the cache configuration.
- PassThroughResourceConfig() - Constructor for class com.tangosol.coherence.rest.server.PassThroughResourceConfig
- PassThroughRootResource - Class in com.tangosol.coherence.rest
- 
An alternateResourceConfigimplementation that supports pass-through access to all the caches defined by the cache configuration.
- PassThroughRootResource() - Constructor for class com.tangosol.coherence.rest.PassThroughRootResource
- PasswordProvider - Interface in com.tangosol.net
- 
PasswordProvider allows Coherence users to plug in their own mechanism to determine the appropriate password.
- PasswordProviderBuilderProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor <password-provider> elements defined by a Coherence Operational Configuration file.
- PasswordProviderBuilderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PasswordProviderBuilderProcessor
- 
Constructs aPasswordProviderBuilderProcessor.
- PasswordProviderBuilderProcessor.DefaultPasswordProvider - Class in com.tangosol.coherence.config.xml.processor
- 
This class is to wrap the existing password into the password-provider approach.
- PasswordProvidersProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
APasswordProvidersProcessoris responsible for processing <password-providers>XmlElementof Coherence Operational Configuration files
- PasswordProvidersProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PasswordProvidersProcessor
- PasswordURLProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
ThePasswordURLProcessoris responsible for processing the <password-url>XmlElementin a Coherence configuration file.
- PasswordURLProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PasswordURLProcessor
- path() - Method in class com.oracle.coherence.cdi.PofExtractor.Literal
- 
Returns a property path to use to extract the value.
- path() - Method in annotation type com.oracle.coherence.cdi.PofExtractor
- 
Returns a property path to use to extract the value.
- PATH_HEALTHZ - Static variable in interface com.tangosol.util.HealthCheck
- 
The http request path for the healthz endpoint.
- PATH_LIVE - Static variable in interface com.tangosol.util.HealthCheck
- 
The http request path for the live endpoint.
- PATH_READY - Static variable in interface com.tangosol.util.HealthCheck
- 
The http request path for the ready endpoint.
- PATH_SAFE - Static variable in interface com.tangosol.util.HealthCheck
- 
The http request path for the safe endpoint.
- PATH_STARTED - Static variable in interface com.tangosol.util.HealthCheck
- 
The http request path for the started endpoint.
- PathOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
PathOPToken is used to implement dereferencing paths where you have a sequence of identifiers or function calls seperated by a path separator.
- PathOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.PathOPToken
- 
Construct a new PathOPToken with the given parameters.
- PathOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.PathOPToken
- 
Construct a new PathOPToken with the given parameters.
- peek() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
- 
Answer the next token in the stream or null if at end.
- peek() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Wait for a key to be added to the queue and return it without removing it from the queue.
- peek() - Method in class com.tangosol.util.SimpleStack
- 
Return the object that is currently on top of the stack.
- peek(int) - Method in class com.tangosol.run.xml.SimpleParser
- 
Tests if the current token matches the passed token id and, if so, advances to the next token.
- peek(int, int) - Method in class com.tangosol.run.xml.SimpleParser
- 
Tests if the current token matches the passed token category and sub-category.
- peek(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Wait for a key (up to the specified wait time) to be added to the queue and return it without removing it from the queue, or null if the specified wait time has passed).
- peek(Remote.Consumer<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as elements are consumed from the resulting stream.
- peek(Remote.DoubleConsumer) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as elements are consumed from the resulting stream.
- peek(Remote.IntConsumer) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as elements are consumed from the resulting stream.
- peek(Remote.LongConsumer) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as elements are consumed from the resulting stream.
- peek(Object) - Method in class com.tangosol.net.cache.LocalCache
- 
Checks for a valid entry corresponding to the specified key in the cache, and returns the corresponding value if it is.
- peek(String) - Method in class com.tangosol.run.xml.SimpleParser
- 
Tests if the current token is a name that matches the passed String and, if so, advances to the next token.
- peek(InetAddress) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- peek(Consumer<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as elements are consumed from the resulting stream.
- peek(DoubleConsumer) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as elements are consumed from the resulting stream.
- peek(IntConsumer) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as elements are consumed from the resulting stream.
- peek(LongConsumer) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as elements are consumed from the resulting stream.
- peek2() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
- 
Answer the next two tokens in the stream or null(s) if at end.
- peekAll(Collection) - Method in class com.tangosol.net.cache.LocalCache
- 
Checks for a valid entry corresponding to each specified key in the cache, and places the corresponding value in the returned map if it is.
- peekData(DatagramPacket) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- peekNext() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Answer the string representation of the next BaseToken.
- peekNext2AsStrings() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Answer the String[] representation of the next two BaseTokens.
- peekNextAsString() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Answer the string representation of the next BaseToken.
- PeekOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
A PeekOPToken is a token that contains otherOPTokeninstances.
- PeekOPToken(String, int, OPToken...) - Constructor for class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
Construct a new PeekOPToken with the given parameters.
- PeekOPToken(String, int, String, OPToken...) - Constructor for class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
Construct a new PeekOPToken with the given parameters.
- PeekOPToken(String, int, String, String, OPToken...) - Constructor for class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
Construct a new PeekOPToken with the given parameters.
- PeekOPToken(String, OPToken...) - Constructor for class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
Construct a new PeekOPToken with the given parameters.
- PeekOPToken(String, String, OPToken...) - Constructor for class com.tangosol.coherence.dsltools.precedence.PeekOPToken
- 
Construct a new PeekOPToken with the given parameters.
- PeriodicTask(Runnable, long) - Constructor for class com.tangosol.util.TaskDaemon.PeriodicTask
- 
Construct a task that will automatically be run on a periodic basis.
- PermissionInfo - Class in com.tangosol.net.security
- 
PermissionInfo holds the information needed to validate and respond to a security related request.
- PermissionInfo() - Constructor for class com.tangosol.net.security.PermissionInfo
- 
Default constructor (required by PortableObject).
- PermissionInfo(ClusterPermission, String, SignedObject, Subject) - Constructor for class com.tangosol.net.security.PermissionInfo
- 
Construct a PermissionInfo.
- PermitAcquirer - Class in com.oracle.coherence.concurrent
- 
The identity of a acquirer, represented by the UUID of the member, and the ID of a thread holding or attempting to acquire permit.
- PermitAcquirer() - Constructor for class com.oracle.coherence.concurrent.PermitAcquirer
- 
Default constructor (necessary for the ExternalizableLite interface).
- PermitAcquirer(Member, long) - Constructor for class com.oracle.coherence.concurrent.PermitAcquirer
- 
ConstructPermitAcquirerinstance.
- Permits - Annotation Type in com.oracle.coherence.concurrent.cdi
- 
A qualifier annotation used when injecting Coherence resource to specify the permits count.
- Permits.Literal - Class in com.oracle.coherence.concurrent.cdi
- 
An annotation literal for thePermitsannotation.
- PERSISTENCE_COORDINATOR - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
String representation of the responsibility of PersistenceCoordinator.
- PERSISTENCE_SNAPSHOT_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the PersistenceManagerMBean.
- PERSISTENCE_VERSION - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Persistence protocol version.
- PersistenceEnvironmentInfo - Interface in com.tangosol.persistence
- 
Interface that exposes management attributes for a PersistenceEnvironment.
- PersistenceEnvironmentInfo(String, File, File, File, File, File) - Constructor for class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- PersistenceEnvironmentParamBuilder - Class in com.tangosol.coherence.config.builder
- 
Build aPersistenceEnvironment.
- PersistenceEnvironmentParamBuilder() - Constructor for class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Construct aPersistenceEnvironmentbuilder.
- PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo - Class in com.tangosol.coherence.config.builder
- 
APersistenceEnvironmentInfoimplementation that exposes the active, snapshot and trash directories, in addition to the persistence mode.
- PersistenceEnvironmentProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PersistenceEnvironmentsProcessor.PersistenceEnvironmentProcessor
- PersistenceEnvironmentsProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor the <persistence-environments%gt; element of Coherence Operational Configuration files.
- PersistenceEnvironmentsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PersistenceEnvironmentsProcessor
- PersistenceEnvironmentsProcessor.PersistenceEnvironmentProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor children elements of <persistence-environments%gt; element of Coherence Operational Configuration files.
- PersistenceManagerMBean - Interface in com.tangosol.persistence
- 
Standard MBean interface that exposes management attributes and operations relating to a PartitionedService configured with on-demand or active persistence.
- PersistenceProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse a <persistence> element to produce aPersistenceDependenciesinstance.
- PersistenceProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.PersistenceProcessor
- 
Constructs aPersistenceProcessor.
- Ping - Class in com.tangosol.net
- 
Ping is a simple utility for testing if a machine is reachable.
- Ping() - Constructor for class com.tangosol.net.Ping
- pipeline() - Method in interface com.tangosol.util.stream.BaseRemoteStream
- 
Return a pipeline of intermediate operations for this stream.
- plainPutAll(AsyncNamedCache<Binary, Binary>, Map<Binary, Binary>, long) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Perform aputAlloperation on a partitioned cache.
- PLAN_ALL_LISTENER - Static variable in class com.tangosol.util.MapListenerSupport
- 
There is one all-keys non-filtered listener.
- PLAN_KEY_LISTENER - Static variable in class com.tangosol.util.MapListenerSupport
- 
There is one key listener (even if for multiple keys).
- PLAN_NO_LISTENERS - Static variable in class com.tangosol.util.MapListenerSupport
- 
There are no listeners.
- PLAN_NO_OPTIMIZE - Static variable in class com.tangosol.util.MapListenerSupport
- 
There is no optimized plan, so just use the default approach.
- PLAN_NONE - Static variable in class com.tangosol.util.MapListenerSupport
- 
A plan has not yet been formed.
- PofAnnotationSerializer<T> - Class in com.tangosol.io.pof
- 
APofAnnotationSerializerprovides annotation based de/serialization.
- PofAnnotationSerializer(int, Class<T>) - Constructor for class com.tangosol.io.pof.PofAnnotationSerializer
- 
Constructs a PofAnnotationSerializer.
- PofAnnotationSerializer(int, Class<T>, boolean) - Constructor for class com.tangosol.io.pof.PofAnnotationSerializer
- 
Constructs a PofAnnotationSerializer.
- PofArray - Class in com.tangosol.io.pof.reflect
- 
PofArray is aPofValueimplementation for arrays.
- PofArray(PofValue, ReadBuffer, PofContext, int, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.PofArray
- 
Construct a PofArray instance wrapping the supplied buffer.
- PofBufferReader - Class in com.tangosol.io.pof
- 
PofReaderimplementation that reads POF-encoded data from aBufferInput.
- PofBufferReader() - Constructor for class com.tangosol.io.pof.PofBufferReader
- PofBufferReader(ReadBuffer.BufferInput, PofContext) - Constructor for class com.tangosol.io.pof.PofBufferReader
- 
Construct a new PofBufferReader that will read a POF stream from the passed BufferInput object.
- PofBufferReader.IdentityHolder - Class in com.tangosol.io.pof
- PofBufferReader.UserTypeReader - Class in com.tangosol.io.pof
- 
The UserTypeReader implementation is a contextually-aware PofReader whose purpose is to advance through the properties of a value of a specified user type.
- PofBufferWriter - Class in com.tangosol.io.pof
- 
PofWriterimplementation that writes POF-encoded data to aBufferOutput.
- PofBufferWriter(WritingPofHandler, PofContext) - Constructor for class com.tangosol.io.pof.PofBufferWriter
- 
Construct a new PofBufferWriter that will write a POF stream using the passed WritingPofHandler.
- PofBufferWriter(WriteBuffer.BufferOutput, PofContext) - Constructor for class com.tangosol.io.pof.PofBufferWriter
- 
Construct a new PofBufferWriter that will write a POF stream to the passed BufferOutput object.
- PofBufferWriter.ReferenceLibrary - Class in com.tangosol.io.pof
- 
A "library" of object references and their corresponding identities in the POF stream.
- PofBufferWriter.UserTypeWriter - Class in com.tangosol.io.pof
- 
The UserTypeWriter implementation is a contextually-aware PofWriter whose purpose is to write the properties of a value of a specified user type.
- PofCollection - Class in com.tangosol.io.pof.reflect
- 
PofCollection isPofValueimplementation for collections.
- PofCollection(PofValue, ReadBuffer, PofContext, int, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.PofCollection
- 
Construct a PofCollection instance wrapping the supplied buffer.
- PofConfig() - Constructor for class com.tangosol.io.pof.ConfigurablePofContext.PofConfig
- PofConfigProvider - Interface in com.tangosol.io.pof
- 
A provider of POF configuration URIs to load into aConfigurablePofContext.
- PofConstants - Interface in com.tangosol.io.pof
- 
The constants related to POF streams.
- PofContext - Interface in com.tangosol.io.pof
- 
The PofContext interface represents a set of user types that can be serialized to and deserialized from a POF stream.
- PofDeltaCompressor - Class in com.tangosol.io.pof
- 
A DeltaCompressor implementation that works with Portable Object Format (POF) values.
- PofDeltaCompressor() - Constructor for class com.tangosol.io.pof.PofDeltaCompressor
- 
Default constructor.
- PofDeltaCompressor.ChangeTracker - Class in com.tangosol.io.pof
- 
When determining a delta between two POF buffers, the ChangeTracker keeps track of whether the current location within the two POF streams is part of a differing portion or part of an identical portion.
- PofExtractor<T,E> - Class in com.tangosol.util.extractor
- 
POF-based ValueExtractor implementation.
- PofExtractor - Annotation Type in com.oracle.coherence.cdi
- 
AExtractorBindingannotation representing aPofExtractor.
- PofExtractor() - Constructor for class com.tangosol.util.extractor.PofExtractor
- 
Default constructor (necessary for the PortableObject interface).
- PofExtractor(Class<E>, int) - Constructor for class com.tangosol.util.extractor.PofExtractor
- 
Constructs a PofExtractor based on a property index.
- PofExtractor(Class<E>, int, String) - Constructor for class com.tangosol.util.extractor.PofExtractor
- 
Constructs a PofExtractor based on a property index while providing the property's canonical name.
- PofExtractor(Class<E>, PofNavigator) - Constructor for class com.tangosol.util.extractor.PofExtractor
- 
Constructs a PofExtractor based on a POF navigator.
- PofExtractor(Class<E>, PofNavigator, int) - Constructor for class com.tangosol.util.extractor.PofExtractor
- 
Constructs a PofExtractor based on a POF navigator and the entry extraction target.
- PofExtractor(Class<E>, PofNavigator, int, String) - Constructor for class com.tangosol.util.extractor.PofExtractor
- 
Constructs a PofExtractor based on a POF navigator while providing its canonical name.
- PofExtractor(Class<E>, PofNavigator, String) - Constructor for class com.tangosol.util.extractor.PofExtractor
- 
Constructs a VALUE PofExtractor based on a POF navigator while providing its canonical name.
- PofExtractor.Extractors - Annotation Type in com.oracle.coherence.cdi
- 
A holder for the repeatablePofExtractorannotation.
- PofExtractor.Extractors.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for thePofExtractor.Extractorsannotation.
- PofExtractor.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for thePofExtractorannotation.
- PofExtractorsSupplier() - Constructor for class com.oracle.coherence.cdi.ExtractorProducer.PofExtractorsSupplier
- PofExtractorSupplier() - Constructor for class com.oracle.coherence.cdi.ExtractorProducer.PofExtractorSupplier
- PofHandler - Interface in com.tangosol.io.pof
- 
This interface defines the handler for an event-driven approach to parsing (or assembling) a POF stream.
- PofHelper - Class in com.tangosol.io.pof
- 
Collection of helper methods for POF streams.
- PofHelper() - Constructor for class com.tangosol.io.pof.PofHelper
- PofHelper.ReadableEntrySetMap - Class in com.tangosol.io.pof
- 
Map implementation backed by a List of Map.Entry objects.
- PofHelper.WriteableEntrySetMap - Class in com.tangosol.io.pof
- 
Immutable Map implementation backed by a Set of Map.Entry objects.
- PofInputStream - Class in com.tangosol.io.pof
- 
An ObjectInput implementation suitable for reading Externalizable and ExternalizableLite objects from a POF stream, although without support for schema evolution and other advanced POF features.
- PofInputStream(PofReader) - Constructor for class com.tangosol.io.pof.PofInputStream
- 
Construct a PofInputStream that will read its information from an underlyingPofReader.
- PofNavigationException - Exception in com.tangosol.io.pof.reflect
- 
PofNavigationException indicates a failure to navigate aPofValuehierarchy.
- PofNavigationException() - Constructor for exception com.tangosol.io.pof.reflect.PofNavigationException
- 
Construct a PofNavigationException.
- PofNavigationException(String) - Constructor for exception com.tangosol.io.pof.reflect.PofNavigationException
- 
Construct a PofNavigationException with a specified detail message.
- PofNavigationException(String, Throwable) - Constructor for exception com.tangosol.io.pof.reflect.PofNavigationException
- 
Construct a PofNavigationException with a specified detail message and a cause.
- PofNavigationException(Throwable) - Constructor for exception com.tangosol.io.pof.reflect.PofNavigationException
- 
Construct a PofNavigationException with a specified cause.
- PofNavigator - Interface in com.tangosol.io.pof.reflect
- 
The PofNavigator interface represents an algorithm for navigating a PofValue hierarchy in order to locate a contained PofValue for extraction, modification or removal purposes.
- PofOutputStream - Class in com.tangosol.io.pof
- 
An ObjectOutput implementation suitable for writing Externalizable and ExternalizableLite objects to a POF stream, although without support for schema evolution and other advanced POF features.
- PofOutputStream(PofWriter) - Constructor for class com.tangosol.io.pof.PofOutputStream
- 
Construct a PofOutputStream that will write its information to an underlyingPofWriter.
- PofParser - Class in com.tangosol.io.pof
- 
A "push" parser (event-based parser) for ripping through a POF stream and delivering the contents as events to a PofHandler object.
- PofParser(PofHandler) - Constructor for class com.tangosol.io.pof.PofParser
- 
Construct a POF parser that will push events to the specified handler.
- PofPrincipal - Class in com.tangosol.io.pof
- 
Generic Principal implementation that can be used to represent the identity of any remote entity.
- PofPrincipal(String) - Constructor for class com.tangosol.io.pof.PofPrincipal
- 
Create a new PortablePrincipal with the given name.
- PofReader - Interface in com.tangosol.io.pof
- 
The PofReader interface provides the capability of reading a set of non-primitive Java types ("user types") from a POF stream as an ordered sequence of indexed properties.
- PofReflectionHelper - Class in com.tangosol.io.pof.reflect
- 
Collection of helper methods for POF reflection.
- PofReflectionHelper() - Constructor for class com.tangosol.io.pof.reflect.PofReflectionHelper
- PofReflectionHelper.NavigatorAndType - Class in com.tangosol.io.pof.reflect
- PofSerializer<T> - Interface in com.tangosol.io.pof
- 
The PofSerializer interface provides the capability of reading and writing a Java object from and to a POF stream.
- PofSerializerPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
APofSerializerPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat replaces any occurrence of <serializer>pof</serializer> with aConfigurablePofContextconfiguration, passing in the provided POF configuration URI in the initialization parameters.
- PofSerializerPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.PofSerializerPreprocessor
- PofSparseArray - Class in com.tangosol.io.pof.reflect
- 
PofSparseArray isPofValueimplementation for sparse arrays.
- PofSparseArray(PofValue, ReadBuffer, PofContext, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.PofSparseArray
- 
Construct a PofSparseArray instance wrapping the supplied buffer.
- PofSparseArray.NilPofValue - Class in com.tangosol.io.pof.reflect
- 
NilPofValue represents a value that does not exist in the original POF stream.
- PofUniformArray - Class in com.tangosol.io.pof.reflect
- 
PofUniformArray isPofValueimplementation for uniform arrays.
- PofUniformArray(PofValue, ReadBuffer, PofContext, int, int, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.PofUniformArray
- 
Construct a PofUniformArray instance wrapping the supplied buffer.
- PofUniformCollection - Class in com.tangosol.io.pof.reflect
- 
PofUniformCollection isPofValueimplementation for uniform collections.
- PofUniformCollection(PofValue, ReadBuffer, PofContext, int, int, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.PofUniformCollection
- 
Construct a PofUniformCollection instance wrapping the supplied buffer.
- PofUniformSparseArray - Class in com.tangosol.io.pof.reflect
- 
PofUniformSparseArray isPofValueimplementation for uniform sparse arrays.
- PofUniformSparseArray(PofValue, ReadBuffer, PofContext, int, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.PofUniformSparseArray
- 
Construct a PofUniformSparseArray instance wrapping the supplied buffer.
- PofUpdater - Class in com.tangosol.util.extractor
- 
POF-based ValueUpdater implementation.
- PofUpdater() - Constructor for class com.tangosol.util.extractor.PofUpdater
- 
Default constructor (necessary for the PortableObject interface).
- PofUpdater(int) - Constructor for class com.tangosol.util.extractor.PofUpdater
- 
Constructs a PofUpdater based on a property index.
- PofUpdater(PofNavigator) - Constructor for class com.tangosol.util.extractor.PofUpdater
- 
Constructs a PofUpdater based on a POF navigator.
- PofUserType - Class in com.tangosol.io.pof.reflect
- 
PofUserType isPofValueimplementation for user types.
- PofUserType(PofValue, ReadBuffer, PofContext, int, int, int, int) - Constructor for class com.tangosol.io.pof.reflect.PofUserType
- 
Construct a PofUserType instance wrapping the supplied buffer.
- PofValue - Interface in com.tangosol.io.pof.reflect
- 
PofValue represents the POF data structure in a POF stream, or any sub-structure or value thereof.
- PofValueParser - Class in com.tangosol.io.pof.reflect
- 
Parses POF-encoded binary and returns an instance of aPofValuewrapper for it.
- PofValueParser() - Constructor for class com.tangosol.io.pof.reflect.PofValueParser
- PofWriter - Interface in com.tangosol.io.pof
- 
The PofWriter interface provides the capability of writing a set of non-primitive Java types ("user types") to a POF stream as an ordered sequence of indexed properties.
- POINT_TO_POINT_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the PointToPointMBean.
- poll() - Method in interface com.oracle.coherence.common.base.Pollable
- 
Removes and returns the next element, or returns null if none is present.
- poll(long, TimeUnit) - Method in interface com.oracle.coherence.common.base.Pollable
- 
Removes and returns the next element, or returns null upon timeout.
- Pollable<E> - Interface in com.oracle.coherence.common.base
- 
The Pollable interface describes a component which supports element removal.
- pollFirst() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- pollFirstEntry() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- pollLast() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- pollLastEntry() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- pop() - Method in class com.tangosol.io.pof.ValidatingPofHandler.Complex
- 
Pop this Complex object off the stack, returning the outer Complex object or null if there is none.
- pop() - Method in class com.tangosol.io.pof.WritingPofHandler.Complex
- 
Pop this Complex object off the stack, returning the outer Complex object or null if there is none.
- pop() - Method in class com.tangosol.util.SimpleStack
- 
Remove and return the object that is currently on top of the stack.
- popCacheContext() - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Pop cache context from a thread-local storage.
- popStream() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Restore the remembered BaseTokenStream as the source of streaming.
- populateFilterArray(Filter[], Filter...) - Method in class com.tangosol.coherence.dslquery.operator.AndOperator
- 
Populate the specified targetFilterarray with the Filters in the source array.
- populateFilterArray(Filter[], Filter...) - Method in class com.tangosol.coherence.dslquery.operator.OrOperator
- 
Populate the specified targetFilterarray with the Filters in the source array.
- Portable - Annotation Type in com.tangosol.io.pof.annotation
- 
Deprecated.Since Coherence 14.1.2. UsePortableTypeannotation instead.
- PortableException - Exception in com.tangosol.io.pof
- 
APortableExceptionis an exception that allows information about a remote exception or error to be serialized and deserialized to/from aPOFstream.
- PortableException() - Constructor for exception com.tangosol.io.pof.PortableException
- 
Default constructor.
- PortableException(String) - Constructor for exception com.tangosol.io.pof.PortableException
- 
Constructs aPortableExceptionwith the specified detail message.
- PortableException(String, Throwable) - Constructor for exception com.tangosol.io.pof.PortableException
- 
Construct aPortableExceptionfrom aThrowableobject and an additional description.
- PortableException(Throwable) - Constructor for exception com.tangosol.io.pof.PortableException
- 
Construct aPortableExceptionfrom aThrowableobject.
- PortableObject - Interface in com.tangosol.io.pof
- 
The PortableObject interface is implemented by Java classes that can self- serialize and deserialize their state to and from a POF data stream.
- PortableObjectSerializer - Class in com.tangosol.io.pof
- 
PofSerializerimplementation that supports the serialization and deserialization of any class that implementsPortableObjectto and from a POF stream.
- PortableObjectSerializer(int) - Constructor for class com.tangosol.io.pof.PortableObjectSerializer
- 
Create a new PortableObjectSerializer for the user type with the given type identifier.
- PortableProperty - Annotation Type in com.tangosol.io.pof.annotation
- 
Deprecated.Since Coherence 14.1.2. UsePortableannotation instead.
- PortableTypeSerializer<T> - Class in com.tangosol.io.pof
- 
APofSerializerimplementation that serializes classes that implementPortableObjectinterface (and optionallyEvolvableObjectinterface).
- PortableTypeSerializer(int, Class<T>) - Constructor for class com.tangosol.io.pof.PortableTypeSerializer
- 
Create a new PortableTypeSerializer for the user type with the given type identifier and class.
- Position - Interface in com.tangosol.net.topic
- 
An opaque representation of the position of an element within a channel of a topic.
- postStart(Context) - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController.Listener
- postStop(Context) - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController.Listener
- potentialStreamClosedException(NullPointerException) - Method in class com.tangosol.io.nio.ByteBufferInputStream
- 
Check if an NPE is caused by the stream being closed.
- potentialStreamClosedException(NullPointerException) - Method in class com.tangosol.io.nio.ByteBufferOutputStream
- 
Check if an NPE is caused by the stream being closed.
- POWER_0 - Static variable in class com.oracle.coherence.common.base.Formatting
- 
Integer constant representing an exponent of zero.
- POWER_0 - Static variable in class com.tangosol.util.Base
- 
Integer constant representing an exponent of zero.
- POWER_G - Static variable in class com.oracle.coherence.common.base.Formatting
- 
Integer constant representing an exponent of 30.
- POWER_G - Static variable in class com.tangosol.util.Base
- 
Integer constant representing an exponent of 30.
- POWER_K - Static variable in class com.oracle.coherence.common.base.Formatting
- 
Integer constant representing an exponent of 10.
- POWER_K - Static variable in class com.tangosol.util.Base
- 
Integer constant representing an exponent of 10.
- POWER_M - Static variable in class com.oracle.coherence.common.base.Formatting
- 
Integer constant representing an exponent of 20.
- POWER_M - Static variable in class com.tangosol.util.Base
- 
Integer constant representing an exponent of 20.
- POWER_T - Static variable in class com.oracle.coherence.common.base.Formatting
- 
Integer constant representing an exponent of 40.
- POWER_T - Static variable in class com.tangosol.util.Base
- 
Integer constant representing an exponent of 40.
- PRECEDENCE_ASSIGNMENT - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for assignment operators assignment such as = += -= *= /= %= &= ^= |= <<= >>= >>>=
- PRECEDENCE_BITWISE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for bitwise operators such as >>> >> and <<
- PRECEDENCE_EXPONENT - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for exponent arithmetic, i.e. raising by a power
- PRECEDENCE_IDENTIFIER - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for identifier tokens
- PRECEDENCE_KEYWORD - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for keyword tokens
- PRECEDENCE_LOGICAL - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for logical tokens such as &&, ||, etc
- PRECEDENCE_LOGICAL_BITWISE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for bitwise logical tokens such as &, |, ^ etc
- PRECEDENCE_PARENTHESES - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for parentheses ( ) [ ]
- PRECEDENCE_PRODUCT - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for product arithmetic, multiplication, division, mod * / %
- PRECEDENCE_RELATIONAL - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for relational operators such as ==, <=, like, contains etc
- PRECEDENCE_SUM - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for sum arithmetic, i.e. + and -
- PRECEDENCE_UNARY - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for other unary operators: pre-increment, pre-decrement, plus, minus, logical negation, bitwise complement, type cast ++expr --expr +expr -expr !
- PRECEDENCE_UNARY_POST - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The binding precedence for unary post operators such as post-increment and post-decrement of the form expr++ or expr--
- predicate(Remote.Predicate<T>) - Static method in class com.tangosol.util.Filters
- 
Return a PredicateFilter for a givenPredicate.
- predicate(Remote.Predicate<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable Predicate.
- predicate(ValueExtractor<T, ? extends E>, Remote.Predicate<? super E>) - Static method in class com.tangosol.util.Filters
- 
Return a PredicateFilter for a givenPredicate.
- Predicate<T> - Interface in com.oracle.coherence.common.base
- 
Predicate represents a boolean test of an object.
- PredicateFilter<T,E> - Class in com.tangosol.util.filter
- 
Ajava.util.function.PredicatebasedExtractorFilter.
- PredicateFilter() - Constructor for class com.tangosol.util.filter.PredicateFilter
- 
Deserialization constructor.
- PredicateFilter(ValueExtractor<? super T, ? extends E>, Predicate<? super E>) - Constructor for class com.tangosol.util.filter.PredicateFilter
- 
Constructs aPredicateFilter.
- PredicateFilter(String, Predicate<? super E>) - Constructor for class com.tangosol.util.filter.PredicateFilter
- 
Constructs aPredicateFilter.
- PredicateFilter(Predicate<? super E>) - Constructor for class com.tangosol.util.filter.PredicateFilter
- 
Constructs aPredicateFilter.
- PrefixOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
PrefixOPToken is used to implement prefix operators.
- PrefixOPToken(String, int) - Constructor for class com.tangosol.coherence.dsltools.precedence.PrefixOPToken
- 
Construct a new PrefixOPToken with the given parameters.
- PrefixOPToken(String, int, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.PrefixOPToken
- 
Construct a new PrefixOPToken with the given parameters.
- preload() - Static method in class com.tangosol.util.Processors
- 
Construct the preload request processor.
- PreloadRequest<K,V> - Class in com.tangosol.util.processor
- 
PreloadRequest is a simple EntryProcessor that performs aEntry.getValuecall.
- PreloadRequest() - Constructor for class com.tangosol.util.processor.PreloadRequest
- 
Construct the PreloadRequest processor.
- prepare() - Method in interface com.tangosol.util.TransactionMap
- 
Prepare to commit changes made to the TransactionMap.
- prepareQuery(String, Map<String, Object>) - Method in class com.tangosol.coherence.rest.query.CoherenceQueryLanguageEngine
- 
Prepares a Query for execution by replacing any parameter placeholders with the appropriate values from the parameter map.
- prepareQuery(String, Map<String, Object>) - Method in interface com.tangosol.coherence.rest.query.QueryEngine
- 
Prepares a Query for execution by replacing any parameter placeholders with the appropriate values from the parameter map.
- prepareStatement(NodeTerm, ExecutionContext, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Realize an instance of theStatementthat will execute the CohQL statement represented by the AST node.
- prepareStatus(Object, OverflowMap.Status) - Method in class com.tangosol.net.cache.OverflowMap
- 
Validate the status and process any deferred events or pending expiry.
- prepareUpdate(Map, Map) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Prepare mapPart, a map representing a partition, for the impending changes in which all of the mappings from mapUpdate will be copied to mapPart.
- prepareUpdate(Map, Map) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Prepare mapPart, a map representing a partition, for the impending changes in which all of the mappings from mapUpdate will be copied to mapPart.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.CacheDefaultsPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.DefaultsCreationPreprocessor
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.ExtendPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.OperationalDefaultsPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.PofSerializerPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.SchemeRefPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.SystemPropertyPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.TCPAcceptorPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.TransactionalPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.preprocessor.ViewSchemePreprocessor
- preprocess(ProcessingContext, XmlElement) - Method in interface com.tangosol.config.xml.DocumentElementPreprocessor.ElementPreprocessor
- 
Process anXmlElement, optionally mutating it (or it's children) if required.
- preprocess(ProcessingContext, XmlElement) - Method in class com.tangosol.config.xml.DocumentElementPreprocessor
- 
Performs pre-processing of the anXmlElement, optionally mutating it (or it's children) as required.
- preprocess(ProcessingContext, XmlElement) - Method in interface com.tangosol.config.xml.DocumentPreprocessor
- 
Performs pre-processing of the anXmlElement, optionally mutating it (or it's children) as required.
- present() - Static method in class com.tangosol.util.Filters
- 
Return a filter that evaluates to true if an entry is present in the cache.
- PRESENT_ONLY - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A flag specifying that this aggregator is only interested in entries that are present in the cache and that the entries which are not present should never be passed to theInvocableMap.StreamingAggregator.accumulate(Entry)method.
- PresentFilter<T> - Class in com.tangosol.util.filter
- 
Filter which returns true forInvocableMap.Entryobjects that currently exist in a Map.
- PresentFilter() - Constructor for class com.tangosol.util.filter.PresentFilter
- 
Construct a PresentFilter.
- preStart(Context) - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController.Listener
- preStop(Context) - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController.Listener
- prev(int) - Method in class com.tangosol.util.Dequeue
- 
Determines the index preceding the passed index for storing or accessing an item from the m_ao storage.
- previous() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- previous() - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
- previous() - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Returns the previous element in the list.
- previous() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
- previousIndex() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- previousIndex() - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
- previousIndex() - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Returns the index of the element that would be returned by a subsequent call to previous.
- previousIndex() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
- previousPage() - Method in class com.tangosol.util.filter.LimitFilter
- 
Switch to the previous page.
- PRIMARY - Static variable in class com.tangosol.coherence.config.builder.ReadLocatorBuilder
- 
A BiFunction implementation that returns the primary member of the ownership chain.
- PRIME_MODULO - Static variable in class com.tangosol.util.SegmentedHashMap
- 
A list of possible modulos to use.
- primeDistribution(Member, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Set the context to pretend to be the "two servers" membership.
- primeDistribution(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Optimize the distribution with minimum backup fan-out by distributing the partitions among first two strong members.
- PRIMING - Static variable in class com.oracle.coherence.grpc.proxy.MapListenerProxy
- 
Constant to indicate that the listener is registered for "priming" events.
- PRIMING - Static variable in class com.tangosol.net.cache.CacheEvent
- 
Flag indicating whether or not the event is a priming event (NearCache).
- PRIMING - Static variable in interface com.tangosol.net.partition.VersionAwareMapListener
- 
A constant that suggests to an event source to send the current version and all future versions.
- PrimingListener() - Constructor for class com.tangosol.net.cache.CachingMap.PrimingListener
- PrimitiveArrayAdapter - Class in com.tangosol.run.xml
- 
A PrimitiveArrayAdapter supports arrays of primitive types, such as "int", "char", etc.
- PrimitiveArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Construct a PrimitiveArrayAdapter.
- PrimitiveArrayAdapter.BooleanArrayAdapter - Class in com.tangosol.run.xml
- 
A PropertyAdapter supporting boolean[].
- PrimitiveArrayAdapter.ByteArrayAdapter - Class in com.tangosol.run.xml
- 
A PropertyAdapter supporting byte[].
- PrimitiveArrayAdapter.CharArrayAdapter - Class in com.tangosol.run.xml
- 
A PropertyAdapter supporting char[].
- PrimitiveArrayAdapter.DoubleArrayAdapter - Class in com.tangosol.run.xml
- 
A PropertyAdapter supporting double[].
- PrimitiveArrayAdapter.FloatArrayAdapter - Class in com.tangosol.run.xml
- 
A PropertyAdapter supporting float[].
- PrimitiveArrayAdapter.IntArrayAdapter - Class in com.tangosol.run.xml
- 
A PropertyAdapter supporting int[].
- PrimitiveArrayAdapter.LongArrayAdapter - Class in com.tangosol.run.xml
- 
A PropertyAdapter supporting long[].
- PrimitiveArrayAdapter.ShortArrayAdapter - Class in com.tangosol.run.xml
- 
A PropertyAdapter supporting short[].
- PrimitiveNode(long, long) - Constructor for class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
- 
Construct a new Node mapping a long key to a long value.
- PrimitiveSparseArray - Class in com.tangosol.util
- 
A data structure resembling a long array indexed by long values.
- PrimitiveSparseArray() - Constructor for class com.tangosol.util.PrimitiveSparseArray
- 
Default constructor.
- PrimitiveSparseArray(PrimitiveSparseArray) - Constructor for class com.tangosol.util.PrimitiveSparseArray
- 
Copy constructor.
- PrimitiveSparseArray.Iterator - Class in com.tangosol.util
- 
Iterator over long values stored in the tree.
- PrimitiveSparseArray.PrimitiveNode - Class in com.tangosol.util
- 
Node mapping long key to Object value.
- PrincipalPofSerializer - Class in com.tangosol.io.pof
- 
PofSerializer implementation that can serialize and deserialize aPrincipalto/from a POF stream.
- PrincipalPofSerializer() - Constructor for class com.tangosol.io.pof.PrincipalPofSerializer
- 
Default constructor.
- print() - Method in class com.tangosol.util.AbstractSparseArray.Node
- 
Print the tree structure.
- print() - Method in class com.tangosol.util.AbstractSparseArray
- 
In-order printing of the contents of the SparseArray.
- print() - Method in class com.tangosol.util.Tree
- 
In-order printing of the contents of the tree.
- print(boolean) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a boolean value.
- print(char) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a character.
- print(char[]) - Method in class com.tangosol.io.WriterPrintStream
- 
Print an array of characters.
- print(double) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a double-precision floating-point number.
- print(float) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a floating-point number.
- print(int) - Method in class com.tangosol.io.WriterPrintStream
- 
Print an integer.
- print(long) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a long integer.
- print(PrintWriter, String) - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- print(PrintWriter, String) - Method in class com.tangosol.coherence.dslquery.statement.FormattedMapStatementResult
- 
Print the result object to the specifiedPrintWriter.
- print(PrintWriter, String) - Method in interface com.tangosol.coherence.dslquery.StatementResult
- 
Print the result object to the specifiedPrintWriter.
- print(Object) - Method in class com.tangosol.io.WriterPrintStream
- 
Print an object.
- print(String) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Print the passed String.
- print(String) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a string.
- printCommaSeparatedCollection(PrintWriter, Collection) - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
Print the contents of the givenCollectionto the specifiedPrintWriteras a comma separated list.
- println() - Method in class com.tangosol.io.IndentingWriter
- 
Terminate the current line by writing the line separator string.
- println() - Method in class com.tangosol.io.WriterPrintStream
- 
Terminate the current line by writing the line separator string.
- println() - Method in class com.tangosol.util.Base.LoggingWriter
- 
Log the accumulated String using the logging severity that this PrintWriter was configured with.
- println(boolean) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a boolean and then terminate the line.
- println(char) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a character and then terminate the line.
- println(char[]) - Method in class com.tangosol.io.WriterPrintStream
- 
Print an array of characters and then terminate the line.
- println(double) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a double and then terminate the line.
- println(float) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a float and then terminate the line.
- println(int) - Method in class com.tangosol.io.WriterPrintStream
- 
Print an integer and then terminate the line.
- println(long) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a long and then terminate the line.
- println(Object) - Method in class com.tangosol.io.WriterPrintStream
- 
Print an Object and then terminate the line.
- println(String) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Print the passed String to the underlying stream.
- println(String) - Method in class com.tangosol.io.WriterPrintStream
- 
Print a String and then terminate the line.
- printObject(PrintWriter, Object, boolean, boolean) - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
Print out the given Object on the givenPrintWriter.
- printResults(PrintWriter, String, Object, boolean) - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
Print the specified result value to the specifiedPrintWriter.
- printResultsCollection(PrintWriter, Collection, boolean) - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
Print the givenCollectionof Objects on the givenPrintWriter.
- printResultsMap(PrintWriter, Map, boolean) - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
Print the contents of the specifiedMapto the specifiedPrintWriter.
- printResultsObjectMap(PrintWriter, Map, boolean) - Method in class com.tangosol.coherence.dslquery.statement.FormattedMapStatementResult
- 
Print the contents of the specifiedMapto the specifiedPrintWriterand format as required.
- printStackTrace(PrintStream) - Method in exception com.tangosol.io.pof.PortableException
- 
Print thisPortableExceptionand its stack trace to the specified stream.
- printStackTrace(PrintWriter) - Method in exception com.tangosol.io.pof.PortableException
- 
Print thisPortableExceptionand its stack trace to the specified writer.
- printStackTrace(Throwable) - Static method in class com.oracle.coherence.common.base.StackTrace
- 
Build a stack trace for the passed exception.
- printStackTrace(Throwable) - Static method in class com.tangosol.util.Base
- 
Build a stack trace for the passed exception.
- printStringOrObject(PrintWriter, Object) - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
If the given Object is a String print it within double quotes around otherwise pass the Object to theDefaultStatementResult.printObject(PrintWriter, Object, boolean, boolean)method.
- printStringOrObject(PrintWriter, Object, boolean) - Method in class com.tangosol.coherence.dslquery.statement.DefaultStatementResult
- 
If the given Object is a String print it within double quotes around otherwise pass the Object to theDefaultStatementResult.printObject(PrintWriter, Object, boolean, boolean)method.
- priority(InvocableMap.EntryProcessor<K, V, T>) - Static method in class com.tangosol.util.Processors
- 
Construct a priority processor for a given processor.
- PRIORITY - Static variable in interface com.tangosol.net.SessionProvider
- 
The default priority for providers.
- PriorityAggregator<K,V,P,R> - Class in com.tangosol.util.aggregator
- 
PriorityAggregator is used to explicitly control the scheduling priority and timeouts for execution of EntryAggregator-based methods.
- PriorityAggregator() - Constructor for class com.tangosol.util.aggregator.PriorityAggregator
- 
Default constructor (necessary for the ExternalizableLite interface).
- PriorityAggregator(InvocableMap.StreamingAggregator<K, V, P, R>) - Constructor for class com.tangosol.util.aggregator.PriorityAggregator
- 
Construct a PriorityAggregator.
- PriorityComparator<T> - Class in com.tangosol.util.comparator
- 
AComparatorthat orders values that are annotated with thePriorityannotation.
- PriorityComparator(Function<T, Priority>, int) - Constructor for class com.tangosol.util.comparator.PriorityComparator
- PriorityFilter<T> - Class in com.tangosol.util.filter
- 
PriorityFilter is used to explicitly control the scheduling priority and timeouts for execution of filter-based methods.
- PriorityFilter() - Constructor for class com.tangosol.util.filter.PriorityFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- PriorityFilter(IndexAwareFilter) - Constructor for class com.tangosol.util.filter.PriorityFilter
- 
Construct a PriorityFilter.
- PriorityProcessor<K,V,T> - Class in com.tangosol.util.processor
- 
PriorityProcessor is used to explicitly control the scheduling priority and timeouts for execution of EntryProcessor-based methods.
- PriorityProcessor() - Constructor for class com.tangosol.util.processor.PriorityProcessor
- 
Default constructor (necessary for the ExternalizableLite interface).
- PriorityProcessor(InvocableMap.EntryProcessor<K, V, T>) - Constructor for class com.tangosol.util.processor.PriorityProcessor
- 
Construct a PriorityProcessor.
- PriorityTask - Interface in com.tangosol.net
- 
The PriorityTask interface allows to control the ordering in which a service schedules tasks for execution using a thread pool and limit their execution times to a specified duration.
- PrivateKeyLoader - Interface in com.tangosol.net.ssl
- 
A class that can create aPrivateKey.
- proceed(Boolean) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore.Token
- 
Resume the execution after the completion of an asynchronous call.
- proceed(Throwable) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment.DefaultFailureContinuation
- 
Resume the execution after the completion of an asynchronous call.
- proceed(R) - Method in interface com.oracle.coherence.common.base.Continuation
- 
Resume the execution after the completion of an asynchronous call.
- proceed(R) - Method in class com.tangosol.util.NullImplementation.NullContinuation
- 
Resume the execution after the completion of an asynchronous call.
- process(boolean, BinaryEntry) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
- 
Process the specified binary entry according to this Bundle state.
- process(boolean, Object) - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
- 
Process the specified key according to this Bundle state.
- process(boolean, Object, Object) - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
- 
Process the specified entry according to this Bundle state.
- process(OPScanner, String, String) - Method in class com.tangosol.coherence.dslquery.token.persistence.AbstractSQLSnapshotOPToken
- 
Process the commands for the given operation and return a validTermfor the command.
- process(ProcessingContext, XmlAttribute) - Method in interface com.tangosol.config.xml.AttributeProcessor
- 
Process anXmlAttributeand return a specific type of value.
- process(ProcessingContext, XmlAttribute) - Method in class com.tangosol.config.xml.SimpleAttributeProcessor
- 
Process anXmlAttributeand return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.oracle.coherence.cdi.server.BeanProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AcceptorDependenciesProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AddressProviderBuilderProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AsyncBackupProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.AuthorizedHostsProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.BackingMapSchemeProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.BufferTypeProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.CacheMappingProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.CacheServiceProxyProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.CachingSchemeMappingProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.CachingSchemesProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.CompositeSchemeProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ConfigurationProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.CustomizableBinaryStoreManagerBuilderProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.CustomizableBuilderProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.DaemonPoolProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.DefaultsProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.DeltaCompressorProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ElementCalculatorProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.EvictionPolicyProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ExecutorProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.GlobalSocketProviderProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.HealthProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.HttpAcceptorDependenciesProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InitiatorDependenciesProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InitParamsProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InstanceProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InterceptorsProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InternalCacheSchemeProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.InvocationServiceProxyProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.KeystoreProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.LeaseGranularityProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.LocalAddressProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.MapListenerProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.MessageDeliveryModeProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.NoOpElementProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.OperationBundlingProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PagedTopicSchemeProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ParamTypeProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PartitionAssignmentStrategyProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PartitionedQuorumPolicyProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PasswordProvidersProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PasswordURLProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.PersistenceEnvironmentsProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ProviderProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ProxyQuorumPolicyProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ReadLocatorProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ResourcesProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SchemesProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ScopeNameProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SerializersProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ServiceBuilderProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ServiceLoadBalancerProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SocketOptionsProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SocketProviderProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SocketProvidersProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SSLHostnameVerifierProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SSLManagerProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SSLNameListProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SSLProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.StorageAccessAuthorizersProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.StorageProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SubscriberGroupProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.SubscriberGroupsProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.TcpAcceptorProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.TcpInitiatorProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.TopicMappingProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.TopicSchemeMappingProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.TransformerProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.UnitCalculatorProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.UnsupportedFeatureProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.ValueStorageSchemeProcessor
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.WrapperStreamFactoryListProcessor
- 
Deprecated.Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in interface com.tangosol.config.xml.ElementProcessor
- 
Process anXmlElementto return a specific type of value.
- process(ProcessingContext, XmlElement) - Method in class com.tangosol.config.xml.SimpleElementProcessor
- 
Process anXmlElementto return a specific type of value.
- process(XmlDocumentReference, XmlDocumentReference...) - Method in class com.tangosol.config.xml.DocumentProcessor
- 
Processes theXmlDocumentlocated at the specifiedXmlDocumentReference.
- process(XmlElement, XmlElement) - Method in class com.tangosol.coherence.config.xml.processor.CacheConfigOverrideProcessor
- 
ProcessXmlElementoverride and merge with theXmlElementbase element from the root configuration xml.
- process(XmlElement, XmlElement) - Method in interface com.tangosol.config.xml.OverrideProcessor
- 
ProcessXmlElementoverride and merge with theXmlElementbase element from the root configuration xml.
- process(BinaryEntry) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler
- 
Process the specified binary entry in a most optimal way according to the bundle settings.
- process(Event<S>) - Method in interface com.tangosol.util.fsm.FiniteStateMachine
- 
Request theFiniteStateMachineto process the specifiedEvent.
- process(Event<S>) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Request theFiniteStateMachineto process the specifiedEvent.
- process(InvocableMap.Entry) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- process(InvocableMap.Entry) - Method in class com.tangosol.util.NullImplementation.NullEntryProcessor
- 
Process a Map.Entry object.
- process(InvocableMap.Entry) - Method in class com.tangosol.util.processor.TouchProcessor
- process(InvocableMap.Entry<K, V>) - Method in interface com.tangosol.util.InvocableMap.EntryProcessor
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
Not supported.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.AbstractEvolvableProcessor
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.CompositeProcessor
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Process a Map.Entry object if it satisfies the underlying filter.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.ConditionalPut
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.ExtractorProcessor
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.NumberIncrementor
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.NumberMultiplier
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.PreloadRequest
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.PriorityProcessor
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.ScriptProcessor
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.UpdaterProcessor
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.VersionedPut
- 
Process a Map.Entry object.
- process(InvocableMap.Entry<K, V>) - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Process a Map.Entry object.
- process(MapTrigger.Entry) - Method in class com.tangosol.util.filter.FilterTrigger
- 
This method is called before the result of a mutating operation represented by the specified Entry object is committed into the underlying map.
- process(MapTrigger.Entry<K, V>) - Method in interface com.tangosol.util.MapTrigger
- 
This method is called before the result of a mutating operation represented by the specified Entry object is committed into the underlying map.
- process(Object) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- process(Object) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- process(Object) - Method in class com.tangosol.net.cache.AbstractKeyBundler
- 
Process the specified key in a most optimal way according to the bundle settings.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.BigDecimalAverage
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.BigDecimalMax
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.BigDecimalMin
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.BigDecimalSum
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.ComparableMax
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.ComparableMin
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.DistinctValues
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.DoubleAverage
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.DoubleMax
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.DoubleMin
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.DoubleSum
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.LongMax
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.LongMin
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.LongSum
- 
Incorporate one aggregatable value into the result.
- process(Object, boolean) - Method in class com.tangosol.util.aggregator.ReducerAggregator
- 
Incorporate one aggregatable value into the result.
- process(Object, Object) - Method in class com.tangosol.net.cache.AbstractEntryBundler
- 
Process the specified entry in a most optimal way according to the bundle settings.
- process(String) - Method in class com.tangosol.coherence.rest.EntryResource
- 
Invoke the specified processor against the entry's key.
- process(String) - Method in class com.tangosol.coherence.rest.EntrySetResource
- 
Invoke the specified processor against the entries.
- process(String, ParameterResolver, int) - Method in class com.tangosol.config.expression.ValueMacroExpression.DefaultDelimiterExpansionProcessor
- process(String, ParameterResolver, int) - Method in class com.tangosol.config.expression.ValueMacroExpression.MacroExpansionProcessor
- 
Process macro parameter expansion onsMacrocontaining no registered delimiters.
- process(String, ParameterResolver, int) - Method in class com.tangosol.config.expression.ValueMacroExpression.OffsetLengthSubstringExpansionProcessor
- 
Perform substring expansion onsMacro.
- process(String, ParameterResolver, int) - Method in class com.tangosol.config.expression.ValueMacroExpression.SpaceDefaultDelimiterExpansionProcessor
- process(String, String) - Method in class com.tangosol.coherence.rest.CacheResource
- 
Invoke the specified processor against the entries that satisfy the specified criteria.
- process(Socket, Socket) - Method in class com.tangosol.net.LoadBalancer.SocketHandler
- 
Process the transfer of data from one socket to another.
- process(UriInfo, String) - Method in class com.tangosol.coherence.rest.NamedQueryResource
- 
Invoke the specified processor against the entries that belong to the named query.
- PROCESS - com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor.EmptyElementBehavior
- 
When an emptyXmlElementis encountered, attempt to process it.
- processAll(boolean, Collection) - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
- 
Process the specified key collection according to this Bundle state.
- processAll(boolean, Map) - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
- 
Process the specified collection of entries according to this Bundle state.
- processAll(boolean, Set) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
- 
Process the specified set of binary entries according to this Bundle state.
- processAll(Collection) - Method in class com.tangosol.net.cache.AbstractKeyBundler
- 
Process a colKeys of specified items in a most optimal way according to the bundle settings.
- processAll(Map) - Method in class com.tangosol.net.cache.AbstractEntryBundler
- 
Process a colllection of entries in a most optimal way according to the bundle settings.
- processAll(Set) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler
- 
Process a collection of binary entries in a most optimal way according to the bundle settings.
- processAll(Set) - Method in class com.tangosol.net.cache.ContinuousQueryCache.ConverterAsynchronousProcessor
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in interface com.tangosol.util.InvocableMap.EntryProcessor
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.AbstractAsynchronousProcessor
- 
Not supported.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.AbstractEvolvableProcessor
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.AbstractProcessor
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.ConditionalPut
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.PreloadRequest
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.PriorityProcessor
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.VersionedPut
- 
Process a Set of InvocableMap.Entry objects.
- processAll(Set<? extends InvocableMap.Entry<K, V>>) - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Process a Set of InvocableMap.Entry objects.
- processBackEvent(OverflowMap.Status, MapEvent) - Method in class com.tangosol.net.cache.OverflowMap
- 
Process an event.
- processDeferredEvents() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Process deferred events, if there are any.
- processDeferredEvents(boolean) - Method in class com.tangosol.net.cache.OverflowMap
- 
Process deferred events, if there are any.
- processDeletedEntry(Object, Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.InternalMapListener
- 
Process an entry that is about to be removed from the internal cache.
- processDocument(XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that the specifiedXmlElement(representing the root of an XmlDocument) be processed with appropriateNamespaceHandlers.
- processDocument(XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that the specifiedXmlElement(representing the root of an XmlDocument) be processed with appropriateNamespaceHandlers.
- processDocument(String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that the specified xml string (representing an xml document) be processed with appropriateNamespaceHandlers.
- processDocument(String) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that the specified xml string (representing an xml document) be processed with appropriateNamespaceHandlers.
- processDocumentAt(String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that the document specified by the URI/filename (containing the root of an XmlDocument) be processed with appropriateNamespaceHandlers.
- processDocumentAt(String) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that the document specified by the URI/filename (containing the root of an XmlDocument) be processed with appropriateNamespaceHandlers.
- processDocumentAt(URI) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that the document specified by the URI/filename (containing the root of an XmlDocument) be processed with appropriateNamespaceHandlers.
- processDocumentAt(URI) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that the document specified by the URI/filename (containing the root of an XmlDocument) be processed with appropriateNamespaceHandlers.
- processElement(XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request the specifiedXmlElementto be processed with an appropriateNamespaceHandlerknown by theProcessingContextor outerProcessingContexts.
- processElement(XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request the specifiedXmlElementto be processed with an appropriateNamespaceHandlerknown by theProcessingContextor outerProcessingContexts.
- processElement(String) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request the specified xml string be processed with an appropriateNamespaceHandlerknown by theProcessingContext.
- processElement(String) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request the specified xml string be processed with an appropriateNamespaceHandlerknown by theProcessingContext.
- processElementsOf(XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that all of the child elements contained with in the specifiedXmlElementbe processed using appropriateNamespaceHandlers known by theProcessingContext.
- processElementsOf(XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that all of the child elements contained with in the specifiedXmlElementbe processed using appropriateNamespaceHandlers known by theProcessingContext.
- processEntry(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Incorporate one aggregatable entry into the result.
- processEntry(InvocableMap.Entry<? extends K, ? extends V>) - Method in class com.tangosol.util.aggregator.ReducerAggregator
- 
Incorporate one aggregatable entry into the result.
- processEntry(InvocableMap.Entry<K, V>, Map<? extends K, ? extends V>, boolean, boolean) - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Process the given entry.
- processEntry(InvocableMap.Entry<K, V>, V, boolean, boolean) - Method in class com.tangosol.util.processor.VersionedPut
- 
Process the given entry.
- processEvent(OverflowMap.Status, MapEvent) - Method in class com.tangosol.net.cache.OverflowMap
- 
Process an arbitrary event that has occurred against either the front or back map.
- ProcessEvent(Event<S>) - Constructor for class com.tangosol.util.fsm.Instruction.ProcessEvent
- 
Constructs aInstruction.ProcessEventInstruction.
- ProcessEventLater(Event<S>) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.ProcessEventLater
- 
Constructs aNonBlockingFiniteStateMachine.ProcessEventLaterwithout a specified time (to be schedule as soon as possible).
- ProcessEventLater(Event<S>, long, TimeUnit) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.ProcessEventLater
- 
Constructs aNonBlockingFiniteStateMachine.ProcessEventLaterwith the specified delay time.
- processExpiries(K, CoherenceCacheEventEventDispatcher<K, V>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Process expiry for entry of key.
- processExpiries(K, V, CoherenceCacheEventEventDispatcher<K, V>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- 
Dispatch an ExpiryEvent to registered CacheEntryListeners.
- processFile(String) - Method in class com.tangosol.coherence.dslquery.QueryPlus
- 
Process the given file of CohQL statements.
- processForeignElementsOf(XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that all of the child elements contained within the specifiedXmlElementthat do not belong to the namespace of the saidXmlElementare processed using appropriate processes.
- processForeignElementsOf(XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that all of the child elements contained within the specifiedXmlElementthat do not belong to the namespace of the saidXmlElementare processed using appropriate processes.
- processFrontEvent(OverflowMap.Status, MapEvent) - Method in class com.tangosol.net.cache.OverflowMap
- 
Process an event.
- processFrontEvent(SimpleOverflowMap.Status, MapEvent) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Process an event.
- ProcessingContext - Interface in com.tangosol.config.xml
- 
AProcessingContextprovides contextual information concerning the processing of content in an xml document.
- processLater(Event<S>) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Request theFiniteStateMachineto process the specifiedEventas soon as possible.
- processLater(Event<S>, long, TimeUnit) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Request theFiniteStateMachineto process the specifiedEventat some point in the future (represented as a duration to wait from the moment the method is called).
- processOnlyElementOf(XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that the only child element contained within theXmlElementis processed using an appropriateNamespaceHandlerknown by theProcessingContext.
- processOnlyElementOf(XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that the only child element contained within theXmlElementis processed using an appropriateNamespaceHandlerknown by theProcessingContext.
- Processor - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used to indicate processor class when observingEntryProcessorEvents.
- PROCESSOR_REQUEST_REGEX - Static variable in class com.tangosol.coherence.rest.util.processor.ProcessorRegistry
- 
Regex pattern that defines the processor request syntax.
- Processor.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theProcessorannotation.
- ProcessorConfig - Class in com.tangosol.coherence.rest.config
- 
The ProcessorConfig class encapsulates information related to a Coherence REST EntryProcessor configuration.
- ProcessorConfig(String, Class) - Constructor for class com.tangosol.coherence.rest.config.ProcessorConfig
- 
Construct a ProcessorConfig.
- ProcessorFactory<K,V,R> - Interface in com.tangosol.coherence.rest.util.processor
- 
A factory for processors.
- ProcessorRegistry - Class in com.tangosol.coherence.rest.util.processor
- 
A registry forProcessorFactoryinstances.
- ProcessorRegistry() - Constructor for class com.tangosol.coherence.rest.util.processor.ProcessorRegistry
- 
Construct an ProcessorRegistry.
- ProcessorRegistry(Collection<ProcessorConfig>) - Constructor for class com.tangosol.coherence.rest.util.processor.ProcessorRegistry
- 
Construct an ProcessorRegistry that includes built-in processors in addition to the specified processors.
- Processors - Class in com.tangosol.util
- 
SimpleInvocableMap.EntryProcessorDSL.
- Processors() - Constructor for class com.tangosol.util.Processors
- processParameterizedBuilder(ProcessingContext, XmlElement) - Static method in class com.tangosol.coherence.config.xml.processor.ElementProcessorHelper
- 
Attempts to process the specifiedXmlElementto produce aParameterizedBuildergiven aProcessingContext.
- processPending(Binary, Binary) - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Store the specified value under the specific key in the underlying store, or if the value isAsyncBinaryStore.DELETEDthen erase the value from the underlying store.
- processRegisteredMacroExpansions(String, ParameterResolver, int) - Method in class com.tangosol.config.expression.ValueMacroExpression
- 
Process macro expansion ofsMacrobyregistered macro-expansion processors.
- processRegistrations() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Process any scheduled selector registrations.
- processRemainingElementOf(XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that the last remaining unprocessed child element contained within the specifiedXmlElementis processed using an appropriateElementProcessor.
- processRemainingElementOf(XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that the last remaining unprocessed child element contained within the specifiedXmlElementis processed using an appropriateElementProcessor.
- processRemainingElementsOf(XmlElement) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Request that the last remaining unprocessed children contained within the specifiedXmlElementare processed using appropriateElementProcessors.
- processRemainingElementsOf(XmlElement) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Request that the last remaining unprocessed children contained within the specifiedXmlElementare processed using appropriateElementProcessors.
- processValueMacro(XmlElement) - Static method in class com.tangosol.coherence.config.xml.preprocessor.SystemPropertyPreprocessor
- 
Process macros embedded in element's value
- processValueMacro(XmlElement, ParameterResolver) - Static method in class com.tangosol.coherence.config.xml.preprocessor.SystemPropertyPreprocessor
- 
Process macros embedded in element's value
- PRODUCT - Static variable in class com.tangosol.net.CacheFactory
- 
The product name string.
- PROP_CHANNEL_COUNT - Static variable in interface com.tangosol.net.topic.Publisher
- 
The system property to use to configure a default publisher channel count.
- PROP_CONNECTION_TTL - Static variable in class com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics
- 
The system property used to set the expiry time used to evict connection MBeans when connections have had no activity for a period of time.
- PROP_CREDENTIALS - Static variable in class com.oracle.coherence.grpc.CredentialsHelper
- 
The system property to use to set the type of credentials to use.
- PROP_CREDENTIALS - Static variable in class com.oracle.coherence.grpc.Requests
- 
The system property that sets the credentials type.
- PROP_GLOBAL_PROVIDER - Static variable in class com.tangosol.net.SocketProviderFactory
- 
The name of the system property used to set the global socket provider id.
- PROP_HTTP_TIMEOUT - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the http connection timeout.
- PROP_MACHINE - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the URL to read the machine name from.
- PROP_MEMBER - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the URL to read the member name from.
- PROP_RACK - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the URL to read the rack name from.
- PROP_RETRY_PERIOD - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the retry period.
- PROP_RETRY_TIMEOUT - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the retry timeout.
- PROP_ROLE - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the URL to read the role name from.
- PROP_SITE - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the URL to read the site name from.
- PROP_SOCKET_PROVIDER - Static variable in class com.tangosol.net.URLMemberIdentityProvider
- 
The system property to use to set the URL to read the role name from.
- PROP_START_TIMEOUT - Static variable in class com.tangosol.net.Coherence
- 
The system property to use to set the default timeout to wait for Coherence instances to start.
- PROP_TLS_CA - Static variable in class com.oracle.coherence.grpc.CredentialsHelper
- 
The system property that sets the location of the TLS CA file.
- PROP_TLS_CA - Static variable in class com.oracle.coherence.grpc.Requests
- 
The system property that sets the location of the TLS CA file.
- PROP_TLS_CERT - Static variable in class com.oracle.coherence.grpc.CredentialsHelper
- 
The system property that sets the location of the TLS cert file.
- PROP_TLS_CERT - Static variable in class com.oracle.coherence.grpc.Requests
- 
The system property that sets the location of the TLS cert file.
- PROP_TLS_CLIENT_AUTH - Static variable in class com.oracle.coherence.grpc.Requests
- 
The system property that sets whether mutual TLS is enabled.
- PROP_TLS_KEY - Static variable in class com.oracle.coherence.grpc.CredentialsHelper
- 
The system property that sets the location of the TLS key file.
- PROP_TLS_KEY - Static variable in class com.oracle.coherence.grpc.Requests
- 
The system property that sets the location of the TLS key file.
- PROP_TLS_KEYPASS - Static variable in class com.oracle.coherence.grpc.CredentialsHelper
- 
The system property that sets the password for the TLS key file.
- PROP_TLS_KEYPASS - Static variable in class com.oracle.coherence.grpc.Requests
- 
The system property that sets the password for the TLS key file.
- PROP_TLS_KEYPASS_URI - Static variable in class com.oracle.coherence.grpc.CredentialsHelper
- 
The system property that sets the URI of a file to read to obtain the password for the TLS key file.
- PROP_TLS_KEYPASS_URI - Static variable in class com.oracle.coherence.grpc.Requests
- 
The system property that sets the URI of a file to read to obtain the password for the TLS key file.
- PROP_WB_REMOVE_DEFAULT - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
- 
A Boolean system property to control whether write behind remove is enabled.
- PropertiesParameterResolver - Class in com.tangosol.config.expression
- PropertiesParameterResolver(Map<String, String>) - Constructor for class com.tangosol.config.expression.PropertiesParameterResolver
- 
Construct aPropertiesParameterResolverusing aMapof values.
- PROPERTY - Static variable in interface com.tangosol.net.MemberIdentityProvider
- 
The System property to use to set the name of the identity provider class to use.
- PROPERTY_CONFIG - Static variable in class com.tangosol.io.pof.ConfigurablePofContext
- 
The name of the system property ("tangosol.pof.config") that can be used to override the location of the default POF configuration file.
- PROPERTY_CONFIG - Static variable in class com.tangosol.net.security.DefaultController
- 
The name of the system property that can be used to override the location of the DefaultController configuration file.
- PROPERTY_CONFIG - Static variable in class com.tangosol.util.ExternalizableHelper
- 
The name of the system property that can be used to override the location of the ExternalizableHelper configuration file.
- PropertyAdapter - Class in com.tangosol.run.xml
- 
The PropertyAdapter is the base class for handling the operations that can occur on any property.
- PropertyAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PropertyAdapter
- 
Construct a PropertyAdapter.
- PropertyExtractor - Annotation Type in com.oracle.coherence.cdi
- 
AExtractorBindingannotation representing aUniversalExtractor.
- PropertyExtractor.Extractors - Annotation Type in com.oracle.coherence.cdi
- 
A holder for the repeatablePropertyExtractorannotation.
- PropertyExtractor.Extractors.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for thePropertyExtractor.Extractorsannotation.
- PropertyExtractor.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for thePropertyExtractorannotation.
- PropertyManipulator<V,R> - Class in com.tangosol.util.processor
- 
PropertyManipulator is a reflection based ValueManipulator implementation based on the JavaBean property name conventions.
- PropertyManipulator() - Constructor for class com.tangosol.util.processor.PropertyManipulator
- 
Default constructor (necessary for the ExternalizableLite interface).
- PropertyManipulator(String) - Constructor for class com.tangosol.util.processor.PropertyManipulator
- 
Construct a PropertyManipulator for the specified property name.
- PropertyManipulator(String, boolean) - Constructor for class com.tangosol.util.processor.PropertyManipulator
- 
Construct a PropertyManipulator for the specified property name.
- PropertyProcessor<K,V,R> - Class in com.tangosol.util.processor
- 
PropertyProcessor is a base class for EntryProcessor implementations that depend on a ValueManipulator.
- PropertyProcessor() - Constructor for class com.tangosol.util.processor.PropertyProcessor
- 
Default constructor (necessary for the ExternalizableLite interface).
- PropertyProcessor(ValueManipulator<V, R>) - Constructor for class com.tangosol.util.processor.PropertyProcessor
- 
Construct a PropertyProcessor based for the specified ValueManipulator.
- PropertyProcessor(String) - Constructor for class com.tangosol.util.processor.PropertyProcessor
- 
Construct a PropertyProcessor for the specified property name.
- PropertyProcessor(String, boolean) - Constructor for class com.tangosol.util.processor.PropertyProcessor
- 
Construct a PropertyProcessor for the specified property name.
- PropertySet<T> - Class in com.tangosol.coherence.rest.util
- 
Represents a set of named properties and allows the extraction of those properties from a target object.
- PropertySet() - Constructor for class com.tangosol.coherence.rest.util.PropertySet
- 
Default constructor.
- PropertySet(PropertySpec...) - Constructor for class com.tangosol.coherence.rest.util.PropertySet
- 
Construct a PropertySet instance.
- PropertySet(Set<PropertySpec>) - Constructor for class com.tangosol.coherence.rest.util.PropertySet
- 
Construct a PropertySet instance.
- PropertySpec - Class in com.tangosol.coherence.rest.util
- 
Specification for a single property.
- PropertySpec() - Constructor for class com.tangosol.coherence.rest.util.PropertySpec
- 
Default constructor (necessary for deserialization).
- PropertySpec(String) - Constructor for class com.tangosol.coherence.rest.util.PropertySpec
- 
Construct PropertySpec instance.
- PropertySpec(String, PropertySet) - Constructor for class com.tangosol.coherence.rest.util.PropertySpec
- 
Construct PropertySpec instance.
- PROTOCOL_MAGIC - Static variable in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Protcol identifier used to identify that peers are also TcpDatagramSockets.
- provider() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Return the SelectorProvider associated with this socket.
- ProviderBuilder() - Constructor for class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ProviderBuilder
- ProviderProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse and produce a ProviderBuilder based on a provider configuration element.
- ProviderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ProviderProcessor
- Providers() - Constructor for class com.tangosol.net.SessionProvider.Providers
- 
Deprecated.
- PROXY - Static variable in class com.tangosol.coherence.config.xml.processor.ServiceLoadBalancerProcessor
- 
Proxy option for the service load balancer.
- PROXY_SCHEME - Static variable in class com.tangosol.coherence.config.xml.processor.ServiceLoadBalancerProcessor
- 
Proxy scheme.
- Proxyable<T> - Interface in com.tangosol.util
- 
An interface that should be implemented by the classes that are able to create a client-side proxy for itself.
- ProxyQuorumPolicy(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[]) - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.ProxyQuorumPolicy
- 
Construct a ProxyQuorumPolicy with the specified rule.
- ProxyQuorumPolicyBuilder - Class in com.tangosol.coherence.config.builder
- 
Defer cache configuration validation of a ProxyQuorumPolicy until realized.
- ProxyQuorumPolicyBuilder(int, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ProxyQuorumPolicyBuilder
- 
ConstructsProxyQuorumPolicyBuilderfrom configuration file context and xml element
- ProxyQuorumPolicyProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse a <proxy-quorum-policy-scheme> and produce a suitableActionPolicy
- ProxyQuorumPolicyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ProxyQuorumPolicyProcessor
- ProxyScheme - Class in com.tangosol.coherence.config.scheme
- 
TheProxySchemeclass builds a Proxy scheme.
- ProxyScheme() - Constructor for class com.tangosol.coherence.config.scheme.ProxyScheme
- 
Constructs aProxyScheme.
- ProxyService - Interface in com.tangosol.net
- 
A ProxyService is a clustered service that accepts connections from external clients (e.g.
- ProxyService.ProxyAction - Interface in com.tangosol.net
- 
ProxyAction represents a type of action taken by a ProxyService.
- ProxyServiceLoad - Interface in com.tangosol.net.proxy
- 
A ProxyServiceLoad encapsulates information about the current utilization of a ProxyService.
- ProxyServiceLoadBalancer - Interface in com.tangosol.net.proxy
- 
A ProxyServiceLoadBalancer is a pluggable strategy for controlling the client load across individual members of a clustered ProxyService.
- ProxyServiceLoadBalancerBuilder - Class in com.tangosol.coherence.config.builder
- 
ProxyServiceLoadBalancerBuilderdefers evaluating configuration parameters until ServiceLoadBalancer is instantiated.
- ProxyServiceLoadBalancerBuilder(ParameterizedBuilder, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ProxyServiceLoadBalancerBuilder
- 
ConstructsProxyServiceLoadBalancerBuilder
- prune() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Prune the cache by discarding the lowest priority cache entries.
- prune() - Method in class com.tangosol.util.ThreadLocalObject
- 
Deprecated.as of Coherence 3.3 this method is a no-op
- publish(V) - Method in interface com.tangosol.net.topic.Publisher
- 
Asynchronously publish the specified value to the topic.
- Publisher<V> - Interface in com.tangosol.net.topic
- 
Publisher provides a means to publish values to theNamedTopic.
- Publisher.FailOnFull - Class in com.tangosol.net.topic
- 
The FailOnFull option indicates that theCompletableFuturereturned from thePublisher.publish(V)operation should complete exceptionally upon identifying that the topic is or has become full.
- Publisher.OnFailure - Enum in com.tangosol.net.topic
- 
This option controls how aPublisherhandles a failure of an individualPublisher.publish(V)call.
- Publisher.Option<V> - Interface in com.tangosol.net.topic
- 
A marker interface to indicate that a class is a validPublisher.Optionfor aPublisher.
- Publisher.Orderable - Interface in com.tangosol.net.topic
- 
Orderable represents a value published byPublisherthat has a natural ordering.
- Publisher.OrderBy<V> - Class in com.tangosol.net.topic
- 
The OrderBy option specifies the ordering of async operations with respect to one another.
- Publisher.OrderById<V> - Class in com.tangosol.net.topic
- 
Publisher.OrderByoption ensures ordering ofsent valuesacross all threads which share the sameorderId.
- Publisher.OrderByNone<V> - Class in com.tangosol.net.topic
- 
Publisher.OrderByoption enforces no specific ordering betweensent valuesallowing for the greatest level of parallelism.
- Publisher.OrderByRoundRobin<V> - Class in com.tangosol.net.topic
- 
Publisher.OrderByoption which computes the unit-of-order such that each message is sent to the next channel in a round-robin order.
- Publisher.OrderByThread<V> - Class in com.tangosol.net.topic
- 
Publisher.OrderByoption which ensures that a sequence ofsent valuesissued by a single thread will complete in order.
- Publisher.OrderByValue<V> - Class in com.tangosol.net.topic
- 
Publisher.OrderByoption which computes the unit-of-order based on applyingconstructor'sorderIdFunction parameteronsent value.
- Publisher.Status - Interface in com.tangosol.net.topic
- 
The status for a successfully published element.
- PunctuationBaseToken - Class in com.tangosol.coherence.dsltools.base
- 
PunctuationBaseToken is a token that represents a known punctuation.
- PunctuationBaseToken(String) - Constructor for class com.tangosol.coherence.dsltools.base.PunctuationBaseToken
- 
Construct a new PunctuationBaseToken with the given punctuation value.
- PunctuationOPToken - Class in com.tangosol.coherence.dsltools.precedence
- 
PunctuationOPToken is used in situations where you need a place holder to test for something like a ",".
- PunctuationOPToken(String) - Constructor for class com.tangosol.coherence.dsltools.precedence.PunctuationOPToken
- 
Construct a new PunctuationOPToken with the given parameters.
- purgeChildrenNamespace(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
For the children elements of the specified XmlElement purge the repetitive Namespace declarations.
- purgeNamespace(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
For the specified XmlElement purge the Namespace declarations that are declared somewhere up the xml tree.
- push(Object) - Method in class com.tangosol.util.SimpleStack
- 
Add the given object to the top of the stack.
- pushCacheContext(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Push cache context into a thread-local storage.
- pushStream(BaseTokenStream) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Remember the current BaseTokenStream and stream over the given stream.
- put(CacheRequestHolder<PutRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute a put request.
- put(PutRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Associate the specified value with the specified key in this cache.
- put(PutRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- put(PutRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- put(Filter, V) - Static method in class com.tangosol.util.Processors
- 
Construct a put processor that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.
- put(Filter, V, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct a put processor that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.
- put(Comparable, Object) - Method in class com.tangosol.util.Tree
- 
Add the passed key to the tree and associate the passed value with the key.
- put(Object, Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- put(Object, Object) - Method in class com.tangosol.io.nio.BinaryMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.io.pof.PofHelper.ReadableEntrySetMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.OverflowMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EvictingBackupMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.SerializationMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- put(Object, Object) - Method in class com.tangosol.util.ChainedMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- put(Object, Object) - Method in class com.tangosol.util.OpenHashMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object) - Method in class com.tangosol.util.SafeSortedMap
- put(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- put(Object, Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object, boolean, long) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Implementation of put method that optionally skips the return value retrieval and allows to specify an expiry for the cache entry.
- put(Object, Object, long) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- put(Object, Object, long) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Associates the specified value with the specified key in this cache.
- put(Object, Object, long) - Method in class com.tangosol.net.cache.OverflowMap
- 
Associates the specified value with the specified key in this cache.
- put(Object, Object, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Associates the specified value with the specified key in this map.
- put(Object, Object, long) - Method in class com.tangosol.net.cache.SerializationCache
- 
Associates the specified value with the specified key in this cache.
- put(Object, Object, long) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Associates the specified value with the specified key in this cache.
- put(String, Object) - Method in class com.tangosol.coherence.rest.util.JsonMap
- put(String, Object) - Method in class com.tangosol.util.StringTable
- 
Add the passed string to the table and associate the passed value with the string.
- put(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aPutRequest.
- put(String, String, String, ByteString, ByteString, long) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aPutRequest.
- put(HttpHeaders, InputStream) - Method in class com.tangosol.coherence.rest.EntryResource
- 
Update the entry value.
- put(K, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- put(K, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- put(K, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- put(K, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- put(K, V) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Associates the specified value with the specified key in this map.
- put(K, V) - Method in interface com.tangosol.net.cache.CacheMap
- 
Associates the specified value with the specified key in this cache.
- put(K, V) - Method in class com.tangosol.net.cache.CachingMap
- put(K, V) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- put(K, V) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Associates the specified value with the specified key in this map.
- put(K, V) - Method in interface com.tangosol.util.ConcurrentMap
- 
Associates the specified value with the specified key in this map (optional operation).
- put(K, V) - Method in class com.tangosol.util.CopyOnWriteMap
- put(K, V) - Method in class com.tangosol.util.ObservableHashMap
- 
Store a value in the cache.
- put(K, V) - Method in class com.tangosol.util.SafeHashMap
- 
Associates the specified value with the specified key in this map.
- put(K, V) - Method in class com.tangosol.util.SetMap
- put(K, V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- put(K, V) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- put(K, V) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Associates the specified value with the specified key in this map.
- put(K, V) - Method in class com.tangosol.util.WrapperObservableMap
- 
Associates the specified value with the specified key in this map.
- put(K, V_FRONT) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- put(K, V_FRONT, long) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- put(K, V, boolean, long) - Method in class com.tangosol.net.cache.CachingMap
- 
Implementation of put method that optionally skips the return value retrieval and allows to specify an expiry for the cache entry.
- put(K, V, long) - Method in interface com.tangosol.net.AsyncNamedCache
- 
Associates the specified value with the specified key in this cache.
- put(K, V, long) - Method in interface com.tangosol.net.cache.CacheMap
- 
Associates the specified value with the specified key in this cache.
- put(K, V, long) - Method in class com.tangosol.net.cache.NearCache
- 
Associates the specified value with the specified key in this cache and allows to specify an expiry for the cache entry.
- put(K, V, long) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Associates the specified value with the specified key in this cache and allows to specify an expiry for the cache entry.
- put(K, V, long) - Method in interface com.tangosol.net.NamedCache
- 
Associates the specified value with the specified key in this cache and allows to specify an expiry for the cache entry.
- put(TK, TV) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- put(TK, TV, long) - Method in class com.tangosol.util.ConverterCollections.ConverterCacheMap
- 
Associates the specified value with the specified key in this cache.
- putAll(CacheRequestHolder<PutAllRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute a putAll request.
- putAll(PutAllRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Add the specified key value pair mappings to this cache.
- putAll(PutAllRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- putAll(PutAllRequest, StreamObserver<Empty>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- putAll(Filter, Map<? extends K, ? extends V>) - Static method in class com.tangosol.util.Processors
- 
Construct a putAll processor that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.
- putAll(StringTable) - Method in class com.tangosol.util.StringTable
- 
Puts all of the nodes in the specified StringTable to this StringTable including the ones that are already present.
- putAll(Tree) - Method in class com.tangosol.util.Tree
- 
Puts all of the nodes in the specified Tree to this Tree (including the ones that are already present).
- putAll(String, String, String, Iterable<Entry>) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aPutAllRequest.
- putAll(String, String, String, Iterable<Entry>, long) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aPutAllRequest.
- putAll(Map) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- putAll(Map) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.OverflowMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Associates the specified values with the respective keys in this map.
- putAll(Map) - Method in class com.tangosol.net.cache.SerializationCache
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.SerializationMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Copy all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.util.NullImplementation.NullMap
- putAll(Map) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map) - Method in class com.tangosol.util.SegmentedHashMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map<? extends K, ? extends V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- putAll(Map<? extends K, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.net.cache.CachingMap
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map<? extends K, ? extends V>) - Method in interface com.tangosol.util.ConcurrentMap
- 
Copies all of the mappings from the specified map to this map (optional operation).
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.util.CopyOnWriteMap
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.util.SetMap
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.util.WrapperObservableMap
- 
Copies all of the mappings from the specified map to this map.
- putAll(Map<? extends K, ? extends V>, boolean, boolean) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- putAll(Map<? extends K, ? extends V>, long) - Method in interface com.tangosol.net.AsyncNamedCache
- 
Copies all the mappings from the specified map to this map with the specified expiry delay.
- putAll(Map<? extends TK, ? extends TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- PUTALL_THRESHOLD - Static variable in class com.tangosol.util.SegmentedHashMap
- 
Size threshold used by the putAll operation.
- putAllInternal(Map, Map) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.CapacityAwareMap
- 
Put all entries in mapUpdate into the provided map.
- putAllInternal(Map, Map) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Put all entries in mapUpdate into the provided map.
- putBackElement(Object) - Method in class com.tangosol.util.Dequeue
- 
Returns the most recently returned element to the Dequeue.
- PutBundler() - Constructor for class com.tangosol.net.cache.BundlingNamedCache.PutBundler
- putCacheToConfigurationMapping(JCacheIdentifier, CoherenceBasedCompleteConfiguration) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- 
put entry with key of sName
- putIfAbsent(CacheRequestHolder<PutIfAbsentRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute aPutIfAbsentRequestrequest.
- putIfAbsent(PutIfAbsentRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
If the specified key is not already associated with a value (or is mapped tonull) associate it with the given value and returnsnull, else return the current value.
- putIfAbsent(PutIfAbsentRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- putIfAbsent(PutIfAbsentRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- putIfAbsent(Object, Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- putIfAbsent(Object, Object) - Method in class com.tangosol.util.SafeSortedMap
- putIfAbsent(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- putIfAbsent(Object, Object) - Method in class com.tangosol.util.SegmentedConcurrentMap
- putIfAbsent(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aPutIfAbsentRequest.
- putIfAbsent(K, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- putIfAbsent(K, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- putIfAbsent(K, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- putIfAbsent(K, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- putIfAbsent(K, V) - Method in interface com.tangosol.net.AsyncNamedMap
- 
If the specified key is not already associated with a value (or is mapped tonull) associates it with the given value and returnsnull, else returns the current value.
- putIfAbsent(K, V) - Method in interface com.tangosol.util.InvocableMap
- putIfAbsent(K, V) - Method in class com.tangosol.util.SafeHashMap
- putIfAbsent(K, V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- putIfAbsent(K, V) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- putIfAbsent(TK, TV) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- putIfAbsent(TK, TV) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- putInternal(Object) - Method in class com.tangosol.coherence.rest.EntryResource
- 
Update the cache entry.
- putInternal(Object, Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Associates the specified value with the specified key in this map.
- putInternal(Object, Object, boolean) - Method in class com.tangosol.util.SegmentedHashMap
- 
Associates the specified value with the specified key in this map.
- putInternal(Object, Object, boolean, long) - Method in class com.tangosol.net.cache.OverflowMap
- 
A combined implementation ofOverflowMap.put(Object, Object)and "void put(Object, Object)" that eliminates duplicate (and muchos complex) code between theOverflowMap.put(java.lang.Object, java.lang.Object)andOverflowMap.putAll(java.util.Map)methods.
- putInternal(Object, Object, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
An actual implementation for the extended put() method.
- putInternal(Map, Object, Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.CapacityAwareMap
- 
Put the key and value into a map representing a given partition.
- putInternal(Map, Object, Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Put the key and value into a map representing a given partition.
- putOne(Map, Object, Object, boolean) - Static method in class com.tangosol.net.cache.OverflowMap
- 
Helper to put a value into a map using either the put or putAll method.
- putOne(Map, Object, Object, boolean) - Static method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Helper to put a value into a map using either the put or putAll method.
- putToInternalCache(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Add the key and value pair to the internal cache in such a way that the resulting map event would be marked as "synthetic".
- putToInternalCache(Object, Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Add the key and value pair to the internal cache in such a way that the resulting map event would be marked as "synthetic".
- putToInternalCache(Object, Object, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Add the key and value pair to the internal cache in such a way that the resulting map event would be marked as "synthetic".
- putToInternalMap(Object, Object, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Put the specified key in internal format and value in internal format into the internal backing map.
Q
- QNameAdapter - Class in com.tangosol.run.xml
- 
A property adapter for QName primitive datatype.
- QNameAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.QNameAdapter
- 
Construct a QNameAdapter.
- QualifiedName - Class in com.tangosol.run.xml
- 
AQualifiedNameis a useful class to separately capture the xml namespace prefix and local name of xml elements and attributes as a single object (instead of having to parse them out ofStrings all the time).
- QualifiedName(QualifiedName, String) - Constructor for class com.tangosol.run.xml.QualifiedName
- 
Standard Constructor (using a specifiedQualifiedNamefor the prefix).
- QualifiedName(XmlElement) - Constructor for class com.tangosol.run.xml.QualifiedName
- 
Standard Constructor.
- QualifiedName(String) - Constructor for class com.tangosol.run.xml.QualifiedName
- 
Standard Constructor.
- QualifiedName(String, String) - Constructor for class com.tangosol.run.xml.QualifiedName
- 
Standard Constructor.
- query(Invocable, Set) - Method in interface com.tangosol.net.InvocationService
- 
Synchronously invoke the specified task on each of the specified members.
- query(Invocable, Set) - Method in class com.tangosol.net.WrapperInvocationService
- 
Synchronously invoke the specified task on each of the specified members.
- query(String) - Method in class com.tangosol.coherence.dslquery.QueryPlus
- 
Process the specified query.
- query(Map, Filter, boolean, boolean, Comparator) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Generic implementation of theQueryMapAPI.
- query(Map, Map, Filter, boolean, boolean, Comparator) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Generic implementation of theQueryMapAPI.
- Query - Interface in com.tangosol.coherence.rest.query
- 
Defines an interface that Query implementations must support.
- QueryBuilder() - Constructor for class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- QueryConfig - Class in com.tangosol.coherence.rest.config
- 
Holder for query configuration.
- QueryConfig() - Constructor for class com.tangosol.coherence.rest.config.QueryConfig
- QueryContext - Interface in com.tangosol.util
- 
The QueryContext provides an execution context to server-side agents during query execution.
- QueryEngine - Interface in com.tangosol.coherence.rest.query
- 
The QueryEngine interface provides a pluggable mechanism for producing queries that can be executed against a NamedCache.
- QueryEngineConfig - Class in com.tangosol.coherence.rest.config
- 
Holder forQueryEngineconfiguration.
- QueryEngineConfig(String, Class) - Constructor for class com.tangosol.coherence.rest.config.QueryEngineConfig
- 
Construct a QueryEngineConfig.
- QueryEngineRegistry - Class in com.tangosol.coherence.rest.query
- 
A registry forQueryEngineinstances.
- QueryEngineRegistry() - Constructor for class com.tangosol.coherence.rest.query.QueryEngineRegistry
- 
Construct a QueryEngineRegistry instance.
- QueryEngineRegistry(Collection<? extends QueryEngineConfig>) - Constructor for class com.tangosol.coherence.rest.query.QueryEngineRegistry
- 
Construct a QueryEngineRegistry instance.
- QueryException - Exception in com.tangosol.coherence.rest.query
- 
Query execution specific exception.
- QueryException(String) - Constructor for exception com.tangosol.coherence.rest.query.QueryException
- 
Construct an instance of QueryException.
- QueryException(String, Throwable) - Constructor for exception com.tangosol.coherence.rest.query.QueryException
- 
Construct an instance of QueryException.
- QueryException(Throwable) - Constructor for exception com.tangosol.coherence.rest.query.QueryException
- 
Construct an instance of QueryException.
- QueryExpFilter(Filter<ObjectName>) - Constructor for class com.tangosol.net.management.MBeanHelper.QueryExpFilter
- QueryHelper - Class in com.tangosol.util
- 
QueryHelper is a utility class that provides a set of factory methods used for building instances ofFilterorValueExtractor.
- queryKeys(MBeanAccessor.QueryBuilder.ParsedQuery) - Method in class com.tangosol.net.management.MBeanAccessor
- 
Return a list of MBean ObjectNames determined by the providedMBeanAccessor.QueryBuilder.
- QueryMap<K,V> - Interface in com.tangosol.util
- 
Map with additional query features.
- QueryMap.Entry<K,V> - Interface in com.tangosol.util
- 
A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.
- QueryMapComparator<T> - Interface in com.tangosol.util.comparator
- 
This interface is used by Comparator implementations that can use value extraction optimization exposed by theQueryMap.Entryinterface.
- queryNames(String, Filter<ObjectName>) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Get the names of MBeans controlled by the MBean server that is collocated with thecluster registry.
- queryNames(String, Filter<ObjectName>) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- queryNames(ObjectName, Filter<ObjectName>) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Get the names of MBeans controlled by the MBean server that is collocated with thecluster registry.
- queryNames(ObjectName, Filter<ObjectName>) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- QueryPlus - Class in com.tangosol.coherence.dslquery
- 
QueryPlus implements a simple command line processor for a sql like language.
- QueryPlus(QueryPlus.Dependencies) - Constructor for class com.tangosol.coherence.dslquery.QueryPlus
- 
Create a QueryPlus instance that uses the specifiedQueryPlus.Dependencies.
- QueryPlus.DefaultDependencies - Class in com.tangosol.coherence.dslquery
- 
A default implementation ofQueryPlus.Dependencies.
- QueryPlus.Dependencies - Interface in com.tangosol.coherence.dslquery
- 
The Dependencies for QueryPlus.
- QueryPlus.DependenciesHelper - Class in com.tangosol.coherence.dslquery
- 
The DependenciesHelper provides helper method for constructingQueryPlus.Dependenciesimplementations forQueryPlus.
- QueryRecord - Interface in com.tangosol.util
- 
The QueryRecord object carries information regarding the estimated or actual execution cost for a query operation.
- QueryRecord.PartialResult - Interface in com.tangosol.util
- 
A QueryRecord.PartialResult is a partial query record that contains recorded costs for a query operation.
- QueryRecord.PartialResult.ExplainStep - Interface in com.tangosol.util
- 
A QueryRecord.ExplainStep is aQueryRecord.PartialResult.RecordableStepthat provides the ability to record the estimated cost of evaluating a filter as part of a query operation.
- QueryRecord.PartialResult.IndexLookupRecord - Interface in com.tangosol.util
- 
An IndexLookupRecord holds the recorded information about an index lookup performed during filter evaluation as part of a query record.
- QueryRecord.PartialResult.RecordableStep - Interface in com.tangosol.util
- 
A QueryRecord.RecordableStep is astepthat provides the ability to record the cost of evaluating a filter as part of a query operation.
- QueryRecord.PartialResult.Step - Interface in com.tangosol.util
- 
A QueryRecord.Step carries the recorded cost of evaluating a filter as part of a query operation.
- QueryRecord.PartialResult.TraceStep - Interface in com.tangosol.util
- 
A QueryRecord.TraceStep is aQueryRecord.PartialResult.RecordableStepthat provides the ability to record the information associated with the actual cost of evaluating a filter as part of a query operation.
- QueryRecorder<K,V> - Class in com.tangosol.util.aggregator
- 
This aggregator is used to produce aQueryRecordobject that contains an estimated or actual cost of the query execution for a given filter.
- QueryRecorder() - Constructor for class com.tangosol.util.aggregator.QueryRecorder
- 
Default constructor (necessary for the ExternalizableLite interface).
- QueryRecorder(QueryRecorder.RecordType) - Constructor for class com.tangosol.util.aggregator.QueryRecorder
- 
Construct a QueryRecorder.
- QueryRecorder.RecordType - Enum in com.tangosol.util.aggregator
- 
RecordType enum specifies whether theQueryRecordershould be used to produce aQueryRecordobject that contains an estimated or an actual cost of the query execution.
- QueryRecorderFilter<T> - Interface in com.tangosol.util.filter
- 
QueryRecorderFilter is an extension of EntryFilter that allows the projected or actual costs of query execution to be recorded.
- QueryRecorderStatement(String, Filter, QueryRecorder.RecordType) - Constructor for class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder.QueryRecorderStatement
- 
Construct a QueryRecorderStatement that produces a plan or trace of the specified filter query against the specified cache.
- QueryRecorderStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aQueryRecorderStatementBuilder.QueryRecorderStatement.
- QueryRecorderStatementBuilder(QueryRecorder.RecordType) - Constructor for class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
- 
Construct a QueryRecorderStatementBuilder of the specified type.
- QueryRecorderStatementBuilder.QueryRecorderStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "QueryRecorder" command.
- Queue() - Constructor for class com.tangosol.net.LoadBalancer.Queue
- 
Construct a queue.
- QueueDaemon() - Constructor for class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Construct a queue daemon to process pending writes.
- quiesceThenStop() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Requests theFiniteStateMachineto stop accepting newEvents to process, wait for any existing queuedEvents to be processed and then stop.
- QuorumListener() - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumListener
- QuorumRule(int, int) - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Construct a state with the specified threshold and numeric representation.
- QuorumRule(int, int, float) - Constructor for class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Construct a state with the specified threshold and numeric representation.
- QuorumRule(String, int, int, float, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
- 
ConstructsActionPolicyBuilder.QuorumRule
- QuorumRule(String, int, int, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
- 
ConstructsActionPolicyBuilder.QuorumRule
- quote(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Create an escape-sequence string that allows for special characters to be included in a JMX ObjectName.
- quote(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
XML quote the passed string.
- quote(String, boolean) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Create an escape-sequence string that allows for special characters to be included in a JMX ObjectName.
- quoteCanonical(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Return a quotedKeyPropertyStringor a quoted canonical name.
R
- RACK_SAFE - com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
The cluster nodes running on a rack can be stopped simultaneously without any data loss.
- RACK_SAFE - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Rack-safety (members are on different racks).
- RAMJOURNAL - Static variable in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
A Ram Journal backup storage.
- RamJournalScheme - Class in com.tangosol.coherence.config.scheme
- 
TheRamJournalSchemeis used to create an instance of a Ram Journal map.
- RamJournalScheme() - Constructor for class com.tangosol.coherence.config.scheme.RamJournalScheme
- RANDOM - Static variable in class com.tangosol.coherence.config.builder.ReadLocatorBuilder
- 
A BiFunction implementation that returns a random member of the ownership chain.
- RANDOM - Static variable in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
Random number generator.
- RANDOM_BACKUP - Static variable in class com.tangosol.coherence.config.builder.ReadLocatorBuilder
- 
A BiFunction implementation that returns a random backup member of the ownership chain.
- randomize(int[]) - Static method in class com.oracle.coherence.common.base.Randoms
- 
Randomize the order of the elements within the passed array.
- randomize(int[]) - Static method in class com.tangosol.util.Base
- 
Randomize the order of the elements within the passed array.
- randomize(long[]) - Static method in class com.oracle.coherence.common.base.Randoms
- 
Randomize the order of the elements within the passed array.
- randomize(long[]) - Static method in class com.tangosol.util.Base
- 
Randomize the order of the elements within the passed array.
- randomize(Object[]) - Static method in class com.oracle.coherence.common.base.Randoms
- 
Randomize the order of the elements within the passed array.
- randomize(Object[]) - Static method in class com.tangosol.util.Base
- 
Randomize the order of the elements within the passed array.
- randomize(Collection) - Static method in class com.oracle.coherence.common.base.Randoms
- 
Randomize the order of the elements within the passed collection.
- randomize(Collection) - Static method in class com.tangosol.util.Base
- 
Randomize the order of the elements within the passed collection.
- Randoms - Class in com.oracle.coherence.common.base
- 
Class for providing random functionality.
- Randoms() - Constructor for class com.oracle.coherence.common.base.Randoms
- rangeCheck(int) - Method in class com.tangosol.util.CircularArrayList
- 
Check if the given index is in range.
- RawDate - Class in com.tangosol.io.pof
- 
An immutable POF date value.
- RawDate(int, int, int) - Constructor for class com.tangosol.io.pof.RawDate
- 
Construct a raw POF date value.
- RawDateTime - Class in com.tangosol.io.pof
- 
An immutable POF date-time value.
- RawDateTime(RawDate, RawTime) - Constructor for class com.tangosol.io.pof.RawDateTime
- 
Construct a date-time value.
- RawDayTimeInterval - Class in com.tangosol.io.pof
- 
An immutable POF day-time interval value.
- RawDayTimeInterval(int, int, int, int, int) - Constructor for class com.tangosol.io.pof.RawDayTimeInterval
- 
Construct a raw POF day-time interval value.
- RawQuad - Class in com.tangosol.io.pof
- 
An immutable POF 128-bit float.
- RawQuad(double) - Constructor for class com.tangosol.io.pof.RawQuad
- 
Construct a RawQuad from a double.
- RawQuad(Binary) - Constructor for class com.tangosol.io.pof.RawQuad
- 
Construct a RawQuad from the raw binary data.
- RawQuad(BigInteger, int) - Constructor for class com.tangosol.io.pof.RawQuad
- 
Construct a RawQuad from an unscaled integer value and a scale.
- RawTime - Class in com.tangosol.io.pof
- 
An immutable POF time value.
- RawTime(int, int, int, int, boolean) - Constructor for class com.tangosol.io.pof.RawTime
- 
Construct a raw POF time value.
- RawTime(int, int, int, int, int, int) - Constructor for class com.tangosol.io.pof.RawTime
- 
Construct a raw POF time value with a timezone.
- RawTimeInterval - Class in com.tangosol.io.pof
- 
An immutable POF time interval value.
- RawTimeInterval(int, int, int, int) - Constructor for class com.tangosol.io.pof.RawTimeInterval
- 
Construct a raw POF time interval value.
- RawYearMonthInterval - Class in com.tangosol.io.pof
- 
An immutable POF year-month interval value.
- RawYearMonthInterval(int, int) - Constructor for class com.tangosol.io.pof.RawYearMonthInterval
- 
Construct a raw POF year-month interval value.
- read() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Read the next byte of data from the InputStream.
- read() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read the next byte of data from the InputStream.
- read() - Method in class com.tangosol.io.Base64InputStream
- 
Reads the next byte of data from the input stream.
- read() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read the next byte of data from the InputStream.
- read() - Method in class com.tangosol.io.MultiByteArrayInputStream
- 
Reads the next byte of data from the input stream.
- read() - Method in class com.tangosol.io.nio.ByteBufferInputStream
- 
Reads the next byte of data from the input stream.
- read() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read the next byte of data from the InputStream.
- read() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read the next byte of data from the InputStream.
- read() - Method in class com.tangosol.io.Utf8Reader
- 
Read a single character.
- read() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read the next byte of data from the InputStream.
- read() - Method in class com.tangosol.io.WrapperInputStream
- 
Read the next byte of data from the InputStream.
- read() - Method in class com.tangosol.io.WrapperObjectInputStream
- 
Read the next byte of data from the InputStream.
- read() - Method in class com.tangosol.net.CompressionFilter.InflaterInputShell
- 
Deprecated.Overrides the underlyingInflaterInputStream.read()implementation making the known bug fix in JDK 1.4.1 ( "InflaterInputStream is very memory inefficient") retroactive for prior JDKs.
- read() - Method in class com.tangosol.util.NullImplementation.NullReader
- read(byte[]) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read some number of bytes from the input stream and store them into the passed arrayab.
- read(byte[]) - Method in class com.tangosol.io.pof.PofInputStream
- 
Read some number of bytes from the input stream and store them into the passed arrayab.
- read(byte[]) - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read some number of bytes from the input stream and store them into the passed arrayab.
- read(byte[]) - Method in class com.tangosol.io.WrapperInputStream
- 
Read some number of bytes from the input stream and store them into the passed arrayab.
- read(byte[]) - Method in class com.tangosol.io.WrapperObjectInputStream
- 
Read some number of bytes from the input stream and store them into the passed arrayab.
- read(byte[], int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Read up tocbbytes from the input stream and store them into the passed arrayabstarting at offsetof.
- read(byte[], int, int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read up tocbbytes from the input stream and store them into the passed arrayabstarting at offsetof.
- read(byte[], int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read up tocbbytes from the input stream and store them into the passed arrayabstarting at offsetof.
- read(byte[], int, int) - Method in class com.tangosol.io.MultiByteArrayInputStream
- 
Reads up tolenbytes of data from the input stream into an array of bytes.
- read(byte[], int, int) - Method in class com.tangosol.io.nio.ByteBufferInputStream
- 
Reads up tolenbytes of data from the input stream into an array of bytes.
- read(byte[], int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read up tocbbytes from the input stream and store them into the passed arrayabstarting at offsetof.
- read(byte[], int, int) - Method in class com.tangosol.io.pof.PofInputStream
- 
Read up tocbbytes from the input stream and store them into the passed arrayabstarting at offsetof.
- read(byte[], int, int) - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read up tocbbytes from the input stream and store them into the passed arrayabstarting at offsetof.
- read(byte[], int, int) - Method in class com.tangosol.io.WrapperInputStream
- 
Read up tocbbytes from the input stream and store them into the passed arrayabstarting at offsetof.
- read(byte[], int, int) - Method in class com.tangosol.io.WrapperObjectInputStream
- 
Read up tocbbytes from the input stream and store them into the passed arrayabstarting at offsetof.
- read(char[]) - Method in class com.tangosol.io.Utf8Reader
- 
Read characters into an array.
- read(char[]) - Method in class com.tangosol.util.NullImplementation.NullReader
- read(char[], int, int) - Method in class com.tangosol.io.Utf8Reader
- 
Read characters into a portion of an array.
- read(char[], int, int) - Method in class com.tangosol.util.NullImplementation.NullReader
- read(DataInput) - Static method in class com.oracle.coherence.common.base.Reads
- 
Read the contents out of the passed stream and return the result as a byte array.
- read(DataInput) - Static method in class com.tangosol.util.Base
- 
Read the contents out of the passed stream and return the result as a byte array.
- read(DataInputStream) - Static method in class com.oracle.coherence.common.base.Reads
- 
Read the contents out of the passed stream and return the result as a byte array.
- read(DataInputStream) - Static method in class com.tangosol.util.Base
- 
Read the contents out of the passed stream and return the result as a byte array.
- read(File) - Static method in class com.oracle.coherence.common.base.Reads
- 
Read the contents out of the specified file and return the result as a byte array.
- read(File) - Static method in class com.tangosol.util.Base
- 
Read the contents out of the specified file and return the result as a byte array.
- read(InputStream) - Static method in class com.oracle.coherence.common.base.Reads
- 
Read the contents out of the passed stream and return the result as a byte array.
- read(InputStream) - Static method in class com.tangosol.util.Base
- 
Read the contents out of the passed stream and return the result as a byte array.
- read(InputStream, byte[]) - Static method in class com.oracle.coherence.common.base.Reads
- 
Read the contents out of the passed stream into the passed byte array and return the length read.
- read(InputStream, byte[]) - Static method in class com.tangosol.util.Base
- 
Read the contents out of the passed stream into the passed byte array and return the length read.
- read(Reader) - Static method in class com.oracle.coherence.common.base.Reads
- 
Read the contents out of the passed Reader and return the result as a String.
- read(Reader) - Static method in class com.tangosol.util.Base
- 
Read the contents out of the passed Reader and return the result as a String.
- read(String, ReadBuffer.BufferInput) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Read the PersistenceStore associated with the specified identifier from the given input stream, making it available to this manager.
- read(String, ReadBuffer.BufferInput) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Read the PersistenceStore associated with the specified identifier from the given input stream, making it available to this manager.
- read(String, ReadBuffer.BufferInput) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Read the PersistenceStore associated with the specified identifier from the given input stream, making it available to this manager.
- read(String, InputStream) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Read the PersistenceStore associated with the specified identifier from the given input stream, making it available to this manager.
- read(String, InputStream) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Read the PersistenceStore associated with the specified identifier from the given input stream, making it available to this manager.
- read(URL) - Static method in class com.oracle.coherence.common.base.Reads
- 
Read the contents of the specified URL and return the result as a byte array.
- read(URL) - Static method in class com.tangosol.util.Base
- 
Read the contents of the specified URL and return the result as a byte array.
- read(CharBuffer) - Method in class com.tangosol.util.NullImplementation.NullReader
- READ - com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- READ - Static variable in interface com.tangosol.net.CacheService.CacheAction
- 
Singleton action for cache reads.
- ReadableEntrySetMap() - Constructor for class com.tangosol.io.pof.PofHelper.ReadableEntrySetMap
- 
Create a new ReadableEntrySetMap.
- readArray(int, IntFunction<T[]>) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read an array of values.
- readArray(int, IntFunction<T[]>) - Method in interface com.tangosol.io.pof.PofReader
- 
Read an array of values.
- readArray(DataInput, int) - Method in class com.tangosol.run.xml.ArrayAdapter
- 
Read an array of specified length from the passed DataInput object.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Read an array of primitive values.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Read an array of primitive values.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Read an array of primitive values.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Read an array of primitive values.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Read an array of primitive values.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Read an array of primitive values.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Read an array of primitive values.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Read an array of primitive values.
- readArray(Iterator, XmlElement, boolean) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Read an array of primitive values.
- readAsBigDecimal(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a value of the specified encoding from the POF stream and convert it to a BigDecimal.
- readAsBigInteger(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a value of the specified encoding from the POF stream and convert it to a BigInteger.
- readAsChar(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a value of the specified encoding from the POF stream and convert it to a char.
- readAsDouble(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a value of the specified encoding from the POF stream and convert it to a double.
- readAsFloat(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a value of the specified encoding from the POF stream and convert it to a float.
- readAsInt(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a value of the specified encoding from the POF stream and convert it to an integer.
- readAsLong(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a value of the specified encoding from the POF stream and convert it to a long.
- readAsObject(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a POF value as an Object.
- readAsObjectArray(int, int, Object[]) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a POF value as an Object array.
- readAsQuad(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a value of the specified encoding from the POF stream and convert it to a quad.
- readAsTypedObjectArray(int, int, IntFunction<T[]>) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a POF value as an Object array.
- readAsUniformObject(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a POF value in a uniform array/map as an Object.
- readBigDecimal(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a BigDecimal from the POF stream.
- readBigDecimal(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a BigDecimal from the POF stream.
- readBigDecimal(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read an IEEE754 value from the passed DataInput and convert it to a Java BigDecimal.
- readBigDecimal(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a BigDecimal from a DataInput stream.
- readBigInteger(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a BigInteger from the POF stream.
- readBigInteger(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a BigInteger from the POF stream.
- readBigInteger(DataInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a BigInteger value from the passed DataInput.
- readBigInteger(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a BigInteger from a DataInput stream.
- readBinary(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a Binary from the POF stream.
- readBinary(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a Binary from the POF stream.
- readBinary(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofBufferReader
- 
Read a Binary object from the specified BufferInput in an optimal way, depending on the existence of an enclosing ReadBuffer.
- readBinary(DataInput) - Static method in class com.tangosol.util.Binary
- 
Read a Binary from the specified DataInput.
- readBinary(DataInputStream) - Static method in class com.tangosol.util.Binary
- 
Read a Binary from the specified DataInputStream.
- readBinary(File) - Static method in class com.tangosol.util.Binary
- 
Read a Binary from the specified File.
- readBinary(InputStream) - Static method in class com.tangosol.util.Binary
- 
Read a Binary from the specified InputStream.
- readBinary(InputStream, int) - Static method in class com.tangosol.util.Binary
- 
Read a Binary from the specified InputStream.
- readBinary(URL) - Static method in class com.tangosol.util.Binary
- 
Read a Binary from the specified URL.
- readBinary(FileChannel, long, int, byte[]) - Static method in class com.tangosol.util.Binary
- 
Read a Binary of the specified length at the specified offset from the specified FileChannel.
- readBoolean() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a boolean value.
- readBoolean() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read a boolean value.
- readBoolean() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read a boolean value.
- readBoolean() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a boolean value.
- readBoolean() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read a boolean value.
- readBoolean(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a boolean property from the POF stream.
- readBoolean(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a boolean property from the POF stream.
- readBooleanArray(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a boolean[] property from the POF stream.
- readBooleanArray(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a boolean[] property from the POF stream.
- readBooleanArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a packed boolean array.
- readBooleanArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read the specified number of booleans from a boolean array.
- readBuffer(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Readcbbytes and return them as a ReadBuffer object.
- readBuffer(int) - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Readcbbytes and return them as a ReadBuffer object.
- readBuffer(int) - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Readcbbytes and return them as a ReadBuffer object.
- readBuffer(int) - Method in class com.tangosol.io.WrapperBufferInput
- 
Readcbbytes and return them as a ReadBuffer object.
- ReadBuffer - Interface in com.tangosol.io
- 
The ReadBuffer interface represents an in-memory block of binary data, such as that represented by a byte[], a Binary object, or an NIO buffer.
- ReadBuffer.BufferInput - Interface in com.tangosol.io
- 
The BufferInput interface represents a DataInputStream on top of a ReadBuffer.
- readByte() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Read a byte value.
- readByte() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a byte value.
- readByte() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read a byte value.
- readByte() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read a byte value.
- readByte() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read a byte value.
- readByte() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read a byte value.
- readByte() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a byte value.
- readByte() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read a byte value.
- readByte(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a byte property from the POF stream.
- readByte(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a byte property from the POF stream.
- readByteArray(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a byte[] property from the POF stream.
- readByteArray(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a byte[] property from the POF stream.
- readByteArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a variable-length encoded byte array.
- readChar() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a char value.
- readChar() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read a char value.
- readChar() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read a char value.
- readChar() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read a char value.
- readChar() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read a char value.
- readChar() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a char value.
- readChar() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read a char value.
- readChar(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a char property from the POF stream.
- readChar(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a char property from the POF stream.
- readChar(DataInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a "char" value from the passed DataInput.
- readCharArray(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a char[] property from the POF stream.
- readCharArray(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a char[] property from the POF stream.
- readCharArray(Utf8Reader, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of char for the specified length from the reader.
- readCharArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a char array.
- readCollection(int, C) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a Collection of object values from the POF stream.
- readCollection(int, C) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a Collection of object values from the POF stream.
- readCollection(DataInput, Collection, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read collection content from a DataInput stream and update the specified collection.
- readDate(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a java.util.Date from the POF stream.
- readDate(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a java.util.Date from the POF stream.
- readDate(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a Date from a DataInput stream.
- readDouble() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a double value.
- readDouble() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read a double value.
- readDouble() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read a double value.
- readDouble() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read a double value.
- readDouble() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read a double value.
- readDouble() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a double value.
- readDouble() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read a double value.
- readDouble(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a double property from the POF stream.
- readDouble(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a double property from the POF stream.
- readDoubleArray(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a double[] property from the POF stream.
- readDoubleArray(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a double[] property from the POF stream.
- readDoubleArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of double numbers from a DataInput stream.
- readDoubleArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of the specified number of doubles from a DataInput stream.
- readElements(XmlElement) - Method in class com.tangosol.run.xml.ArrayAdapter
- readElements(XmlElement) - Method in class com.tangosol.run.xml.CollectionAdapter
- readElements(XmlElement) - Method in class com.tangosol.run.xml.IterableAdapter
- readElements(XmlElement) - Method in class com.tangosol.run.xml.MapAdapter
- readElements(XmlElement) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- readExternal(PofReader) - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- readExternal(PofReader) - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- readExternal(PofReader) - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.config.ParameterMacroExpression
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.config.ResolvableParameterList
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.config.SimpleParameterList
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- readExternal(PofReader) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
- readExternal(PofReader) - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.coherence.rest.util.StaticContent
- readExternal(PofReader) - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.config.expression.ChainedParameterResolver
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.config.expression.LiteralExpression
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.config.expression.NullParameterResolver
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.config.expression.Parameter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.config.expression.ScopedParameterResolver
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.config.expression.ValueMacroExpression
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in exception com.tangosol.io.pof.PortableException
- readExternal(PofReader) - Method in interface com.tangosol.io.pof.PortableObject
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.io.pof.reflect.SimplePofPath
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.net.AbstractPriorityTask
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- readExternal(PofReader) - Method in class com.tangosol.net.partition.Ownership
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.net.partition.PartitionSet
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.net.partition.SimplePartitionKey
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.net.partition.VersionedOwnership
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in exception com.tangosol.net.RequestIncompleteException
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in exception com.tangosol.net.RequestPolicyException
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.net.security.PermissionInfo
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Publisher.FailOnFull
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Publisher.OrderById
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Publisher.OrderByNone
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Publisher.OrderByThread
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Publisher.OrderByValue
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Subscriber.Convert
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Subscriber.Filtered
- readExternal(PofReader) - Method in class com.tangosol.net.topic.Subscriber.Name
- readExternal(PofReader) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.run.xml.SimpleElement
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.run.xml.SimpleValue
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.AbstractScript
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.Count
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.GroupAggregator
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.PriorityAggregator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.QueryRecorder
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.ScriptAggregator
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- readExternal(PofReader) - Method in class com.tangosol.util.aggregator.TopNAggregator
- readExternal(PofReader) - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.comparator.EntryComparator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.comparator.ExtractorComparator
- readExternal(PofReader) - Method in class com.tangosol.util.comparator.SafeComparator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.CompositeKey
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.ChainedExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.ChainedFragmentExtractor
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.CompositeUpdater
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.EntryExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.FragmentExtractor
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.IdentityExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.KeyExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.PofExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.PofUpdater
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.ScriptValueExtractor
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.CacheEventFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.ExtractorFilter
- readExternal(PofReader) - Method in class com.tangosol.util.filter.FilterTrigger
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.InFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.LikeFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.LimitFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.MapEventFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.NeverFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.NotFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.PredicateFilter
- readExternal(PofReader) - Method in class com.tangosol.util.filter.PresentFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.PriorityFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- readExternal(PofReader) - Method in class com.tangosol.util.Fragment
- readExternal(PofReader) - Method in class com.tangosol.util.MapEvent
- readExternal(PofReader) - Method in class com.tangosol.util.NullFilter
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.NullImplementation.NullEntryProcessor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.NullImplementation.NullMap
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.CompositeProcessor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.ConditionalPut
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.ExtractorProcessor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- readExternal(PofReader) - Method in class com.tangosol.util.processor.NumberIncrementor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.NumberMultiplier
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.PreloadRequest
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.PriorityProcessor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.TouchProcessor
- readExternal(PofReader) - Method in class com.tangosol.util.processor.UpdaterProcessor
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.VersionedPut
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.SimpleHolder
- readExternal(PofReader) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.SimpleQueryRecord
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.transformer.SamplingEventTransformer
- readExternal(PofReader) - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
- readExternal(PofReader) - Method in class com.tangosol.util.UID
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(PofReader) - Method in class com.tangosol.util.UUID
- 
Restore the contents of a user type instance by reading its state using the specified PofReader object.
- readExternal(DataInput) - Method in class com.oracle.coherence.concurrent.atomic.Atomics.SerializableAtomicMarkableReference
- readExternal(DataInput) - Method in class com.oracle.coherence.concurrent.atomic.Atomics.SerializableAtomicStampedReference
- readExternal(DataInput) - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- readExternal(DataInput) - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- readExternal(DataInput) - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.coherence.config.ParameterMacroExpression
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.coherence.config.ResolvableParameterList
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.coherence.config.SimpleParameterList
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
read from datainput
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- readExternal(DataInput) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
- readExternal(DataInput) - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.coherence.rest.util.StaticContent
- readExternal(DataInput) - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.config.expression.ChainedParameterResolver
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.config.expression.LiteralExpression
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.config.expression.NullParameterResolver
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.config.expression.Parameter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.config.expression.ScopedParameterResolver
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.config.expression.ValueMacroExpression
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in interface com.tangosol.io.ExternalizableLite
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.io.pof.EvolvableHolder
- readExternal(DataInput) - Method in class com.tangosol.io.pof.reflect.SimplePofPath
- readExternal(DataInput) - Method in class com.tangosol.net.AbstractPriorityTask
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- readExternal(DataInput) - Method in class com.tangosol.net.partition.Ownership
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.net.partition.PartitionSet
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.net.partition.SimplePartitionKey
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.net.partition.VersionedOwnership
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Publisher.FailOnFull
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Publisher.OrderById
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Publisher.OrderByNone
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Publisher.OrderByThread
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Publisher.OrderByValue
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Subscriber.Convert
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Subscriber.Filtered
- readExternal(DataInput) - Method in class com.tangosol.net.topic.Subscriber.Name
- readExternal(DataInput) - Method in class com.tangosol.run.xml.ArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.CollectionAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.DateTimeAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.MapAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.RestrictedStringAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SerializableAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.BigDecimalAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.BigIntegerAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.BooleanAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.ByteAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.CharAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.DateAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.DoubleAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.FloatAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.IntAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.LongAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.ShortAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.StringAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.TimeAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleElement
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.SimpleValue
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.XmlBean
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.XmlElementAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.run.xml.XmlSerializableAdapter
- 
Read a value from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.AbstractScript
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.Count
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.GroupAggregator
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.PriorityAggregator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.QueryRecorder
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.ScriptAggregator
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- readExternal(DataInput) - Method in class com.tangosol.util.aggregator.TopNAggregator
- readExternal(DataInput) - Method in class com.tangosol.util.Binary
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.comparator.EntryComparator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.comparator.ExtractorComparator
- readExternal(DataInput) - Method in class com.tangosol.util.comparator.SafeComparator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.CompositeKey
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.ChainedExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.ChainedFragmentExtractor
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.CompositeUpdater
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.EntryExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.FragmentExtractor
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.IdentityExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.KeyExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.ScriptValueExtractor
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.CacheEventFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.ExtractorFilter
- readExternal(DataInput) - Method in class com.tangosol.util.filter.FilterTrigger
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.LikeFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.LimitFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.MapEventFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.NeverFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.NotFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.PredicateFilter
- readExternal(DataInput) - Method in class com.tangosol.util.filter.PresentFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.PriorityFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- readExternal(DataInput) - Method in class com.tangosol.util.Fragment
- readExternal(DataInput) - Method in class com.tangosol.util.ImmutableArrayList
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.LiteMap
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.LiteSet
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.MapSet
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.NullFilter
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.NullImplementation.NullEntryProcessor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.NullImplementation.NullMap
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.CompositeProcessor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.ConditionalPut
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.ExtractorProcessor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- readExternal(DataInput) - Method in class com.tangosol.util.processor.NumberIncrementor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.NumberMultiplier
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.PreloadRequest
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.PriorityProcessor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.TouchProcessor
- readExternal(DataInput) - Method in class com.tangosol.util.processor.UpdaterProcessor
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.VersionedPut
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.SimpleHolder
- readExternal(DataInput) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.SimpleQueryRecord
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.transformer.SamplingEventTransformer
- readExternal(DataInput) - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
- readExternal(DataInput) - Method in class com.tangosol.util.UID
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(DataInput) - Method in class com.tangosol.util.UUID
- 
Restore the contents of this object by loading the object's state from the passed DataInput object.
- readExternal(ObjectInput) - Method in class com.tangosol.net.security.PermissionInfo
- readExternal(ObjectInput) - Method in class com.tangosol.run.xml.SimpleDocument
- 
The object implements the readExternal method to restore its contents by calling the methods of DataInput for primitive types and readObject for objects, strings and arrays.
- readExternal(ObjectInput) - Method in class com.tangosol.run.xml.XmlBean
- 
The object implements the readExternal method to restore its contents by calling the methods of DataInput for primitive types and readObject for objects, strings and arrays.
- readExternal(ObjectInput) - Method in class com.tangosol.util.Binary
- 
The object implements the readExternal method to restore its contents by calling the methods of DataInput for primitive types and readObject for objects, strings and arrays.
- readExternal(ObjectInput) - Method in class com.tangosol.util.LiteSet
- 
Initialize this object from the data in the passed ObjectInput stream.
- readExternal(ObjectInput) - Method in class com.tangosol.util.MapSet
- 
Initialize this object from the contents of the passed object stream.
- readExternal(ObjectInput) - Method in class com.tangosol.util.UUID
- 
Read this object from an ObjectInputStream.
- readExternalizableLite(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an ExternalizableLite object from a DataInput stream.
- readExternalizableLite(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an ExternalizableLite object from a DataInput stream.
- readFloat() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a float value.
- readFloat() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read a float value.
- readFloat() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read a float value.
- readFloat() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read a float value.
- readFloat() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read a float value.
- readFloat() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a float value.
- readFloat() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read a float value.
- readFloat(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a float property from the POF stream.
- readFloat(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a float property from the POF stream.
- readFloatArray(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a float[] property from the POF stream.
- readFloatArray(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a float[] property from the POF stream.
- readFloatArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of float numbers from a DataInput stream.
- readFloatArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of the specified number of floats from a DataInput stream.
- readFully(byte[]) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Readab.lengthbytes and store them inab.
- readFully(byte[]) - Method in class com.tangosol.io.PackedDataInputStream
- 
Readab.lengthbytes and store them inab.
- readFully(byte[]) - Method in class com.tangosol.io.pof.PofInputStream
- 
Readab.lengthbytes and store them inab.
- readFully(byte[]) - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Readab.lengthbytes and store them inab.
- readFully(byte[]) - Method in class com.tangosol.io.WrapperDataInputStream
- 
Readab.lengthbytes and store them inab.
- readFully(byte[], int, int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Readcbbytes and store them inabstarting at offsetof.
- readFully(byte[], int, int) - Method in class com.tangosol.io.PackedDataInputStream
- 
Readcbbytes and store them inabstarting at offsetof.
- readFully(byte[], int, int) - Method in class com.tangosol.io.pof.PofInputStream
- 
Readcbbytes and store them inabstarting at offsetof.
- readFully(byte[], int, int) - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Readcbbytes and store them inabstarting at offsetof.
- readFully(byte[], int, int) - Method in class com.tangosol.io.WrapperDataInputStream
- 
Readcbbytes and store them inabstarting at offsetof.
- readHeader() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Read a block's header data from the Buffer.
- ReadHeavyLongArray<V> - Class in com.tangosol.util
- 
A thread-safe LongArray implementation for read heavy workloads but which is also efficient with frequent and/or bursty writes.
- ReadHeavyLongArray() - Constructor for class com.tangosol.util.ReadHeavyLongArray
- 
Construct a ReadHeavyLongArray.
- ReadHeavyLongArray(LongArray<V>) - Constructor for class com.tangosol.util.ReadHeavyLongArray
- 
Construct a ReadHeavyLongArray around the specified delegate.
- readInt() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Read an int value.
- readInt() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read an int value.
- readInt() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read an int value.
- readInt() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read an int value.
- readInt() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read an int value.
- readInt() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read an int value.
- readInt() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read an int value.
- readInt() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read an int value.
- readInt(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a int property from the POF stream.
- readInt(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a int property from the POF stream.
- readInt(ReadBuffer.BufferInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an int that uses variable length storage in the buffer.
- readInt(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an int that uses variable length storage in the stream.
- readIntArray(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a int[] property from the POF stream.
- readIntArray(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a int[] property from the POF stream.
- readIntArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of int numbers from a DataInput stream which use fixed-length 4-byte Big Endian binary format.
- readIntArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of the specified number of int from a DataInput stream.
- readIntArray2d(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a 2-dimensional int-array from the stream.
- readKey() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Read the "key" portion of an Entry block.
- readLargeArray(DataInput, int) - Method in class com.tangosol.run.xml.ArrayAdapter
- 
Read an array of property data with length larger thanExternalizableHelper.CHUNK_THRESHOLD>> 4.
- readLargeBooleanArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a boolean array with length larger thanExternalizableHelper.CHUNK_THRESHOLD.
- readLargeByteArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read byte array with length larger thanExternalizableHelper.CHUNK_THRESHOLD.
- readLargeCharArray(Utf8Reader, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of char for the specified length from the reader.
- readLargeDoubleArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a double array with length larger thanExternalizableHelper.CHUNK_THRESHOLD>> 3.
- readLargeFloatArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a float array with length larger thanExternalizableHelper.CHUNK_THRESHOLD>> 2.
- readLargeIntArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of ints with length larger thanExternalizableHelper.CHUNK_THRESHOLD>> 2.
- readLargeLongArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of longs with length larger thanExternalizableHelper.CHUNK_THRESHOLD>> 3.
- readLargeObjectArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of objects with length larger thanExternalizableHelper.CHUNK_THRESHOLD>> 4.
- readLargeStringArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read array of string with length larger than thresholdExternalizableHelper.CHUNK_THRESHOLD>> 3.
- ReadLatch(Object) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.ReadLatch
- 
Create a new ReadLatch for the specified key.
- readLine() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Reads the next "line" of text.
- readLine() - Method in class com.tangosol.io.PackedDataInputStream
- 
Reads the next "line" of text.
- readLine() - Method in class com.tangosol.io.pof.PofInputStream
- 
Reads the next "line" of text.
- readLine() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Reads the next "line" of text.
- readLine() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Reads the next "line" of text.
- readLocalDate(int) - Method in class com.tangosol.io.pof.PofBufferReader
- readLocalDate(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a java.time.LocalDate from the POF stream.
- readLocalDate(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a LocalDate value from a POF stream.
- readLocalDateTime(int) - Method in class com.tangosol.io.pof.PofBufferReader
- readLocalDateTime(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a java.time.LocalDateTime from the POF stream.
- readLocalDateTime(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a LocalDateTime value from a POF stream.
- readLocalTime(int) - Method in class com.tangosol.io.pof.PofBufferReader
- readLocalTime(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a java.time.LocalTime from the POF stream.
- readLocalTime(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a LocalTime value from a POF stream.
- ReadLocatorBuilder - Class in com.tangosol.coherence.config.builder
- 
TheReadLocatorBuilderclass builds aBiFunctionthat given the currentownershipof a partition andservicewill return amemberto target reads against.
- ReadLocatorBuilder() - Constructor for class com.tangosol.coherence.config.builder.ReadLocatorBuilder
- ReadLocatorProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AReadLocatorProcessoris responsible for processing theread-locatorxmlto produce aReadLocatorBuilder.
- ReadLocatorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ReadLocatorProcessor
- readLock() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Returns the lock used for reading.
- ReadLock(RemoteReadWriteLock) - Constructor for class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.ReadLock
- 
Constructor for use by subclasses.
- readLong() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Read a long value.
- readLong() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a long value.
- readLong() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read a long value.
- readLong() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read a long value.
- readLong() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read a long value.
- readLong() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read a long value.
- readLong() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a long value.
- readLong() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read a long value.
- readLong(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a long property from the POF stream.
- readLong(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a long property from the POF stream.
- readLong(ReadBuffer.BufferInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a long that uses variable length storage in the buffer.
- readLong(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a long that uses variable length storage in the stream.
- readLongArray(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a long[] property from the POF stream.
- readLongArray(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a long[] property from the POF stream.
- readLongArray(int, LongArray) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a LongArray of object values.
- readLongArray(int, LongArray<T>) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a LongArray of object values.
- readLongArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of long numbers from a DataInput stream that use fixed-length 8-byte Big Endian binary format.
- readLongArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of the specified number of longs from a DataInput stream.
- readMap(int, M) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a Map of key/value pairs from the POF stream.
- readMap(int, M) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a Map of key/value pairs from the POF stream.
- readMap(DataInput, Map, int, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read map content from a DataInput stream and update the specified map using the "putAll" method.
- readMap(DataInput, Map, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read map content from a DataInput stream and update the specified map.
- readMap(InputStream) - Method in interface com.tangosol.net.management.MapJsonBodyHandler
- 
Read a jsonInputStreamand deserialize into aMap.
- readMetadata(File) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Read persistence metadata from the specified directory.
- readMetadata(File) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Read persistence metadata from the specified directory.
- readNestedCommaSeparatedList(NestedBaseTokens) - Method in class com.tangosol.coherence.dsltools.precedence.OPParser
- 
Build an array of ASTNodes by processing the this tokens nest as a comma separated list.
- readObject() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read and return an object.
- readObject() - Method in class com.tangosol.io.WrapperObjectInputStream
- 
Read and return an object.
- readObject(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a property of any type, including a user type, from the POF stream.
- readObject(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a property of any type, including a user type, from the POF stream.
- readObject(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an Object from the passed DataInput object.
- readObject(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an Object from the passed DataInput object.
- readObjectArray(int, Object[]) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read an array of object values.
- readObjectArray(int, Object[]) - Method in interface com.tangosol.io.pof.PofReader
- 
Deprecated.
- readObjectArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of object from a DataInput stream.
- readObjectArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an array of the specified number of object from a DataInput stream.
- readOffsetDateTime(int) - Method in class com.tangosol.io.pof.PofBufferReader
- readOffsetDateTime(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a java.time.OffsetDateTime from the POF stream.
- readOffsetDateTime(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a OffsetDateTime value from a POF stream.
- readOffsetTime(int) - Method in class com.tangosol.io.pof.PofBufferReader
- readOffsetTime(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a java.time.OffsetTime from the POF stream.
- readOffsetTime(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a OffsetTime value from a POF stream.
- readOldValue() - Method in class com.tangosol.util.AbstractKeyBasedMap.DeferredCacheEvent
- 
Perform a deferred read for the old value in a usage-specific way.
- ReadonlyNamedCache<K,V> - Class in com.tangosol.net.cache
- 
A simple extension of the WrapperNamedCache implementation that shields all content mutating operations such as put(), remove(), lock() etc.
- ReadonlyNamedCache(NamedCache<K, V>, boolean) - Constructor for class com.tangosol.net.cache.ReadonlyNamedCache
- 
Construct a NamedCache wrapper based on the specified map.
- ReadonlyNamedCache(Map<K, V>, String, boolean) - Constructor for class com.tangosol.net.cache.ReadonlyNamedCache
- 
Construct a NamedCache wrapper based on the specified map.
- readPackedInt() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Read an int value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedInt(int).
- readPackedInt() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read an int value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedInt(int).
- readPackedInt() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read an int value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedInt(int).
- readPackedInt() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read an int value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedInt(int).
- readPackedInt() - Method in class com.tangosol.io.WrapperBufferInput
- 
Read an int value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedInt(int).
- readPackedInt(ByteSequence, int) - Static method in class com.tangosol.io.AbstractReadBuffer
- 
Read an int value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedInt(int)from the givenByteSequenceand offset.
- readPackedLong() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Read a long value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedLong(long).
- readPackedLong() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a long value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedLong(long).
- readPackedLong() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read a long value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedLong(long).
- readPackedLong() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a long value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedLong(long).
- readPackedLong() - Method in class com.tangosol.io.WrapperBufferInput
- 
Read a long value using a variable-length storage format as described byWriteBuffer.BufferOutput.writePackedLong(long).
- readQuad(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a quad (a 128-bit base-2 IEEE754 value) from the passed DataInput and convert it to a RawQuad.
- ReadQueue() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Construct a ReadQueue.
- readQuorum(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Read the membership information from the "META" extent.
- readQuorumRaw(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Read the membership information in Binary format from the "META" extent.
- readRawDate(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a RawDate from the POF stream.
- readRawDate(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a RawDate from the POF stream.
- readRawDate(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a RawDate value from a POF stream.
- readRawDateTime(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a RawDateTime from the POF stream.
- readRawDateTime(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a RawDateTime from the POF stream.
- readRawDayTimeInterval(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a RawDayTimeInterval from the POF stream.
- readRawDayTimeInterval(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a RawDayTimeInterval from the POF stream.
- readRawQuad(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a RawQuad from the POF stream.
- readRawQuad(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a RawQuad from the POF stream.
- readRawTime(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a RawTime from the POF stream.
- readRawTime(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a RawTime from the POF stream.
- readRawTime(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Read a RawTime value from a POF stream.
- readRawTimeInterval(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a RawTimeInterval from the POF stream.
- readRawTimeInterval(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a RawTimeInterval from the POF stream.
- readRawYearMonthInterval(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a RawYearMonthInterval from the POF stream.
- readRawYearMonthInterval(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a RawYearMonthInterval from the POF stream.
- readRemainder() - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read all remaining indexed properties of the current user type from the POF stream.
- readRemainder() - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Read all remaining indexed properties of the current user type from the POF stream.
- readRemainder() - Method in interface com.tangosol.io.pof.PofReader
- 
Read all remaining indexed properties of the current user type from the POF stream.
- readResolve() - Method in exception com.tangosol.io.pof.PortableException
- 
Returns the original type, iff the type is a subclass ofPortableException, during deserialization opposed to a newPortableExceptionwith the metadata of the original exception.
- readResolve() - Method in interface com.tangosol.io.SerializationSupport
- 
Designate a replacement for an object after an instance of it is read from the buffer.
- readResolve() - Method in class com.tangosol.util.aggregator.ScriptAggregator
- Reads - Class in com.oracle.coherence.common.base
- 
Class for providing read functionality.
- Reads() - Constructor for class com.oracle.coherence.common.base.Reads
- readSafeUTF() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a variable-length encoded UTF packed String.
- readSafeUTF() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read a variable-length encoded UTF packed String.
- readSafeUTF() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a variable-length encoded UTF packed String.
- readSafeUTF() - Method in class com.tangosol.io.WrapperBufferInput
- 
Read a variable-length encoded UTF packed String.
- readSafeUTF(ReadBuffer.BufferInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a variable-length encoded UTF packed String in the buffer.
- readSafeUTF(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a variable-length encoded UTF packed String.
- readSerializable(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a DataInput stream.
- readSerializable(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an object from a DataInput stream.
- readSerializationHeader(ReadBuffer.BufferInput) - Method in class com.tangosol.io.MultiplexingSerializer
- readShort() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read a short value.
- readShort() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read a short value.
- readShort() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read a short value.
- readShort() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read a short value.
- readShort() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read a short value.
- readShort() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read a short value.
- readShort() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read a short value.
- readShort(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a short property from the POF stream.
- readShort(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a short property from the POF stream.
- readShortArray(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a short[] property from the POF stream.
- readShortArray(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a short[] property from the POF stream.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Read a sparse array of primitive values.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Read a sparse array of primitive values.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Read a sparse array of primitive values.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Read a sparse array of primitive values.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Read a sparse array of primitive values.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Read a sparse array of primitive values.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Read a sparse array of primitive values.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Read a sparse array of primitive values.
- readSparseArray(Iterator, int) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Read a sparse array of primitive values.
- readString(int) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Read a String from the POF stream.
- readString(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a String from the POF stream.
- readStringArray(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a String array.
- readStringArray(DataInput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read array of string for the specified size.
- ReadThread() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.ReadThread
- 
Default constructor.
- readTime(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a Time from a DataInput stream.
- readTimestamp(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a Timestamp from a DataInput stream.
- readTrint(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a signed three-byte integer value from a stream.
- readUnsignedByte() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read an unsigned byte value.
- readUnsignedByte() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read an unsigned byte value.
- readUnsignedByte() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read an unsigned byte value.
- readUnsignedByte() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read an unsigned byte value.
- readUnsignedByte() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read an unsigned byte value.
- readUnsignedByte(ByteSequence, int) - Static method in class com.tangosol.io.AbstractReadBuffer
- 
Read an unsigned byte value from the givenByteSequenceand offset.
- readUnsignedShort() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer.ByteArrayBufferInput
- 
Read an unsigned short value.
- readUnsignedShort() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Read an unsigned short value.
- readUnsignedShort() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Read an unsigned short value.
- readUnsignedShort() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Read an unsigned short value.
- readUnsignedShort() - Method in class com.tangosol.io.PackedDataInputStream
- 
Read an unsigned short value.
- readUnsignedShort() - Method in class com.tangosol.io.pof.PofInputStream
- 
Read an unsigned short value.
- readUnsignedShort() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Read an unsigned short value.
- readUnsignedShort() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Read an unsigned short value.
- readUnsignedTrint(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an unsigned three-byte integer value from a stream.
- readUTF() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Reads a String value.
- readUTF() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Reads a String value.
- readUTF() - Method in class com.tangosol.io.PackedDataInputStream
- 
Reads a String value.
- readUTF() - Method in class com.tangosol.io.pof.PofInputStream
- 
Reads a String value.
- readUTF() - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Reads a String value.
- readUTF() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Reads a String value.
- readUTF(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Reads the specified-length UTF data and converts it to a String value.
- readUTF(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read a variable-length encoded UTF packed String.
- readValue() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Read the "value" portion of an Entry block.
- ReadWriteBackingMap - Class in com.tangosol.net.cache
- 
Backing Map implementation that provides a size-limited cache of a persistent store and supports configurable write-behind and refresh- ahead caching.
- ReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, BinaryEntryStore, boolean, int, double) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap
- 
Construct a ReadWriteBackingMap based on a BinaryEntryStore.
- ReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, BinaryEntryStore, boolean, int, double, boolean) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap
- 
Construct a ReadWriteBackingMap based on a BinaryEntryStore.
- ReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap
- 
Construct a ReadWriteBackingMap based on a CacheLoader (CacheStore).
- ReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, boolean, int, double) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap
- 
Construct a ReadWriteBackingMap based on a CacheLoader (CacheStore).
- ReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, boolean, int, double, boolean) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap
- 
Construct a ReadWriteBackingMap based on a CacheLoader (CacheStore).
- ReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, NonBlockingEntryStore, boolean, int, double) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap
- 
Construct a ReadWriteBackingMap based on a NonBlockingEntryStore.
- ReadWriteBackingMap(BackingMapManagerContext, ObservableMap, Map, NonBlockingEntryStore, boolean, int, double, boolean) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap
- 
Construct a ReadWriteBackingMap based on a NonBlockingEntryStore.
- ReadWriteBackingMap.BinaryEntryStoreWrapper - Class in com.tangosol.net.cache
- 
A wrapper around the original BinaryEntryStore to allow operations to be overridden and extended.
- ReadWriteBackingMap.CacheLoaderCacheStore - Class in com.tangosol.net.cache
- 
A CacheStore wrapped around a CacheLoader.
- ReadWriteBackingMap.CacheStoreWrapper - Class in com.tangosol.net.cache
- 
A wrapper around the original CacheStore to allow operations to be overridden and extended.
- ReadWriteBackingMap.Entry - Class in com.tangosol.net.cache
- 
A queue entry that is scheduled to come out of the front of the queue no earlier than some specific point in time.
- ReadWriteBackingMap.EntrySet - Class in com.tangosol.net.cache
- 
A set of entries corresponding to this backing map.
- ReadWriteBackingMap.EvictingBackupMap - Class in com.tangosol.net.cache
- 
A Map implementation used for a backup map that evicts all data that has been successfully written.
- ReadWriteBackingMap.InternalMapListener - Class in com.tangosol.net.cache
- 
A MapListener implementation that listens to the internal cache and routes those events to anyone listening to this ReadWriteBackingMap.
- ReadWriteBackingMap.KeySet - Class in com.tangosol.net.cache
- 
A set of entries backed by this backing map.
- ReadWriteBackingMap.NonBlockingEntryStoreWrapper - Class in com.tangosol.net.cache
- 
A wrapper around the original NonBlockingEntryStore to allow operations to be overridden and extended.
- ReadWriteBackingMap.NonBlockingEntryStoreWrapper.LoadOperationObserver - Class in com.tangosol.net.cache
- 
Callbacks invoked by NonBlockingEntryStore implementation to handle the result of load operations.
- ReadWriteBackingMap.NonBlockingEntryStoreWrapper.StoreOperationObserver - Class in com.tangosol.net.cache
- 
Callbacks invoked by NonBlockingEntryStore implementer to handle the result of store operations.
- ReadWriteBackingMap.ReadLatch - Class in com.tangosol.net.cache
- 
A synchronization construct used to coordinate asynchronous loads by the refresh-ahead thread with cache accesses by other threads.
- ReadWriteBackingMap.ReadQueue - Class in com.tangosol.net.cache
- 
A queue of keys that should be read from the underlying CacheStore.
- ReadWriteBackingMap.ReadThread - Class in com.tangosol.net.cache
- 
A thread that removes keys from aReadWriteBackingMap.ReadQueue, reads the value for the key from the underlying CacheStore, and caches the value in the internal ReadWriteBackingMap cache.
- ReadWriteBackingMap.StoreWrapper - Class in com.tangosol.net.cache
- 
Abstract wrapper around a cache store to allow operations to be overridden and extended.
- ReadWriteBackingMap.ValuesCollection - Class in com.tangosol.net.cache
- 
A collection of values backed by this map.
- ReadWriteBackingMap.WriteQueue - Class in com.tangosol.net.cache
- 
A queue that only releases entries after a configurable period of time.
- ReadWriteBackingMap.WriteThread - Class in com.tangosol.net.cache
- 
This is the write-behind thread that pulls things from the write-behind queue and writes them to the CacheStore that the backing map uses.
- ReadWriteBackingMapScheme - Class in com.tangosol.coherence.config.scheme
- 
TheRemoteCacheSchemeis responsible for creating a fully configured ReadWriteBackingMap.
- ReadWriteBackingMapScheme() - Constructor for class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- readWriteLocksMap() - Static method in class com.oracle.coherence.concurrent.locks.Locks
- 
Return CoherenceNamedMapcontaining the read/write locks state.
- ReadWriteMap(CacheStore, boolean) - Constructor for class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Construct a read/write CacheStoreMap.
- ReadWriteSplittingBackingMap - Class in com.tangosol.net.partition
- 
A PartitionAwareBackingMap extension to the ReadWriteBackingMap.
- ReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, BinaryEntryStore, boolean, int, double) - Constructor for class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Construct a ReadWriteSplittingBackingMap based on a BinaryEntryStore.
- ReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, BinaryEntryStore, boolean, int, double, boolean) - Constructor for class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Construct a ReadWriteSplittingBackingMap based on a BinaryEntryStore.
- ReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, CacheLoader, boolean, int, double) - Constructor for class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Construct a ReadWriteSplittingBackingMap based on a CacheStore.
- ReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, CacheLoader, boolean, int, double, boolean) - Constructor for class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Construct a ReadWriteSplittingBackingMap based on a CacheStore.
- ReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, NonBlockingEntryStore, boolean, int, double) - Constructor for class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Construct a ReadWriteSplittingBackingMap based on a BinaryEntryStore.
- ReadWriteSplittingBackingMap(BackingMapManagerContext, PartitionAwareBackingMap, Map, NonBlockingEntryStore, boolean, int, double, boolean) - Constructor for class com.tangosol.net.partition.ReadWriteSplittingBackingMap
- 
Construct a ReadWriteSplittingBackingMap based on a BinaryEntryStore.
- readXml(XmlElement) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Deserialize an object from XML.
- readXml(XmlElement) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Deserialize an object from XML.
- readXmlBean(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an XmlBean object from a DataInput stream.
- readXmlSerializable(DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an XmlSerializable object from a DataInput stream.
- readXmlSerializable(DataInput, ClassLoader) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Read an XmlSerializable object from a DataInput stream.
- ready() - Method in class com.tangosol.io.Utf8Reader
- 
Tell whether this stream is ready to be read.
- ready() - Method in class com.tangosol.util.NullImplementation.NullReader
- ready(String, String) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aClearRequest.
- readZonedDateTime(int) - Method in interface com.tangosol.io.pof.PofReader
- 
Read a java.time.ZonedDateTime from the POF stream.
- realize() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Realize a SSLSocketProviderDefaultDependencies based on configured/defaulted values for config element ssl.
- realize() - Method in interface com.tangosol.util.Builder
- 
Realizes an instance of type T.
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.queryplus.CommandsStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.queryplus.ExtendedLanguageStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.queryplus.HelpStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ArchiveSnapshotStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.CreateSnapshotStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
- realize(ExecutionContext, NodeTerm, List, ParameterResolver) - Method in interface com.tangosol.coherence.dslquery.StatementBuilder
- 
Realizes an implementation of aStatementthat can be executed to perform a specific CohQL command.
- realize(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Realize (ensure) a remote NamedCache, CacheStore, CacheLoader, or BinaryEntryStore as specified by the builder.
- realize(ParameterResolver, ClassLoader, boolean) - Method in class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
- 
Realize aBinaryStoreManagergiven the provided parameters.
- realize(ParameterResolver, ClassLoader, boolean) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Realize aBinaryStoreManagergiven the provided parameters.
- realize(ParameterResolver, ClassLoader, boolean) - Method in interface com.tangosol.coherence.config.builder.storemanager.BinaryStoreManagerBuilder
- 
Realize aBinaryStoreManagergiven the provided parameters.
- realize(ParameterResolver, ClassLoader, boolean) - Method in class com.tangosol.coherence.config.builder.storemanager.CustomStoreManagerBuilder
- 
Realize aBinaryStoreManagergiven the provided parameters.
- realize(ParameterResolver, ClassLoader, boolean) - Method in class com.tangosol.coherence.config.builder.storemanager.NioFileManagerBuilder
- 
Realize aBinaryStoreManagergiven the provided parameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.oracle.coherence.cdi.server.BeanBuilder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.ActionPolicyParameterizedBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.NullImplementationBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ClusterQuorumPolicyBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.CustomAddressProviderBuilder
- 
Realize the custom builder.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.DaemonPoolBuilder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ElementCalculatorBuilder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.EvictionPolicyBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.FactoryBasedAddressProviderBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.InetAddressRangeFilterBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.InvalidConfigServiceLoadBalancerBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ListBasedAddressProviderBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.NamedResourceBuilder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.PartitionAssignmentStrategyBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.PartitionedCacheQuorumPolicyBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ProxyQuorumPolicyBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ProxyServiceLoadBalancerBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ReadLocatorBuilder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ServiceFailurePolicyBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.ServiceLoadBalancerBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.SocketProviderBuilder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.HostnameVerifierBuilder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ProviderBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
RealizeSSLSocketProviderDefaultDependenciesfrom this builder
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.UnitCalculatorBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.builder.WrapperSocketAddressProviderBuilder
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(ParameterResolver, ClassLoader, ParameterList) - Method in class com.tangosol.coherence.config.scheme.ClassScheme
- 
Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolverto resolve values any referencedParameters.
- realize(NamedTopic<V>, ParameterResolver) - Method in class com.tangosol.coherence.config.builder.SubscriberGroupBuilder
- 
Realize a durable subscriber group.
- realize(ValueTypeAssertion<E>, ParameterResolver, MapBuilder.Dependencies) - Method in interface com.tangosol.coherence.config.builder.NamedCollectionBuilder
- 
Realizes aNamedCollection(possibly "ensuring it") based on the state of the builder, the providedParameterResolverandMapBuilderdependencies.
- realize(ValueTypeAssertion<V>, ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- realize(Object, Serializer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Realizes object after deserialization by applying post-serialization rules.
- realize(String, int, String) - Method in class com.tangosol.coherence.dslquery.ChainedExtractorBuilder
- 
Call the realize(String, int, String) method on eachExtractorBuilderin the chain returning the result of the first ExtractorBuilder to return a non-null value.
- realize(String, int, String) - Method in interface com.tangosol.coherence.dslquery.ExtractorBuilder
- 
Create aValueExtractorfor the given cache name, target and property chain.
- realize(String, int, String) - Method in class com.tangosol.coherence.dslquery.ReflectionExtractorBuilder
- realize(String, int, String) - Method in class com.tangosol.coherence.dslquery.UniversalExtractorBuilder
- realizeBackingMapManager(ConfigurableCacheFactory) - Method in interface com.tangosol.coherence.config.builder.BackingMapManagerBuilder
- 
Realize aBackingMapManagerto be scoped by the specifiedConfigurableCacheFactory.
- realizeBackingMapManager(ConfigurableCacheFactory) - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- 
Realize aBackingMapManagerto be scoped by the specifiedConfigurableCacheFactory.
- realizeBackingMapManager(ConfigurableCacheFactory) - Method in class com.tangosol.coherence.config.scheme.NearScheme
- 
Realize aBackingMapManagerto be scoped by the specifiedConfigurableCacheFactory.
- realizeBackingMapManager(ConfigurableCacheFactory) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- realizeBackingMapManager(ConfigurableCacheFactory) - Method in class com.tangosol.coherence.config.scheme.ViewScheme
- realizeBackingMapManager(ConfigurableCacheFactory) - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- realizeCache(ParameterResolver, MapBuilder.Dependencies) - Method in interface com.tangosol.coherence.config.builder.NamedCacheBuilder
- 
Realizes aNamedCache(possibly "ensuring it") based on the state of the builder, the providedParameterResolverandMapBuilderdependencies.
- realizeCache(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- 
Realizes aNamedCache(possibly "ensuring it") based on the state of the builder, the providedParameterResolverandMapBuilderdependencies.
- realizeCache(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.ClassScheme
- 
Realizes aNamedCache(possibly "ensuring it") based on the state of the builder, the providedParameterResolverandMapBuilderdependencies.
- realizeCache(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.CustomScheme
- 
Realizes aNamedCache(possibly "ensuring it") based on the state of the builder, the providedParameterResolverandMapBuilderdependencies.
- realizeCache(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.NearScheme
- 
Realizes aNamedCache(possibly "ensuring it") based on the state of the builder, the providedParameterResolverandMapBuilderdependencies.
- realizeCache(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.PagedTopicStorageScheme
- realizeCache(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.TransactionalScheme
- 
Realizes aNamedCache(possibly "ensuring it") based on the state of the builder, the providedParameterResolverandMapBuilderdependencies.
- realizeCache(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- realizeLocal(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Return an instance of a CacheStore, CacheLoader or a BinaryEntryStore.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in interface com.tangosol.coherence.config.builder.MapBuilder
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.ClassScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.CustomScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.FlashJournalScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.PagedTopicStorageScheme
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.RamJournalScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Realize aMapbased on the state of theMapBuilder, resolvable parameters and providedMapBuilder.Dependencies.
- realizeMap(ParameterResolver, MapBuilder.Dependencies) - Method in class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- realizeProvider() - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Realize the SSL provider.
- realizes(ParameterizedBuilder<?>, Class<?>, ParameterResolver, ClassLoader) - Static method in class com.tangosol.coherence.config.builder.ParameterizedBuilderHelper
- 
Deprecated.
- realizes(Class<?>, ParameterResolver, ClassLoader) - Method in class com.oracle.coherence.cdi.server.BeanBuilder
- realizes(Class<?>, ParameterResolver, ClassLoader) - Method in class com.tangosol.coherence.config.builder.ElementCalculatorBuilder
- 
Returnstrueif this builder realizes the specified type.
- realizes(Class<?>, ParameterResolver, ClassLoader) - Method in class com.tangosol.coherence.config.builder.EvictionPolicyBuilder
- 
Determines if theParameterizedBuilderwill realize an instance of the specified class (without requiring the builder to actually realize an object).
- realizes(Class<?>, ParameterResolver, ClassLoader) - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Determines if theParameterizedBuilderwill realize an instance of the specified class (without requiring the builder to actually realize an object).
- realizes(Class<?>, ParameterResolver, ClassLoader) - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilder.ReflectionSupport
- 
Deprecated.Determines if theParameterizedBuilderwill realize an instance of the specified class (without requiring the builder to actually realize an object).
- realizes(Class<?>, ParameterResolver, ClassLoader) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Determines if theParameterizedBuilderwill realize an instance of the specified class (without requiring the builder to actually realize an object).
- realizes(Class<?>, ParameterResolver, ClassLoader) - Method in class com.tangosol.coherence.config.builder.UnitCalculatorBuilder
- realizes(Class<?>, ParameterResolver, ClassLoader) - Method in class com.tangosol.coherence.config.scheme.ClassScheme
- 
Determines if theParameterizedBuilderwill realize an instance of the specified class (without requiring the builder to actually realize an object).
- realizes(Class<T>) - Method in interface com.tangosol.coherence.config.builder.NamedCollectionBuilder
- 
Determines whether thisNamedCollectionBuildercan realize aNamedCollectionof the specified type.
- realizes(Class<T>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- realizeService(ParameterResolver, ClassLoader, Cluster) - Method in interface com.tangosol.coherence.config.builder.ServiceBuilder
- 
Realize (ensure) a Service.
- realizeService(ParameterResolver, ClassLoader, Cluster) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Realize (ensure) a Service.
- realizeService(ParameterResolver, ClassLoader, Cluster) - Method in class com.tangosol.coherence.config.scheme.CustomScheme
- 
Realize (ensure) a Service.
- realizeService(ParameterResolver, ClassLoader, Cluster) - Method in class com.tangosol.coherence.config.scheme.RemoteCacheScheme
- 
Realize (ensure) a Service.
- realizeService(ParameterResolver, ClassLoader, Cluster) - Method in class com.tangosol.coherence.config.scheme.RemoteInvocationScheme
- 
Realize (ensure) a Service.
- realizeService(ParameterResolver, ClassLoader, Cluster) - Method in class com.tangosol.coherence.config.scheme.TransactionalScheme
- 
Realize (ensure) a Service.
- realizeService(ParameterResolver, ClassLoader, Cluster) - Method in class com.tangosol.coherence.config.scheme.ViewScheme
- REASON_AGGREGATE - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_CLEAR - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_ENTRYSET - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_GET - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_INDEX_ADD - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_INDEX_REMOVE - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_INTERCEPTOR_ADD - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_INTERCEPTOR_REMOVE - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_INVOKE - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_KEYSET - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_LISTENER_ADD - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_LISTENER_REMOVE - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_PUT - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_REMOVE - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_TRIGGER_ADD - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_TRIGGER_REMOVE - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_UNKNOWN - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- REASON_VALUES - Static variable in interface com.tangosol.net.security.StorageAccessAuthorizer
- reasonToString(int) - Static method in interface com.tangosol.net.security.StorageAccessAuthorizer
- 
Return a human-readable description for the specified REASON_ constant.
- receive() - Method in interface com.tangosol.net.topic.Subscriber
- 
Receive a value from the topic.
- receive(int) - Method in interface com.tangosol.net.topic.Subscriber
- 
Receive a batch ofelementsfrom the topic.
- receive(DatagramPacket) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- receive(DatagramPacket) - Method in class com.tangosol.net.TcpDatagramSocket
- recordDuration(long) - Method in interface com.tangosol.util.QueryRecord.PartialResult.TraceStep
- 
Record the time spent evaluating the filter or applying an index.
- recordDuration(long) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.TraceStep
- 
Record the time spent evaluating the filter or applying an index.
- recordEfficiency(int) - Method in interface com.tangosol.util.QueryRecord.PartialResult.ExplainStep
- 
Record the calculated cost of applying the filter as defined bycalculateEffectiveness
- recordEfficiency(int) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.ExplainStep
- 
Record the calculated cost of applying the filter as defined bycalculateEffectiveness
- recordEndTime() - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Record the end time of the operation and update min and max values.
- recordExtractor(ValueExtractor) - Method in interface com.tangosol.util.QueryRecord.PartialResult.RecordableStep
- 
Record all relevant index information for any index associated with the given extractor (e.g. index lookup and range scan).
- recordExtractor(ValueExtractor) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.AbstractRecordableStep
- 
Record all relevant index information for any index associated with the given extractor (e.g. index lookup and range scan).
- recordPostFilterKeys(int) - Method in interface com.tangosol.util.QueryRecord.PartialResult.TraceStep
- 
Record the number of keys remaining after filter evaluation.
- recordPostFilterKeys(int) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.TraceStep
- 
Record the number of keys remaining after filter evaluation.
- recordPreFilterKeys(int) - Method in interface com.tangosol.util.QueryRecord.PartialResult.RecordableStep
- 
Record the number of keys passed to the filter for evaluation.
- recordPreFilterKeys(int) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.AbstractRecordableStep
- 
Record the number of keys passed to the filter for evaluation.
- recordRequest(long, long) - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Update the partition statistics to record the specified request.
- recordStartTime() - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Record the start time of the operation.
- recover() - Method in interface com.tangosol.net.Guardable
- 
Attempt to recover this Guardable.
- recover() - Method in class com.tangosol.util.Daemon
- 
Attempt to recover this Guardable.
- RECOVER - com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- RECOVER_BEGIN - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the start of recovery.
- RECOVER_DISALLOWED - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the recovery being disallowed by the quorum.
- RECOVER_END - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the end of recovery.
- RECOVER_SNAPSHOT_BEGIN - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the start of recovering from a snapshot.
- RECOVER_SNAPSHOT_END - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the end of recovering from a snapshot.
- Recovered - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any RECOVERED event.
- RECOVERED - com.tangosol.net.events.partition.TransferEvent.Type
- 
ThisTransferEventis dispatched when a set ofentrieshave been recovered from a persistent storage by thelocal member.
- Recovered.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theRecoveredannotation.
- recoverSnapshot(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Recover the snapshot that was previously created with the specified name.
- RecoverSnapshotStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder.RecoverSnapshotStatement
- RecoverSnapshotStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aRecoverSnapshotStatementBuilder.RecoverSnapshotStatement.
- RecoverSnapshotStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.RecoverSnapshotStatementBuilder
- RecoverSnapshotStatementBuilder.RecoverSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "RECOVER SNAPSHOT" command.
- recycleBlock(BinaryMap.Block) - Method in class com.tangosol.io.nio.BinaryMap
- 
Release (recycle) the specified Block object.
- recycleNode(RecyclingLinkedList.Node) - Method in class com.tangosol.util.RecyclingLinkedList
- 
Recycle the passed Node.
- RecyclingLinkedList - Class in com.tangosol.util
- 
Extends SafeLinkedList and adds recycling of Node objects.
- RecyclingLinkedList() - Constructor for class com.tangosol.util.RecyclingLinkedList
- 
Construct an empty List.
- RecyclingLinkedList(int) - Constructor for class com.tangosol.util.RecyclingLinkedList
- 
Construct an empty List.
- RecyclingLinkedList(Collection) - Constructor for class com.tangosol.util.RecyclingLinkedList
- 
Construct a List containing the elements of the specified Collection.
- RecyclingLinkedList(Collection, int) - Constructor for class com.tangosol.util.RecyclingLinkedList
- 
Construct a List containing the elements of the specified Collection.
- RecyclingLinkedList.Node - Class in com.tangosol.util
- 
A Node in the List.
- reduce(double, Remote.DoubleBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Performs a reduction on the elements of this stream, using the provided identity value and an associative accumulation function, and returns the reduced value.
- reduce(double, DoubleBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Performs a reduction on the elements of this stream, using the provided identity value and an associative accumulation function, and returns the reduced value.
- reduce(int, Remote.IntBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Performs a reduction on the elements of this stream, using the provided identity value and an associative accumulation function, and returns the reduced value.
- reduce(int, IntBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Performs a reduction on the elements of this stream, using the provided identity value and an associative accumulation function, and returns the reduced value.
- reduce(long, Remote.LongBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Performs a reduction on the elements of this stream, using the provided identity value and an associative accumulation function, and returns the reduced value.
- reduce(long, LongBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Performs a reduction on the elements of this stream, using the provided identity value and an associative accumulation function, and returns the reduced value.
- reduce(Remote.BinaryOperator<T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a reduction on the elements of this stream, using an associative accumulation function, and returns anOptionaldescribing the reduced value, if any.
- reduce(Remote.DoubleBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Performs a reduction on the elements of this stream, using an associative accumulation function, and returns anOptionalDoubledescribing the reduced value, if any.
- reduce(Remote.IntBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Performs a reduction on the elements of this stream, using an associative accumulation function, and returns anOptionalIntdescribing the reduced value, if any.
- reduce(Remote.LongBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Performs a reduction on the elements of this stream, using an associative accumulation function, and returns anOptionalLongdescribing the reduced value, if any.
- reduce(ValueExtractor<? super T, ? extends R>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that will return the extracted value for each entry in the map.
- reduce(String) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that will return the extracted value for each entry in the map.
- reduce(BinaryOperator<T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a reduction on the elements of this stream, using an associative accumulation function, and returns anOptionaldescribing the reduced value, if any.
- reduce(DoubleBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Performs a reduction on the elements of this stream, using an associative accumulation function, and returns anOptionalDoubledescribing the reduced value, if any.
- reduce(IntBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Performs a reduction on the elements of this stream, using an associative accumulation function, and returns anOptionalIntdescribing the reduced value, if any.
- reduce(LongBinaryOperator) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Performs a reduction on the elements of this stream, using an associative accumulation function, and returns anOptionalLongdescribing the reduced value, if any.
- reduce(T, Remote.BinaryOperator<T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a reduction on the elements of this stream, using the provided identity value and an associative accumulation function, and returns the reduced value.
- reduce(T, BinaryOperator<T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a reduction on the elements of this stream, using the provided identity value and an associative accumulation function, and returns the reduced value.
- reduce(U, Remote.BiFunction<U, ? super T, U>, Remote.BinaryOperator<U>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a reduction on the elements of this stream, using the provided identity, accumulation and combining functions.
- reduce(U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Performs a reduction on the elements of this stream, using the provided identity, accumulation and combining functions.
- reducePermits(int) - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Shrinks the number of available permits by the indicated reduction.
- ReducerAggregator<K,V,T,E> - Class in com.tangosol.util.aggregator
- 
The ReducerAggregator is used to implement functionality similar toCacheMap.getAll(Collection)API.
- ReducerAggregator() - Constructor for class com.tangosol.util.aggregator.ReducerAggregator
- 
Default constructor (necessary for the ExternalizableLite interface).
- ReducerAggregator(ValueExtractor<? super T, ? extends E>) - Constructor for class com.tangosol.util.aggregator.ReducerAggregator
- 
Construct a ReducerAggregator based on the specified extractor.
- ReducerAggregator(String) - Constructor for class com.tangosol.util.aggregator.ReducerAggregator
- 
Construct a ReducerAggregator based on the specified method name.
- reducing(Remote.BinaryOperator<T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorwhich performs a reduction of its input elements under a specifiedBinaryOperator.
- reducing(T, Remote.BinaryOperator<T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorwhich performs a reduction of its input elements under a specifiedBinaryOperatorusing the provided identity.
- reducing(U, Remote.BiFunction<? super U, ? super T, ? extends U>, Remote.BinaryOperator<U>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorwhich performs a reduction of its input elements under a specified mapping function andBinaryOperator.
- reducing(U, Remote.Function<? super T, ? extends U>, Remote.BinaryOperator<U>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorwhich performs a reduction of its input elements under a specified mapping function andBinaryOperator.
- ReferenceInternalConverter<T> - Class in com.tangosol.coherence.jcache.common
- 
AnInternalConverterthat simply returns a reference to the provided value.
- ReferenceInternalConverter() - Constructor for class com.tangosol.coherence.jcache.common.ReferenceInternalConverter
- ReferenceLibrary() - Constructor for class com.tangosol.io.pof.PofBufferWriter.ReferenceLibrary
- REFLECT_ALLOW_ALL - Static variable in class com.tangosol.util.ClassHelper
- 
Value to set system propertyClassHelper.REFLECT_FILTER_PROPERTYto disable the reflection allowed filter.
- REFLECT_FILTER_PROPERTY - Static variable in class com.tangosol.util.ClassHelper
- 
Configure reflection allowed class white list and/or black list by setting the value of this system property to a set of patterns.
- REFLECT_FILTER_SEPARATOR - Static variable in class com.tangosol.util.ClassHelper
- 
Separator for filter patterns.
- ReflectionExtractor<T,E> - Class in com.tangosol.util.extractor
- 
Reflection-based ValueExtractor implementation.
- ReflectionExtractor() - Constructor for class com.tangosol.util.extractor.ReflectionExtractor
- 
Default constructor (necessary for the ExternalizableLite interface).
- ReflectionExtractor(String) - Constructor for class com.tangosol.util.extractor.ReflectionExtractor
- 
Construct a ReflectionExtractor based on a method name.
- ReflectionExtractor(String, Object[]) - Constructor for class com.tangosol.util.extractor.ReflectionExtractor
- 
Construct a ReflectionExtractor based on a method name and optional parameters.
- ReflectionExtractor(String, Object[], int) - Constructor for class com.tangosol.util.extractor.ReflectionExtractor
- 
Construct a ReflectionExtractor based on a method name, optional parameters and the entry extraction target.
- ReflectionExtractorBuilder - Class in com.tangosol.coherence.dslquery
- 
AnExtractorBuilderimplementation that will build instances ofReflectionExtractors.
- ReflectionExtractorBuilder() - Constructor for class com.tangosol.coherence.dslquery.ReflectionExtractorBuilder
- ReflectionHelper - Class in com.tangosol.util.fsm
- 
A collection of utilities to assist in using Reflection to create objects.
- ReflectionHelper() - Constructor for class com.tangosol.util.fsm.ReflectionHelper
- ReflectionUpdater - Class in com.tangosol.util.extractor
- 
Reflection-based ValueUpdater implementation.
- ReflectionUpdater() - Constructor for class com.tangosol.util.extractor.ReflectionUpdater
- 
Default constructor (necessary for the ExternalizableLite interface).
- ReflectionUpdater(String) - Constructor for class com.tangosol.util.extractor.ReflectionUpdater
- 
Construct a ReflectionUpdater for a given method name.
- REFRESH_DEFAULT - Static variable in class com.tangosol.net.RefreshableAddressProvider
- 
Default refresh time of 10 seconds.
- RefreshableAddressProvider - Class in com.tangosol.net
- 
A RefreshableAddressProvider is an AddressProvider implementation that wraps another AddressProvider and refresh the address list of the provider asynchronously.
- RefreshableAddressProvider(AddressProvider) - Constructor for class com.tangosol.net.RefreshableAddressProvider
- 
Construct a RefreshableAddressProvider with the given AddressProvider using default refresh interval
- RefreshableAddressProvider(AddressProvider, long) - Constructor for class com.tangosol.net.RefreshableAddressProvider
- 
Construct a RefreshableAddressProvider with the specified AddressProvider and refresh interval
- RefreshableAddressProvider.CircularIterator - Class in com.tangosol.net
- 
An Iterator implementation that can be converted intocircular modeto allow the remaining addresses and previously skipped addresses to be used; typically set once an address has beenaccepted.
- RefreshableAddressProvider.RefreshThread - Class in com.tangosol.net
- RefreshableSslContext - Class in com.oracle.coherence.grpc
- 
A refreshableSslContext.
- RefreshableSslContext(SSLContextDependencies, boolean) - Constructor for class com.oracle.coherence.grpc.RefreshableSslContext
- refreshAddressList() - Method in class com.tangosol.net.RefreshableAddressProvider
- 
Refresh the cached address list using the underlying provider.
- refreshIterator() - Method in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
- 
Set the value ofm_iteratorto a new iterator from the address list, and ensure the address list is refreshed.
- RefreshPolicy - Interface in com.tangosol.net.ssl
- 
Implemented by classes that wish to control whether anSSLContextis updated when its scheduled update check runs.
- RefreshThread(long) - Constructor for class com.tangosol.net.RefreshableAddressProvider.RefreshThread
- 
Construct a new RefreshThread with the specified refresh interval.
- regex() - Method in class com.oracle.coherence.cdi.Name.Literal
- 
Returntrueto indicate whether name is a regular expression.
- regex() - Method in annotation type com.oracle.coherence.cdi.Name
- 
Returntrueto indicate whether name is a regular expression.
- regex(ValueExtractor<T, E>, String) - Static method in class com.tangosol.util.Filters
- 
Return a RegexFilter for pattern match.
- RegExCacheMapping - Class in com.tangosol.coherence.config
- 
An extension ofCacheMappingthat can use a regular expression to match with a given cache name.
- RegExCacheMapping(String, String) - Constructor for class com.tangosol.coherence.config.RegExCacheMapping
- 
Construct aRegExCacheMappingfor caches that will use raw types by default.
- RegexFilter<T,E> - Class in com.tangosol.util.filter
- 
Filter which uses the regular expression pattern match defined by thePattern.matches(String, CharSequence)contract.
- RegexFilter() - Constructor for class com.tangosol.util.filter.RegexFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- RegexFilter(ValueExtractor<? super T, ? extends E>, String) - Constructor for class com.tangosol.util.filter.RegexFilter
- 
Construct a RegexFilter for testing pattern matching.
- RegexFilter(String, String) - Constructor for class com.tangosol.util.filter.RegexFilter
- 
Construct a RegexFilter for testing pattern matching.
- regionMatches(int, Binary, int, int) - Method in class com.tangosol.util.Binary
- 
Tests if two Binary regions are equal.
- register() - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- 
Register this listener.
- register() - Method in class com.tangosol.net.cache.CachingMap.FrontMapListener
- 
Register this listener with the "front" map.
- register() - Method in class com.tangosol.persistence.AbstractPersistenceManager.Task
- 
Register this task with the manager.
- register(CacheMapping) - Method in class com.tangosol.coherence.config.CacheMappingRegistry
- 
Deprecated.Registers aCacheMappingwith theCacheMappingRegistry.
- register(ResourceMapping) - Method in interface com.tangosol.coherence.config.ResourceMappingRegistry
- 
Registers aResourceMappingwith theResourceMappingRegistry.
- register(ResourceMapping) - Method in class com.tangosol.coherence.config.SchemeMappingRegistry
- register(ServiceScheme) - Method in class com.tangosol.coherence.config.ServiceSchemeRegistry
- 
Attempts to register the specifiedServiceScheme.
- register(CacheService, String, String, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.as of Coherence 3.7.1; useMBeanHelper.registerCacheMBean(CacheService, String, String, Map)instead
- register(MBeanMetric) - Method in class com.oracle.coherence.mp.metrics.CdiMetricsRegistryAdapter
- register(MBeanMetric) - Method in class com.oracle.coherence.mp.metrics.MpMetricsRegistryAdapter
- register(NamedCache, String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.as of Coherence 3.7.1; useMBeanHelper.registerCacheMBean(NamedCache, String)instead
- register(HealthCheck) - Method in interface com.tangosol.net.management.Registry
- 
Register aHealthCheck.
- register(ServerCall<?, ?>) - Method in class com.oracle.coherence.grpc.proxy.GrpcConnectionMetrics
- 
Register aServerCallwith the connection metrics, creating a new connection metric if this call is from a new remote address.
- register(Object) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext.ExternalSerializer
- 
Register a class as having been encountered by the serializer.
- register(String) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext.SafePofSerializer
- 
Register a class as having been encountered by the serializer.
- register(String, AggregatorFactory) - Method in class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
- 
Register an aggregator factory with the given name.
- register(String, ProcessorFactory) - Method in class com.tangosol.coherence.rest.util.processor.ProcessorRegistry
- 
Registers a processor factory with the given name.
- register(String, Class) - Method in class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
- 
Register an aggregator or aggregator factory with the given name.
- register(String, Class) - Method in class com.tangosol.coherence.rest.util.processor.ProcessorRegistry
- 
Registers processor factory with the given name.
- register(String, Object) - Method in interface com.tangosol.net.management.Registry
- 
Register a manageable object.
- register(Collection<AggregatorConfig>) - Method in class com.tangosol.coherence.rest.util.aggregator.AggregatorRegistry
- 
Register a collection of aggregators.
- register(Collection<ProcessorConfig>) - Method in class com.tangosol.coherence.rest.util.processor.ProcessorRegistry
- 
Register a collection of processors.
- registerAttributeType(Class<T>) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Automatically creates and registers anAttributeProcessorfor the specified type.
- registerAttributeType(Class<T>) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Automatically creates and registers anAttributeProcessorfor the specified type.
- registerAttributeType(String, Class<T>) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Registers (internally creates) an appropriateAttributeProcessorforXmlAttributes with the specified local name so that they produce the specified type of value when processed.
- registerBackEvent(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Register a MapEvent that has been raised by the back Map against the same key for which this Status object exists.
- registerBackingMapManager(BackingMapManager) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Register the specified BackingMapManager as a "valid" one.
- registerBackingMapManager(BackingMapManager) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Register the specified BackingMapManager as a "valid" one.
- registerBackServiceListener() - Method in class com.tangosol.net.cache.NearCache
- 
Instantiate and register a MemberListener with the back cache service.
- registerBuilder(Class<T>, ParameterizedBuilder<? extends T>) - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry
- 
Registers aParameterizedBuilderfor later retrieval withParameterizedBuilderRegistry.getBuilder(Class).
- registerBuilder(Class<T>, ParameterizedBuilder<? extends T>) - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- registerBuilder(Class<T>, String, ParameterizedBuilder<? extends T>) - Method in interface com.tangosol.coherence.config.builder.ParameterizedBuilderRegistry
- 
Registers aParameterizedBuilderwith the specified name for later retrieval withParameterizedBuilderRegistry.getBuilder(Class, String).
- registerBuilder(Class<T>, String, ParameterizedBuilder<? extends T>) - Method in class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- registerCacheMBean(CacheService, String, String, Map) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Register the specified map with the cluster registry.
- registerCacheMBean(NamedCache, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Register the specified NamedCache with the cluster registry.
- registerCacheObject(AbstractCoherenceBasedCache, MBeanServerRegistrationUtility.ObjectNameType) - Static method in class com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility
- 
Utility method for registering CacheStatistics with the platform MBeanServer
- registerCachePrune(long) - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a cache prune.
- registerContainerRequestFilters() - Method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Register the predefined Coherence REST container request filters.
- registerContainerResponseFilters() - Method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Register the predefined Coherence REST container response filters.
- registerDeactivationListener() - Method in class com.tangosol.net.cache.CachingMap
- 
Instantiate and register a DeactivationListener with the back cache.
- registerDeactivationListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Instantiate and register aNamedCacheDeactivationListenerwith the underlying cache service.
- registerElementType(Class<T>) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Automatically creates and registers anElementProcessorfor the specified type.
- registerElementType(Class<T>) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Automatically creates and registers anElementProcessorfor the specified type.
- registerElementType(String, Class<T>) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Registers (internally creates) an appropriateElementProcessorforXmlElements with the specified local name so that they produce the specified type of value when processed.
- registerEventDispatcher(EventDispatcher) - Method in interface com.tangosol.net.events.EventDispatcherRegistry
- 
Add the specifiedEventDispatcherto the list of known EventDispatchers that are informed about registeredEventInterceptors.
- registerEventInterceptor(EventInterceptor<?>) - Method in interface com.tangosol.net.events.InterceptorRegistry
- 
Register anEventInterceptoruniquely identified based on the presence of anannotationor default to the fully qualified class name.
- registerEventInterceptor(EventInterceptor<?>, RegistrationBehavior) - Method in interface com.tangosol.net.events.InterceptorRegistry
- 
Register anEventInterceptoruniquely identified based on the presence of anannotationor default to the fully qualified class name.
- registerEventInterceptor(String, EventInterceptor<?>, RegistrationBehavior) - Method in interface com.tangosol.net.events.InterceptorRegistry
- 
Register a uniquely identifiedEventInterceptor.
- registerExpiry(long) - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Register (or unregister or replace the registration of) this entry for expiry.
- registerExpiry(Object, long) - Method in class com.tangosol.net.cache.OverflowMap
- 
Register an expiry for the specified key.
- registerFrontEvent(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Register a MapEvent that has been raised by the front Map against the same key for which this Status object exists.
- registerFrontEvent(MapEvent) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Register a MapEvent that has been raised by the front Map against the same key for which this Status object exists.
- registerFrontListener() - Method in class com.tangosol.net.cache.CachingMap
- 
Register the global front map listener.
- registerGUIDs(Member, String[]) - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Register the specified list of GUIDs from the specified member.
- registerHit() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a cache hit (no timing information).
- registerHit(long) - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a cache hit.
- registerHits(int, long) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerHits(int, long) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
add Cache Hits of count and compute time in cache hits
- registerHits(int, long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerHits(int, long) - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a multiple cache hit.
- registerHitsCompleted(long) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerHitsCompleted(long) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
Record elapsed time in milliseconds performing hit(s)
- registerHitsCompleted(long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerIdentity(int) - Method in class com.tangosol.io.pof.AbstractPofHandler
- 
This method is invoked when an identity is encountered in the POF stream.
- registerIdentity(int) - Method in class com.tangosol.io.pof.DuplexingPofHandler
- 
This method is invoked when an identity is encountered in the POF stream.
- registerIdentity(int) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
This method is invoked when an identity is encountered in the POF stream.
- registerIdentity(int) - Method in interface com.tangosol.io.pof.PofHandler
- 
This method is invoked when an identity is encountered in the POF stream.
- registerIdentity(int) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
This method is invoked when an identity is encountered in the POF stream.
- registerIdentity(int) - Method in class com.tangosol.io.pof.WritingPofHandler
- 
This method is invoked when an identity is encountered in the POF stream.
- registerIdentity(int) - Method in class com.tangosol.util.NullImplementation.NullPofHandler
- 
This method is invoked when an identity is encountered in the POF stream.
- registerIdentity(int, Object) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Register the passed value with the passed identity.
- registerIdentity(int, Object) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Register the passed value with the passed identity.
- registerIdentity(Object) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Register an identity for a newly created user type instance.
- registerIdentity(Object) - Method in class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Register an identity for a newly created user type instance.
- registerIdentity(Object) - Method in interface com.tangosol.io.pof.PofReader
- 
Register an identity for a newly created user type instance.
- registerIncrementalCachePrune(long) - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register an incremental cache prune, which is to say that the time is accreted but the number of prunes does not increase.
- registerIndex(PersistentStore<ReadBuffer>, long, Binary, Binary, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Store the index registration in the specified persistent store.
- registerInterceptor(XmlElement, String, String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.This method will instantiate anEventInterceptorbased on the XML provided.
- registerKey(Object, Binary, Binary) - Method in class com.tangosol.net.cache.SerializationCache
- 
Register a new key for the SerializationMap.
- registerKey(Object, Binary, Binary) - Method in class com.tangosol.net.cache.SerializationMap
- 
Register a new key for the SerializationMap.
- registerKey(Object, Binary, Binary, int) - Method in class com.tangosol.net.cache.SerializationCache
- 
Register a new key for the SerializationMap.
- registerListener() - Method in class com.tangosol.net.cache.CachingMap
- 
Register the global back map listener.
- registerListener(PersistentStore<ReadBuffer>, long, Binary, long, boolean, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Store the listener registration in the specified persistent store.
- registerListener(Object) - Method in class com.tangosol.net.cache.CachingMap
- 
Register the back map listener for the specified key.
- registerListeners(String, String, String, String) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListenerManager
- registerListeners(Set) - Method in class com.tangosol.net.cache.CachingMap
- 
Register the back map listeners for the specified set of keys.
- registerLock(PersistentStore<ReadBuffer>, long, Binary, long, long, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Store the cache entry lock in the specified persistent store.
- registerMarshaller(Class, String, Marshaller) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Register a marshaller for the specified root class and media type.
- registerMarshaller(Class, String, Class) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Register a marshaller for the specified root class and media type.
- registerMarshaller(Class, MediaType, Marshaller) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Register a marshaller for the specified root class and media type.
- registerMarshaller(Class, MediaType, Class) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Register a marshaller for the specified root class and media type.
- registerMBean() - Method in class com.tangosol.net.cache.NearCache
- 
Register an MBean representing this NearCache.
- registerMBean() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Register an MBean representing this SimpleAssignmentStrategy.
- registerMBean(Registry) - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- 
Registers an MBean for thisGrpcProxyMetrics.
- registerMiss() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a cache miss (no timing information).
- registerMiss(long) - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a cache miss.
- registerMisses(int, long) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerMisses(int, long) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
add Cache Misses of count and compute time in cache misses
- registerMisses(int, long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerMisses(int, long) - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a multiple cache miss.
- registerMissesCompleted(long) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerMissesCompleted(long) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
Record elapsed time in milliseconds performing miss(es)
- registerMissesCompleted(long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerPagedTopicMBean(PagedTopicService, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Register the specified PagedTopic with the cluster registry.
- registerPortableType(Class<T>) - Method in class com.tangosol.io.pof.SimplePofContext
- 
RegisterPortableType.
- registerPortableTypes(Class<?>...) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Register multiplePortableTypes.
- registerProcessor(Class<?>) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Registers the specified processor as anElementProcessororAttributeProcessor(based on the interfaces it implements) using theXmlSimpleNameannotation to determine the localName of the said processor.
- registerProcessor(Class<T>, AttributeProcessor<T>) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Registers anAttributeProcessorthat may be used to process specific types of values contained inXmlAttributes with in theProcessingContext.
- registerProcessor(Class<T>, AttributeProcessor<T>) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Registers anAttributeProcessorthat may be used to process specific types of values contained inXmlAttributes with in theProcessingContext.
- registerProcessor(Class<T>, ElementProcessor<T>) - Method in class com.tangosol.config.xml.DefaultProcessingContext
- 
Registers anElementProcessorthat may be used to process specific types of values contained inXmlElements with in theProcessingContext.
- registerProcessor(Class<T>, ElementProcessor<T>) - Method in interface com.tangosol.config.xml.ProcessingContext
- 
Registers anElementProcessorthat may be used to process specific types of values contained inXmlElements with in theProcessingContext.
- registerProcessor(String, AttributeProcessor<?>) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Registers anAttributeProcessorforXmlAttributes with the specified name.
- registerProcessor(String, ElementProcessor<?>) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Registers anElementProcessorforXmlElements with a name with in the context of theNamespaceHandlernamespace.
- registerProviders() - Method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Register the default Coherence REST providers.
- registerPut(long) - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a cache put.
- registerPuts(int, long) - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Register a multiple cache put.
- registerPuts(long, long) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerPuts(long, long) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
add Cache Puts of count and compute time in cache puts
- registerPuts(long, long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerPutsCompleted(long) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerPutsCompleted(long) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
Record elapsed time performing puts
- registerPutsCompleted(long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerQueryEngine(String, QueryEngine) - Method in class com.tangosol.coherence.rest.query.QueryEngineRegistry
- 
Register a query engine for the specified name.
- registerQueryEngine(String, Class) - Method in class com.tangosol.coherence.rest.query.QueryEngineRegistry
- 
Register a query engine for the specified name.
- registerQueryMBeans(String, String, String, Registry) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Find all MBeans matching to the specified query at a local MBeanServer and register them with the specified Registry.
- registerReference(Object) - Method in class com.tangosol.io.pof.PofBufferWriter.ReferenceLibrary
- 
Register an object.
- registerRemove() - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerRemove() - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
register a Cache Remove
- registerRemove() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerRemoveCompleted(long) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerRemoveCompleted(long) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
Record elapsed time in milliseconds performing removal(s)
- registerRemoveCompleted(long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerRemoves(long, long) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- registerRemoves(long, long) - Method in interface com.tangosol.coherence.jcache.common.JCacheStatistics
- 
add Cache Removals of count and compute time in cache removals
- registerRemoves(long, long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- registerResource(Class<R>, Builder<? extends R>, RegistrationBehavior, ResourceRegistry.ResourceLifecycleObserver<R>) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
- registerResource(Class<R>, Builder<? extends R>, RegistrationBehavior, ResourceRegistry.ResourceLifecycleObserver<R>) - Method in interface com.tangosol.util.ResourceRegistry
- 
Registers a resource according to the specifiedRegistrationBehavior.
- registerResource(Class<R>, Builder<? extends R>, RegistrationBehavior, ResourceRegistry.ResourceLifecycleObserver<R>) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Registers a resource according to the specifiedRegistrationBehavior.
- registerResource(Class<R>, String, Builder<? extends R>, RegistrationBehavior, ResourceRegistry.ResourceLifecycleObserver<R>) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
- registerResource(Class<R>, String, Builder<? extends R>, RegistrationBehavior, ResourceRegistry.ResourceLifecycleObserver<R>) - Method in interface com.tangosol.util.ResourceRegistry
- 
Registers a resource according to the specifiedRegistrationBehavior.
- registerResource(Class<R>, String, Builder<? extends R>, RegistrationBehavior, ResourceRegistry.ResourceLifecycleObserver<R>) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Registers a resource according to the specifiedRegistrationBehavior.
- registerResource(Class<R>, String, R) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
- registerResource(Class<R>, String, R) - Method in interface com.tangosol.util.ResourceRegistry
- 
Registers the resource with the specified name for later retrieval withResourceResolver.getResource(Class, String).
- registerResource(Class<R>, String, R) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Registers the resource with the specified name for later retrieval withResourceResolver.getResource(Class, String).
- registerResource(Class<R>, R) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
- registerResource(Class<R>, R) - Method in interface com.tangosol.util.ResourceRegistry
- 
Registers the resource for later retrieval withResourceResolver.getResource(Class).
- registerResource(Class<R>, R) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Registers the resource for later retrieval withResourceResolver.getResource(Class).
- registerResource(String, Disposable) - Method in interface com.tangosol.net.Cluster
- 
Deprecated.UseCluster.getResourceRegistry()to manage resources.
- registerResourceFilterFactories() - Method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Register the predefined Coherence REST resource filter factories.
- registerResources(ResourceRegistry) - Method in interface com.tangosol.net.ClusterDependencies
- 
Register all the custom resources contained in thisClusterDependencieswith the target registry.
- registerResources(ResourceRegistry) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Register all the resources contained in this registry with the target registry.
- registerResources(ResourceRegistry, RegistrationBehavior) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Register all the resources contained in this registry with the target registry.
- registerRootResource() - Method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
- 
Register the default Coherence REST root resource class.
- registerRootResource() - Method in class com.tangosol.coherence.rest.server.PassThroughResourceConfig
- registerServiceListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Instantiate and register aMemberListenerwith the underlying cache service.
- registerServices(Map<Service, String>) - Method in interface com.tangosol.net.ServiceMonitor
- 
Adds a set ofServices to be monitored providing life support.
- registerServices(Map<Service, String>) - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Adds a set ofServices to be monitored providing life support.
- registerSubscriberGroupMBean(PagedTopicService, PagedTopicSubscription) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Register the specified PagedTopic subscriber group with the cluster registry.
- registerSubscriberMBean(PagedTopicSubscriber<?>) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Register the specified PagedTopic subscriber with the cluster registry.
- registerTrigger(PersistentStore<ReadBuffer>, long, Binary, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Store the trigger registration in the specified persistent store.
- registerUserType(int, Class<T>, PofSerializer<T>) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Associate a user type with a type identifier andPofSerializer.
- registerViewMBean(ContinuousQueryCache) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Register the specified view cache with the cluster registry.
- registerViewMBean(CacheService, ContinuousQueryCache) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Register the specified view cache with the cluster registry.
- RegistrationBehavior - Enum in com.tangosol.util
- 
A RegistrationBehavior is used by numerous registries for the purpose of specifying the required behavior when registering an artifact.
- Registry - Interface in com.tangosol.net.management
- 
The Coherence cluster management gateway is an abstraction of the basic JMX registration APIs that is specific to managing Coherence clustered resources.
- RegistryKey(Class) - Constructor for class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
- 
Construct aSimpleParameterizedBuilderRegistry.RegistryKey.
- RegistryKey(Class<?>) - Constructor for class com.tangosol.util.SimpleResourceRegistry.RegistryKey
- 
Construct aSimpleResourceRegistry.RegistryKey.
- RegistryKey(Class<?>, String) - Constructor for class com.tangosol.util.SimpleResourceRegistry.RegistryKey
- 
Construct aSimpleResourceRegistry.RegistryKey.
- RegistryKey(Class, String) - Constructor for class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryKey
- 
Construct aSimpleParameterizedBuilderRegistry.RegistryKey.
- RegistryValue(ParameterizedBuilder<?>) - Constructor for class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry.RegistryValue
- 
Construct aSimpleParameterizedBuilderRegistry.RegistryValue.
- RegistryValue(Object, ResourceRegistry.ResourceLifecycleObserver<Object>) - Constructor for class com.tangosol.util.SimpleResourceRegistry.RegistryValue
- 
Construct aSimpleResourceRegistry.RegistryValueobject.
- rehash(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Rehash the specified bucket such that, when done, it will only contain keys that hash to it with the current modulo.
- rehashAll() - Method in class com.tangosol.io.nio.BinaryMap
- 
Rehash all blocks such that no block will be linked into the wrong bucket.
- rehashBegin() - Method in class com.tangosol.io.nio.BinaryMap
- 
Configure the incremental rehash.
- rehashComplete() - Method in class com.tangosol.io.nio.BinaryMap
- 
Complete the incremental rehash.
- rehashNext() - Method in class com.tangosol.io.nio.BinaryMap
- 
Rehash the next incremental rehash block.
- reject(Throwable) - Method in class com.tangosol.net.CompositeAddressProvider
- 
This method should be called by the client immediately after it determines that an attempt to use an address returned by theSocketAddressProvider.getNextAddress()method has failed.
- reject(Throwable) - Method in class com.tangosol.net.CompositeAddressProvider.SingleProvider
- 
This method should be called by the client immediately after it determines that an attempt to use an address returned by theSocketAddressProvider.getNextAddress()method has failed.
- reject(Throwable) - Method in class com.tangosol.net.CompositeSocketAddressProvider
- 
This method should be called by the client immediately after it determines that an attempt to use an address returned by theSocketAddressProvider.getNextAddress()method has failed.
- reject(Throwable) - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
This method should be called by the client immediately after it determines that an attempt to use an address returned by theSocketAddressProvider.getNextAddress()method has failed.
- reject(Throwable) - Method in class com.tangosol.net.RefreshableAddressProvider
- 
This method should be called by the client immediately after it determines that an attempt to use an address returned by theSocketAddressProvider.getNextAddress()method has failed.
- reject(Throwable) - Method in interface com.tangosol.net.SocketAddressProvider
- 
This method should be called by the client immediately after it determines that an attempt to use an address returned by theSocketAddressProvider.getNextAddress()method has failed.
- reject(Throwable) - Method in class com.tangosol.util.NullImplementation.NullAddressProvider
- 
This method should be called by the client immediately after it determines that an attempt to use an address returned by theSocketAddressProvider.getNextAddress()method has failed.
- rejectChange() - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Signal that the modifiedChangeRecord.Entryshould not be applied.
- Rejected - com.tangosol.net.topic.Subscriber.CommitResultStatus
- 
The commit request was rejected.
- relayResponse(Socket, Socket) - Method in class com.tangosol.net.LoadBalancer.ResponseHandler
- 
This method is used to assign a task to the ResponseHandler thread from the RequestHandler thread.
- Releasable - Interface in com.tangosol.net
- 
A resource that is activated and then at a later time be released.
- release() - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- release() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Releases a permit, returning it to the semaphore.
- release() - Method in interface com.oracle.coherence.concurrent.Semaphore
- 
Releases a permit, returning it to the semaphore.
- release() - Method in class com.tangosol.net.cache.CachingMap
- 
Release the CachingMap.
- release() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- release() - Method in class com.tangosol.net.cache.NearCache
- 
Release the CachingMap.
- release() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Release the backing map when it is no longer being used.
- release() - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Invalidate the CachingMap.
- release() - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Release local resources associated with this Releasable instance.
- release() - Method in interface com.tangosol.net.Guardian.GuardContext
- 
Release this context, causing the Guardian to discontinue monitoring of the represented Guardable.
- release() - Method in class com.tangosol.net.GuardSupport.Context
- 
Release this context, causing the Guardian to discontinue monitoring of the represented Guardable.
- release() - Method in class com.tangosol.net.GuardSupport
- 
Release the Guardables managed by this GuardSupport.
- release() - Method in interface com.tangosol.net.Releasable
- 
Release local resources associated with this Releasable instance.
- release() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Release all resources held by this environment.
- release() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Release any resources held by this persistent store.
- release() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Release all resources held by this manager.
- release() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Release all resources held by this environment.
- release() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Release all resources held by this manager.
- release() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Release local resources associated with this Releasable instance.
- release() - Method in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
- 
Release all resources held by this environment.
- release() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Release all resources held by this manager.
- release() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Release this Lock.
- release(boolean) - Method in class com.tangosol.net.cache.NearCache
- 
Release this cache, optionally destroying it.
- release(int) - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- release(int) - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Releases the given number of permits, returning them to the semaphore.
- release(int) - Method in interface com.oracle.coherence.concurrent.Semaphore
- 
Releases the given number of permits, returning them to the semaphore.
- release(BinaryStore) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Release all resources associated with the specified binary store.
- release(BinaryStore) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Release all resources associated with the specified binary store.
- release(WriteBuffer) - Method in class com.tangosol.io.ByteArrayWriteBuffer.Allocator
- 
Release the supplied buffer into the pool.
- release(WriteBuffer) - Method in interface com.tangosol.io.MultiBufferWriteBuffer.WriteBufferPool
- 
Returns a WriteBuffer to the pool.
- release(WriteBuffer) - Method in class com.tangosol.util.ExternalizableHelper.Stats
- 
Returns a WriteBuffer to the pool.
- release(CacheLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Release all resources associated with the specified loader.
- release(CacheLoader) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Release all resources associated with the specified loader.
- release(ConfigurableCacheFactory) - Method in interface com.tangosol.net.CacheFactoryBuilder
- 
Release the specified ConfigurableCacheFactory.
- release(ConfigurableCacheFactory) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Release the specified ConfigurableCacheFactory.
- release(ConfigurableCacheFactory) - Method in class com.tangosol.net.SingletonCacheFactoryBuilder
- 
Release the specified ConfigurableCacheFactory.
- release(ClassLoader, URI) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCachingProvider
- 
Releases the CacheManager with the specified URI and ClassLoader from this CachingProvider.
- release(Map, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Release all resources associated with the specified backing map.
- release(Map, Map) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Release all resources associated with the specified backing map.
- releaseAll(ClassLoader) - Method in interface com.tangosol.net.CacheFactoryBuilder
- 
Release all ConfigurableCacheFactory objects for a given ClassLoader.
- releaseAll(ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Release all ConfigurableCacheFactory objects for a given ClassLoader.
- releaseAll(ClassLoader) - Method in class com.tangosol.net.SingletonCacheFactoryBuilder
- 
Release all ConfigurableCacheFactory objects for a given ClassLoader.
- releaseBackingMap(String, Map) - Method in class com.tangosol.net.AbstractBackingMapManager
- 
Release the specified Map that was created using theBackingMapManager.instantiateBackingMap(String)method.
- releaseBackingMap(String, Map) - Method in interface com.tangosol.net.BackingMapManager
- 
Release the specified Map that was created using theBackingMapManager.instantiateBackingMap(String)method.
- releaseBackingMap(String, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Release the specified Map that was created using theBackingMapManager.instantiateBackingMap(String)method.
- releaseBackingMap(String, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.PartitionedBackingMapManager
- 
Deprecated.Release the specified Map that was created using theBackingMapManager.instantiateBackingMap(String)method.
- releaseBackingMap(String, Map) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Release the specified Map that was created using theBackingMapManager.instantiateBackingMap(String)method.
- releaseBackingMap(String, Map) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.PartitionedBackingMapManager
- 
Release the specified Map that was created using theBackingMapManager.instantiateBackingMap(String)method.
- releaseBackupMap(String, Map, Map) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Release the specified Map that was created using theExtensibleConfigurableCacheFactory.Manager.instantiateBackupMap(String)method.
- releaseBuffer(int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Release the specified buffer.
- releaseBuffers() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Release the internal buffers held by the WriteBuffer.
- releaseCache(NamedCache) - Static method in class com.tangosol.net.CacheFactory
- 
Release local resources associated with the specified instance of the cache.
- releaseCache(NamedCache) - Method in interface com.tangosol.net.CacheService
- 
Release local resources associated with the specified instance of the cache.
- releaseCache(NamedCache) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Release a cache and its associated resources.
- releaseCache(NamedCache) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Release a cache and its associated resources.
- releaseCache(NamedCache) - Method in class com.tangosol.net.WrapperCacheService
- 
Release local resources associated with the specified instance of the cache.
- releaseCache(NamedCache<?, ?>) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Release a cache and its associated resources.
- releaseCache(NamedCache, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Release a cache managed by this factory, optionally destroying it.
- releaseCache(NamedCache, boolean) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Release a cache managed by this factory, optionally destroying it.
- releaseCache(String) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- 
release cache namedsName
- releaseClosedStatus(Object) - Method in class com.tangosol.net.cache.OverflowMap
- 
Helper method to encapsulate the release of a Status object on which closeProcessing() has already been called.
- releaseIndexMap() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Release the the entire index map.
- releaseInternal() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Release the underlying persistent storage.
- releaseIterator(Iterator) - Method in class com.tangosol.util.SegmentedHashMap
- 
Release the (formerly-active) Iterator.
- releaseListeners() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Release thelisteners.
- releaseSession(Session) - Method in interface com.tangosol.net.CacheFactoryBuilder
- releaseSession(Session) - Method in interface com.tangosol.net.SessionProvider
- 
Release theSession.
- releaseThread() - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler.Bundle
- 
Release all bundle resources associated with the current thread.
- releaseThread() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Release all bundle resources associated with the current thread.
- releaseThread() - Method in class com.tangosol.net.cache.AbstractEntryBundler.Bundle
- 
Release all bundle resources associated with the current thread.
- releaseThread() - Method in class com.tangosol.net.cache.AbstractKeyBundler.Bundle
- 
Release all bundle resources associated with the current thread.
- releaseTopic(NamedTopic) - Method in interface com.tangosol.net.TopicService
- 
Release local resources associated with the specified instance of the topic.
- releaseTopic(NamedTopic<?>) - Method in interface com.tangosol.net.ConfigurableCacheFactory
- 
Release aNamedTopicand its associated resources.
- releaseTopic(NamedTopic<?>) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.This method will throw anUnsupportedOperationExceptionasNamedTopics are not supported by DefaultConfigurableCacheFactory.
- releaseTopic(NamedTopic<?>) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Release aNamedTopicand its associated resources.
- remainingTimeoutMillis() - Static method in class com.oracle.coherence.common.base.Timeout
- 
Return the number of milliseconds before this thread will timeout.
- Remote - Class in com.tangosol.util.function
- 
Helper interfaces and methods that enable capture of standard JDK functional interfaces as serializable lambdas.
- Remote - Annotation Type in com.oracle.coherence.cdi
- 
A qualifier annotation used when injecting Coherence resource to indicate that a resource is remote.
- Remote() - Constructor for class com.tangosol.util.function.Remote
- Remote.BiConsumer<T,U> - Interface in com.tangosol.util.function
- 
Represents an operation that accepts two input arguments and returns no result.
- Remote.BiFunction<T,U,R> - Interface in com.tangosol.util.function
- 
Represents a function that accepts two arguments and produces a result.
- Remote.BinaryOperator<T> - Interface in com.tangosol.util.function
- 
Represents an operation upon two operands of the same type, producing a result of the same type as the operands.
- Remote.BiPredicate<T,U> - Interface in com.tangosol.util.function
- 
Represents a predicate (boolean-valued function) of two arguments.
- Remote.BooleanSupplier - Interface in com.tangosol.util.function
- 
Represents a supplier ofboolean-valued results.
- Remote.Callable<V> - Interface in com.tangosol.util.function
- 
A task that returns a result and may throw an exception.
- Remote.Comparator<T> - Interface in com.tangosol.util.function
- 
A comparison function, which imposes a total ordering on some collection of objects.
- Remote.Consumer<T> - Interface in com.tangosol.util.function
- 
Represents an operation that accepts a single input argument and returns no result.
- Remote.DoubleBinaryOperator - Interface in com.tangosol.util.function
- 
Represents an operation upon twodouble-valued operands and producing adouble-valued result.
- Remote.DoubleConsumer - Interface in com.tangosol.util.function
- 
Represents an operation that accepts a singledouble-valued argument and returns no result.
- Remote.DoubleFunction<R> - Interface in com.tangosol.util.function
- 
Represents a function that accepts a double-valued argument and produces a result.
- Remote.DoublePredicate - Interface in com.tangosol.util.function
- 
Represents a predicate (boolean-valued function) of onedouble-valued argument.
- Remote.DoubleSupplier - Interface in com.tangosol.util.function
- 
Represents a supplier ofdouble-valued results.
- Remote.DoubleToIntFunction - Interface in com.tangosol.util.function
- 
Represents a function that accepts a double-valued argument and produces an int-valued result.
- Remote.DoubleToLongFunction - Interface in com.tangosol.util.function
- 
Represents a function that accepts a double-valued argument and produces a long-valued result.
- Remote.DoubleUnaryOperator - Interface in com.tangosol.util.function
- 
Represents an operation on a singledouble-valued operand that produces adouble-valued result.
- Remote.Function<T,R> - Interface in com.tangosol.util.function
- 
Represents a function that accepts one argument and produces a result.
- Remote.IntBinaryOperator - Interface in com.tangosol.util.function
- 
Represents an operation upon twoint-valued operands and producing anint-valued result.
- Remote.IntConsumer - Interface in com.tangosol.util.function
- 
Represents an operation that accepts a singleint-valued argument and returns no result.
- Remote.IntFunction<R> - Interface in com.tangosol.util.function
- 
Represents a function that accepts an int-valued argument and produces a result.
- Remote.IntPredicate - Interface in com.tangosol.util.function
- 
Represents a predicate (boolean-valued function) of oneint-valued argument.
- Remote.IntSupplier - Interface in com.tangosol.util.function
- 
Represents a supplier ofint-valued results.
- Remote.IntToDoubleFunction - Interface in com.tangosol.util.function
- 
Represents a function that accepts an int-valued argument and produces a double-valued result.
- Remote.IntToLongFunction - Interface in com.tangosol.util.function
- 
Represents a function that accepts an int-valued argument and produces a long-valued result.
- Remote.IntUnaryOperator - Interface in com.tangosol.util.function
- 
Represents an operation on a singleint-valued operand that produces anint-valued result.
- Remote.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theRemoteannotation.
- Remote.LongBinaryOperator - Interface in com.tangosol.util.function
- 
Represents an operation upon twolong-valued operands and producing along-valued result.
- Remote.LongConsumer - Interface in com.tangosol.util.function
- 
Represents an operation that accepts a singlelong-valued argument and returns no result.
- Remote.LongFunction<R> - Interface in com.tangosol.util.function
- 
Represents a function that accepts a long-valued argument and produces a result.
- Remote.LongPredicate - Interface in com.tangosol.util.function
- 
Represents a predicate (boolean-valued function) of onelong-valued argument.
- Remote.LongSupplier - Interface in com.tangosol.util.function
- 
Represents a supplier oflong-valued results.
- Remote.LongToDoubleFunction - Interface in com.tangosol.util.function
- 
Represents a function that accepts a long-valued argument and produces a double-valued result.
- Remote.LongToIntFunction - Interface in com.tangosol.util.function
- 
Represents a function that accepts a long-valued argument and produces an int-valued result.
- Remote.LongUnaryOperator - Interface in com.tangosol.util.function
- 
Represents an operation on a singlelong-valued operand that produces along-valued result.
- Remote.ObjDoubleConsumer<T> - Interface in com.tangosol.util.function
- 
Represents an operation that accepts an object-valued and adouble-valued argument, and returns no result.
- Remote.ObjIntConsumer<T> - Interface in com.tangosol.util.function
- 
Represents an operation that accepts an object-valued and aint-valued argument, and returns no result.
- Remote.ObjLongConsumer<T> - Interface in com.tangosol.util.function
- 
Represents an operation that accepts an object-valued and along-valued argument, and returns no result.
- Remote.Predicate<T> - Interface in com.tangosol.util.function
- 
Represents a predicate (boolean-valued function) of one argument.
- Remote.Runnable - Interface in com.tangosol.util.function
- 
TheRunnableinterface should be implemented by any class whose instances are intended to be executed by a thread.
- Remote.Supplier<T> - Interface in com.tangosol.util.function
- 
Represents a supplier of results.
- Remote.ToBigDecimalFunction<T> - Interface in com.tangosol.util.function
- 
Represents a function that produces a BigDecimal-valued result.
- Remote.ToComparableFunction<T,R extends Comparable<? super R>> - Interface in com.tangosol.util.function
- 
Represents a function that produces a Comparable-valued result.
- Remote.ToDoubleBiFunction<T,U> - Interface in com.tangosol.util.function
- 
Represents a function that accepts two arguments and produces a double-valued result.
- Remote.ToDoubleFunction<T> - Interface in com.tangosol.util.function
- 
Represents a function that produces a double-valued result.
- Remote.ToIntBiFunction<T,U> - Interface in com.tangosol.util.function
- 
Represents a function that accepts two arguments and produces an int-valued result.
- Remote.ToIntFunction<T> - Interface in com.tangosol.util.function
- 
Represents a function that produces an int-valued result.
- Remote.ToLongBiFunction<T,U> - Interface in com.tangosol.util.function
- 
Represents a function that accepts two arguments and produces a long-valued result.
- Remote.ToLongFunction<T> - Interface in com.tangosol.util.function
- 
Represents a function that produces a long-valued result.
- Remote.UnaryOperator<T> - Interface in com.tangosol.util.function
- 
Represents an operation on a single operand that produces a result of the same type as its operand.
- remoteAtomicBoolean(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicBooleaninstance for the specified name.
- remoteAtomicBoolean(String, boolean) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicBooleaninstance for the specified name and initial value.
- RemoteAtomicBoolean - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAtomicBoolean, backed by a CoherenceNamedMapentry.
- RemoteAtomicBoolean(NamedMap<String, AtomicBoolean>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- 
ConstructRemoteAtomicBooleaninstance.
- remoteAtomicInteger(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicIntegerinstance for the specified name.
- remoteAtomicInteger(String, int) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicIntegerinstance for the specified name and initial value.
- RemoteAtomicInteger - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAtomicInteger, backed by a CoherenceNamedMapentry.
- RemoteAtomicInteger(NamedMap<String, AtomicInteger>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- 
ConstructRemoteAtomicIntegerinstance.
- remoteAtomicLong(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicLonginstance for the specified name.
- remoteAtomicLong(String, long) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicLonginstance for the specified name and initial value.
- RemoteAtomicLong - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAtomicLong, backed by a CoherenceNamedMapentry.
- remoteAtomicMarkableReference(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicMarkableReferenceinstance for the specified name.
- remoteAtomicMarkableReference(String, V, boolean) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicMarkableReferenceinstance for the specified name and initial value and mark.
- RemoteAtomicMarkableReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAtomicMarkableReference, backed by a CoherenceNamedMapentry.
- RemoteAtomicMarkableReference(NamedMap<String, AtomicMarkableReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- 
ConstructRemoteAtomicMarkableReferenceinstance.
- remoteAtomicReference(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicReferenceinstance for the specified name.
- remoteAtomicReference(String, V) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicReferenceinstance for the specified name and initial value.
- RemoteAtomicReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAtomicReference, backed by a CoherenceNamedMapentry.
- RemoteAtomicReference(NamedMap<String, AtomicReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- 
ConstructRemoteAtomicReferenceinstance.
- remoteAtomicStampedReference(String) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicStampedReferenceinstance for the specified name.
- remoteAtomicStampedReference(String, V, int) - Static method in class com.oracle.coherence.concurrent.atomic.Atomics
- 
ReturnRemoteAtomicStampedReferenceinstance for the specified name and initial value and stamp.
- RemoteAtomicStampedReference<V> - Class in com.oracle.coherence.concurrent.atomic
- 
The remote implementation ofAtomicStampedReference, backed by a CoherenceNamedMapentry.
- RemoteAtomicStampedReference(NamedMap<String, AtomicStampedReference<V>>, String) - Constructor for class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- 
ConstructRemoteAtomicStampedReferenceinstance.
- RemoteCache<K,V> - Class in com.tangosol.coherence.jcache.remotecache
- 
A remote partitioned-cache implementation of aCachebased on a Coherence <partitioned-cache>.
- RemoteCache(CoherenceBasedCacheManager, String, RemoteCacheConfiguration) - Constructor for class com.tangosol.coherence.jcache.remotecache.RemoteCache
- 
Constructs aRemoteCacheconfigured byPartitionedCacheConfigurationin context ofCoherenceBasedCacheManagerwith JCache namesJCacheName.
- RemoteCacheConfiguration<K,V> - Class in com.tangosol.coherence.jcache.remotecache
- 
AConfigurationfor aCachebased on a Coherence <remote-scheme>, or more specifically aNamedCache.
- RemoteCacheConfiguration() - Constructor for class com.tangosol.coherence.jcache.remotecache.RemoteCacheConfiguration
- 
Constructs a defaultRemoteCacheConfiguration.
- RemoteCacheConfiguration(CompleteConfiguration<K, V>) - Constructor for class com.tangosol.coherence.jcache.remotecache.RemoteCacheConfiguration
- 
Constructs aRemoteCacheConfigurationbased on aCompleteConfiguration.
- RemoteCacheScheme - Class in com.tangosol.coherence.config.scheme
- 
TheRemoteCacheSchemeis responsible for building a remote cache.
- RemoteCacheScheme() - Constructor for class com.tangosol.coherence.config.scheme.RemoteCacheScheme
- 
Constructs aRemoteCacheScheme.
- RemoteCollector<T,A,R> - Interface in com.tangosol.util.stream
- 
An extension ofCollectorthat adds serialization support.
- RemoteCollectors - Class in com.tangosol.util.stream
- 
Static factory for variousRemoteCollectors that can be executed in parallel in a distributed environment.
- RemoteCollectors() - Constructor for class com.tangosol.util.stream.RemoteCollectors
- remoteCountDownLatch(String, int) - Static method in class com.oracle.coherence.concurrent.Latches
- 
Return a singleton instance of aRemoteCountDownLatchwith a specified name and count.
- RemoteCountDownLatch - Class in com.oracle.coherence.concurrent
- 
A distributed count down latch with the same basic behavior and semantics as the JavaCountDownLatchclass, but uses theNamedCacheto support for synchronization aid that allows one or more threads across multiple cluster members to wait until a set of operations being performed in other threads/members completes.
- RemoteCountDownLatch(String, int, NamedMap<String, LatchCounter>) - Constructor for class com.oracle.coherence.concurrent.RemoteCountDownLatch
- 
Constructs aRemoteCountDownLatchinitialized with the given count.
- RemoteDoubleStream - Interface in com.tangosol.util.stream
- 
A sequence of primitive double-valued elements supporting sequential and parallel aggregate operations.
- RemoteExecutor - Interface in com.oracle.coherence.concurrent.executor
- RemoteIntStream - Interface in com.tangosol.util.stream
- 
A sequence of primitive int-valued elements supporting sequential and parallel aggregate operations.
- RemoteInvocationScheme - Class in com.tangosol.coherence.config.scheme
- 
TheRemoteInvocationSchemeclass builds a remote invocation service.
- RemoteInvocationScheme() - Constructor for class com.tangosol.coherence.config.scheme.RemoteInvocationScheme
- 
Constructs aRemoteCacheScheme.
- remoteLock(String) - Static method in class com.oracle.coherence.concurrent.locks.Locks
- 
Return a singleton instance of a remoteRemoteLockwith a specified name.
- RemoteLock - Class in com.oracle.coherence.concurrent.locks
- 
A reentrant mutual exclusion distributedLockwith the same basic behavior and semantics as the implicit monitor lock accessed usingsynchronizedmethods and statements, and theReentrantLockclass, but with support for access synchronization across multiple cluster members.
- RemoteLongStream - Interface in com.tangosol.util.stream
- 
A sequence of primitive long-valued elements supporting sequential and parallel aggregate operations.
- RemoteMember - Class in com.tangosol.net.proxy
- 
A RemoteMember is a specialMemberimplementation that carries the remote IP/port information of a member that isn't in the cluster.
- RemoteMember(InetAddress, int) - Constructor for class com.tangosol.net.proxy.RemoteMember
- 
Construct a RemoteMember.
- RemotePipeline<S_OUT> - Interface in com.tangosol.util.stream
- 
A serializable pipeline of intermediate stream operations.
- remoteReadWriteLock(String) - Static method in class com.oracle.coherence.concurrent.locks.Locks
- 
Return a singleton instance of a remoteRemoteReadWriteLockwith a specified name.
- RemoteReadWriteLock - Class in com.oracle.coherence.concurrent.locks
- 
An implementation ofReadWriteLocksupporting similar semantics toReentrantReadWriteLock, but with support for access synchronization across multiple cluster members.
- RemoteReadWriteLock.ReadLock - Class in com.oracle.coherence.concurrent.locks
- 
The lock returned by methodRemoteReadWriteLock.readLock().
- RemoteReadWriteLock.WriteLock - Class in com.oracle.coherence.concurrent.locks
- 
The lock returned by methodRemoteReadWriteLock.writeLock().
- remoteSemaphore(String, int) - Static method in class com.oracle.coherence.concurrent.Semaphores
- 
Return a singleton instance of aRemoteSemaphorewith a specified name and number of permits.
- RemoteSemaphore - Class in com.oracle.coherence.concurrent
- 
A distributed counting semaphore.
- RemoteSemaphore(String, int, NamedMap<String, SemaphoreStatus>) - Constructor for class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Create an instance ofRemoteSemaphore
- RemoteStream<T> - Interface in com.tangosol.util.stream
- 
This interface is an extension ofjava.util.stream.Streamthat captures lambdas used as method arguments as serializable lambdas.
- remove() - Method in class com.tangosol.coherence.dsltools.termtrees.Term.TermIterator
- remove() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEventFilteringIterator
- remove() - Method in class com.tangosol.coherence.jcache.common.MapEntryIteratorToCacheEntryIteratorAdapter
- remove() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache.EntryIterator
- remove() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache.EntryIterator
- remove() - Method in class com.tangosol.coherence.rest.EntryResource
- 
Remove entry from the cache.
- remove() - Method in class com.tangosol.coherence.rest.EntrySetResource
- 
Remove the entries from the cache.
- remove() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Wait for item in the queue to ripen (to be ready to be removed), and when there is one and it is ripe, then remove and return it.
- remove() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
- 
Removes from the underlying collection the last element returned by the iterator.
- remove() - Method in class com.tangosol.net.LoadBalancer.Queue
- 
Wait for and remove an item from the from of the queue.
- remove() - Method in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
- remove() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet.EntrySetIterator
- remove() - Method in class com.tangosol.run.xml.SimpleElement.ElementIterator
- remove() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.EntrySetIterator
- 
Removes from the underlying collection the last element returned by the iterator.
- remove() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection.ValuesIterator
- 
Removes from the underlying collection the last element returned by the iterator.
- remove() - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- remove() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Removes from the underlying collection the last element returned by the iterator (optional operation).
- remove() - Method in class com.tangosol.util.ChainedEnumerator
- 
Remove the last-returned element that was returned by the Iterator.
- remove() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet.ConverterIterator
- remove() - Method in class com.tangosol.util.ConverterCollections.ConverterEnumerator
- 
Remove the last-returned element that was returned by the Iterator.
- remove() - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- remove() - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
Removes from the underlying collection the last element returned by the iterator (optional operation).
- remove() - Method in class com.tangosol.util.DeltaSet.DeltaIterator
- 
Removes from the underlying Collection the last element returned by the Iterator .
- remove() - Method in class com.tangosol.util.Dequeue
- 
Remove the last-returned element that was returned by the Iterator.
- remove() - Method in class com.tangosol.util.EnumerationIterator
- 
Remove the last-returned element that was returned by the Iterator.
- remove() - Method in class com.tangosol.util.FilterEnumerator
- 
Remove the last-returned element that was returned by the Iterator.
- remove() - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
- remove() - Method in class com.tangosol.util.IteratorEnumerator
- 
Remove the last-returned element that was returned by the Iterator.
- remove() - Method in interface com.tangosol.util.LongArray.Iterator
- 
Removes from the underlying collection the last element returned by the iterator (optional operation).
- remove() - Method in class com.tangosol.util.NullImplementation.NullEnumerator
- 
Removes from the underlying Collection the last element returned by the Iterator .
- remove() - Method in class com.tangosol.util.PagedIterator
- 
Removes from the underlying collection the last element returned by the iterator.
- remove() - Static method in class com.tangosol.util.Processors
- 
Construct a remove processor that unconditionally removes an InvocableMap entry.
- remove() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
- 
Removes from the underlying collection the last element returned by the iterator.
- remove() - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Removes from the list the last element that was returned by next or previous.
- remove() - Method in class com.tangosol.util.SimpleEnumerator
- 
Remove the last-returned element that was returned by the Iterator.
- remove() - Method in class com.tangosol.util.SimpleLongArray.Iterator
- 
Removes from the underlying collection the last element returned by the iterator (optional operation).
- remove() - Method in interface com.tangosol.util.Streamer
- 
This operation is not supported.
- remove() - Method in class com.tangosol.util.SubSet.SubSetIterator
- remove() - Method in class com.tangosol.util.ThreadLocalObject
- 
Remove the ThreadLocalObject for the current thread.
- remove() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- remove(boolean) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Remove this Entry from the Map if it is present in the Map.
- remove(boolean) - Method in interface com.tangosol.util.BinaryEntry
- 
Remove this Entry from the Map if it is present in the Map.
- remove(boolean) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Remove this Entry from the Map if it is present in the Map.
- remove(boolean) - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Remove this Entry from the Map if it is present in the Map.
- remove(boolean) - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- remove(boolean) - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Remove this Entry from the Map if it is present in the Map.
- remove(boolean) - Static method in class com.tangosol.util.Processors
- 
Construct a remove processor that unconditionally removes an InvocableMap entry, and optionally returns the removed value.
- remove(boolean) - Method in class com.tangosol.util.SimpleMapEntry
- remove(int) - Method in class com.tangosol.net.partition.PartitionSet
- 
Remove the specified partition from the set.
- remove(int) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
- 
Removes the element at the specified position in this list.
- remove(int) - Method in class com.tangosol.util.CircularArrayList
- 
Removes the element at the specified position in this list.
- remove(int) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- remove(int) - Method in class com.tangosol.util.InflatableList
- remove(int) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Removes the element at the specified position in this list (optional operation).
- remove(int) - Method in class com.tangosol.util.SafeLinkedList
- 
Removes the element at the specified position in this List.
- remove(int) - Method in class com.tangosol.util.SubList
- remove(int) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- remove(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Wait for the next item in the queue to ripen (to be ready to be removed), and remove and return it, or return null if the specified wait time has passed.
- remove(long) - Method in class com.tangosol.util.AbstractLongArray
- 
Remove the specified key from the LongArray, returning its associated value.
- remove(long) - Method in class com.tangosol.util.AbstractSafeLongArray
- remove(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Remove the specified index from the LongArray, returning its associated value.
- remove(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- remove(long) - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Remove the specified index from the LongArray, returning its associated value.
- remove(long) - Method in interface com.tangosol.util.LongArray
- 
Remove the specified index from the LongArray, returning its associated value.
- remove(long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- remove(long) - Method in class com.tangosol.util.SimpleLongArray
- 
Remove the specified index from the LongArray, returning its associated value.
- remove(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- remove(long, long) - Method in class com.tangosol.util.AbstractLongArray
- 
Remove all nodes in the specified range.
- remove(long, long) - Method in class com.tangosol.util.AbstractSafeLongArray
- remove(long, long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Remove all nodes in the specified range.
- remove(long, long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- remove(long, long) - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Remove all nodes in the specified range.
- remove(long, long) - Method in interface com.tangosol.util.LongArray
- 
Remove all nodes in the specified range.
- remove(long, long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- remove(long, long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- remove(CacheRequestHolder<RemoveRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute aRemoveRequestrequest.
- remove(RemoveRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Remove the mapping that is associated with the specified key.
- remove(RemoveRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- remove(RemoveRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- remove(Guardable) - Method in class com.tangosol.net.GuardSupport
- 
Remove the specified Guardable from the set of Guardables managed by this manager.
- remove(MBeanMetric.Identifier) - Method in class com.oracle.coherence.mp.metrics.CdiMetricsRegistryAdapter
- remove(MBeanMetric.Identifier) - Method in class com.oracle.coherence.mp.metrics.MpMetricsRegistryAdapter
- remove(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSet
- 
Remove the specified PartitionSet from this set.
- remove(AbstractSparseArray.Node<V>) - Method in class com.tangosol.util.AbstractSparseArray
- 
Remove the specified node from the tree.
- remove(Filter) - Static method in class com.tangosol.util.Processors
- 
Construct a remove processor that removes an InvocableMap entry if and only if the filter applied to the entry evaluates to true.
- remove(Filter, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct a remove processor that removes an InvocableMap entry if and only if the filter applied to the entry evaluates to true.
- remove(Comparable) - Method in class com.tangosol.util.Tree
- 
Remove the specified key from the tree, returning its associated value.
- remove(Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- remove(Object) - Method in class com.tangosol.io.nio.BinaryMap.KeySet
- 
Removes the specified element from this Set of keys if it is present by removing the associated entry from the underlying Map.
- remove(Object) - Method in class com.tangosol.io.nio.BinaryMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.BundlingNamedCache
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.CachingMap
- remove(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- remove(Object) - Method in class com.tangosol.net.cache.LocalCache
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.OverflowMap.EntrySet.EntrySetIterator
- 
Remove the specified item.
- remove(Object) - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet.InternalKeySetIterator
- 
Remove the specified item.
- remove(Object) - Method in class com.tangosol.net.cache.OverflowMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- remove(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- 
Removes the specified element from this Set of entries if it is present by removing the associated entry from the underlying Map.
- remove(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EvictingBackupMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- 
Removes the specified element from this Set of keys if it is present by removing the associated entry from the underlying Map.
- remove(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Remove a key from the queue if the key is in the queue.
- remove(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Remove a key from the queue if the key is in the queue.
- remove(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.SerializationMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.net.CompositeAddressProvider.AddressIterator
- 
Remove the specified item.
- remove(Object) - Method in class com.tangosol.net.CompositeAddressProvider
- 
Removes the specified element from this set if it is present (optional operation).
- remove(Object) - Method in class com.tangosol.net.partition.AbstractPartitionedIterator
- remove(Object) - Method in class com.tangosol.net.partition.PartitionedIterator
- remove(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.PartitionedIterator
- 
Remove the specified item.
- remove(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- remove(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
- 
Removes the specified element from this Set of entries if it is present by removing the associated entry from the underlying Map.
- remove(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
- 
Removes the specified element from this Set of keys if it is present by removing the associated key from the underlying Map.
- remove(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
- 
Removes the specified element from this Collection of values if it is present by removing the associated key/value mapping from the underlying Map.
- remove(Object) - Method in class com.tangosol.util.AbstractKeySetBasedMap.KeyIterator
- 
Remove the specified item.
- remove(Object) - Method in class com.tangosol.util.ChainedCollection
- remove(Object) - Method in class com.tangosol.util.ChainedMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.util.ChainedSet
- remove(Object) - Method in interface com.tangosol.util.ConcurrentMap
- 
Removes the mapping for this key from this map if present (optional operation).
- remove(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- remove(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- remove(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- remove(Object) - Method in class com.tangosol.util.CopyOnWriteMap.EntrySet
- remove(Object) - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
- remove(Object) - Method in class com.tangosol.util.CopyOnWriteMap
- remove(Object) - Method in class com.tangosol.util.DeltaSet
- 
Removes a single instance of the specified element from this Collection, if it is present (optional operation).
- remove(Object) - Method in class com.tangosol.util.InflatableCollection
- remove(Object) - Method in class com.tangosol.util.LiteSet
- 
Removes the specified element from this Set if it is present.
- remove(Object) - Method in class com.tangosol.util.MapSet
- 
Removes the specified element from this Set if it is present.
- remove(Object) - Method in class com.tangosol.util.NullImplementation.NullMap
- remove(Object) - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Removes a single instance of the specified element from this Collection, if it is present (optional operation).
- remove(Object) - Method in class com.tangosol.util.ObservableHashMap
- 
Remove an entry from the cache.
- remove(Object) - Method in class com.tangosol.util.OpenHashMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.util.OpenHashSet
- remove(Object) - Method in interface com.tangosol.util.PagedIterator.Advancer
- 
Remove the specified object from the underlying collection.
- remove(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Removes a single instance of the specified element from this Collection, if it is present (optional operation).
- remove(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Removes a single instance of the specified element from this Collection, if it is present (optional operation).
- remove(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.util.SafeHashMap.EntrySet.EntrySetIterator
- 
Remove the specified item.
- remove(Object) - Method in class com.tangosol.util.SafeHashMap.EntrySet
- 
Removes the specified element from this Set of entries if it is present by removing the associated entry from the underlying Map.
- remove(Object) - Method in class com.tangosol.util.SafeHashMap.KeySet
- 
Removes the specified element from this Set of keys if it is present by removing the associated entry from the underlying Map.
- remove(Object) - Method in class com.tangosol.util.SafeHashMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.util.SafeLinkedList
- 
Removes the first occurrence in this List of the specified element.
- remove(Object) - Method in class com.tangosol.util.SafeSortedMap
- remove(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- remove(Object) - Method in class com.tangosol.util.SegmentedHashMap.EntrySet.EntrySetIterator
- 
Remove the specified item from the underlying Map.
- remove(Object) - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
- 
Removes the specified element from this Set of entries if it is present by removing the associated entry from the underlying Map.
- remove(Object) - Method in class com.tangosol.util.SegmentedHashMap.KeySet
- 
Removes the specified element from this Set of keys if it is present by removing the associated entry from the underlying Map.
- remove(Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.util.SetMap
- remove(Object) - Method in class com.tangosol.util.SortedBag
- remove(Object) - Method in class com.tangosol.util.SubList
- remove(Object) - Method in class com.tangosol.util.SubSet
- remove(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- remove(Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- remove(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- remove(Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- remove(Object) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Removes the mapping for this key from this map if present.
- remove(Object) - Method in class com.tangosol.util.WrapperObservableMap
- 
Removes the mapping for this key from this map if present.
- remove(Object, Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- remove(Object, Object) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- remove(Object, Object) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- remove(Object, Object) - Method in interface com.tangosol.util.InvocableMap
- remove(Object, Object) - Method in class com.tangosol.util.SafeHashMap
- remove(Object, Object) - Method in class com.tangosol.util.SafeSortedMap
- remove(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- remove(Object, Object) - Method in class com.tangosol.util.SegmentedConcurrentMap
- remove(Object, Object) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- remove(Object, Object) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- remove(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- remove(String) - Method in interface com.tangosol.persistence.SnapshotArchiver
- 
Remove the archived snapshot with the specified identifier.
- remove(String) - Method in class com.tangosol.util.StringTable
- 
Remove the specified string from the table, returning its associated value.
- remove(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aRemoveRequest.
- remove(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aRemoveMappingRequest.
- remove(EventListener) - Method in class com.tangosol.util.Listeners
- 
Remove a listener.
- remove(K) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- remove(K) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- remove(K) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- remove(K) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- remove(K) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Removes the mapping for a key from this map if it is present.
- remove(K, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- remove(K, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- remove(K, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- remove(K, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- remove(K, V) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Removes the entry for the specified key only if it is currently mapped to the specified value.
- remove(T) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove the specified entity.
- remove(T) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove the specified entity.
- remove(T, boolean) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove the specified entity.
- remove(T, boolean) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove specified entity.
- REMOVE_ARCHIVED_SNAPSHOT_BEGIN - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the start of purging (removing) an archived snapshot.
- REMOVE_ARCHIVED_SNAPSHOT_END - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the end of purging (removing) an archived snapshot.
- REMOVE_SNAPSHOT_BEGIN - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the start of removing a snapshot.
- REMOVE_SNAPSHOT_END - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the end of removing a snapshot.
- RemoveAction() - Constructor for class com.tangosol.util.SegmentedConcurrentMap.RemoveAction
- RemoveAction() - Constructor for class com.tangosol.util.SegmentedHashMap.RemoveAction
- removeAll() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- removeAll() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- removeAll() - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- removeAll() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- removeAll() - Method in class com.tangosol.util.Listeners
- 
Remove all listeners.
- removeAll(Filter<?>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove all entities based on the specified criteria.
- removeAll(Filter<?>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove all entities based on the specified criteria.
- removeAll(Filter<?>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Removes all of the mappings that satisfy the specified filter from this map.
- removeAll(Filter<?>, boolean) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove all entities based on the specified criteria.
- removeAll(Filter<?>, boolean) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove all entities based on the specified criteria.
- removeAll(StringTable) - Method in class com.tangosol.util.StringTable
- 
Removes from this StringTable all of its nodes that are contained in the specified StringTable.
- removeAll(Tree) - Method in class com.tangosol.util.Tree
- 
Removes from this Tree all of its nodes that are contained in the specified Tree.
- removeAll(Collection) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- 
Removes the provided collection from this Set of keys by removing the associated entries from the underlying Map.
- removeAll(Collection) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Remove the collection of keys from this ReadWriteBackingMap.
- removeAll(Collection) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.KeySet
- removeAll(Collection) - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
- removeAll(Collection) - Method in class com.tangosol.util.InflatableCollection
- removeAll(Collection) - Method in class com.tangosol.util.MapSet
- 
Removes from this Set all of its elements that are contained in the specified Collection.
- removeAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Removes all this Collection's elements that are also contained in the specified Collection (optional operation).
- removeAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Removes all this Collection's elements that are also contained in the specified Collection (optional operation).
- removeAll(Collection<?>) - Method in class com.tangosol.util.ChainedCollection
- removeAll(Collection<?>) - Method in class com.tangosol.util.ChainedSet
- removeAll(Collection<?>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- removeAll(Collection<?>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- removeAll(Collection<?>) - Method in class com.tangosol.util.LiteSet
- 
Removes from this Set all of its elements that are contained in the specified Collection.
- removeAll(Collection<?>) - Method in class com.tangosol.util.SubList
- removeAll(Collection<?>) - Method in class com.tangosol.util.SubSet
- removeAll(Collection<?>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- removeAll(Collection<?>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- removeAll(Collection<? extends K>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Removes all of the mappings from the specified keys from this map, if they are present in the map.
- removeAll(Collection<? extends T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove the specified entities.
- removeAll(Collection<? extends T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove the specified entities.
- removeAll(Collection<? extends T>, boolean) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove the specified entities.
- removeAll(Collection<? extends T>, boolean) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove the specified entities.
- removeAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- removeAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- removeAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- removeAll(Set<? extends K>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- removeAll(Stream<? extends T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove the specified entities.
- removeAll(Stream<? extends T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove the specified entities.
- removeAll(Stream<? extends T>, boolean) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove the specified entities.
- removeAll(Stream<? extends T>, boolean) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove specified entities.
- removeAllById(Collection<? extends ID>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove entities with the specified identifiers.
- removeAllById(Collection<? extends ID>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove entities with the specified identifiers.
- removeAllById(Collection<? extends ID>, boolean) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove entities with the specified identifiers.
- removeAllById(Collection<? extends ID>, boolean) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove entities with the specified identifiers.
- removeAllElements() - Method in class com.tangosol.util.Dequeue
- 
Removes all items from the dequeue.
- removeArchivedSnapshot(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Purge the archived snapshot from a centralized location.
- removeBlind(Object) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.cache.CacheStoreMap.ReadWriteMap
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.cache.OverflowMap
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- removeBlind(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.cache.SerializationMap
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Removes the mapping for this key from this map if present.
- removeBlind(Object) - Method in class com.tangosol.util.WrapperObservableMap
- 
Removes the mapping for this key from this map if present.
- RemoveBundler() - Constructor for class com.tangosol.net.cache.BundlingNamedCache.RemoveBundler
- removeById(ID) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove the entity with a specified identifier.
- removeById(ID) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove the entity with a specified identifier.
- removeById(ID, boolean) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Remove the entity with a specified identifier.
- removeById(ID, boolean) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Remove the entity with a specified identifier.
- removeCacheToConfigurationMapping(JCacheIdentifier) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- 
remove entry with key of sName
- removeCountDownLatch(String) - Static method in class com.oracle.coherence.concurrent.Latches
- 
Remove the named countdown latch.
- Removed - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any REMOVED event.
- REMOVED - com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent.Type
- 
A REMOVED event is raised after theEventInterceptorwas successfully removed from theEventDispatcher.
- REMOVED - com.tangosol.net.events.partition.cache.EntryEvent.Type
- 
ThisEntryEventis dispatched after one or moreBinaryEntry(s) have been removed from the backing-map.
- REMOVED - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Marker object used byReadWriteBackingMap.Entryto indicateremovewas called on the Entry.
- REMOVED - Static variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
- Removed.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theRemovedannotation.
- removeElement(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Remove all immediate child elements with the given name
- removeEmptyElements(XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Remove all empty descendant elements.
- removeEntryInternal(SafeHashMap.Entry<K, V>) - Method in class com.tangosol.util.SafeHashMap
- 
Removes the passed Entry from the map.
- removeEventInterceptor(EventInterceptor<E>) - Method in interface com.tangosol.net.events.EventDispatcher
- 
Remove anEventInterceptorfrom this dispatcher.
- removeEventInterceptor(String) - Method in interface com.tangosol.net.events.EventDispatcher
- 
Remove anEventInterceptorfrom this dispatcher.
- removeEvicted(OldCache.Entry) - Method in class com.tangosol.net.cache.LocalCache
- 
Remove an entry (if it is eligible for eviction) because it has expired.
- removeEvicted(OldCache.Entry) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Remove an entry (if it is eligible for eviction) because it has expired.
- removeExpired(OldCache.Entry, boolean) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.useOldCache.removeEvicted(Entry)instead
- removeExtension(String) - Static method in class com.tangosol.io.FileHelper
- 
Removes the extension from a filename.
- removeFilterMapListener(String, String, String, ByteString, long, boolean, boolean, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aMapListenerRequestthat will subscribe toMapEventsfor all entries in a cache matching a filter.
- removeFirst() - Method in class com.tangosol.util.SafeLinkedList
- 
Removes and returns the first element in the list.
- removeFirst() - Method in class com.tangosol.util.SortedBag
- 
Remove and return the least element in this bag, or null if empty.
- removeForwardEntry(Object) - Method in class com.tangosol.util.ConditionalIndex
- 
Remove the forward index entry for the specified key.
- removeForwardEntry(Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Remove the forward index entry for the specified key.
- removeFromWriteQueue(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Remove the specified entry from the WriteQueue.
- removeFunction(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Remove the CohQL function mapping for the specified function name.
- removeIf(Predicate<? super E>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- removeIfExpired(OldCache.Entry) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Remove an entry if it has expired.
- removeImmediate() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Remove the first key from the queue immediately.
- removeIndex(CacheRequestHolder<RemoveIndexRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theRemoveIndexRequestrequest.
- removeIndex(RemoveIndexRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Remove an index from a cache.
- removeIndex(RemoveIndexRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- removeIndex(RemoveIndexRequest, StreamObserver<Empty>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- removeIndex(ValueExtractor<? super T, ? extends E>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
IfContinuousQueryCache.isCacheValues()istrue, the index will be removed locally, however, this call will not cause the index on theNamedCachethisContinuousQueryCachewraps.
- removeIndex(ValueExtractor<? super T, ? extends E>) - Method in class com.tangosol.net.cache.NearCache
- 
Remove an index from this QueryMap.
- removeIndex(ValueExtractor<? super T, ? extends E>) - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Remove an index from this QueryMap.
- removeIndex(ValueExtractor<? super T, ? extends E>) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Remove an index from this QueryMap.
- removeIndex(ValueExtractor<? super T, ? extends E>) - Method in class com.tangosol.util.ConverterCollections.ConverterQueryMap
- 
Remove an index from this QueryMap.
- removeIndex(ValueExtractor<? super T, ? extends E>) - Method in interface com.tangosol.util.QueryMap
- 
Remove an index from this QueryMap.
- removeIndex(ValueExtractor, ObservableMap, Map) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Remove the index keyed by the given extractor from the given map of indexes.
- removeIndex(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aRemoveIndexRequest.
- removeInstance(String) - Static method in class com.tangosol.net.Coherence
- removeInstance(String, ClassLoader) - Static method in class com.tangosol.net.Coherence
- removeIntDecoration(ReadBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Remove a decoration value from the specified ReadBuffer that contains a representation of an IntDecoratedObject.
- removeIntDecoration(Binary) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Deprecated.as of Coherence 3.7.2
- removeInternal(Object, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Implementation of the remove() API.
- removeInternal(Object, boolean, boolean) - Method in class com.tangosol.net.cache.OverflowMap
- 
A combined implementation of remove() and removeBlind() that eliminates duplicate (and muchos complex) code
- removeInternal(Object, SegmentedHashMap.EntryAction, Object) - Method in class com.tangosol.util.SegmentedHashMap
- 
Removes the mapping for this key from this map if present.
- removeInternal(String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Internal implementation to remove the specified archived snapshot.
- removeInternal(String) - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
- removeInternalValueDecoration(Object, int) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Remove a decoration from the specified value in the internal form.
- removeInternalValueDecoration(Object, int) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Remove a decoration from the specified value in the internal form.
- removeInverseMapping(Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Remove the mapping from the given indexed value to the given key from the inverse index.
- removeInverseMapping(Object, Object, Collection) - Method in class com.tangosol.util.SimpleMapIndex
- 
Remove the mapping from the given indexed value to the given key from the inverse index.
- removeInverseMapping(Map, Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Remove the mapping from the given indexed value to the given key from the supplied index.
- removeKeyHolder() - Method in class com.tangosol.net.cache.CachingMap
- 
Remove the key holder from the ThreadLocal object.
- removeKeyMapListener(String, String, String, ByteString, boolean, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aMapListenerRequestthat will subscribe toMapEventsfor a single entry in a cache.
- removeLast() - Method in class com.tangosol.util.SortedBag
- 
Remove and return the greatest element in this bag, or null if empty.
- removeLifecycleListener(LifecycleListener) - Method in class com.tangosol.net.DefaultCacheServer
- 
Remove aLifecycleListenerso that it will no longer be notified of lifecycle events for thisDefaultCacheServer.
- removeListener(AbstractRepositoryBase.Listener<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Unregister a listener that observes all repository events.
- removeListener(Filter<?>, AbstractRepositoryBase.Listener<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Unregister a listener that observes all events for entities that satisfy the specified criteria.
- removeListener(FiniteStateMachineListener<S>) - Method in interface com.tangosol.util.fsm.FiniteStateMachine
- 
Remove aFiniteStateMachineListenerfrom theFiniteStateMachine.
- removeListener(FiniteStateMachineListener<S>) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Remove aFiniteStateMachineListenerfrom theFiniteStateMachine.
- removeListener(MapListener, Filter) - Method in class com.tangosol.util.MapListenerSupport
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeListener(MapListener, Object) - Method in class com.tangosol.util.MapListenerSupport
- 
Remove a map listener that previously signed up for events about a specific key.
- removeListener(MapListener, Set) - Method in class com.tangosol.util.MapListenerSupport
- 
Remove a map listener that previously signed up for events about specific keys.
- removeListener(ID, AbstractRepositoryBase.Listener<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepositoryBase
- 
Unregister a listener that observes all events for a specific entity.
- RemoveListener() - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.RemoveListener
- removeListenerState(Map, Object, MapListener) - Static method in class com.tangosol.util.MapListenerSupport
- 
Remove a state information (lite or standard) associated with specified key and listener.
- removeListenerWithCheck(MapListener, Filter) - Method in class com.tangosol.util.MapListenerSupport
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeListenerWithCheck(MapListener, Object) - Method in class com.tangosol.util.MapListenerSupport
- 
Remove a map listener that previously signed up for events about a specific key.
- removeListenerWithCheck(MapListener, Set) - Method in class com.tangosol.util.MapListenerSupport
- 
Remove a map listener that previously signed up for events about specific keys.
- removeMap(int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MapArray
- 
Remove the mapping for the specified partition ID and its corresponding backing map.
- removeMapListener(MapListener) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- removeMapListener(MapListener) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Remove a standard map listener that previously signed up for all events.
- removeMapListener(MapListener) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Remove a standard map listener that previously signed up for all events.
- removeMapListener(MapListener) - Method in class com.tangosol.net.cache.OverflowMap
- 
Remove a standard map listener that previously signed up for all events.
- removeMapListener(MapListener) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Remove a standard map listener that previously signed up for all events.
- removeMapListener(MapListener) - Method in class com.tangosol.util.NullImplementation.NullObservableMap
- 
Remove a standard map listener that previously signed up for all events.
- removeMapListener(MapListener) - Method in class com.tangosol.util.ObservableHashMap
- removeMapListener(MapListener<? super K, ? super V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- removeMapListener(MapListener<? super K, ? super V_FRONT>, Filter) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- removeMapListener(MapListener<? super K, ? super V_FRONT>, K) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- removeMapListener(MapListener<? super K, ? super V>) - Method in class com.tangosol.net.cache.NearCache
- 
Remove a standard map listener.
- removeMapListener(MapListener<? super K, ? super V>) - Method in interface com.tangosol.util.ObservableMap
- 
Remove a standard map listener that previously signed up for all events.
- removeMapListener(MapListener<? super K, ? super V>) - Method in class com.tangosol.util.WrapperObservableMap
- 
Remove a standard map listener that previously signed up for all events.
- removeMapListener(MapListener<? super K, ? super V>, Filter) - Method in class com.tangosol.net.cache.NearCache
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener<? super K, ? super V>, Filter) - Method in class com.tangosol.util.ObservableHashMap
- removeMapListener(MapListener<? super K, ? super V>, Filter) - Method in interface com.tangosol.util.ObservableMap
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener<? super K, ? super V>, Filter) - Method in class com.tangosol.util.WrapperObservableMap
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener<? super K, ? super V>, K) - Method in class com.tangosol.net.cache.NearCache
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener<? super K, ? super V>, K) - Method in class com.tangosol.util.ObservableHashMap
- removeMapListener(MapListener<? super K, ? super V>, K) - Method in interface com.tangosol.util.ObservableMap
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener<? super K, ? super V>, K) - Method in class com.tangosol.util.WrapperObservableMap
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener<? super TK, ? super TV>) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
- 
Remove a standard map listener that previously signed up for all events.
- removeMapListener(MapListener<? super TK, ? super TV>, Filter) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener<? super TK, ? super TV>, TK) - Method in class com.tangosol.util.ConverterCollections.ConverterObservableMap
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener, Filter) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- removeMapListener(MapListener, Filter) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener, Filter) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener, Filter) - Method in class com.tangosol.net.cache.OverflowMap
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener, Filter) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener, Filter) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener, Filter) - Method in class com.tangosol.util.NullImplementation.NullObservableMap
- 
Remove a map listener that previously signed up for events based on a filter evaluation.
- removeMapListener(MapListener, Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- removeMapListener(MapListener, Object) - Method in class com.tangosol.net.cache.AbstractSerializationCache
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener, Object) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener, Object) - Method in class com.tangosol.net.cache.OverflowMap
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener, Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener, Object) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapListener(MapListener, Object) - Method in class com.tangosol.util.NullImplementation.NullObservableMap
- 
Remove a map listener that previously signed up for events about a specific key.
- removeMapping(CacheRequestHolder<RemoveMappingRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theRemoveMappingRequestrequest and return aCompletionStagethat will complete when theAsyncNamedCacherequest completes and will contain aCacheRequestHolderholding the result of theRemoveMappingRequestrequest as a serialized Boolean.
- removeMapping(RemoveMappingRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Remove the mapping that is associated with the specified key only if the mapping exists in the cache.
- removeMapping(RemoveMappingRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- removeMapping(RemoveMappingRequest, StreamObserver<BoolValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- removeMemberListener(MemberListener) - Method in interface com.tangosol.net.Service
- 
Remove a Member listener.
- removeMemberListener(MemberListener) - Method in class com.tangosol.net.WrapperService
- 
Remove a Member listener.
- removeNext(int) - Method in class com.tangosol.net.partition.PartitionSet
- 
Remove the first marked partition starting at the specified partition.
- removeNotificationListener(String, NotificationListener) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Removes a listener from a registered MBean.
- removeNotificationListener(String, NotificationListener) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- removeNotificationListener(String, NotificationListener, NotificationFilter, Object) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Removes a listener from a registered MBean.
- removeNotificationListener(String, NotificationListener, NotificationFilter, Object) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- removeNotificationListener(NotificationListener) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean.SilentEmitter
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.tangosol.net.management.AnnotatedStandardEmitterMBean.SilentEmitter
- removeNoWait() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Check for a ripe or soft-ripe item in the queue, and if there is one, return it; otherwise, return null.
- removeNoWait() - Method in class com.tangosol.net.LoadBalancer.Queue
- 
Remove an item from the queue if the queue is not empty.
- removePartitionListener(PartitionListener) - Method in interface com.tangosol.net.PartitionedService
- 
Remove a PartitionListener from this service.
- removePrimitive(long) - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Remove the specified index from the PrimitiveSparseArray, returning its associated value.
- removeRange(int, int) - Method in class com.tangosol.util.CircularArrayList
- 
Removes from this list all of the elements whose indexes are between fromIndex, inclusive and toIndex, exclusive.
- removeSafeListener(Map, Object, MapListener) - Static method in class com.tangosol.util.MapListenerSupport
- 
Remove the specified listener from the Listeners object associated with the specified key.
- removeScope(String) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
Remove the scope prefix from a specified service name.
- removeServiceListener(ServiceListener) - Method in class com.tangosol.net.WrapperService
- 
Unregister a ServiceListener from this ConnectionManager.
- removeServiceListener(ServiceListener) - Method in interface com.tangosol.util.Service
- 
Unregister a ServiceListener from this ConnectionManager.
- removeSnapshot(String) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Remove the persistent artifacts associated with the snapshot with the specified identifier.
- removeSnapshot(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Remove the snapshot that was previously created with the specified name.
- removeSnapshot(String) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Remove the persistent artifacts associated with the snapshot with the specified identifier.
- removeSnapshot(String) - Method in class com.tangosol.util.NullImplementation.NullPersistenceEnvironment
- 
Remove the persistent artifacts associated with the snapshot with the specified identifier.
- removeSnapshotInternal(File, String) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Remove the snapshot with the specified identifier.
- RemoveSnapshotStatement(String, String, boolean) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder.RemoveSnapshotStatement
- 
Create a new RemoveSnapshotStatement for the snapshot and service name.
- RemoveSnapshotStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aRemoveSnapshotStatementBuilder.RemoveSnapshotStatement.
- RemoveSnapshotStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.RemoveSnapshotStatementBuilder
- RemoveSnapshotStatementBuilder.RemoveSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "REMOVE [ARCHIVED] SNAPSHOT" command.
- removeStatementBuilder(String) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Remove theStatementBuilderassociated with the given functor.
- removeSubscriptionListener(PagedTopicSubscription.Listener) - Method in interface com.tangosol.net.PagedTopicService
- 
Remove a listener that was being notified when changes are made to topic subscriptions.
- Removing - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any REMOVING event.
- REMOVING - com.tangosol.net.events.partition.cache.EntryEvent.Type
- 
ThisEntryEventis dispatched before aBinaryEntryhas been removed from backing-map.
- Removing.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theRemovingannotation.
- Render - Class in com.tangosol.util.fsm
- 
Provides Render capabilities forFiniteStateMachines, in particular theirModels.
- Render() - Constructor for class com.tangosol.util.fsm.Render
- repl() - Method in class com.tangosol.coherence.dslquery.QueryPlus
- 
Start a statement processing loop.
- replace(byte, byte) - Method in class com.tangosol.util.Binary
- 
Replace all occurrences of one specified byte with another in this Binary object.
- replace(CacheRequestHolder<ReplaceRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute aReplaceRequestrequest.
- replace(ReplaceRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Replace the entry for the specified key only if it is currently mapped to some value.
- replace(ReplaceRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- replace(ReplaceRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- replace(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Replace the value in the internal cache for the specified entry.
- replace(AbstractSparseArray.Node<V>, AbstractSparseArray.Node<V>) - Method in class com.tangosol.util.AbstractSparseArray
- 
Replace one node with another.
- replace(Binary, Binary) - Method in class com.tangosol.util.Binary
- 
Replace all occurrences of one specified Binary with another in this Binary object.
- replace(Object) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Potentially replaces specified argument with a different object before serialization.
- replace(Object, Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- replace(Object, Object) - Method in class com.tangosol.util.SafeSortedMap
- replace(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- replace(Object, Object) - Method in class com.tangosol.util.SegmentedConcurrentMap
- replace(Object, Object, Object) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- replace(Object, Object, Object) - Method in class com.tangosol.util.SafeSortedMap
- replace(Object, Object, Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- replace(Object, Object, Object) - Method in class com.tangosol.util.SegmentedConcurrentMap
- replace(String, String, String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Replace all occurrences of the specified substring in the specified string.
- replace(String, String, String) - Static method in class com.tangosol.util.Base
- 
Replace all occurrences of the specified substring in the specified string.
- replace(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aReplaceRequest.
- replace(String, String, String, ByteString, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aReplaceMappingRequest.
- replace(K, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- replace(K, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- replace(K, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- replace(K, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- replace(K, V) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Replaces the entry for the specified key only if it is currently mapped to some value.
- replace(K, V) - Method in interface com.tangosol.util.InvocableMap
- replace(K, V) - Method in class com.tangosol.util.SafeHashMap
- replace(K, V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- replace(K, V) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- replace(K, V, V) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- replace(K, V, V) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- replace(K, V, V) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- replace(K, V, V) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- replace(K, V, V) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Replaces the entry for the specified key only if currently mapped to the specified value.
- replace(K, V, V) - Method in interface com.tangosol.util.InvocableMap
- replace(K, V, V) - Method in class com.tangosol.util.SafeHashMap
- replace(K, V, V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- replace(K, V, V) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- replace(TK, TV) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- replace(TK, TV) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- replace(TK, TV, TV) - Method in class com.tangosol.util.ConverterCollections.ConverterInvocableMap
- replace(TK, TV, TV) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- REPLACE - com.tangosol.util.RegistrationBehavior
- 
Specifies that registration should replace an existing identified artifact with that of which was specified.
- replaceAll(Filter<?>, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Replace each entry's value with the result of invoking the given function on that entry until all entries selected by the specified filter have been processed or the function throws an exception.
- replaceAll(Filter, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- 
Replace each entry's value with the result of invoking the given function on that entry until all entries selected by the specified filter have been processed or the function throws an exception.
- replaceAll(Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Replace each entry's value with the result of invoking the given function on that entry until all entries have been processed or the function throws an exception.
- replaceAll(Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- 
Replace each entry's value with the result of invoking the given function on that entry until all entries have been processed or the function throws an exception.
- replaceAll(Collection<? extends K>, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Replace each entry's value with the result of invoking the given function on that entry until all entries for the specified key set have been processed or the function throws an exception.
- replaceAll(Collection<? extends K>, Remote.BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- 
Replace each entry's value with the result of invoking the given function on that entry until all entries for the specified key set have been processed or the function throws an exception.
- replaceAll(BiFunction) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- replaceAll(BiFunction) - Method in class com.tangosol.util.SafeSortedMap
- replaceAll(BiFunction) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in interface com.tangosol.util.InvocableMap
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.SafeHashMap
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- replaceAll(UnaryOperator<E>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- replaceAttributes(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.CacheInfo
- 
Deprecated.Find and replace the attributes names in "{}" format with the corresponding values for this cache info.
- replaceDateMacros(String) - Static method in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Replace the following macro's for the snapshot name:
 %y - Year %m - Month %d - Day of month %w - Day of week. mon,tues,wed, etc %M - Month name - Jan, Feb, etc %hh - Hour %mm - Minute
- replaceElement(XmlElement, XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Replace a child element with the same name as the specified element.
- replaceMapping(CacheRequestHolder<ReplaceMappingRequest, Void>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute aReplaceMappingRequestrequest.
- replaceMapping(ReplaceMappingRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Replace the mapping for the specified key only if currently mapped to the specified value.
- replaceMapping(ReplaceMappingRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- replaceMapping(ReplaceMappingRequest, StreamObserver<BoolValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- replaceRegion(int, int, Binary) - Method in class com.tangosol.util.Binary
- 
Replace a region within this Binary with another Binary.
- replaceSystemProperties(XmlElement, String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Replace the values of the XmlElement and all its children that contain the specified attribute with the values returned by the Config.getProperty() call.
- ReplicatedScheme - Class in com.tangosol.coherence.config.scheme
- 
TheReplicatedSchemeclass builds replicated cache.
- ReplicatedScheme() - Constructor for class com.tangosol.coherence.config.scheme.ReplicatedScheme
- 
Constructs aReplicatedScheme.
- Replicating - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any REPLICATING event.
- Replicating.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theReplicatingannotation.
- report(QueryRecord) - Static method in class com.tangosol.util.SimpleQueryRecordReporter
- 
Return a report for the given query record.
- report(String) - Method in class com.tangosol.io.pof.ValidatingPofHandler
- 
Report an error in the POF stream.
- report(String, int, String, Throwable, String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Assemble and throw an informative exception based on the passed details.
- reportConversionError(XmlValue, String, String, RuntimeException) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Log a failed type conversion.
- reportDisallowedAction(int, List<ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.Notification>) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Report all disallowed actions if the quorum rule has changed.
- REPORTER_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the ReporterMBean.
- reportFooter(List<String>) - Static method in class com.tangosol.util.SimpleQueryRecordReporter
- 
Report the index look ups.
- reportFooterItem(int, String) - Static method in class com.tangosol.util.SimpleQueryRecordReporter
- 
Print the full name that corresponds to the given footer number.
- reportIncompatibleSerializers(NamedCache, String, Serializer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Log the message explaining the serializer incompatibility between the specified cache and a service.
- reportIndexLookupRecord(int, QueryRecord.PartialResult.IndexLookupRecord, List<String>) - Static method in class com.tangosol.util.SimpleQueryRecordReporter
- 
Report the given index lookup record with the given id.
- reportIndexLookUps(List<QueryRecord.PartialResult.IndexLookupRecord>, List<String>) - Static method in class com.tangosol.util.SimpleQueryRecordReporter
- 
Report the index look ups.
- reportLastOwnership(PartitionSet, QuorumInfo) - Static method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- 
Report the machine names in the "last good" membership that owned the specified partitions.
- reportMissingPartition(Object, int) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Report a missing partition according to the "strict" flag rules.
- reportOutOfMemory(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Report on an insufficient memory problem.
- reportResult(QueryRecord.PartialResult, QueryRecorder.RecordType, List<QueryRecord.PartialResult.IndexLookupRecord>, boolean, List<String>) - Static method in class com.tangosol.util.SimpleQueryRecordReporter
- 
Report the given result.
- reportScheduledDistributions(boolean) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Report partitions that storage-enabled members are waiting to receive or still need to send in order to achieve distribution goal set by the strategy.
- reportScheduledDistributions(boolean) - Method in interface com.tangosol.net.partition.SimpleStrategyMBean
- 
Report partitions that storage-enabled members are waiting to receive or still need to send in order to achieve distribution goal set by the strategy.
- reportStarted() - Method in class com.tangosol.net.DefaultCacheServer
- 
Log the start message.
- reportStarted(Collection<Service>) - Method in class com.tangosol.net.DefaultCacheServer
- 
Log the start message.
- reportStep(QueryRecord.PartialResult.Step, QueryRecorder.RecordType, List<QueryRecord.PartialResult.IndexLookupRecord>, int, List<String>) - Static method in class com.tangosol.util.SimpleQueryRecordReporter
- 
Report the given step.
- reportUnsupported(String) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Log the info about an unsupported operation.
- requestCapacity(int) - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Ensure that the current block contains some available capacity, preferably enough to fulfill the specified capacity.
- requestEviction(int) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.EvictionPolicy
- 
This method is called by the cache when the cache requires the eviction policy to evict entries.
- requestEviction(int) - Method in class com.tangosol.net.cache.OldCache.InternalEvictionPolicy
- 
Deprecated.This method is called by the cache when the cache requires the eviction policy to evict entries.
- requestEviction(int) - Method in class com.tangosol.net.cache.SerializationCache.InternalEvictionPolicy
- 
This method is called by the cache when the cache requires the eviction policy to evict entries.
- RequestHandler(LoadBalancer.Queue) - Constructor for class com.tangosol.net.LoadBalancer.RequestHandler
- 
Constructs a RequestHandler that will pull request connections (Socket objects) from a Queue.
- RequestHolder<Req,Res> - Class in com.oracle.coherence.grpc
- 
A class that holds a gRPC request andBinaryconverters.
- RequestHolder(Req, String, Serializer, Service, Executor) - Constructor for class com.oracle.coherence.grpc.RequestHolder
- 
Create aRequestHolder.
- RequestHolder.DownConverter - Class in com.oracle.coherence.grpc
- RequestHolder.ErrorHandlingConverter<F,T> - Class in com.oracle.coherence.grpc
- RequestHolder.UpConverter - Class in com.oracle.coherence.grpc
- RequestIncompleteException - Exception in com.tangosol.net
- 
Signals that a request execution in a distributed environment failed to complete successfully.
- RequestIncompleteException() - Constructor for exception com.tangosol.net.RequestIncompleteException
- 
Construct a RequestIncompleteException with no detail message.
- RequestIncompleteException(String) - Constructor for exception com.tangosol.net.RequestIncompleteException
- 
Construct a RequestIncompleteException with the specified detail message.
- RequestIncompleteException(String, Throwable) - Constructor for exception com.tangosol.net.RequestIncompleteException
- 
Construct a RequestIncompleteException from a Throwable object and an additional description.
- RequestIncompleteException(Throwable) - Constructor for exception com.tangosol.net.RequestIncompleteException
- 
Construct a RequestIncompleteException from a Throwable object.
- RequestPolicyException - Exception in com.tangosol.net
- 
Signals that a request was not allowed to complete due to the related service action being disallowed by the corresponding ActionPolicy.
- RequestPolicyException() - Constructor for exception com.tangosol.net.RequestPolicyException
- 
Constructs a RequestPolicyException with no detail message.
- RequestPolicyException(String) - Constructor for exception com.tangosol.net.RequestPolicyException
- 
Constructs a RequestPolicyException with the specified detail message.
- RequestPolicyException(String, Throwable) - Constructor for exception com.tangosol.net.RequestPolicyException
- 
Construct a RequestPolicyException from a Throwable object and an additional description.
- RequestPolicyException(Throwable) - Constructor for exception com.tangosol.net.RequestPolicyException
- 
Construct a RequestPolicyException from a Throwable object.
- requestReservation() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Attempt to reserve the Status by marking it as committing if it is available.
- Requests - Class in com.oracle.coherence.grpc
- 
A factory to simplify creating proto-buffer requests.
- RequestTimeoutException - Exception in com.tangosol.net
- 
Signals that a request execution in a distributed environment did not complete in a pre-determined amount of time.
- RequestTimeoutException() - Constructor for exception com.tangosol.net.RequestTimeoutException
- 
Constructs a RequestTimeoutException with no detail message.
- RequestTimeoutException(String) - Constructor for exception com.tangosol.net.RequestTimeoutException
- 
Constructs a RequestTimeoutException with the specified detail message.
- RequestTimeoutException(String, Throwable) - Constructor for exception com.tangosol.net.RequestTimeoutException
- 
Construct a RequestTimeoutException from a Throwable object and an additional description.
- RequestTimeoutException(Throwable) - Constructor for exception com.tangosol.net.RequestTimeoutException
- 
Construct a RequestTimeoutException from a Throwable object.
- requeue(ReadWriteBackingMap.WriteQueue, int, ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Requeue the specified entry.
- requiresDeepClone() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Determine if a clone of the XmlBean should be a deep clone, which typically means that at least one property value is mutable reference type.
- RESERVED_META_EXTENTS - Static variable in class com.tangosol.persistence.CachePersistenceHelper
- 
Reserve a certain number of extents identifiers for holding metadata.
- reset() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Reset the receiver so that tokenizing may begin again.
- reset() - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Reset this scanner to process the current BaseTokenStream
- reset() - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Rewind this stream to the position at the time theInputStreaming.mark(int)method was last called on this InputStream.
- reset() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Rewind this stream to the position at the time theInputStreaming.mark(int)method was last called on this InputStream.
- reset() - Method in class com.tangosol.io.MultiByteArrayInputStream
- 
Repositions this stream to the position at the time themarkmethod was last called on this input stream.
- reset() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Reset the Block object so that it doesn't point into the Buffer.
- reset() - Method in class com.tangosol.io.nio.ByteBufferInputStream
- 
Repositions this stream to the position at the time themarkmethod was last called on this input stream.
- reset() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Rewind this stream to the position at the time theInputStreaming.mark(int)method was last called on this InputStream.
- reset() - Method in class com.tangosol.io.pof.PofInputStream
- 
Rewind this stream to the position at the time thePofInputStream.mark(int)method was last called on this InputStream.
- reset() - Method in class com.tangosol.io.Utf8Reader
- 
Reset the stream.
- reset() - Method in class com.tangosol.io.WrapperDataInputStream
- 
Rewind this stream to the position at the time theWrapperDataInputStream.mark(int)method was last called on this InputStream.
- reset() - Method in class com.tangosol.io.WrapperInputStream
- 
Rewind this stream to the position at the time theWrapperInputStream.mark(int)method was last called on this InputStream.
- reset() - Method in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
Reset the statistics.
- reset() - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Make all addresses iterable, starting at the first address.
- reset() - Method in class com.tangosol.net.DatagramPacketOutputStream
- 
Reset the output stream back to the beginning of the buffer.
- reset() - Method in class com.tangosol.net.GuardSupport.Context
- 
If more than half of the soft-timeout interval has passed, issue a heartbeat and clear the interrupted status if set.
- reset() - Static method in class com.tangosol.net.GuardSupport
- 
Issue a reset on the GuardContext associated with the current thread.
- reset() - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Reset the partition statistics state.
- reset() - Method in class com.tangosol.util.DeltaSet
- 
Discard the changes to the set ("rollback").
- reset() - Method in class com.tangosol.util.NullImplementation.NullReader
- reset() - Method in class com.tangosol.util.SafeLinkedList
- 
Completely reset the state of the List.
- reset() - Method in class com.tangosol.util.SubSet
- 
Discard the changes to the set ("rollback").
- reset(char[]...) - Static method in interface com.tangosol.net.PasswordProvider
- 
Resets the contents of a password array
- reset(int) - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Make all addresses iterable, starting at the index after the specified one.
- reset(PofBufferReader, int, Object) - Static method in class com.tangosol.io.pof.PofBufferReader.IdentityHolder
- resetCacheRefs() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Reset cache references to null.
- resetFrontMap() - Method in class com.tangosol.net.cache.CachingMap
- 
Reset the front map.
- resetHitStatistics() - Method in interface com.tangosol.net.cache.CacheStatistics
- 
Reset all of the cache statistics.
- resetHitStatistics() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Reset the cache statistics.
- resetHitStatistics() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
Reset all of the cache statistics.
- resetHitStatistics() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
Reset all of the cache statistics.
- resetInvalidationStrategy() - Method in class com.tangosol.net.cache.CachingMap
- 
Reset the "current invalidation strategy" flag.
- resetRange(int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Reset the portion of the byte array the ReadBuffer operates upon.
- resetRange(int, int) - Method in class com.tangosol.io.ByteArrayReadBuffer
- 
Reset the portion of the byte array the ReadBuffer operates upon.
- resetState(Set, Set, boolean) - Method in class com.tangosol.util.SubSet
- 
Reset the state of the subset according to the specified parameters.
- resetStatistics() - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Reset the statistics.
- resetStatistics() - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- resetStatistics() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Reset statistics for this Bundle.
- resetStatistics() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Reset this Bundler statistics.
- resetStatistics() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Reset the CacheStore statistics.
- resetStatistics() - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Reset the statistics recording the archive and retrieve times.
- resetTokenString() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Reset the buffer used for holding the current token
- resetTouchCount() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Reset the number of times that the cache entry has been touched.
- resetTransients() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Reset those attributes that should be transient betweenSimpleAssignmentStrategy.analyzeDistribution()requests.
- resizeArray(T[], int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Expand the passed array to contain the specified number of elements.
- RESIZING - Variable in class com.tangosol.util.SafeHashMap
- 
When resizing completes, a notification is issued against this object.
- RESIZING - Variable in class com.tangosol.util.SegmentedHashMap
- 
When resizing completes, a notification is issued against this object.
- ResolvableParameterList - Class in com.tangosol.coherence.config
- 
AResolvableParameterListis aParameterListimplementation that additionally supports name-basedParameterresolution as defined by theParameterResolverinterface.
- ResolvableParameterList() - Constructor for class com.tangosol.coherence.config.ResolvableParameterList
- 
Constructs an emptyResolvableParameterList.
- ResolvableParameterList(ParameterList) - Constructor for class com.tangosol.coherence.config.ResolvableParameterList
- 
Constructs aResolvableParameterListbased on aParameterList.
- ResolvableParameterList(Map) - Constructor for class com.tangosol.coherence.config.ResolvableParameterList
- 
Construct aResolvableParameterListfrom provided map.
- resolve() - Method in class com.tangosol.persistence.GUIDHelper.GUIDResolver
- 
Resolve the registered GUIDs and return a map associating each member to the set of partitions that it had registered as having the newest GUID for.
- resolve() - Method in class com.tangosol.util.DeltaSet
- 
Apply the changes to the underlying set ("commit").
- resolve() - Method in class com.tangosol.util.SubSet
- 
Apply the changes to the underlying set ("commit").
- resolve(NameService.RequestContext) - Method in interface com.tangosol.net.NameService.Resolvable
- 
Resolve the object to be returned by thelookupcall
- resolve(String) - Method in class com.tangosol.coherence.config.ResolvableParameterList
- 
Obtains the specified namedParameter.
- resolve(String) - Method in class com.tangosol.config.expression.ChainedParameterResolver
- 
Obtains the specified namedParameter.
- resolve(String) - Method in class com.tangosol.config.expression.NullParameterResolver
- 
Obtains the specified namedParameter.
- resolve(String) - Method in interface com.tangosol.config.expression.ParameterResolver
- 
Obtains the specified namedParameter.
- resolve(String) - Method in class com.tangosol.config.expression.PropertiesParameterResolver
- 
Obtains the specified namedParameter.
- resolve(String) - Method in class com.tangosol.config.expression.ScopedParameterResolver
- 
Obtains the specified namedParameter.
- resolve(String) - Method in class com.tangosol.config.expression.SystemEnvironmentParameterResolver
- 
Resolve Coherence system propertysName
- resolve(String) - Method in class com.tangosol.config.expression.SystemPropertyParameterResolver
- 
Resolve Coherence system propertysName
- resolve(String, Class<T>) - Method in class com.tangosol.config.expression.SystemPropertyParameterResolver
- 
Return property's value as requested type.
- resolve(Set<Annotation>) - Method in interface com.oracle.coherence.cdi.events.AnnotatedMapListener.FilterProducer
- 
Produce aFilterinstance from a set of annotations.
- resolve(Set<Annotation>) - Method in interface com.oracle.coherence.cdi.events.AnnotatedMapListener.MapEventTransformerProducer
- 
Produce aMapEventTransformerinstance from a set of annotations.
- resolve(Set<Annotation>) - Method in class com.oracle.coherence.cdi.FilterProducer
- resolve(Set<Annotation>) - Method in class com.oracle.coherence.cdi.MapEventTransformerProducer
- resolveAddress() - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
Resolve the host address if provided as a string and cache the value.
- resolveAddress(String, int) - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Resolve an address and port.
- resolveAddress(String, int) - Method in class com.tangosol.net.ConfigurableLocalAddressProvider
- 
Resolve an address and port.
- resolveBackingMapScheme(DefaultConfigurableCacheFactory.CacheInfo, XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Traverse the specified scheme to find an enclosed "backing-map-scheme" or a scheme that could serve as such.
- resolveClass(ObjectStreamClass) - Method in class com.tangosol.io.ResolvingObjectInputStream
- 
Load the local class equivalent of the specified stream class description.
- resolveClass(String) - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Resolve a Class name into a Class object.
- resolveFilter(AnnotatedMapListener.FilterProducer) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Resolve this listener's filter annotation into aFilterinstance.
- resolveMaxResults(int, int, int) - Static method in class com.tangosol.coherence.rest.util.RestHelper
- 
Resolve the size of a result set Coherence REST resource will return.
- resolveNewest(Collection<String>, int) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Deprecated.Replaced byGUIDHelper.resolveNewest(Map, Set, int).
- resolveNewest(Map<Member, String[]>, Set<String>, int) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Return an array of the newest GUID for each partition, indexed by the partition-id and collect previous GUIDs into the provided set.
- resolveParameter(String, String) - Method in interface com.tangosol.run.xml.XmlHelper.ParameterResolver
- 
Resolve the passed substitutable parameter.
- resolveParameterType(String) - Method in class com.tangosol.coherence.rest.query.AbstractQueryEngine
- 
Return the Class that corresponds with the given type hint.
- resolveSchemaSources(List<String>) - Method in class com.tangosol.run.xml.SaxParser
- 
For a given set of XSD URIs, return theSources to be used by the XML parser to validate an XML document.
- resolveScheme(DefaultConfigurableCacheFactory.CacheInfo) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.In the configuration XML find a "scheme" element associated with a given cache and resolve it (recursively) using the "scheme-ref" elements.
- resolveScheme(XmlElement, DefaultConfigurableCacheFactory.CacheInfo, boolean, boolean) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Resolve the specified "XYZ-scheme" by retrieving the base element referred to by the "scheme-ref" element, resolving it recursively, and combining it with the specified overrides and cache specific attributes.
- resolveScheme(XmlElement, XmlElement, DefaultConfigurableCacheFactory.CacheInfo, boolean, boolean, boolean) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Resolve the specified "XYZ-scheme" by retrieving the base element referred to by the "scheme-ref" element, resolving it recursively, and combining it with the specified overrides and cache specific attributes.
- resolveScopeName(String, ClassLoader, String) - Method in interface com.tangosol.net.ScopeResolver
- 
Implementations of this method must decide whether to return the scope name provided by the cache configuration return a modified scope name or return a different scope name based on external configuration throw an exception indicating rejection of the requested scope
- resolveSerializer(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Resolve and inject service serializer elements based on defaults defined in the cache configuration.
- resolveSocketProvider(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Resolve and inject service socket-provider elements based on defaults defined in the cache configuration.
- resolveTransformer(AnnotatedMapListener.MapEventTransformerProducer) - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
Resolve this listener's transformer annotation into aMapEventTransformerinstance.
- resolveType(ParameterResolver, MapBuilder) - Method in interface com.tangosol.coherence.config.scheme.BackupMapConfig
- 
Resolve the backup map type using the configuration specified by the application.
- resolveType(ParameterResolver, MapBuilder) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Resolve the backup map type using the configuration specified by the application.
- resolveURI(String) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Resolve the URI that identifies the cache configuration.
- resolveURI(String) - Method in interface com.tangosol.net.ScopeResolver
- 
Resolve the URI that identifies the cache configuration.
- resolveURL(String, ClassLoader) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Resolve the URL based on the provided configuration URI.
- Resolving - Interface in com.tangosol.io
- 
Marker interface for Resolving*Stream implementations.
- ResolvingObjectInputStream - Class in com.tangosol.io
- 
Provides an ObjectInputStream that uses a caller provided ClassLoader to resolve classes during objects deserialization.
- ResolvingObjectInputStream(InputStream, ClassLoader) - Constructor for class com.tangosol.io.ResolvingObjectInputStream
- 
Create an ObjectInputStream that reads from the specified InputStream using the specified ClassLoader to resolve classes.
- ResolvingObjectOutputStream - Class in com.tangosol.io
- 
A marker implementation to mirror the ResolvingObjectInputStream implementation.
- ResolvingObjectOutputStream(OutputStream) - Constructor for class com.tangosol.io.ResolvingObjectOutputStream
- ResourceBuilderProcessor<T> - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor <resource> elements defined by a Coherence Operational Configuration file.
- ResourceBuilderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ResourceBuilderProcessor
- 
Constructs aResourceBuilderProcessor.
- ResourceConfig - Class in com.tangosol.coherence.rest.config
- 
The ResourceConfig class encapsulates information related to a Coherence REST resource.
- ResourceConfig() - Constructor for class com.tangosol.coherence.rest.config.ResourceConfig
- ResourceMapping - Class in com.tangosol.coherence.config
- 
A base class for mapping elements.
- ResourceMapping(String, String) - Constructor for class com.tangosol.coherence.config.ResourceMapping
- 
Construct aResourceMappingfor resources that will use raw types by default.
- ResourceMappingRegistry - Interface in com.tangosol.coherence.config
- 
ASchemeMappingRegistryprovides a mechanism manage a collection ofResourceMappings, together with the ability to search the registry for saidResourceMappings, possibly using wild-cards.
- ResourceRefExpression(Expression<?>, ParameterizedBuilderRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.ResourceRefExpression
- 
Constructs a SchemeRefExpression.
- ResourceRegistry - Interface in com.tangosol.util
- 
AResourceRegistryis a registry and owner of strongly typed and explicitly named resources.
- ResourceRegistry.ResourceLifecycleObserver<R> - Interface in com.tangosol.util
- 
TheResourceRegistry.ResourceLifecycleObserverinterface defines lifecycle handlers for resources registered with aResourceRegistry.
- ResourceResolver - Interface in com.tangosol.util
- 
AResourceResolverprovides a mechanism to lookup and resolve optionally named, strongly typed resources.
- resourceResolverFrom(MapBuilder.Dependencies) - Static method in class com.tangosol.util.ResourceResolverHelper
- 
Constructs and configures aResourceResolverfrom aMapBuilderdependencies.
- resourceResolverFrom(ParameterResolver, ParameterResolver) - Static method in class com.tangosol.util.ResourceResolverHelper
- 
Constructs aResourceResolverbased on aParameterResolver.
- resourceResolverFrom(ResourceResolver...) - Static method in class com.tangosol.util.ResourceResolverHelper
- 
Constructs aResourceResolverbased on a sequence of specifiedResourceResolvers.
- resourceResolverFrom(Class<T>, String, T) - Static method in class com.tangosol.util.ResourceResolverHelper
- 
Constructs aResourceResolverfor a single named resource.
- resourceResolverFrom(Class<T>, T) - Static method in class com.tangosol.util.ResourceResolverHelper
- 
Constructs aResourceResolverfor a single resource.
- ResourceResolverHelper - Class in com.tangosol.util
- 
Provides helpful methods for working withResourceResolvers.
- ResourceResolverHelper() - Constructor for class com.tangosol.util.ResourceResolverHelper
- Resources - Class in com.oracle.coherence.common.base
- 
Implement simple basis for package (and other) resources.
- Resources() - Constructor for class com.oracle.coherence.common.base.Resources
- ResourcesProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor the <resources%gt; element of Coherence Operational Configuration files.
- ResourcesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ResourcesProcessor
- ResponseHandler(LoadBalancer.RequestHandler) - Constructor for class com.tangosol.net.LoadBalancer.ResponseHandler
- 
Construct a ResponseHandler that belongs to the specified RequestHandler.
- ResponseHandlers - Class in com.oracle.coherence.grpc.proxy
- 
Helper methods to handle gRPC async responses.
- ResponseHandlers() - Constructor for class com.oracle.coherence.grpc.proxy.ResponseHandlers
- RestConfig - Class in com.tangosol.coherence.rest.config
- 
The RestConfig class encapsulates information related to Coherence REST configuration.
- RestConfig(XmlElement) - Constructor for class com.tangosol.coherence.rest.config.RestConfig
- 
Construct an instance of RestConfig based on the specified XML element.
- RestHelper - Class in com.tangosol.coherence.rest.util
- 
A collection of utility methods used by Coherence REST.
- RestHelper() - Constructor for class com.tangosol.coherence.rest.util.RestHelper
- RESTORE - com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- RESTORE - Static variable in interface com.tangosol.net.PartitionedService.PartitionedAction
- 
Singleton action for partition restore.
- RestoreStatement(String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder.RestoreStatement
- 
Construct a RestoreStatement that restores a cache from a given file.
- RestoreStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aRestoreStatementBuilder.RestoreStatement.
- RestoreStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder
- RestoreStatementBuilder.RestoreStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "RESTORE" command.
- RestrictedCollection(Collection, Class) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Constructor.
- RestrictedCollections - Class in com.tangosol.util
- 
A collection of Collection implementation classes that limit the data type.
- RestrictedCollections.RestrictedCollection - Class in com.tangosol.util
- 
A restricted Collection that requires its contents to be of a specified class.
- RestrictedCollections.RestrictedEntrySet - Class in com.tangosol.util
- 
A restricted Collection that requires its contents to be of a specified class.
- RestrictedCollections.RestrictedEntrySet.RestrictedEntry - Class in com.tangosol.util
- 
A Map Entry that restricts the key and value types.
- RestrictedCollections.RestrictedEntrySet.RestrictedIterator - Class in com.tangosol.util
- 
A Map Entry Iterator that restricts the key and value types.
- RestrictedCollections.RestrictedList - Class in com.tangosol.util
- 
A restricted List that requires its contents to be of a specified class.
- RestrictedCollections.RestrictedListIterator - Class in com.tangosol.util
- 
A restricted ListIterator that requires its contents to be of a specified class.
- RestrictedCollections.RestrictedMap - Class in com.tangosol.util
- 
A restricted Map that requires its keys and values to be of specified classes.
- RestrictedCollections.RestrictedSet - Class in com.tangosol.util
- 
A restricted Set that requires its contents to be of a specified class.
- RestrictedCollections.RestrictedSortedMap - Class in com.tangosol.util
- 
A restricted SortedMap that requires its keys and values to be of specified classes.
- RestrictedCollections.RestrictedSortedSet - Class in com.tangosol.util
- 
A restricted Set that requires its contents to be of a specified class.
- RestrictedEntry(Map.Entry) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
- 
Constructor.
- RestrictedEntrySet(Set, Class, Class) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Constructor.
- RestrictedIterator(Iterator) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
- 
Constructor.
- RestrictedList(List, Class) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Constructor.
- RestrictedListIterator(ListIterator, Class) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Constructor.
- RestrictedMap(Map, Class, Class) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Constructor.
- RestrictedSet(Set, Class) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedSet
- 
Constructor.
- RestrictedSortedMap(Map, Class, Class) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedSortedMap
- 
Constructor.
- RestrictedSortedSet(SortedSet, Class) - Constructor for class com.tangosol.util.RestrictedCollections.RestrictedSortedSet
- 
Constructor.
- RestrictedStringAdapter - Class in com.tangosol.run.xml
- 
A property adapter for a String based type that is known to have a converting factory method with the following signature:public static <type> valueOf(String s).
- RestrictedStringAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.RestrictedStringAdapter
- 
Construct a RestrictedStringAdapter.
- resume() - Method in class com.tangosol.io.IndentingWriter
- 
Resumes indentation.
- resumeService(Cluster, String) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Resume a service on a separate thread and wait for the resume to complete.
- resumeService(String) - Method in interface com.tangosol.net.Cluster
- 
Resume all suspended members of the service identified by the specified name.
- ResumeServiceStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder.ResumeServiceStatement
- 
Create a ResumeServiceStatement that will resume a suspended service.
- ResumeServiceStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aResumeServiceStatementBuilder.ResumeServiceStatement.
- ResumeServiceStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder
- ResumeServiceStatementBuilder.ResumeServiceStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "RESUME SERVICE" command.
- retain(int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Starting with the byte at offset of, retain the remainder of this WriteBuffer, such that the byte at offset of is shifted to offset 0, the byte at offset of + 1 is shifted to offset 1, and so on up to the byte at offsetWriteBuffer.length()- 1, which is shifted to offsetWriteBuffer.length()- of - 1.
- retain(int) - Method in interface com.tangosol.io.WriteBuffer
- 
Starting with the byte at offset of, retain the remainder of this WriteBuffer, such that the byte at offset of is shifted to offset 0, the byte at offset of + 1 is shifted to offset 1, and so on up to the byte at offsetWriteBuffer.length()- 1, which is shifted to offsetWriteBuffer.length()- of - 1.
- retain(int, int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Starting with the byte at offset of, retain cb bytes in this WriteBuffer, such that the byte at offset of is shifted to offset 0, the byte at offset of + 1 is shifted to offset 1, and so on up to the byte at offset of + cb - 1, which is shifted to offset cb - 1.
- retain(int, int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Starting with the byte at offset of, retain cb bytes in this WriteBuffer, such that the byte at offset of is shifted to offset 0, the byte at offset of + 1 is shifted to offset 1, and so on up to the byte at offset of + cb - 1, which is shifted to offset cb - 1.
- retain(int, int) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Starting with the byte at offset of, retain cb bytes in this WriteBuffer, such that the byte at offset of is shifted to offset 0, the byte at offset of + 1 is shifted to offset 1, and so on up to the byte at offset of + cb - 1, which is shifted to offset cb - 1.
- retain(int, int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Starting with the byte at offset of, retain cb bytes in this WriteBuffer, such that the byte at offset of is shifted to offset 0, the byte at offset of + 1 is shifted to offset 1, and so on up to the byte at offset of + cb - 1, which is shifted to offset cb - 1.
- retain(int, int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Starting with the byte at offset of, retain cb bytes in this WriteBuffer, such that the byte at offset of is shifted to offset 0, the byte at offset of + 1 is shifted to offset 1, and so on up to the byte at offset of + cb - 1, which is shifted to offset cb - 1.
- retain(int, int) - Method in interface com.tangosol.io.WriteBuffer
- 
Starting with the byte at offset of, retain cb bytes in this WriteBuffer, such that the byte at offset of is shifted to offset 0, the byte at offset of + 1 is shifted to offset 1, and so on up to the byte at offset of + cb - 1, which is shifted to offset cb - 1.
- retain(PartitionSet) - Method in class com.tangosol.net.partition.PartitionSet
- 
Retain only partitions in this set that are contained in the specified PartitionSet.
- retainAll(StringTable) - Method in class com.tangosol.util.StringTable
- 
Retains only the nodes in this StringTable that are contained in the specified StringTable.
- retainAll(Tree) - Method in class com.tangosol.util.Tree
- 
Retains only the nodes in this Tree that are contained in the specified Tree.
- retainAll(Collection) - Method in class com.tangosol.util.InflatableCollection
- retainAll(Collection) - Method in class com.tangosol.util.MapSet
- 
Retains only the elements in this Set that are contained in the specified Collection.
- retainAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Retains only the elements in this Collection that are contained in the specified Collection (optional operation).
- retainAll(Collection) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Retains only the elements in this Collection that are contained in the specified Collection (optional operation).
- retainAll(Collection<?>) - Method in class com.tangosol.util.ChainedCollection
- retainAll(Collection<?>) - Method in class com.tangosol.util.ChainedSet
- retainAll(Collection<?>) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- retainAll(Collection<?>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- retainAll(Collection<?>) - Method in class com.tangosol.util.LiteSet
- 
Retains only the elements in this Set that are contained in the specified Collection.
- retainAll(Collection<?>) - Method in class com.tangosol.util.SubList
- retainAll(Collection<?>) - Method in class com.tangosol.util.SubSet
- retainAll(Collection<?>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- retainAll(Collection<?>) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- retainAllInternal(Collection, Collection, Set) - Method in class com.tangosol.util.SubSet
- 
Instantiate a new retained set with all elements in the specified collection that also exist in the providedcolMatchcollection and are not excluded.
- RETAINS_ENTRIES - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A flag specifying that this aggregator retainsInvocableMap.Entryinstances passed toInvocableMap.StreamingAggregator.accumulate(Entry)method, which will force creation of a separateInvocableMap.Entryinstance for each cache entry.
- retrieve(Snapshot, PersistenceEnvironment<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- retrieve(Snapshot, PersistenceEnvironment<ReadBuffer>) - Method in interface com.tangosol.persistence.SnapshotArchiver
- 
Retrieve the specified archived snapshot.
- RETRIEVE_ARCHIVED_SNAPSHOT_BEGIN - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the start of retrieving an archived snapshot.
- RETRIEVE_ARCHIVED_SNAPSHOT_END - Static variable in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Notification type for the end of retrieving an archiving snapshot.
- retrieveArchivedSnapshot(String) - Method in interface com.tangosol.persistence.PersistenceManagerMBean
- 
Retrieve the archived snapshot from a centralized location.
- retrieveInternal(Snapshot, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Internal implementation to retrieve the specified snapshot.
- retrieveInternal(Snapshot, PersistenceManager<ReadBuffer>) - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
- RetrieveSnapshotStatement(String, String, boolean) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder.RetrieveSnapshotStatement
- 
Create a new RetrieveSnapshotStatement for the snapshot and service name.
- RetrieveSnapshotStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aRetrieveSnapshotStatementBuilder.RetrieveSnapshotStatement.
- RetrieveSnapshotStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.RetrieveSnapshotStatementBuilder
- RetrieveSnapshotStatementBuilder.RetrieveSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "RETRIEVE SNAPSHOT" command.
- RETURNED - Static variable in class com.tangosol.run.xml.SimpleElement.ElementIterator
- reuse(Object, Object) - Method in class com.tangosol.util.OpenHashMap.EntrySet.Entry
- 
Re-use the Entry instance for a different key and value.
- reverse() - Method in class com.tangosol.util.Binary
- 
Reverse this Binary object's byte sequence such that the byte at offset zero of this sequence occurs at offset length()-1 in the resulting sequence, the byte at offset one of this sequence occurs at offset length()-2 in the resulting sequence, and so on.
- reversed() - Method in class com.tangosol.util.comparator.PriorityComparator
- reversed() - Method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a comparator that imposes the reverse ordering of this comparator.
- reverseIterator() - Method in class com.tangosol.util.AbstractSafeLongArray
- reverseIterator() - Method in class com.tangosol.util.AbstractSparseArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices).
- reverseIterator() - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- reverseIterator() - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices).
- reverseIterator() - Method in interface com.tangosol.util.LongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices).
- reverseIterator() - Method in class com.tangosol.util.NullImplementation.NullLongArray
- reverseIterator() - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices).
- reverseIterator() - Method in class com.tangosol.util.SimpleLongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices).
- reverseIterator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- reverseIterator(long) - Method in class com.tangosol.util.AbstractSafeLongArray
- reverseIterator(long) - Method in class com.tangosol.util.AbstractSparseArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices), starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is less than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- reverseIterator(long) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- reverseIterator(long) - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices), starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is less than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- reverseIterator(long) - Method in interface com.tangosol.util.LongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices), starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is less than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- reverseIterator(long) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- reverseIterator(long) - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices), starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is less than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- reverseIterator(long) - Method in class com.tangosol.util.SimpleLongArray
- 
Obtain a LongArray.Iterator of the contents of the LongArray in reverse order (decreasing indices), starting at a particular index such that the first call to next will set the location of the iterator at the first existent index that is less than or equal to the specified index, or will throw a NoSuchElementException if there is no such existent index.
- reverseIterator(long) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- reverseOrder() - Static method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a comparator that imposes the reverse of the natural ordering.
- right - Variable in class com.tangosol.util.AbstractSparseArray.Node
- 
The right child of this node.
- RIGHT - Static variable in class com.tangosol.util.AbstractSparseArray.Crawler
- RMI_COMMAND_LINE_ARG - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Command line argument to start RMI server.
- RMI_CONNECTION_PORT_ADJUST_PROPERTY - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Property name to specify RMI connection max port.
- RMI_CONNECTION_PORT_PROPERTY - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Property name to specify RMI connection port.
- RMI_CUSTOM_AUTHENTICATOR_PROPERTY - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Property name to specify custom RMI Authenticator.
- RMI_HOST_PROPERTY - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Property name to specify the RMI host.
- RMI_REGISTRY_PORT_PROPERTY - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Property name to specify RMI registry port.
- rnd() - Method in class com.tangosol.net.partition.PartitionSet
- 
Obtain a random partition from the partition set.
- ROLE_ALL - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
The role identifier to use for matching any cluster members.
- rollback() - Method in interface com.tangosol.util.TransactionMap
- 
Rollback the changes made to the TransactionMap.
- Rollback - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any ROLLBACK event.
- ROLLBACK - com.tangosol.net.events.partition.TransferEvent.Type
- 
ThisTransferEventis dispatched when partition transfer has failed and was therefore rolled back.
- Rollback.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theRollbackannotation.
- rollbackTransactionCollection(Collection) - Static method in class com.tangosol.net.CacheFactory
- 
Roll back the transaction represented by a collection of TransactionMap objects.
- RollbackTransitionException - Exception in com.tangosol.util.fsm
- 
ARollbackTransitionExceptionmay be thrown during anTransitionActionfor aTransitionif the saidTransitionshould be aborted.
- RollbackTransitionException(Enum<?>, Enum<?>, String) - Constructor for exception com.tangosol.util.fsm.RollbackTransitionException
- 
Constructs aRollbackTransitionExceptionwith the specified from and to states.
- RollbackTransitionException(Enum<?>, Enum<?>, Throwable) - Constructor for exception com.tangosol.util.fsm.RollbackTransitionException
- 
Constructs aRollbackTransitionExceptionwith the specified from and to states.
- ROOT_LAMBDA_CLASS - Static variable in class com.tangosol.io.pof.ConfigurablePofContext
- 
Marker serving as the implicit root class for all lambdas.
- rotate(AbstractSparseArray.Node<V>, boolean) - Method in class com.tangosol.util.AbstractSparseArray
- 
Rotate a node in a given direction.
- rotateLeft(byte, int) - Static method in class com.tangosol.util.BitHelper
- 
Rotate the bits of the passed byte value to the left by the number of bits specified.
- rotateLeft(int, int) - Static method in class com.tangosol.util.BitHelper
- 
Rotate the bits of the passed int value to the left by the number of bits specified.
- rotateLeft(long, int) - Static method in class com.tangosol.util.BitHelper
- 
Rotate the bits of the passed long value to the left by the number of bits specified.
- rotateRight(byte, int) - Static method in class com.tangosol.util.BitHelper
- 
Rotate the bits of the passed byte value to the right by the number of bits specified.
- rotateRight(int, int) - Static method in class com.tangosol.util.BitHelper
- 
Rotate the bits of the passed int value to the right by the number of bits specified.
- rotateRight(long, int) - Static method in class com.tangosol.util.BitHelper
- 
Rotate the bits of the passed long value to the right by the number of bits specified.
- roundRobin() - Static method in class com.tangosol.net.topic.Publisher.OrderBy
- 
Return an OrderBy which will compute the unit-of-order such that each message is published to the next channel in a round robin order.
- RoutableFilter() - Constructor for class com.tangosol.net.InetAddressHelper.RoutableFilter
- RoutingBinaryEntry(BinaryEntry) - Constructor for class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- 
Construct a routing entry.
- RoutingMapTriggerEntry(BinaryEntry) - Constructor for class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- 
Construct a routing entry.
- RoutingMapTriggerEntry(MapTrigger.Entry) - Constructor for class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- 
Construct a routing entry.
- run() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool.TracingRunnable
- run() - Method in class com.tangosol.coherence.dslquery.QueryPlus
- 
Run this instance of QueryPlus.
- run() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
This method is invoked on the daemon thread and performs the daemon processing until the thread stops.
- run() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Shutdown hook runnable method.
- run() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadThread
- 
The daemon's implementation method.
- run() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteThread
- 
The daemon's implementation method.
- run() - Method in interface com.tangosol.net.Invocable
- 
Called exactly once by the InvocationService to invoke this Invocable object.
- run() - Method in class com.tangosol.net.LoadBalancer.RequestHandler
- 
Processing loop for the RequestHandler daemon.
- run() - Method in class com.tangosol.net.LoadBalancer.ResponseHandler
- 
Processing loop for the ResponseHandler daemon.
- run() - Method in class com.tangosol.net.LoadBalancer
- 
Start the LoadBalancer.
- run() - Method in class com.tangosol.net.LoadBalancer.SocketHandler
- 
Processing loop for the SocketHandler.
- run() - Method in class com.tangosol.net.RefreshableAddressProvider.RefreshThread
- 
The daemon's implementation method.
- run() - Method in class com.tangosol.net.security.DoAsAction
- run() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.EraseOperation
- 
Perform the erase operation.
- run() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.StoreOperation
- 
Perform the erase operation.
- run() - Method in class com.tangosol.persistence.AbstractPersistenceManager.BatchTasks
- run() - Method in class com.tangosol.persistence.AbstractPersistenceManager.Task
- run() - Method in class com.tangosol.util.Daemon.DaemonWorker
- run() - Method in class com.tangosol.util.Daemon
- 
The daemon's implementation method.
- run() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
- run() - Method in class com.tangosol.util.TaskDaemon.PeriodicTask
- run() - Method in class com.tangosol.util.TaskDaemon
- 
The task processing loop.
- run(Continuation) - Method in interface com.tangosol.net.NonBlockingInvocable
- 
Called exactly once by the InvocationService to execute this task.
- run(Runnable) - Method in class com.tangosol.util.TaskDaemon
- 
Execute a Runnable task.
- runAs(Subject, PrivilegedAction) - Static method in class com.tangosol.net.security.Security
- 
Executes a privileged action on behalf of the user identity.
- runAs(Subject, PrivilegedExceptionAction) - Static method in class com.tangosol.net.security.Security
- 
Executes a privileged exception action on behalf of the user identity.
- runAsync(CompletionStage<T>) - Method in class com.oracle.coherence.grpc.CacheRequestHolder
- 
Return aCompletionStagethat will complete with a value of aRequestHolderwith a result value that is the result of the completion of the specifiedCompletionStage.
- runCanceled(boolean) - Method in class com.tangosol.net.AbstractInvocable
- 
This method will be called if and only if all attempts to interrupt this task were unsuccessful in stopping the execution or if the execution was canceled before it had a chance to run at all.
- runCanceled(boolean) - Method in class com.tangosol.net.AbstractPriorityTask
- 
This method will be called if and only if all attempts to interrupt this task were unsuccessful in stopping the execution or if the execution was canceled before it had a chance to run at all.
- runCanceled(boolean) - Method in interface com.tangosol.net.PriorityTask
- 
This method will be called if and only if all attempts to interrupt this task were unsuccessful in stopping the execution or if the execution was canceled before it had a chance to run at all.
- runCanceled(boolean) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
- 
This method will be called if and only if all attempts to interrupt this task were unsuccessful in stopping the execution or if the execution was canceled before it had a chance to run at all.
- runnable(Remote.Runnable) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable Runnable.
- runTask(Runnable) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Run the passed task on a separate thread.
- RWBM_WB_REMOVE_DEFAULT - Static variable in class com.tangosol.net.cache.ReadWriteBackingMap
- 
The default write behind remove behavior.
S
- s_atomicLogTime - Static variable in class com.tangosol.net.GuardSupport
- 
Atomic counter containing the last log time stamp.
- s_clzMVEL - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
Reflection lookup of class org.mvel2.MVEL.
- s_clzParserContext - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
Reflection lookup of class org.mvel2.ParserContext.
- s_cSignal - Static variable in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- 
An intentionally non-volatile signal counter to ensure periodic flushes.
- s_fEnabled - Static variable in class com.tangosol.coherence.rest.util.MvelHelper
- 
True iff mvel2 jar is on classpath and all reflection lookups succeeded.
- s_mapClassAdapters - Static variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Map from the class of a property type to the class of the adapter that handles the type.
- s_mapClassNames - Static variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Map from type name / short class name to actual class instance.
- s_mapPartialClasses - Static variable in class com.tangosol.coherence.rest.util.PartialObject
- 
Partial classes cache.
- s_mapPartialClassLoaders - Static variable in class com.tangosol.coherence.rest.util.PartialObject
- 
ClassLoader instances that is used to define and load partial classes.
- s_mapPartialConstructors - Static variable in class com.tangosol.coherence.rest.util.PartialObject
- 
Partial class constructors cache.
- s_mapPrimitiveNames - Static variable in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Map from class of an intrinsic type to its JVM signature.
- s_streamfactory - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Option: Configurable ObjectStreamFactory.
- s_tloTimeout - Static variable in class com.oracle.coherence.common.base.Timeout
- 
A thread-local containing the calling thread's timeout value.
- safe(Comparator) - Method in class com.tangosol.coherence.rest.util.ComparatorBuilder
- 
Wrap given comparator with aSafeComparator.
- SafeClock - Class in com.tangosol.util
- 
SafeClock maintains a "safe" time in milliseconds.
- SafeClock(long) - Constructor for class com.tangosol.util.SafeClock
- 
Create a new SafeClock with the default maximum expected jitter as specified by the "coherence.safeclock.jitter" system property.
- SafeClock(long, long) - Constructor for class com.tangosol.util.SafeClock
- 
Create a new SafeClock with the specified jitter threshold.
- safeClose(Closeable) - Method in class com.tangosol.net.ssl.AbstractCertificateLoader
- safeClose(Closeable) - Method in class com.tangosol.net.ssl.AbstractKeyStoreLoader
- safeClose(Closeable) - Method in class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- SafeComparator<T> - Class in com.tangosol.util.comparator
- 
Null-safe delegating comparator.
- SafeComparator() - Constructor for class com.tangosol.util.comparator.SafeComparator
- 
Default constructor (for ExternalizableLite and PortableObject).
- SafeComparator(Comparator<? super T>) - Constructor for class com.tangosol.util.comparator.SafeComparator
- 
Construct a SafeComparator delegating to the specified (wrapped) comparator.
- SafeComparator(Comparator<? super T>, boolean) - Constructor for class com.tangosol.util.comparator.SafeComparator
- 
Construct a SafeComparator delegating to the specified (wrapped) comparator.
- SafeConfigurablePofContext - Class in com.tangosol.io.pof
- 
SafeConfigurablePofContext is an extension of ConfigurablePofContext that can serialize and deserialize any valid POF user type, even those that have not been explicitly configured, as well as any Java serializable types (Serializable, Externalizable, or ExternalizableLite).
- SafeConfigurablePofContext() - Constructor for class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Default constructor.
- SafeConfigurablePofContext(Serializer, ClassLoader) - Constructor for class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Create a SafeConfigurablePofContext that serializes instances of non-POF classes with specified serializer.
- SafeConfigurablePofContext(XmlElement) - Constructor for class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Create a SafeConfigurablePofContext that will use the passed configuration information.
- SafeConfigurablePofContext(String) - Constructor for class com.tangosol.io.pof.SafeConfigurablePofContext
- 
Create a SafeConfigurablePofContext that will load configuration information from the specified locator.
- SafeConfigurablePofContext.ExternalSerializer - Class in com.tangosol.io.pof
- 
Serializer used for Serializable and ExternalizableLite objects.
- SafeConfigurablePofContext.JavaPofSerializer - Class in com.tangosol.io.pof
- 
Default Java serializer.
- SafeConfigurablePofContext.SafePofSerializer - Class in com.tangosol.io.pof
- 
Serializer used for objects implementing the PortableObject interface.
- SafeHashMap<K,V> - Class in com.tangosol.util
- 
An implementation of java.util.Map that is synchronized, but minimally so.
- SafeHashMap() - Constructor for class com.tangosol.util.SafeHashMap
- 
Construct a thread-safe hash map using the default settings.
- SafeHashMap(int, float, float) - Constructor for class com.tangosol.util.SafeHashMap
- 
Construct a thread-safe hash map using the specified settings.
- SafeHashMap.Entry<K,V> - Class in com.tangosol.util
- 
A map entry (key-value pair).
- SafeHashMap.EntrySet - Class in com.tangosol.util
- 
A set of entries backed by this map.
- SafeHashMap.EntrySet.EntrySetIterator - Class in com.tangosol.util
- 
An Iterator over the EntrySet that is backed by the SafeHashMap.
- SafeHashMap.KeySet - Class in com.tangosol.util
- 
A set of entries backed by this map.
- SafeHashMap.ValuesCollection - Class in com.tangosol.util
- 
A collection of values backed by this map.
- SafeHashSet - Class in com.tangosol.util
- 
An implementation of java.util.Set that is synchronized, but minimally so.
- SafeHashSet() - Constructor for class com.tangosol.util.SafeHashSet
- 
Construct a thread-safe hash set using the default settings.
- SafeHashSet(int, float, float) - Constructor for class com.tangosol.util.SafeHashSet
- 
Construct a thread-safe hash set using the specified settings.
- SafeIterator(LongArray<V>, boolean, long) - Constructor for class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- SafeLinkedList - Class in com.tangosol.util
- 
Implementation of the Collection Framework interface "List" using a linked list algorithm.
- SafeLinkedList() - Constructor for class com.tangosol.util.SafeLinkedList
- 
Construct an empty List.
- SafeLinkedList(Collection) - Constructor for class com.tangosol.util.SafeLinkedList
- 
Construct a List containing the elements of the specified Collection.
- SafeLinkedList.Node - Class in com.tangosol.util
- 
A Node in the List.
- SafeLongArray<V> - Class in com.tangosol.util
- 
A thread-safe variant ofLongArrayin which is protected by a ReentrantLock.
- SafeLongArray() - Constructor for class com.tangosol.util.SafeLongArray
- 
Construct a new SafeLongArray.
- SafeLongArray(LongArray<V>) - Constructor for class com.tangosol.util.SafeLongArray
- 
Construct a new SafeLongArray around the specified delegate.
- SafePersistenceEnvironment(PersistenceEnvironment<R>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Construct a PersistenceEnvironment backed by the specified environment.
- SafePersistenceEnvironment(PersistenceEnvironment<R>, Continuation<? super Throwable>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Construct a PersistenceEnvironment backed by the specified environment.
- SafePersistenceEnvironment(PersistenceEnvironment<R>, SafePersistenceWrappers.FailureContinuationFactory<R, ? super T>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Construct a PersistenceEnvironment backed by the specified environment.
- SafePersistenceManager(PersistenceManager<R>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Construct a SafePersistenceManager backed by the specified manager.
- SafePersistenceManager(PersistenceManager<R>, Continuation<? super Throwable>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Construct a SafePersistenceManager backed by the specified manager.
- SafePersistenceManager(PersistenceManager<R>, SafePersistenceWrappers.FailureContinuationFactory<R, ? super T>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Construct a PersistenceManager backed by the specified manager.
- SafePersistenceWrappers - Class in com.tangosol.persistence
- 
SafePersistenceWrappers provides safe wrapper implementations of persistence layer interfaces that can be used to consolidate error handling across the various persistence layers.
- SafePersistenceWrappers() - Constructor for class com.tangosol.persistence.SafePersistenceWrappers
- SafePersistenceWrappers.FailureContinuationFactory<R,T extends Throwable> - Interface in com.tangosol.persistence
- 
FailureContinuationFactory encapsulates failure continuations to handle unexpected exceptions thrown by implementations of the various persistence layers.
- SafePersistenceWrappers.SafePersistenceEnvironment<R,T extends Throwable> - Class in com.tangosol.persistence
- 
SafePersistenceEnvironment is a wrapper PersistenceEnvironment implementation which protects all operations on the underlying environment (and any PersistenceManger or PersistentStore instances opened through this environment) from unexpected failures, delegating the exception handling to a failureContinuation.
- SafePersistenceWrappers.SafePersistenceManager<R,T extends Throwable> - Class in com.tangosol.persistence
- 
SafePersistenceManager is a wrapper PersistenceManager implementation which protects all operations on the underlying manager (and any PersistentStore instances opened by the manager) from unexpected failures, delegating the exception handling to a failureContinuation.
- SafePersistenceWrappers.SafePersistentStore<R,T extends Throwable> - Class in com.tangosol.persistence
- 
SafePersistentStore is a wrapper PersistentStore implementation which protects all synchronous operations on the underlying store from unexpected failures, delegating the exception handling to a failureContinuation.
- SafePersistentStore(PersistentStore<R>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Construct a SafePersistentStore backed by the specified store.
- SafePersistentStore(PersistentStore<R>, Continuation<? super T>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Construct a SafePersistentStore backed by the specified store.
- SafePersistentStore(PersistentStore<R>, SafePersistenceWrappers.FailureContinuationFactory<R, ? super T>) - Constructor for class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Construct a PersistenceManager backed by the specified manager.
- SafePofSerializer() - Constructor for class com.tangosol.io.pof.SafeConfigurablePofContext.SafePofSerializer
- SafeSortedMap - Class in com.tangosol.util
- 
Implementation of aSortedMapextendingConcurrentSkipListMapto support null keys and null values.
- SafeSortedMap() - Constructor for class com.tangosol.util.SafeSortedMap
- 
Construct a new SafeSortedMap using the natural ordering of the Comparable keys in this map.
- SafeSortedMap(Comparator) - Constructor for class com.tangosol.util.SafeSortedMap
- 
Construct a new SafeSortedMap with the specified Comparator.
- SafeSortedMap(SortedMap) - Constructor for class com.tangosol.util.SafeSortedMap
- 
Construct a new SafeSortedMap copying the contents of the specified map.
- SafeSortedMap.EntrySet - Class in com.tangosol.util
- 
Entry set delegation of the super map implementation.
- SafeSortedMap.KeySet - Class in com.tangosol.util
- 
Key set delegation of the super map implementation.
- SafeSortedMap.Null - Class in com.tangosol.util
- SafeSortedMap.NullableEntry - Class in com.tangosol.util
- 
Map.Entry implementation that supports null key/value placeholders.
- SafeSortedMap.SubMap - Class in com.tangosol.util
- 
SubMap delegation to manageSafeSortedMap.NULLin entry key and/or value.
- SafeSortedMap.Values - Class in com.tangosol.util
- 
Values delegation of the super map implementation.
- SafeStreamObserver<T> - Class in com.oracle.coherence.grpc
- 
AStreamObserverthat handles exceptions correctly.
- SafetyFilter(Ownership, int) - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
- 
Construct a SafetyFilter with the specified ownership.
- safeUnquote(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unquote a string iff given string is quoted otherwise return original string.
- SamplingEventTransformer<K,V> - Class in com.tangosol.util.transformer
- 
AMapEventTransformerimplementation which will send at most one event per storage member per sampling interval, in order to throttle down the number of events received by the slow consumer.
- SamplingEventTransformer() - Constructor for class com.tangosol.util.transformer.SamplingEventTransformer
- 
Deserialization constructor.
- SamplingEventTransformer(int) - Constructor for class com.tangosol.util.transformer.SamplingEventTransformer
- 
Construct SamplingEventTransformer instance.
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.AbstractStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder.BackupStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder.CreateIndexStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder.DeleteStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder.DropCacheStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder.DropIndexStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder.QueryRecorderStatement
- sanityCheck(ExecutionContext) - Method in interface com.tangosol.coherence.dslquery.Statement
- 
Perform sanity checks on the statement that will be executed.
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder.TruncateCacheStatement
- sanityCheck(ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
- SanityCheckCommandOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder.SanityCheckCommandOPToken
- 
Construct a SanityCheckCommandOPToken.
- SanityCheckQueryPlusStatement(boolean) - Constructor for class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder.SanityCheckQueryPlusStatement
- 
Construct a SanityCheckQueryPlusStatement to turn on or off QueryPlus sanity checks.
- SanityCheckStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
- 
AStatementBuilderthat builds the QueryPlus "SANITY CHECK" command.
- SanityCheckStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.SanityCheckStatementBuilder
- SanityCheckStatementBuilder.SanityCheckCommandOPToken - Class in com.tangosol.coherence.dslquery.queryplus
- 
A CohQL OPToken representing the QueryPlus "sanity check" command.
- SanityCheckStatementBuilder.SanityCheckQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
- 
A class representing the QueryPlus "SANITY CHECK" command.
- save(DataOutput) - Method in class com.tangosol.util.UID
- 
Store this UID in a stream.
- save(T) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Store the specified entity.
- save(T) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Store the specified entity.
- saveAll(Collection<? extends T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Store all specified entities as a batch.
- saveAll(Collection<? extends T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Store all specified entities as a batch.
- saveAll(Stream<? extends T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Store all specified entities as a batch.
- saveAll(Stream<? extends T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Store all specified entities as a batch.
- SaxParser - Class in com.tangosol.run.xml
- 
A simple XML parser.
- SaxParser() - Constructor for class com.tangosol.run.xml.SaxParser
- 
Construct a SaxParser.
- SaxParser(boolean) - Constructor for class com.tangosol.run.xml.SaxParser
- 
Construct a SaxParser.
- SaxParser.ValidationHandler - Class in com.tangosol.run.xml
- 
An inner class Error Handler that is registered in parser that performs validation.
- SCALAR_SIMPLETYPES - Static variable in class com.tangosol.net.management.MBeanHelper
- 
A map of scalar SimpleTypes (classes) keyed by the corresponding JMX signatures.
- SCALAR_TYPES - Static variable in class com.tangosol.net.management.MBeanHelper
- 
A map of scalar types (classes) keyed by the corresponding JMX signatures.
- scale() - Method in class com.tangosol.io.pof.RawQuad
- 
Get the base-2 scale (exponent) of the quad value.
- scan() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Tokenize the entire expression at once.
- scan(Reader) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Initialize a new OPScanner to process the given Reader and load first token into current.
- scan(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
Initialize a new OPScanner to process the given String and load first token into current.
- scanIdentifier() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Attemt to tokenize an Identifier.
- scanLiteral() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Attemt to tokenize a literal.
- scanNest(char) - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Tokenize the characters between the beginning nest chararcer and the character that ends the nest.
- scanOperator() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Attemt to tokenize an Operator.
- schedule(Remote.Callable<V>, long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Submits a value-returning one-shot task that becomes enabled after the given delay.
- schedule(Remote.Runnable, long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Submits a one-shot task that becomes enabled after the given delay.
- schedule(Runnable, long) - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- SCHEDULE_FIRST - Static variable in interface com.tangosol.net.PriorityTask
- 
Scheduling value indicating that this task is to be queued in front of any equal or lower scheduling priority tasks and executed as soon as any of the worker threads become available.
- SCHEDULE_IMMEDIATE - Static variable in interface com.tangosol.net.PriorityTask
- 
Scheduling value indicating that this task is to be immediately executed by any idle worker thread; if all of them are active, a new thread will be created to execute this task.
- SCHEDULE_STANDARD - Static variable in interface com.tangosol.net.PriorityTask
- 
Scheduling value indicating that this task is to be queued and executed in a natural (based on the request arrival time) order.
- scheduleAtFixedRate(Remote.Runnable, long, long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Submits a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period; that is, executions will commence afterinitialDelay, theninitialDelay + period, theninitialDelay + 2 * period, and so on.
- scheduleExpiry() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Reschedule the cache entry expiration.
- scheduleNextAnalysis(long) - Method in interface com.tangosol.net.partition.DistributionManager
- 
Schedule the next distribution analysis in the specified time interval.
- schedulePeriodicTask(Runnable, long, long) - Method in class com.tangosol.util.TaskDaemon
- 
Schedule a periodic task to be run at the specified time, and to repeat at the specified interval.
- scheduleRegistration(SocketChannel, TcpDatagramSocket.Impl.ConnectionStatus) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Schedule a registration with the selector, and wake it up.
- scheduleTask(Runnable, long) - Method in class com.tangosol.util.TaskDaemon
- 
Schedule a task to be run at the specified time, or as soon after as possible.
- scheduleWithFixedDelay(Remote.Runnable, long, long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Submits a periodic action that becomes enabled first after the given initial delay, and subsequently with the given delay between the termination of one execution and the commencement of the next.
- scheduleWork() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Notify the daemon that there is work to be done.
- Scheme - Interface in com.tangosol.coherence.config.scheme
- 
ASchemedefines the configuration information and necessary builders for the construction of various well-known and identifiable structures used by Coherence at runtime.
- SCHEME - Static variable in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
A referenced scheme provides backup storage.
- SCHEME_CLASS - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The custom class scheme.
- SCHEME_CLASS - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The custom class scheme.
- SCHEME_DISK - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.As of Coherence 3.0, replaced byDefaultConfigurableCacheFactory.SCHEME_EXTERNALandDefaultConfigurableCacheFactory.SCHEME_EXTERNAL_PAGED
- SCHEME_DISK - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Deprecated.As of Coherence 3.0, replaced byExtensibleConfigurableCacheFactory.SCHEME_EXTERNALandExtensibleConfigurableCacheFactory.SCHEME_EXTERNAL_PAGED
- SCHEME_DISTRIBUTED - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The distributed cache scheme.
- SCHEME_DISTRIBUTED - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The distributed cache scheme.
- SCHEME_EXTERNAL - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The external scheme.
- SCHEME_EXTERNAL - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The external scheme.
- SCHEME_EXTERNAL_PAGED - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The paged-external scheme.
- SCHEME_EXTERNAL_PAGED - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The paged-external scheme.
- SCHEME_FLASHJOURNAL - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The flash journal cache scheme.
- SCHEME_FLASHJOURNAL - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The flash journal cache scheme.
- SCHEME_INVOCATION - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The invocation service scheme.
- SCHEME_INVOCATION - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The invocation service scheme.
- SCHEME_LOCAL - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The local cache scheme.
- SCHEME_LOCAL - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The local cache scheme.
- SCHEME_NEAR - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The near cache scheme.
- SCHEME_NEAR - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The near cache scheme.
- SCHEME_OPTIMISTIC - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The optimistic cache scheme.
- SCHEME_OPTIMISTIC - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The optimistic cache scheme.
- SCHEME_OVERFLOW - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The overflow map scheme.
- SCHEME_OVERFLOW - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The overflow map scheme.
- SCHEME_PAGED_TOPIC - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The paged topic scheme.
- SCHEME_PROXY - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The proxy service scheme.
- SCHEME_PROXY - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The proxy service scheme.
- SCHEME_RAMJOURNAL - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The ram journal cache scheme.
- SCHEME_RAMJOURNAL - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The ram journal cache scheme.
- SCHEME_READ_WRITE_BACKING - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The read write backing map scheme.
- SCHEME_READ_WRITE_BACKING - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The read write backing map scheme.
- SCHEME_REF - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The name of the replaceable parameter representing a scheme reference.
- SCHEME_REF - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The name of the replaceable parameter representing a scheme reference.
- SCHEME_REMOTE_CACHE - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The remote cache scheme.
- SCHEME_REMOTE_CACHE - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The remote cache scheme.
- SCHEME_REMOTE_INVOCATION - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The remote invocation scheme.
- SCHEME_REMOTE_INVOCATION - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The remote invocation scheme.
- SCHEME_REPLICATED - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The replicated cache scheme.
- SCHEME_REPLICATED - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The replicated cache scheme.
- SCHEME_TRANSACTIONAL - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The transactional cache scheme.
- SCHEME_TRANSACTIONAL - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The transactional cache scheme.
- SCHEME_UNKNOWN - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The unknown scheme type.
- SCHEME_UNKNOWN - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The unknown scheme type.
- SCHEME_VERSIONED_BACKING - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The versioned backing map scheme.
- SCHEME_VERSIONED_BACKING - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The versioned backing map scheme.
- SCHEME_VERSIONED_NEAR - Static variable in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.The versioned near cache scheme.
- SCHEME_VERSIONED_NEAR - Static variable in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
The versioned near cache scheme.
- SchemeMappingKey(Class<? extends ResourceMapping>, String) - Constructor for class com.tangosol.coherence.config.SchemeMappingRegistry.SchemeMappingKey
- 
Construct aSchemeMappingRegistry.SchemeMappingKey.
- SchemeMappingRegistry - Class in com.tangosol.coherence.config
- 
ASchemeMappingRegistryprovides a mechanism to manage a collection ofResourceMappings, together with the ability to search the registry for saidResourceMappings, possibly using wildcards.
- SchemeMappingRegistry() - Constructor for class com.tangosol.coherence.config.SchemeMappingRegistry
- 
Construct aSchemeMappingRegistry.
- SchemeMappingRegistry.SchemeMappingKey - Class in com.tangosol.coherence.config
- 
Key class for a scheme mapping.
- SchemeRefExpression(Expression<?>, ServiceSchemeRegistry) - Constructor for class com.tangosol.coherence.config.xml.processor.InitParamProcessor.SchemeRefExpression
- 
Constructs a SchemeRefExpression.
- SchemeRefPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
ASchemeRefPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat resolves declarations of <scheme-ref> as required by Coherence.
- SchemeRefPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.SchemeRefPreprocessor
- SchemesProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
ASchemesProcessoris anElementProcessorfor the <caching-schemes%gt; element of Coherence Cache Configuration files.
- SchemesProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SchemesProcessor
- Scope - Annotation Type in com.oracle.coherence.cdi
- 
A qualifier annotation used when injecting Coherence resource to indicate that those resource should be obtained from a specificConfigurableCacheFactory.
- Scope.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theScopeannotation.
- ScopedCacheFactoryBuilder - Class in com.tangosol.net
- 
Implementation ofCacheFactoryBuilderthat manages multiple instances ofConfigurableCacheFactory.
- ScopedCacheFactoryBuilder() - Constructor for class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Default constructor; reads scope resolver configuration from operational configuration file (tangosol-coherence.xml).
- ScopedCacheFactoryBuilder(ScopeResolver) - Constructor for class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Constructor to provide a custom scope resolver.
- ScopedParameterResolver - Class in com.tangosol.config.expression
- 
AScopedParameterResolveris aParameterResolverimplementation that provides the ability to "scope"Parameterdefinitions to either an inner (wrapped) or outerParameterResolver, such that those being defined in the outerParameterResolverhide those (of the same name) in the inner (wrapped)ParameterResolver.
- ScopedParameterResolver() - Constructor for class com.tangosol.config.expression.ScopedParameterResolver
- 
Default constructor needed for serialization.
- ScopedParameterResolver(ParameterResolver) - Constructor for class com.tangosol.config.expression.ScopedParameterResolver
- 
Construct aScopedParameterResolvergiven the specified innerParameterResolver.
- ScopeName - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used to indicate a specific scope name.
- ScopeName.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theScopeNameannotation.
- ScopeNameProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
TheScopeNameProcessoris responsible for processing the <scope-name>XmlElementin a Coherence Cache Configuration file.
- ScopeNameProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ScopeNameProcessor
- ScopeResolver - Interface in com.tangosol.net
- 
This interface is used to derive a scope name used to create an instance ofConfigurableCacheFactory.
- script(String, String, int, Object...) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that is implemented in a script using the specified language.
- script(String, String, Object...) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that is implemented in a script using the specified language.
- script(String, String, Object...) - Static method in class com.tangosol.util.Extractors
- 
Instantiate aValueExtractorthat is implemented using the specified language.
- script(String, String, Object...) - Static method in class com.tangosol.util.Filters
- 
Instantiate a Filter that is implemented in a script using the specified language.
- script(String, String, Object...) - Static method in class com.tangosol.util.Processors
- 
Construct an EntryProcessor that is implemented in a script using the specified language.
- ScriptAggregator<K,V,P,R> - Class in com.tangosol.util.aggregator
- 
ScriptAggregator is aInvocableMap.StreamingAggregatorthat wraps a script written in one of the languages supported by Graal VM.
- ScriptAggregator() - Constructor for class com.tangosol.util.aggregator.ScriptAggregator
- 
Default constructor for ExternalizableLite.
- ScriptAggregator(String, String, int, Object...) - Constructor for class com.tangosol.util.aggregator.ScriptAggregator
- 
Create aInvocableMap.StreamingAggregatorthat wraps the specified script.
- ScriptException - Exception in com.tangosol.util
- 
Represents an exception of some sort has occurred while loading or executing scripts.
- ScriptException(String) - Constructor for exception com.tangosol.util.ScriptException
- 
Create an instance ofScriptExceptionwith the specified message.
- ScriptException(String, Throwable) - Constructor for exception com.tangosol.util.ScriptException
- 
Create an instance ofScriptExceptionwith the specified message and cause.
- ScriptFilter<V> - Class in com.tangosol.util.filter
- 
ScriptFilter is aFilterthat wraps a script written in one of the languages supported by Graal VM.
- ScriptFilter() - Constructor for class com.tangosol.util.filter.ScriptFilter
- 
Default constructor for deserialization.
- ScriptFilter(String, String, Object...) - Constructor for class com.tangosol.util.filter.ScriptFilter
- 
Create aFilterthat wraps the specified script.
- ScriptProcessor<K,V,R> - Class in com.tangosol.util.processor
- 
ScriptProcessor is anInvocableMap.EntryProcessorthat wraps a script written in one of the languages supported by Graal VM.
- ScriptProcessor() - Constructor for class com.tangosol.util.processor.ScriptProcessor
- 
Default constructor for deserialization.
- ScriptProcessor(String, String, Object...) - Constructor for class com.tangosol.util.processor.ScriptProcessor
- 
Create aScriptProcessorthat wraps a script written in the specified language and identified by the specified name.
- ScriptValueExtractor<T,E> - Class in com.tangosol.util.extractor
- 
ScriptValueExtractor is anAbstractExtractorthat wraps a script written in one of the languages supported by Graal VM.
- ScriptValueExtractor() - Constructor for class com.tangosol.util.extractor.ScriptValueExtractor
- 
Default constructor for deserialization.
- ScriptValueExtractor(String, String, Object...) - Constructor for class com.tangosol.util.extractor.ScriptValueExtractor
- 
Create aValueExtractorthat wraps the specified script.
- SDP - com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
- seal(PersistentStore<ReadBuffer>, PartitionedService, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Seal the specified PersistentStore on behalf of the specified service, indicating that it is fully initialized and eligible to be recovered from this point forward.
- Seconds - Class in com.tangosol.coherence.config.unit
- 
Secondsis a specializedDurationwhose default constructor assumes that the specified units of time (when the unit magnitude is not specified) are seconds.
- Seconds(int) - Constructor for class com.tangosol.coherence.config.unit.Seconds
- 
Constructs aSecondsrepresenting aDurationmeasured in seconds.
- Seconds(Duration) - Constructor for class com.tangosol.coherence.config.unit.Seconds
- 
Constructs aSecondsbased on anotherDuration.
- Seconds(String) - Constructor for class com.tangosol.coherence.config.unit.Seconds
- 
Constructs aSecondsrepresenting aDurationmeasured in seconds.
- Security - Class in com.tangosol.net.security
- 
The Security class is used to associate client's identity with an action that requires access to protected clustered resources.
- Security() - Constructor for class com.tangosol.net.security.Security
- SecurityExceptionMapper - Class in com.tangosol.coherence.rest.providers
- 
Maps SecurityExceptions to 403: Forbidden response.
- SecurityExceptionMapper() - Constructor for class com.tangosol.coherence.rest.providers.SecurityExceptionMapper
- SecurityFilter - Class in com.tangosol.coherence.rest.providers
- 
Simple authentication filter.
- SecurityFilter() - Constructor for class com.tangosol.coherence.rest.providers.SecurityFilter
- SecurityFilter.Authorizer - Class in com.tangosol.coherence.rest.providers
- SecurityHelper - Class in com.tangosol.net.security
- 
A collection of security-related utilities.
- SecurityHelper() - Constructor for class com.tangosol.net.security.SecurityHelper
- SecurityProvider - Class in com.tangosol.net.security
- 
Security Provider implementation that returns custom security services.
- seek(int, Position) - Method in interface com.tangosol.net.topic.Subscriber
- 
Seek to the specified position in a channel.
- seek(int, Instant) - Method in interface com.tangosol.net.topic.Subscriber
- 
Seek to a position in a channel based the published timestamp of the elements in the topic.
- seek(Map<Integer, Position>) - Method in interface com.tangosol.net.topic.Subscriber
- 
Seek to the specified position in a set of channels.
- seekAndCommit(int, Position) - Method in interface com.tangosol.net.topic.Subscriber
- 
Seek to the specified position in a channel and set the commit point to the newPosition.
- seekAndCommit(int, Instant) - Method in interface com.tangosol.net.topic.Subscriber
- 
Seek to a position in a channel based the published timestamp of the elements in the topic and set the commit point to the new position.
- seekAndCommit(Map<Integer, Position>) - Method in interface com.tangosol.net.topic.Subscriber
- 
Seek to the specified position in a set of channels and sets the commit position for the channels.
- seekToHead(int...) - Method in interface com.tangosol.net.topic.Subscriber
- 
Reposition one or more channels to their respective head positions.
- seekToTail(int...) - Method in interface com.tangosol.net.topic.Subscriber
- 
Reposition one or more channels to their respective tail positions.
- seekToTailAndCommit(int...) - Method in interface com.tangosol.net.topic.Subscriber
- 
Reposition one or more channels to their respective tail positions and set the commit point to the newPosition.
- Segment() - Constructor for class com.tangosol.util.SegmentedHashMap.Segment
- SEGMENT_COUNT - Static variable in class com.tangosol.util.SegmentedHashMap
- 
The number of segments to partition the hash buckets into.
- SEGMENT_LOCK_MAX_SPIN - Static variable in class com.tangosol.util.SegmentedHashMap
- 
Maximum number of times to spin while trying to acquire a segment lock before waiting.
- SegmentedConcurrentMap - Class in com.tangosol.util
- 
An implementation of SegmentedHashMap that also implements the ConcurrentMap interface.
- SegmentedConcurrentMap() - Constructor for class com.tangosol.util.SegmentedConcurrentMap
- 
Default constructor.
- SegmentedConcurrentMap(int, float, float) - Constructor for class com.tangosol.util.SegmentedConcurrentMap
- 
Construct a SegmentedConcurrentMap using the specified settings.
- SegmentedConcurrentMap(int, float, float, SegmentedConcurrentMap.ContentionObserver) - Constructor for class com.tangosol.util.SegmentedConcurrentMap
- 
Construct a thread-safe hash map using the specified settings.
- SegmentedConcurrentMap(SegmentedConcurrentMap.ContentionObserver) - Constructor for class com.tangosol.util.SegmentedConcurrentMap
- 
Construct a SegmentedConcurrentMap with the default settings and the specified ContentionObserver
- SegmentedConcurrentMap.ConditionalRemoveAction - Class in com.tangosol.util
- 
Action support for a conditional remove().
- SegmentedConcurrentMap.ContentionObserver - Interface in com.tangosol.util
- 
ContentionObserver is used to observe the contention lock-related actions performed on the concurrent map.
- SegmentedConcurrentMap.DumpHeldLocksAction - Class in com.tangosol.util
- 
Action support for dumping held locks for a NearCache key/events control map.
- SegmentedConcurrentMap.LockableEntry - Class in com.tangosol.util
- 
LockableEntry is an Entry that supports locking.
- SegmentedConcurrentMap.LockAction - Class in com.tangosol.util
- 
Action support for lock().
- SegmentedConcurrentMap.RemoveAction - Class in com.tangosol.util
- 
Action support for remove().
- SegmentedConcurrentMap.SizeAction - Class in com.tangosol.util
- 
Action support for size().
- SegmentedConcurrentMap.TruncateAction - Class in com.tangosol.util
- 
Action support for truncate() for a NearCache key/events control map.
- SegmentedConcurrentMap.UnlockAction - Class in com.tangosol.util
- 
Action support for unlock().
- SegmentedHashMap - Class in com.tangosol.util
- 
An implementation of java.util.Map that is optimized for heavy concurrent use.
- SegmentedHashMap() - Constructor for class com.tangosol.util.SegmentedHashMap
- 
Default constructor.
- SegmentedHashMap(int, float, float) - Constructor for class com.tangosol.util.SegmentedHashMap
- 
Construct a thread-safe hash map using the specified settings.
- SegmentedHashMap.ContainsValueAction - Class in com.tangosol.util
- 
Action support for containsValue().
- SegmentedHashMap.Entry - Class in com.tangosol.util
- 
A map entry (key-value pair).
- SegmentedHashMap.EntryAction - Interface in com.tangosol.util
- 
An EntryAction encapsulates a logical action to be executed in the context of a key (that may or may not exist in the map).
- SegmentedHashMap.EntryActionAdapter - Class in com.tangosol.util
- 
EntryActionAdapter is a convenience class that provides default implementations for the EntryAction and IterableEntryAction interface methods.
- SegmentedHashMap.EntrySet - Class in com.tangosol.util
- 
A set of entries backed by this map.
- SegmentedHashMap.EntrySet.EntrySetIterator - Class in com.tangosol.util
- 
An Iterator over the EntrySet that is backed by the SegmentedHashMap.
- SegmentedHashMap.GetEntryAction - Class in com.tangosol.util
- 
Action support for getEntryInternal.
- SegmentedHashMap.InsertAction - Class in com.tangosol.util
- 
Action support for insert.
- SegmentedHashMap.IterableEntryAction - Interface in com.tangosol.util
- 
IterableEntryAction is an EntryAction that is suitable for applying to all keys in a map.
- SegmentedHashMap.KeySet - Class in com.tangosol.util
- 
A set of entries backed by this map.
- SegmentedHashMap.RemoveAction - Class in com.tangosol.util
- 
Action support for remove().
- SegmentedHashMap.Segment - Class in com.tangosol.util
- 
Segment metadata.
- SegmentedHashMap.ValuesCollection - Class in com.tangosol.util
- 
A collection of values backed by this map.
- SegmentedHashSet - Class in com.tangosol.util
- 
An implementation of java.util.Set that is optimized for heavy concurrent use.
- SegmentedHashSet() - Constructor for class com.tangosol.util.SegmentedHashSet
- 
Construct a thread-safe hash set using the default settings.
- SegmentedHashSet(int, float, float) - Constructor for class com.tangosol.util.SegmentedHashSet
- 
Construct a thread-safe hash set using the specified settings.
- select(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Select the next key from the refresh-ahead queue that is a candidate for an asynchronous load.
- select(Selector) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Wait on the Selector while still respecting the calling thread'stimeout.
- select(Selector, long) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Wait on the Selector while still respecting the calling thread'stimeout.
- SelectStatement(String, Filter, InvocableMap.EntryAggregator, boolean) - Constructor for class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- 
Construct a SelectStatement that will query the specified cache.
- SelectStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aSelectStatementBuilder.SelectStatement.
- SelectStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder
- SelectStatementBuilder.AsyncSelectStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Async implementation of the CohQL "SELECT" command.
- SelectStatementBuilder.SelectStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "SELECT" command.
- Semaphore - Interface in com.oracle.coherence.concurrent
- Semaphores - Class in com.oracle.coherence.concurrent
- 
Factory methods for local and remote semaphore implementations.
- Semaphores() - Constructor for class com.oracle.coherence.concurrent.Semaphores
- semaphoresMap() - Static method in class com.oracle.coherence.concurrent.Semaphores
- 
Return CoherenceNamedMapfor the remote semaphores.
- SemiLiteEventTransformer<K,V> - Class in com.tangosol.util.transformer
- 
SemiLiteEventTransformer is a special purpose MapEventTransformer implementation that removes an OldValue from the MapEvent object for the purpose of reducing the amount of data that has to be sent over the network to event consumers.
- SemiLiteEventTransformer() - Constructor for class com.tangosol.util.transformer.SemiLiteEventTransformer
- 
Deserialization constructor.
- send(DatagramPacket) - Method in class com.tangosol.net.NonBlockingTcpDatagramSocket.Impl
- send(DatagramPacket) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- send(DatagramPacket) - Method in class com.tangosol.net.TcpDatagramSocket
- send(V) - Method in interface com.tangosol.net.topic.Publisher
- 
Deprecated.UsePublisher.publish(Object)which returns metadata about the published value
- separatorsToUnix(String) - Static method in class com.tangosol.io.FileHelper
- 
Converts all separators to the Unix separator of forward slash.
- SeppukuMapListener - Class in com.tangosol.net.cache
- 
A map listener that follows the "seppuku" pattern, invalidating the Map entries when MapEvents for another related ObservableMap are delivered.
- SeppukuMapListener(Map) - Constructor for class com.tangosol.net.cache.SeppukuMapListener
- 
Construct a SeppukuMapListener for the specified front map.
- SequenceBaseToken - Class in com.tangosol.coherence.dsltools.base
- 
SequenceBaseToken is a token that holds a sequence of tokens.
- SequenceBaseToken(BaseToken[]) - Constructor for class com.tangosol.coherence.dsltools.base.SequenceBaseToken
- 
Construct a new SequenceBaseToken with the array of tokens.
- sequential() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- sequential() - Method in interface com.tangosol.util.stream.RemoteIntStream
- sequential() - Method in interface com.tangosol.util.stream.RemoteLongStream
- sequential() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns an equivalent stream that is sequential.
- SERIAL - Static variable in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
A flag specifying that this aggregator should be executed serially.
- SerializableAdapter - Class in com.tangosol.run.xml
- 
A SerializableAdapter supports Java objects that implement the Serializable interface.
- SerializableAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SerializableAdapter
- 
Construct a SerializableAdapter.
- SerializableAtomicMarkableReference() - Constructor for class com.oracle.coherence.concurrent.atomic.Atomics.SerializableAtomicMarkableReference
- 
Required for serialization.
- SerializableAtomicMarkableReference(V, boolean) - Constructor for class com.oracle.coherence.concurrent.atomic.Atomics.SerializableAtomicMarkableReference
- SerializableAtomicStampedReference() - Constructor for class com.oracle.coherence.concurrent.atomic.Atomics.SerializableAtomicStampedReference
- 
Required for serialization.
- SerializableAtomicStampedReference(V, int) - Constructor for class com.oracle.coherence.concurrent.atomic.Atomics.SerializableAtomicStampedReference
- SerializableSerializer - Class in com.tangosol.io.pof
- SerializableSerializer() - Constructor for class com.tangosol.io.pof.SerializableSerializer
- SerializationCache - Class in com.tangosol.net.cache
- 
A version of SerializationMap that implements an LRU policy.
- SerializationCache(BinaryStore, int) - Constructor for class com.tangosol.net.cache.SerializationCache
- 
Construct a SerializationCache on top of a BinaryStore.
- SerializationCache(BinaryStore, int, boolean) - Constructor for class com.tangosol.net.cache.SerializationCache
- 
Construct a SerializationCache on top of a BinaryStore.
- SerializationCache(BinaryStore, int, ClassLoader) - Constructor for class com.tangosol.net.cache.SerializationCache
- 
Construct a SerializationCache on top of a BinaryStore.
- SerializationCache.EntryAttributes - Class in com.tangosol.net.cache
- 
A class that holds on to the expiry time and touch order for an entry.
- SerializationCache.EntrySet - Class in com.tangosol.net.cache
- 
A set of entries backed by this map.
- SerializationCache.EntrySet.Entry - Class in com.tangosol.net.cache
- 
A Cache Entry implementation.
- SerializationCache.InternalEvictionPolicy - Class in com.tangosol.net.cache
- 
The InternalEvictionPolicy represents a pluggable eviction policy for the non-pluggable built-in (internal) eviction policies supported by this cache implementation.
- SerializationMap - Class in com.tangosol.net.cache
- 
Map implementation that stores its contents in a BinaryStore.
- SerializationMap(BinaryStore) - Constructor for class com.tangosol.net.cache.SerializationMap
- 
Construct a SerializationMap on top of a BinaryStore.
- SerializationMap(BinaryStore, boolean) - Constructor for class com.tangosol.net.cache.SerializationMap
- 
Construct a SerializationMap on top of a BinaryStore, optionally storing only Binary keys and values.
- SerializationMap(BinaryStore, ClassLoader) - Constructor for class com.tangosol.net.cache.SerializationMap
- 
Construct a SerializationMap on top of a BinaryStore, using the passed ClassLoader for deserialization.
- SerializationPagedCache - Class in com.tangosol.net.cache
- 
A version of SerializationMap that implements an LRU policy using time-based paging of the cache.
- SerializationPagedCache(BinaryStoreManager, int, int) - Constructor for class com.tangosol.net.cache.SerializationPagedCache
- 
Construct a SerializationPagedCache on top of a BinaryStoreManager.
- SerializationPagedCache(BinaryStoreManager, int, int, boolean, boolean) - Constructor for class com.tangosol.net.cache.SerializationPagedCache
- 
Construct a SerializationPagedCache on top of a BinaryStoreManager.
- SerializationPagedCache(BinaryStoreManager, int, int, ClassLoader) - Constructor for class com.tangosol.net.cache.SerializationPagedCache
- 
Construct a SerializationPagedCache on top of a BinaryStoreManager.
- SerializationPagedCache.FakeBinaryStore - Class in com.tangosol.net.cache
- 
A lite BinaryStore implementation used when the real underlying BinaryStore gets destroyed.
- SerializationPagedCache.PagedBinaryStore - Class in com.tangosol.net.cache
- 
A virtual BinaryStore implementation that aggregates a sequence (newest to oldest) of periodic BinaryStore objects.
- SerializationPagedCache.WrapperBinaryStore - Class in com.tangosol.net.cache
- 
A wrapper BinaryStore implementation that keeps track of its size.
- SerializationSupport - Interface in com.tangosol.io
- 
The SerializationSupport interface provides the ability for objects that are serialized by anySerializerto affect the initial stage of serialization and the final stage of deserialization.
- serialize(PofWriter, JsonMap) - Method in class com.tangosol.coherence.rest.util.JsonMap.Serializer
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.EnumPofSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.ExternalizableLitePofSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.ExternalizablePofSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.PofAnnotationSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.PortableObjectSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.PrincipalPofSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext.ExternalSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.SafeConfigurablePofContext.SafePofSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.SerializableSerializer
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.SubjectPofSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.ThrowablePofSerializer
- serialize(PofWriter, Object) - Method in class com.tangosol.io.pof.XmlSerializablePofSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, InetAddress) - Method in class com.tangosol.io.pof.InetAddressSerializer
- serialize(PofWriter, InetSocketAddress) - Method in class com.tangosol.io.pof.InetSocketAddressSerializer
- serialize(PofWriter, AtomicBoolean) - Method in class com.oracle.coherence.concurrent.atomic.AtomicBoolean.Serializer
- serialize(PofWriter, AtomicInteger) - Method in class com.oracle.coherence.concurrent.atomic.AtomicInteger.Serializer
- serialize(PofWriter, AtomicLong) - Method in class com.oracle.coherence.concurrent.atomic.AtomicLong.Serializer
- serialize(PofWriter, AtomicMarkableReference<V>) - Method in class com.oracle.coherence.concurrent.atomic.AtomicMarkableReference.Serializer
- serialize(PofWriter, AtomicReference<V>) - Method in class com.oracle.coherence.concurrent.atomic.AtomicReference.Serializer
- serialize(PofWriter, AtomicStampedReference<V>) - Method in class com.oracle.coherence.concurrent.atomic.AtomicStampedReference.Serializer
- serialize(PofWriter, Optional) - Method in class com.tangosol.io.pof.OptionalSerializer
- serialize(PofWriter, OptionalDouble) - Method in class com.tangosol.io.pof.OptionalDoubleSerializer
- serialize(PofWriter, OptionalInt) - Method in class com.tangosol.io.pof.OptionalIntSerializer
- serialize(PofWriter, OptionalLong) - Method in class com.tangosol.io.pof.OptionalLongSerializer
- serialize(PofWriter, T) - Method in interface com.tangosol.io.pof.PofSerializer
- 
Serialize a user type instance to a POF stream by writing its state using the specified PofWriter object.
- serialize(PofWriter, T) - Method in class com.tangosol.io.pof.PortableTypeSerializer
- serialize(WriteBuffer.BufferOutput, Object) - Method in class com.tangosol.io.DefaultSerializer
- serialize(WriteBuffer.BufferOutput, Object) - Method in class com.tangosol.io.MultiplexingSerializer
- serialize(WriteBuffer.BufferOutput, Object) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Serialize an object to a WriteBuffer by writing its state using the specified BufferOutput object.
- serialize(WriteBuffer.BufferOutput, Object) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Serialize an object to a WriteBuffer by writing its state using the specified BufferOutput object.
- serialize(WriteBuffer.BufferOutput, Object) - Method in interface com.tangosol.io.Serializer
- 
Serialize an object to a WriteBuffer by writing its state using the specified BufferOutput object.
- serialize(WriteBuffer.BufferOutput, Object) - Method in class com.tangosol.util.NullImplementation.NullPofContext
- 
Serialize an object to a WriteBuffer by writing its state using the specified BufferOutput object.
- Serializer - Interface in com.tangosol.io
- 
The Serializer interface provides the capability of reading and writing a Java object from and to an in-memory buffer.
- Serializer() - Constructor for class com.oracle.coherence.concurrent.atomic.AtomicBoolean.Serializer
- Serializer() - Constructor for class com.oracle.coherence.concurrent.atomic.AtomicInteger.Serializer
- Serializer() - Constructor for class com.oracle.coherence.concurrent.atomic.AtomicLong.Serializer
- Serializer() - Constructor for class com.oracle.coherence.concurrent.atomic.AtomicMarkableReference.Serializer
- Serializer() - Constructor for class com.oracle.coherence.concurrent.atomic.AtomicReference.Serializer
- Serializer() - Constructor for class com.oracle.coherence.concurrent.atomic.AtomicStampedReference.Serializer
- Serializer() - Constructor for class com.tangosol.coherence.rest.util.JsonMap.Serializer
- SerializerAware - Interface in com.tangosol.io
- 
The SerializerAware interface provides the ability to configure a Serializer to be used by the implementing object when serializing or deserializing objects.
- SerializerBuilderProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor <serializer> elements defined by a Coherence Operational Configuration file.
- SerializerBuilderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SerializerBuilderProcessor
- 
Constructs aSerializerBuilderProcessor.
- SerializerFactory - Interface in com.tangosol.io
- 
A factory forSerializerobjects.
- SerializerFactoryProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
An ElementProcessor that will parse a <serializer> and produce a suitable SerializerFactory
- SerializerFactoryProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SerializerFactoryProcessor
- 
Constructs aSerializerFactoryProcessor.
- SerializerFormat - Annotation Type in com.oracle.coherence.cdi
- 
A qualifier annotation used when injecting aSerializerto identify the specificSerializerto inject.
- SerializerFormat.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theSerializerFormatannotation.
- SerializerProducer - Class in com.oracle.coherence.cdi
- 
A CDI producer ofSerializerinstances.
- SerializerProducer.Builder - Class in com.oracle.coherence.cdi
- 
A builder that buildsSerializerProducerinstances.
- SerializersProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor the <serializers%gt; element of Coherence Operational Configuration files.
- SerializersProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SerializersProcessor
- SerializingInternalConverter<T> - Class in com.tangosol.coherence.jcache.common
- 
AnInternalConverterthat converts values to and from their Coherence-based serializedBinaryrepresentation.
- SerializingInternalConverter(Serializer) - Constructor for class com.tangosol.coherence.jcache.common.SerializingInternalConverter
- 
Constructs aSerializingInternalConverter.
- Server - Class in com.oracle.coherence.cdi.server
- 
This class bootstraps the CDI container, which will in turn start Coherence server via CDI extension.
- Server() - Constructor for class com.oracle.coherence.cdi.server.Server
- ServerCoherenceProducer - Class in com.oracle.coherence.cdi.server
- 
A CDI server-sideCoherencebean producer.
- ServerCoherenceProducer() - Constructor for class com.oracle.coherence.cdi.server.ServerCoherenceProducer
- ServerLoggingInterceptor - Class in com.oracle.coherence.grpc.proxy
- 
A gRPC server interceptor that will log messages on the server.
- ServerLoggingInterceptor() - Constructor for class com.oracle.coherence.grpc.proxy.ServerLoggingInterceptor
- Service - Interface in com.tangosol.net
- 
This Service interface represents a controllable service that operates in a clustered network environment.
- Service - Interface in com.tangosol.util
- 
A Service is a Controllable that emits service lifecycle events.
- SERVICE - Static variable in class com.tangosol.net.management.MBeanAccessor
- 
The "service" key in the ObjectName.
- SERVICE_NAME - Static variable in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
The name of the gRPC service.
- SERVICE_NAME - Static variable in interface com.tangosol.net.management.Registry
- 
The name of the Invocation service used for remote management.
- SERVICE_STARTED - Static variable in class com.tangosol.util.ServiceEvent
- 
This event indicates that a service has started.
- SERVICE_STARTING - Static variable in class com.tangosol.util.ServiceEvent
- 
This event indicates that a service is starting.
- SERVICE_STOPPED - Static variable in class com.tangosol.util.ServiceEvent
- 
This event indicates that a service has stopped.
- SERVICE_STOPPING - Static variable in class com.tangosol.util.ServiceEvent
- 
This event indicates that a service is stopping.
- SERVICE_TYPE - Static variable in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
The type of the SSLContext service.
- SERVICE_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the ServiceMBean.
- Service.MemberJoinAction - Interface in com.tangosol.net
- 
MemberJoinAction is taken to allow a new member to join a clustered Service.
- ServiceBuilder - Interface in com.tangosol.coherence.config.builder
- 
The ServiceBuilder interface is used by a builder that creates a Service.
- ServiceBuilderProcessor<T extends ServiceBuilder> - Class in com.tangosol.coherence.config.xml.processor
- 
AServiceBuilderProcessoris anElementProcessorresponsible for producing various kinds ofServiceBuilders.
- ServiceBuilderProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.ServiceBuilderProcessor
- ServiceDependencies - Interface in com.tangosol.net
- 
The ServiceDependencies interface defines externally provided dependencies forclustered services.
- ServiceEvent - Class in com.tangosol.util
- 
An event which indicates that a Service state has changed: a service is starting a service has started a service is stopping a service has stopped A ServiceEvent object is sent as an argument to the ServiceListener interface methods.
- ServiceEvent(Service, int) - Constructor for class com.tangosol.util.ServiceEvent
- 
Constructs a new ServiceEvent.
- ServiceEventHandler(EventObserverSupport.EventObserver<E>, Class<T>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.ServiceEventHandler
- ServiceFailurePolicy - Interface in com.tangosol.net
- 
ServiceFailurePolicy is used to control how a Guardable associated with a service is managed by its Guardian after the configured timeout.
- ServiceFailurePolicyBuilder - Class in com.tangosol.coherence.config.builder
- 
Build a default or customizedServiceFailurePolicy.
- ServiceFailurePolicyBuilder(int) - Constructor for class com.tangosol.coherence.config.builder.ServiceFailurePolicyBuilder
- 
Create Defaults.
- ServiceFailurePolicyBuilder(ParameterizedBuilder<ServiceFailurePolicy>, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ServiceFailurePolicyBuilder
- 
ServiceFailurePolicyconstructor for customized builder.
- ServiceFailurePolicyBuilder(String, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ServiceFailurePolicyBuilder
- 
Default ServiceFailurePolicy from Xml value in configuration <service-failure-policy>.
- ServiceFailurePolicyProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
An ElementProcessor that will parse a <service-failure-policyr> and produce a suitable ServiceFailurePolicy
- ServiceFailurePolicyProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ServiceFailurePolicyProcessor
- 
Constructs aServiceFailurePolicyProcessor.
- ServiceInfo - Interface in com.tangosol.net
- 
The ServiceInfo represents information about a Service that operates in a clustered network environment.
- ServiceListener - Interface in com.tangosol.util
- 
The listener interface for receiving ServiceEvents.
- ServiceListener() - Constructor for class com.tangosol.net.cache.ContinuousQueryCache.ServiceListener
- ServiceLoad - Interface in com.tangosol.net
- 
A ServiceLoad encapsulates information about the current utilization of a Service.
- ServiceLoadBalancer<S extends Service,T extends ServiceLoad> - Interface in com.tangosol.net
- 
A ServiceLoadBalancer is a pluggable strategy for controlling the client load across individual members of a clustered Service.
- ServiceLoadBalancerBuilder - Class in com.tangosol.coherence.config.builder
- 
ServiceLoadBalancerBuilderdefers evaluating configuration parameters until ServiceLoadBalancer is instantiated.
- ServiceLoadBalancerBuilder(ParameterizedBuilder<ServiceLoadBalancer>, XmlElement) - Constructor for class com.tangosol.coherence.config.builder.ServiceLoadBalancerBuilder
- 
ConstructsServiceLoadBalancerBuilder
- ServiceLoadBalancerProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor <load-balancer> configuration used by federated and proxy services.
- ServiceLoadBalancerProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ServiceLoadBalancerProcessor
- ServiceMonitor - Interface in com.tangosol.net
- 
TheServiceMonitoris a facility that keeps registered services alive.
- ServiceName - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used to indicate a specific service name.
- ServiceName.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theServiceNameannotation.
- ServiceScheme - Interface in com.tangosol.coherence.config.scheme
- 
This interface exposes service related scheme information.
- ServiceSchemeRegistry - Class in com.tangosol.coherence.config
- 
AServiceSchemeRegistryprovides a mechanism manage a collection ofServiceSchemes together with the ability to search the registry for saidServiceSchemes, either by name or service name.
- ServiceSchemeRegistry() - Constructor for class com.tangosol.coherence.config.ServiceSchemeRegistry
- 
Constructs aServiceSchemeRegistry.
- ServicesCommandOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder.ServicesCommandOPToken
- 
Construct a ServicesCommandOPToken.
- ServicesQueryPlusStatement(String) - Constructor for class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder.ServicesQueryPlusStatement
- 
Construct a ServicesQueryPlusStatement that will execute the specified service command action.
- ServicesStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
- 
AStatementBuilderthat builds the QueryPlus "SERVICES" command.
- ServicesStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.ServicesStatementBuilder
- ServicesStatementBuilder.ServicesCommandOPToken - Class in com.tangosol.coherence.dslquery.queryplus
- 
A CohQL OPToken representing the QueryPlus "services" command.
- ServicesStatementBuilder.ServicesQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
- 
A class representing the "SERVICES" QueryPlus command.
- serviceStarted(ServiceEvent) - Method in interface com.tangosol.util.ServiceListener
- 
Invoked when a service has started.
- serviceStarting(ServiceEvent) - Method in interface com.tangosol.util.ServiceListener
- 
Invoked when a service is starting.
- serviceStopped(ServiceEvent) - Method in interface com.tangosol.util.ServiceListener
- 
Invoked when a service has stopped.
- ServiceStoppedException - Exception in com.tangosol.net
- 
Signals that a request was not able to execute because the underlying service has been stopped.
- ServiceStoppedException() - Constructor for exception com.tangosol.net.ServiceStoppedException
- 
Constructs a ServiceStoppedException with no detail message.
- ServiceStoppedException(String) - Constructor for exception com.tangosol.net.ServiceStoppedException
- 
Constructs a ServiceStoppedException with the specified detail message.
- ServiceStoppedException(String, Throwable) - Constructor for exception com.tangosol.net.ServiceStoppedException
- 
Construct a ServiceStoppedException from a Throwable object and an additional description.
- ServiceStoppedException(Throwable) - Constructor for exception com.tangosol.net.ServiceStoppedException
- 
Construct a ServiceStoppedException from a Throwable object.
- serviceStopping(ServiceEvent) - Method in interface com.tangosol.util.ServiceListener
- 
Invoked when a service is stopping.
- session() - Static method in class com.oracle.coherence.concurrent.Latches
- 
Return CoherenceSessionfor the Latches module.
- session() - Static method in class com.oracle.coherence.concurrent.locks.Locks
- 
Return CoherenceSessionfor the Locks module.
- session() - Static method in class com.oracle.coherence.concurrent.Semaphores
- 
Return CoherenceSessionfor the Semaphore module.
- Session - Interface in com.tangosol.net
- 
A thread-safe mechanism to request Coherence-based resources, likeNamedCaches, from a deployed module.
- SESSION_NAME - Static variable in class com.oracle.coherence.concurrent.atomic.Atomics
- 
The session name.
- SESSION_NAME - Static variable in class com.oracle.coherence.concurrent.Latches
- 
The session name.
- SESSION_NAME - Static variable in class com.oracle.coherence.concurrent.locks.Locks
- 
The session name.
- SESSION_NAME - Static variable in class com.oracle.coherence.concurrent.Semaphores
- 
The session name.
- Session.Option - Interface in com.tangosol.net
- 
Deprecated.since 20.12Session.Optionhas been replaced bySessionConfiguration
- SessionConfiguration - Interface in com.tangosol.net
- 
A class that can provide the configuration options for aSession.
- SessionConfiguration.Builder - Class in com.tangosol.net
- 
A builder to build aSessionConfiguration.ConfigurableCacheFactorySessionConfig.
- SessionConfiguration.ConfigurableCacheFactorySessionConfig - Class in com.tangosol.net
- 
An immutableSessionConfigurationto configure aSessionthat wraps an underlyingConfigurableCacheFactory.
- sessionContext() - Method in class com.oracle.coherence.grpc.RefreshableSslContext
- SessionDispatcher - Interface in com.tangosol.net.events
- 
A CoherenceDispatcher raisesEvents pertaining to operations on aCoherenceinstance:CoherenceLifecycleEvents
- SessionInitializer - Interface in com.oracle.coherence.cdi
- 
An interface that should be implemented by custom Coherence scoped session configurations in order to enable their discovery and automatic initialization at startup.
- SessionLifecycleEvent - Interface in com.tangosol.net.events
- 
ASessionLifecycleEventallows subscribers to capture events pertaining to the lifecycle of aSessioninstance.
- SessionLifecycleEvent.Type - Enum in com.tangosol.net.events
- 
The emitted event types for aSessionLifecycleEvent.
- SessionLifecycleEventHandler(EventObserverSupport.EventObserver<SessionLifecycleEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.SessionLifecycleEventHandler
- SessionLifecycleEvents - Annotation Type in com.tangosol.net.events.annotation
- 
SessionLifecycleEvents is an annotation that should be applied toEventInterceptorimplementations that want to receiveSessionLifecycleEvents.
- SessionName - Annotation Type in com.oracle.coherence.cdi
- 
A qualifier annotation used when injecting Coherence resource to indicate a specific Session name.
- SessionName.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theSessionNameannotation.
- SessionProducer - Class in com.oracle.coherence.cdi
- 
A CDI producer forSessioninstances.
- SessionProducer(BeanManager) - Constructor for class com.oracle.coherence.cdi.SessionProducer
- sessionProvider() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- sessionProvider() - Method in interface com.tangosol.net.SessionConfiguration
- 
Return theSessionProviderto use to create a session.
- SessionProvider - Interface in com.tangosol.net
- 
CreatesSessions for use by applications requiring Coherence-based resources, includingNamedCaches, often for specificClassLoaders, for deployed modules.
- SessionProvider.Context - Interface in com.tangosol.net
- 
A context used by providers.
- SessionProvider.DefaultContext - Class in com.tangosol.net
- SessionProvider.Option - Interface in com.tangosol.net
- 
Deprecated.
- SessionProvider.Provider - Interface in com.tangosol.net
- 
Implemented by suppliers of aSessionProvider.
- SessionProvider.Providers - Class in com.tangosol.net
- 
Deprecated.since 20.12 there is no replacement for this class
- set(boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicBoolean
- 
Sets the value tonewValue.
- set(boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
- set(boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- set(boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicBoolean
- 
Sets the value tonewValue.
- set(boolean) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- set(boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- set(int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Sets the value tonewValue.
- set(int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- set(int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- set(int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Sets the value tonewValue.
- set(int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- set(int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- set(int, E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- set(int, Object) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
- 
Replaces the element at the specified position in this list with the specified element.
- set(int, Object) - Method in class com.tangosol.util.CircularArrayList
- set(int, Object) - Method in class com.tangosol.util.InflatableList
- set(int, Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Replaces the element at the specified position in this list with the specified element (optional operation).
- set(int, Object) - Method in class com.tangosol.util.SafeLinkedList
- 
Replaces the element at the specified position in this List with the specified element.
- set(int, T) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- set(int, T) - Method in class com.tangosol.util.SubList
- set(long) - Method in class com.oracle.coherence.common.base.MutableLong
- 
Update the value
- set(long) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Sets the value tonewValue.
- set(long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- set(long) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- set(long) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Sets the value tonewValue.
- set(long) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- set(long) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- set(long, Object) - Method in class com.tangosol.util.SimpleLongArray
- 
Add the passed item to the LongArray at the specified index.
- set(long, T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray
- set(long, V) - Method in class com.tangosol.util.AbstractSafeLongArray
- set(long, V) - Method in class com.tangosol.util.AbstractSparseArray
- 
Add the passed item to the LongArray at the specified index.
- set(long, V) - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Add the passed item to the LongArray at the specified index.
- set(long, V) - Method in interface com.tangosol.util.LongArray
- 
Add the passed item to the LongArray at the specified index.
- set(long, V) - Method in class com.tangosol.util.NullImplementation.NullLongArray
- set(long, V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperLongArray
- set(PofBufferReader, int) - Static method in class com.tangosol.io.pof.PofBufferReader.IdentityHolder
- set(XmlBean, Object) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Store the property value in the passed bean.
- set(InvocableMap.Entry<K, V>, R) - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Set the property value into the passed Entry object.
- set(E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperListIterator
- set(Object) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Sets the internal value (without updating the modification time)
- set(Object) - Method in class com.tangosol.util.ImmutableMultiList.MultiIterator
- set(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedListIterator
- 
Replaces the last element returned by next or previous with the specified element.
- set(Object) - Method in class com.tangosol.util.ThreadLocalObject
- 
Set the value of the ThreadLocalObject for the current thread.
- set(T) - Method in class com.tangosol.util.ConverterCollections.ConverterHolder
- set(T) - Method in class com.tangosol.util.ConverterCollections.ConverterListIterator
- set(V) - Method in interface com.oracle.coherence.common.base.Holder
- 
Specify the held object.
- set(V) - Method in class com.oracle.coherence.common.base.SimpleHolder
- 
Specify the held object.
- set(V) - Method in class com.oracle.coherence.common.base.VolatileHolder
- 
Specify the held object.
- set(V) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Sets the value tonewValue.
- set(V) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- set(V) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- set(V) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Sets the value tonewValue.
- set(V) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- set(V) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- set(V, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicMarkableReference
- 
Unconditionally sets the value of both the reference and mark.
- set(V, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
- set(V, boolean) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- set(V, boolean) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicMarkableReference
- 
Unconditionally sets the value of both the reference and mark.
- set(V, boolean) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- set(V, boolean) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- set(V, int) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicStampedReference
- 
Unconditionally sets the value of both the reference and stamp.
- set(V, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
- set(V, int) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- set(V, int) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicStampedReference
- 
Unconditionally sets the value of both the reference and stamp.
- set(V, int) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- set(V, int) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- SET_OVERHEAD - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
The memory cost of creating an InflatableSet.
- setAccessTime(long) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Gets the internal value with the side-effect of updating the access time to that which is specified and incrementing the access count.
- setAction(String) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.HostnameVerifierBuilder
- 
The action to take on a name mismatch.
- setActiveDirectory(String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Set the persistence active directory.
- setAddress(InetAddress) - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
Set the address to use for any realizedAddressProvider's
- setAdvanceFrequency(int) - Method in class com.tangosol.net.TcpDatagramSocket
- 
Specify the frequency at which the DatagramSocket will advance over the sub-sockets during receive.
- setAdvanceFrequency(int) - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Set frequency for datagram socket
- setAllowAutoAdjust(boolean) - Method in class com.tangosol.net.cache.AbstractBundler
- 
Specify whether or not the auto-adjustment is allowed..
- setAllowEndangered(boolean) - Method in class com.tangosol.coherence.config.xml.processor.HealthProcessor.XMLHealthCheckDependencies
- setAllowUnownedCommits(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the flag that indicates whether the topic allows commits for a position in a channel by subscribers that do not own the channel
- setAnalysisDelay(long) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Set the number of milliseconds the analysis should be delayed;0Lsuggests immediate analysis.
- setApplicationName(String) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the application name to use.
- setAssociatedKey(Object) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DefaultTaskDependencies
- 
Configure the associated key for Task.
- setAssociatedService(PartitionedService) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Set the associated service.
- setAsynchronousPageDeactivation(boolean) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Specify whether a daemon should evict the items from a deactivated page to avoid blocking other work from being done.
- setAsyncLimit(Expression<Bytes>) - Method in class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
- 
Set the maximum number of bytes that are queued to be written asynchronously.
- setAttribute(boolean) - Method in class com.tangosol.run.xml.SimpleValue
- 
Specify that this value is an element attribute.
- setAttribute(String, XmlValue) - Method in class com.tangosol.run.xml.SimpleElement
- 
Set an attribute value.
- setAttribute(String, XmlValue) - Method in interface com.tangosol.run.xml.XmlElement
- 
Set an attribute value.
- setAttribute(String, String, Object) - Method in interface com.tangosol.net.management.MBeanServerProxy
- 
Set the value of the specified MBean attribute.
- setAttribute(String, String, Object) - Method in class com.tangosol.net.management.WrapperMBeanServerProxy
- SetAttributes() - Constructor for class com.tangosol.net.management.MBeanAccessor.SetAttributes
- 
Default constructor.
- SetAttributes(MBeanAccessor.QueryBuilder.ParsedQuery, Map<String, Object>) - Constructor for class com.tangosol.net.management.MBeanAccessor.SetAttributes
- 
Construct a SetAttributes object.
- setAuthenticationScheme(String) - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
- setAutoAdjust(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Set the flag to auto adjust the preferred size value, based on the run-time statistics.
- setAutoStart(boolean) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Set the auto-start enabled flag.
- setBackEvent(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
For internal use only, store the current event from the back Map.
- setBackingMap(String, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory.Manager
- 
Deprecated.Associate the specified backing Map with a given name.
- setBackingMap(String, Map) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory.Manager
- 
Associate the specified backing Map with a given name.
- setBackingMapManager(BackingMapManager) - Method in interface com.tangosol.net.CacheService
- 
Set a backing map manager to be used by this CacheService to create underlying stores for the cached data.
- setBackingMapManager(BackingMapManager) - Method in class com.tangosol.net.WrapperCacheService
- 
Set a backing map manager to be used by this CacheService to create underlying stores for the cached data.
- setBackingMapScheme(BackingMapScheme) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Set theBackingMapSchemewhich builds the backing map for the clustered scheme.
- setBackingMapScheme(BackingMapScheme) - Method in class com.tangosol.coherence.config.scheme.ReplicatedScheme
- 
Set theBackingMapSchemewhich builds the backing map for the clustered scheme.
- setBackMapListener(MapListener) - Method in class com.tangosol.net.cache.OverflowMap
- 
Specify the MapListener for the back map.
- setBackScheme(CachingScheme) - Method in class com.tangosol.coherence.config.scheme.AbstractCompositeScheme
- 
Set the back scheme.
- setBackup(boolean) - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Set the flag indicating that the map is a backup map.
- setBackupDirectory(String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Set the persistence backup directory.
- setBackupMapConfig(BackupMapConfig) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Set theBackupMapConfigwhich is used to configure a backup map.
- setBackupSchemeName(Expression<String>) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Set the name of the caching scheme to use as a backup map.
- setBackupStrength(SimpleAssignmentStrategy.BackupStrength) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Set the BackupStrength for this analysis context.
- setBackUpToDate(boolean) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Specify that the value stored in the back Map is known to be up to date (not needing to be written to the back if evicted from the front).
- setBackUpToDate(boolean) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Specify that the value stored in the back Map is known to be up to date (not needing to be written to the back if evicted from the front).
- setBatchSize(int) - Method in class com.tangosol.util.filter.LimitFilter
- 
Set the number of members query concurrently.
- setBinary(Binary) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the binary value.
- setBinary(Binary) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the binary value.
- setBinaryMap(boolean) - Method in class com.tangosol.net.cache.SerializationMap
- 
Configure the Map to be aware that all the keys and values in the map are known to be Binary or not.
- setBinaryMap(boolean) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Configure the Map to be aware that all the keys and values in the map are known to be Binary or not.
- setBinaryStore(BinaryStore) - Method in class com.tangosol.io.AsyncBinaryStore
- 
Specify the underlying BinaryStore.
- setBinaryStore(BinaryStore) - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Configures the BinaryStore that this CacheStore will use for its storage.
- setBinaryStore(BinaryStore) - Method in class com.tangosol.net.cache.SerializationCache
- 
Configures the BinaryStore that this map will use for its storage.
- setBinaryStore(BinaryStore) - Method in class com.tangosol.net.cache.SerializationMap
- 
Configures the BinaryStore that this map will use for its storage.
- setBinaryStore(BinaryStore) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Configures the BinaryStore that this map will use for its storage.
- setBinaryStore(BinaryStore) - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Specify the store to wrap.
- setBinaryStore(BinaryStore) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Configures the BinaryStore that this map will use for its storage.
- setBinaryStoreManagerBuilder(BinaryStoreManagerBuilder) - Method in class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
- 
Sets theBinaryStoreManagerBuilderfor theBinaryStoreManager.
- setBinaryStoreManagerBuilder(BinaryStoreManagerBuilder) - Method in interface com.tangosol.coherence.config.builder.storemanager.BinaryStoreManagerBuilderCustomization
- 
Sets theBinaryStoreManagerBuilderfor theBinaryStoreManager.
- setBinaryStoreManagerBuilder(BinaryStoreManagerBuilder) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Sets theBinaryStoreManagerBuilderfor theBinaryStoreManager.
- setBinaryStoreManagerBuilder(BinaryStoreManagerBuilder) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Sets theBinaryStoreManagerBuilderfor theBinaryStoreManager.
- setBindingPower(int) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Set The binding precedence that this token will use for binding to the right.
- setBlind(boolean) - Method in class com.tangosol.coherence.config.builder.MapBuilder.Dependencies
- 
Set the flag indicating that the map is in blind mode.
- setBlocking(boolean) - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Set if datagram socket is blocking
- setBoolean(boolean) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the boolean value.
- setBoolean(boolean) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the boolean value.
- setBottomAnchor(Object) - Method in class com.tangosol.util.filter.LimitFilter
- 
Set the bottom anchor object.
- setBucketCount(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Configure the number of hash buckets.
- setBucketLevel(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Configure the hash bucket level.
- setBucketOffset(int, int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the head of the hash bucket linked list for a certain bucket.
- setBuffer(ByteBuffer) - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Set the current ByteBuffer reference.
- setBuffer(ByteBuffer) - Method in class com.tangosol.io.nio.BinaryMap
- 
Specify the ByteBuffer that the BinaryMap will be backed by.
- setBufferManager(ByteBufferManager) - Method in class com.tangosol.io.nio.BinaryMap
- 
Specify the ByteBufferManager for this map.
- setBuilder(ParameterizedBuilder<Provider>) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ProviderBuilder
- 
Customized provider builder
- setBuilder(ParameterizedBuilder<HostnameVerifier>) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.HostnameVerifierBuilder
- setBundleManager(BundleManager) - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Set theBundleManager.
- setBundleManager(BundleManager) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- 
Set theBundleManager.
- setBundleManager(BundleManager) - Method in class com.tangosol.coherence.config.scheme.RemoteCacheScheme
- 
Set theBundleManager.
- setCache(String) - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Set the cache name.
- setCacheConfiguration(ClassLoader, XmlElement) - Method in interface com.tangosol.net.CacheFactoryBuilder
- 
Dynamically set the default cache configuration for a given class loader.
- setCacheConfiguration(ClassLoader, XmlElement) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Dynamically set the default cache configuration for a given class loader.
- setCacheConfiguration(String, ClassLoader, XmlElement) - Method in interface com.tangosol.net.CacheFactoryBuilder
- 
Dynamically set the cache configuration for a given URI and class loader.
- setCacheConfiguration(String, ClassLoader, XmlElement) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Dynamically set the cache configuration for a given URI and class loader.
- setCacheConfiguration(String, ClassLoader, XmlElement) - Method in class com.tangosol.net.SingletonCacheFactoryBuilder
- 
Dynamically set the cache configuration for a given URI and class loader.
- setCacheEntry(ConfigurableCacheMap.Entry) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Configure the backing map cache entry.
- setCacheFactory(ConfigurableCacheFactory) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Deprecated.
- setCacheFactoryBuilder(CacheFactoryBuilder) - Static method in class com.tangosol.net.CacheFactory
- 
Specify a singleton CacheFactoryBuilder.
- setCacheFactoryBuilderConfig(XmlElement) - Static method in class com.tangosol.net.CacheFactory
- 
Set the cache factory builder configuration.
- setCacheLoader(CacheLoader) - Method in class com.tangosol.net.cache.LocalCache
- 
Specify the loader used by this LocalCache.
- setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Set theCacheLoaderfactory.
- setCacheMappingRegistry(CacheMappingRegistry) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Deprecated.As of Coherence 14.1.1, replaced byCacheConfig.addCacheMappingRegistry(SchemeMappingRegistry).
- setCacheName(String) - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Set the name of the cache.
- setCacheName(String) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Set the cache name for thisContinuousQueryCacheas returned byContinuousQueryCache.getCacheName().
- setCacheName(String) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the cache name for ReadThread and WriteThread if not already set.
- setCaches(LongArray) - Method in class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
- 
Set theLongArrayof caches for this visitor.
- setCacheStoreScheme(CacheStoreScheme) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Set theCacheStoreSchemewhich builds a CacheStore or CacheLoader.
- setCacheStoreScheme(CacheStoreScheme) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set theCacheStoreSchemebuilder.
- setCacheStoreTimeout(Expression<Millis>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the timeout interval to use for CacheStore/CacheLoader read and write operations.
- setCacheStoreTimeoutMillis(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the timeout used for CacheStore operations.
- setCacheValues(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Modify the local-caching option for theContinuousQueryCache.
- setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Set theCacheWriterfactory.
- setCapacity(int) - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Set the capacity of the current ByteBuffer.
- setChannelCount(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the number of channels in the topic.
- setCipherSuitesNameList(SSLSocketProviderDependenciesBuilder.NameListDependencies) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set cipher-suites dependencies
- setCircular(boolean) - Method in class com.tangosol.net.RefreshableAddressProvider.CircularIterator
- 
Set whether the Iterator should operate in a circular mode.
- setClassLoader(ClassLoader) - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Sets theClassLoaderthat will be used to dynamically load classes.
- setClassLoader(ClassLoader) - Method in class com.tangosol.io.WrapperDataInputStream
- 
Set the ClassLoader associated with this stream.
- setClassLoader(ClassLoader) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Assign the ClassLoader this context is associated with.
- setClassLoader(ClassLoader) - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Configure the ClassLoader that this CacheStore will use for deserialization.
- setClassLoader(ClassLoader) - Method in class com.tangosol.net.cache.SerializationMap
- 
Configure the ClassLoader that this map will use for deserialization.
- setClassLoader(ClassLoader) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Configure the ClassLoader that this map will use for deserialization.
- setClassLoader(ClassLoader) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Assign the ClassLoader this context is associated with.
- setClassName(Expression<String>) - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Sets theExpressionthat when evaluated will produce the name of the class to realize.
- setClientAuth(String) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set the client auth mode to use.
- setCluster(Cluster) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set the currentClusterto be used by commands executed under this context.
- setClusterQuorumMap(Map) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Set the cluster quorum map, keyed by role name.
- setCoherenceQueryLanguage(CoherenceQueryLanguage) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set theCoherenceQueryLanguagethat will be used by commands.
- setCollectStats(boolean) - Method in class com.tangosol.util.WrapperObservableMap
- 
Specify whether or not statistics are to be collected by the wrapper.
- setColumnHeaders(String[]) - Method in class com.tangosol.coherence.dslquery.statement.FormattedMapStatementResult
- 
Set the column headers to print.
- setComment(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Set the text of this element's comment.
- setComment(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Set the text of this element's comment.
- setComparator(Comparator) - Method in class com.tangosol.util.filter.LimitFilter
- 
Set the Comparator used to partition the values into pages.
- setCompletedTime(long) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Set the timestamp at which the analysis associated with this context completed.
- setConcurrency(int) - Method in interface com.tangosol.util.TransactionMap
- 
Attempt to change the concurrency mode to the given value.
- setConditionalRemoveAction(SegmentedConcurrentMap.ConditionalRemoveAction) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Specify the action for conditional remove.
- setConfig(XmlElement) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Specify the manager's configuration.
- setConfig(XmlElement) - Method in class com.tangosol.io.ConfigurableSerializerFactory
- 
Deprecated.Specify the configuration for the object.
- setConfig(XmlElement) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Specify the configuration for the object.
- setConfig(XmlElement) - Method in interface com.tangosol.net.BackingMapManagerContext
- 
Specify the configuration for the associated BackingMapManager.
- setConfig(XmlElement) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Specify the configuration for the object.
- setConfig(XmlElement) - Method in class com.tangosol.net.CompressionFilter
- 
Deprecated.Specify the configuration for the object.
- setConfig(XmlElement) - Method in class com.tangosol.net.ConfigurableAddressProviderFactory
- 
Deprecated.Specify the configuration for the object.
- setConfig(XmlElement) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Specify the factory configuration XML.
- setConfig(XmlElement) - Method in class com.tangosol.net.SocketOptions
- 
Deprecated.
- setConfig(XmlElement) - Method in class com.tangosol.persistence.ConfigurableSnapshotArchiverFactory
- 
Specify the configuration for the object.
- setConfig(XmlElement) - Method in interface com.tangosol.run.xml.XmlConfigurable
- 
Deprecated.Specify the configuration for the object.
- setConfig(XmlElement) - Method in class com.tangosol.util.NullImplementation.NullBackingMapManagerContext
- 
Specify the configuration for the associated BackingMapManager.
- setConfigClassLoader(ClassLoader) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Set the class loader used to load the configuration for this factory.
- setConfigClassLoader(ClassLoader) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Set the class loader used to load the configuration for this factory.
- setConfigurableCacheFactory(ConfigurableCacheFactory) - Static method in class com.tangosol.net.CacheFactory
- 
Deprecated.As of 12.2.1 deprecated with no replacement
- setConfigurableCacheFactory(ConfigurableCacheFactory) - Method in interface com.tangosol.net.ServiceMonitor
- 
Set theConfigurableCacheFactoryaServiceMonitorcan operate with.
- setConfigurableCacheFactory(ConfigurableCacheFactory) - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Set theConfigurableCacheFactoryaServiceMonitorcan operate with.
- setConfigurableCacheFactory(ConfigurableCacheFactory, String, ClassLoader, boolean) - Method in interface com.tangosol.net.CacheFactoryBuilder
- 
Dynamically set theConfigurableCacheFactoryfor a given URI and class loader.
- setConfigurableCacheFactory(ConfigurableCacheFactory, String, ClassLoader, boolean) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Dynamically set theConfigurableCacheFactoryfor a given URI and class loader.
- setConfigurableCacheFactoryConfig(XmlElement) - Static method in class com.tangosol.net.CacheFactory
- 
Set the configurable cache factory configuration.
- setConfigurableCacheFactorySupplier(Function<String, ConfigurableCacheFactory>) - Method in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl.DefaultDependencies
- 
Set the function to use to obtain namedConfigurableCacheFactoryinstances.
- setConfiguredName(String) - Method in class com.tangosol.util.Daemon
- 
Configure the name for the daemon.
- setConfiguredPriority(int) - Method in class com.tangosol.util.Daemon
- 
Configure the priority for the daemon.
- setConstructorParameterList(ParameterList) - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Sets theParameterListto be used for constructor parameters when realizing the class.
- setContainsValueAction(SegmentedHashMap.ContainsValueAction) - Method in class com.tangosol.util.SegmentedHashMap
- 
Specify the action for containsValue().
- setContentionObserver(SegmentedConcurrentMap.ContentionObserver) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Set the ContentionObserver for this SegmentedConcurrentMap.
- setContext(Context) - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- 
Set theContext.
- setContext(Guardian.GuardContext) - Method in interface com.tangosol.net.Guardable
- 
Set the guard context.
- setContext(Guardian.GuardContext) - Method in class com.tangosol.util.Daemon
- 
Set the guard context.
- setContextClassLoader(ClassLoader) - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- setContextClassLoader(ClassLoader) - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- setContextClassLoader(ClassLoader) - Method in interface com.tangosol.io.ClassLoaderAware
- 
Specify the context ClassLoader for this object.
- setContextClassLoader(ClassLoader) - Method in class com.tangosol.io.DefaultSerializer
- setContextClassLoader(ClassLoader) - Method in class com.tangosol.io.MultiplexingSerializer
- setContextClassLoader(ClassLoader) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Specify the context ClassLoader for this object.
- setContextClassLoader(ClassLoader) - Method in class com.tangosol.net.cache.NearCache
- 
Specify the context ClassLoader for this object.
- setContextClassLoader(ClassLoader) - Method in class com.tangosol.net.WrapperService
- 
Specify the context ClassLoader for this object.
- setContextSerializer(Serializer) - Method in interface com.tangosol.io.SerializerAware
- 
Specify the context Serializer for this object.
- setCookie(Object) - Method in class com.tangosol.util.filter.LimitFilter
- 
Set the cookie object.
- setCurrentRule(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Set the current quorum rule used by the policy.
- setCustomBuilder(ParameterizedBuilder<EventInterceptor>) - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Sets theParameterizedBuilderto be used as the alternate builder.
- setCustomBuilder(ParameterizedBuilder<Object>) - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Sets theParameterizedBuilderto be used as the alternate builder.
- setCustomBuilder(ParameterizedBuilder<Map>) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Set the InstanceBuilder that builds the custom instance.
- setCustomBuilder(ParameterizedBuilder<T>) - Method in interface com.tangosol.coherence.config.builder.BuilderCustomization
- 
Sets theParameterizedBuilderto be used as the alternate builder.
- setCustomBuilder(ParameterizedBuilder<T>) - Method in class com.tangosol.coherence.config.builder.DefaultBuilderCustomization
- 
Sets theParameterizedBuilderto be used as the alternate builder.
- setCustomBuilder(ParameterizedBuilder<T>) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractStoreManagerBuilder
- 
Sets theParameterizedBuilderto be used as the alternate builder.
- setCustomBuilder(ParameterizedBuilder<T>) - Method in class com.tangosol.coherence.config.scheme.AbstractLocalCachingScheme
- 
Sets theParameterizedBuilderto be used as the alternate builder.
- setCustomEnvironment(ParameterizedBuilder<PersistenceEnvironment<ReadBuffer>>) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Set abuilderto be used instantiate the appropriatePersistenceEnvironment.
- setDaemonCountMax(int) - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- setDaemonCountMax(int) - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- setDaemonCountMax(int) - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Set the maximum daemon pool thread count.
- setDaemonCountMin(int) - Method in class com.oracle.coherence.grpc.proxy.DaemonPoolExecutor.DaemonPoolManagement
- setDaemonCountMin(int) - Method in class com.oracle.coherence.grpc.proxy.GrpcProxyMetrics
- setDaemonCountMin(int) - Method in interface com.oracle.coherence.grpc.proxy.GrpcProxyMetricsMBean
- 
Set the minimum daemon pool thread count.
- setDaemonPool(DaemonPool) - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- setDaemonPool(DaemonPool) - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- 
Set theDaemonPool.
- setDaemonPool(DaemonPool) - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Configure the DaemonPool used to execute tasks.
- setDaemonPool(DaemonPool) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Configure the DaemonPool used to execute tasks.
- setDataVersion(int) - Method in class com.tangosol.io.AbstractEvolvable
- 
Set the version associated with the data stream with which this object is being deserialized.
- setDataVersion(int) - Method in interface com.tangosol.io.Evolvable
- 
Set the version associated with the data stream with which this object is being deserialized.
- setDataVersion(int) - Method in class com.tangosol.io.SimpleEvolvable
- 
Set the version associated with the data stream with which this object is being deserialized.
- setDate(Date) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the Date value.
- setDate(Date) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the Date value.
- setDateTime(Timestamp) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the Timestamp value.
- setDateTime(Timestamp) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the Timestamp value.
- setDebug(boolean) - Static method in class com.tangosol.net.cache.SerializationPagedCache
- 
Set the status of the internal debug flag.
- setDecimal(BigDecimal) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the dcimal value.
- setDecimal(BigDecimal) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the dcimal value.
- setDecomposition(int) - Method in class com.tangosol.util.CacheCollator
- 
Set the decomposition mode of this Collator.
- setDecorations(long, ReadBuffer) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Set the decoration mask and decorations for the PofValue.
- setDefaultMarshaller(String, Class) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Configure the default marshaller class for the specified media type.
- setDefaultMarshaller(MediaType, Class) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Configure the default marshaller class for the specified media type.
- setDefaultMarshallers(Map<String, Class>) - Method in class com.tangosol.coherence.rest.io.MarshallerRegistry
- 
Configure the default marshaller classes for the corresponding media types.
- setDefaultNamespaceHandler(NamespaceHandler) - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Sets theNamespaceHandlerfor the default namespace of documents to be processed
- setDefaultParameterResolver(ParameterResolver) - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Sets the defaultParameterResolverto use for resolving externally defined (ie: operating system/container) level parameters.
- setDeferredException(ConfigurationException) - Method in class com.tangosol.coherence.config.builder.FactoryBasedAddressProviderBuilder
- 
Defer reporting ConfigurationException until realized.
- setDelayMillis(long) - Method in class com.tangosol.net.cache.AbstractBundler
- 
Specify the timeout delay value.
- setDelayMillis(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Specify the number of milliseconds that an entry added to the queue will sit in the queue before being removable ("ripe").
- setDelayMillis(Expression<Millis>) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Set the write delay.
- setDelaySeconds(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Specify the number of seconds that an entry added to the queue will sit in the queue before being removable ("ripe").
- setDelegate(SocketProviderBuilder) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set delegate SocketProviderBuilder
- setDelegate(LongArray<V>) - Method in class com.tangosol.util.CopyOnWriteLongArray
- 
Set the internal LongArray.
- setDelegateSocketProvider(SocketProvider) - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Set Delegate SocketProvider
- setDependencies(SSLSocketProvider.Dependencies, ManagerDependencies, ManagerDependencies) - Method in interface com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.DependenciesAware
- 
Set the SSL Socket dependencies.
- setDependencies(GrpcAcceptorDependencies) - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- setDependencies(DaemonPoolDependencies) - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- setDependencies(ClusterDependencies) - Method in interface com.tangosol.net.Cluster
- 
Configure the Cluster.
- setDependencies(ClusterDependencies) - Method in interface com.tangosol.net.MemberIdentityProvider
- 
Set the cluster dependencies.
- setDependencies(ClusterDependencies) - Method in class com.tangosol.net.URLMemberIdentityProvider
- setDependencies(ServiceDependencies) - Method in interface com.tangosol.net.Service
- 
Configure the Service.
- setDependencies(ServiceDependencies) - Method in class com.tangosol.net.WrapperCacheService
- 
Configure the Service.
- setDependencies(ServiceDependencies) - Method in class com.tangosol.net.WrapperService
- 
Configure the Service.
- setDirectory(Expression<String>) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Set the BDB root directory where BDB stores files.
- setDirectory(Expression<String>) - Method in class com.tangosol.coherence.config.builder.storemanager.NioFileManagerBuilder
- 
Set the root directory where the manager stores files.
- setDirectory(Expression<String>) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Set the root directory where the disk persistence manager stores files.
- setDirectory(File) - Method in class com.tangosol.io.nio.MappedStoreManager
- 
Specify the directory to use for MappedBufferManager(s).
- setDirectQuery(DirectQuery) - Method in class com.tangosol.coherence.rest.config.QueryConfig
- 
Set the direct query.
- setDirectStorageSize(long) - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Set the PartitionAwareBackingMaps storage size of the partition.
- setDirty() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Set the dirty flag for this value.
- setDocumentComment(String) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Set the XML comment that appears outside of the root element.
- setDocumentComment(String) - Method in interface com.tangosol.run.xml.XmlDocument
- 
Set the XML comment that appears outside of the root element.
- setDocumentPreprocessor(DocumentPreprocessor) - Method in class com.tangosol.config.xml.AbstractNamespaceHandler
- 
Sets theDocumentPreprocessorfor theNamespaceHandler.
- setDomainPartitions(String[]) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the array of domain partition names to use.
- setDormant(boolean) - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Specify whether the daemon is dormant or not.
- setDouble(double) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the double value.
- setDouble(double) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the double value.
- setDtdName(String) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Set the public identifier of the DTD (DOCTYPE) for the document.
- setDtdName(String) - Method in interface com.tangosol.run.xml.XmlDocument
- 
Set the public identifier of the DTD (DOCTYPE) for the document.
- setDtdUri(String) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Set the URI of the DTD (DOCTYPE) for the document.
- setDtdUri(String) - Method in interface com.tangosol.run.xml.XmlDocument
- 
Set the URI of the DTD (DOCTYPE) for the document.
- setDumpHeldLocksAction(SegmentedConcurrentMap.DumpHeldLocksAction) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Specify the action for dump held locks.
- setElementCalculatorBuilder(ElementCalculatorBuilder) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the ElementCalculatorBuilder.
- setElementCalculatorType(Expression<String>) - Method in class com.tangosol.coherence.config.builder.ElementCalculatorBuilder
- 
Set theNamedTopic.ElementCalculatortype.
- setEnabled(boolean) - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Enable or disable this controller.
- setEncoding(String) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Set the encoding string for the XML document.
- setEncoding(String) - Method in interface com.tangosol.run.xml.XmlDocument
- 
Set the encoding string for the XML document.
- setEntryInBack(boolean) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Specify whether the entry for which this Status exists is present in the back map.
- setEntryInFront(boolean) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Specify whether the entry for which this Status exists is present in the front map.
- setEntryInFront(boolean) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Specify whether the entry for which this Status exists is present in the front map.
- setEphemeral(boolean) - Method in class com.tangosol.coherence.config.builder.WrapperSocketAddressProviderBuilder
- 
Set the flag indicating that the addresses should be ephemeral.
- setEraseAllSupported(boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Set the flag that determines whether or not the wrapped store supports eraseAll() operations.
- setEraseSupported(boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Set the flag that determines whether or not the wrapped store supports erase() operations.
- setErr(PrintWriter) - Static method in class com.tangosol.util.Base
- 
Sets the current writer used for tracing.
- setError() - Method in class com.tangosol.io.WriterPrintStream
- 
Set the error state of the stream totrue.
- setEventInterceptorBuilders(List<NamedEventInterceptorBuilder>) - Method in class com.tangosol.coherence.config.CacheConfig
- setEventInterceptorBuilders(List<NamedEventInterceptorBuilder>) - Method in class com.tangosol.coherence.config.ResourceMapping
- setEventInterceptorBuilders(List<NamedEventInterceptorBuilder>) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme
- setEventInterceptorBuilders(List<NamedEventInterceptorBuilder>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- setEventsDirectory(String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Set the persistence active directory.
- setEvictable(boolean) - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Specify that this entry is evictable or not.
- setEvictionApprover(ConfigurableCacheMap.EvictionApprover) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- setEvictionApprover(ConfigurableCacheMap.EvictionApprover) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Set the EvictionApprover for this ConfigurableCacheMap.
- setEvictionApprover(ConfigurableCacheMap.EvictionApprover) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Set the EvictionApprover for this ConfigurableCacheMap.
- setEvictionApprover(ConfigurableCacheMap.EvictionApprover) - Method in class com.tangosol.net.cache.SerializationCache
- 
Set the EvictionApprover for this ConfigurableCacheMap.
- setEvictionApprover(ConfigurableCacheMap.EvictionApprover) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Set the EvictionApprover for this ConfigurableCacheMap.
- setEvictionPolicy(ConfigurableCacheMap.EvictionPolicy) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- setEvictionPolicy(ConfigurableCacheMap.EvictionPolicy) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Set the EvictionPolicy for the cache to use.
- setEvictionPolicy(ConfigurableCacheMap.EvictionPolicy) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Set the EvictionPolicy for the cache to use.
- setEvictionPolicy(ConfigurableCacheMap.EvictionPolicy) - Method in class com.tangosol.net.cache.SerializationCache
- 
Set the EvictionPolicy for the cache to use.
- setEvictionPolicy(ConfigurableCacheMap.EvictionPolicy) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Set the EvictionPolicy for the cache to use.
- setEvictionPolicyBuilder(EvictionPolicyBuilder) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Set the EvictionPolicyBuilder.
- setEvictionPolicyBuilder(EvictionPolicyBuilder) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Set the EvictionPolicyBuilder.
- setEvictionType(int) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specify the eviction type for the cache.
- setEvictionType(Expression<String>) - Method in class com.tangosol.coherence.config.builder.EvictionPolicyBuilder
- 
Set the EvictionPolicy type.
- setEvolvable(boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Set the Evolvable flag to indicate if the object to be written is Evolvable or part of an Evolvable object.
- setExecutionTimeoutMillis(long) - Method in class com.tangosol.net.AbstractPriorityTask
- 
Specify the maximum amount of time this task is allowed to run before the corresponding service will attempt to stop it.
- setExecutionTimeoutMillis(long) - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.DefaultTaskDependencies
- 
Configure the execution timeout for Task.
- setExecutor(ParameterizedBuilder<Executor>) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set SSL executors builder.
- setExecutor(Executor) - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- 
Set theExecutor.
- setExitWhenProcessingComplete(boolean) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the flag that indicates the QueryPlus process should exit after processing the statements from the command line.
- setExpired(boolean) - Method in class com.tangosol.net.cache.LocalCache.KeyMask
- 
Specify whether or not the currently performed operation concerns an expired entry
- setExpiry(long) - Method in class com.tangosol.net.cache.OverflowMap.ExpirableStatus
- 
Specify the expiry for the entry represented by this Status.
- setExpiry(long) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Specify the expiry for the entry represented by this Status.
- setExpiryArray(LongArray) - Method in class com.tangosol.net.cache.OverflowMap
- 
Specify the array of keys that have an expiration, indexed by expiration times.
- setExpiryDelay(int) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- setExpiryDelay(int) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Specify the default "time to live" for cache entries.
- setExpiryDelay(int) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specify the default "time to live" for cache entries.
- setExpiryDelay(int) - Method in class com.tangosol.net.cache.OverflowMap
- 
Specify the "time to live" for cache entries.
- setExpiryDelay(int) - Method in class com.tangosol.net.cache.SerializationCache
- 
Specify the default "time to live" for cache entries.
- setExpiryDelay(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Specify the default "time to live" for cache entries.
- setExpiryDelay(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Set the expiry delay.
- setExpiryDelay(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Set the expiry delay.
- setExpiryDelay(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Set the expiry delay.
- setExpiryDelay(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Set the expiry delay.
- setExpiryDelay(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
- 
Set the expiry delay.
- setExpiryDelay(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the amount of time that elements offered to the queue remain visible to consumers.
- setExpiryEnabled(boolean) - Method in class com.tangosol.net.cache.OverflowMap
- 
Specify whether or not entry expiry is supported.
- setExpiryEnabled(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
- 
Set the expiry enabled flag.
- setExpiryMillis(long) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
- 
Specify when the cache entry will expire, or disable expiry.
- setExpiryMillis(long) - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Specify when the cache entry will expire, or disable expiry.
- setExpiryMillis(long) - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Specify when the cache entry will expire, or disable expiry.
- setExpiryMillis(long) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Specify when the cache entry will expire, or disable expiry.
- setExpiryMillis(long) - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- 
Specify when the cache entry will expire, or disable expiry.
- setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Set theFactoryfor theExpiryPolicy.
- setExpiryTime(long) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Sets the time (since the Epoc) in milliseconds when the Cache Entry associated with this value should be considered expired.
- setExpiryTime(long) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Sets the time (since the Epoc) in milliseconds when the Cache Entry associated with this value should be considered expired.
- setExpressionParser(ExpressionParser) - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Sets theExpressionParserto use for parsingExpressions during document processing.
- setExtendedLanguage(boolean) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set whether "Extended Language" features are enabled.
- setExtendedLanguage(boolean) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set whether extended language features should be enabled.
- setExtractorBuilder(ExtractorBuilder) - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Set theExtractorBuilderthat will be used by CohQL queries to buildValueExtractors.
- setFactory(SocketProviderFactory) - Method in interface com.tangosol.net.SocketProvider
- 
Specify the SocketProviderFactory associated with this provider.
- setFactoryClassName(Expression<String>) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Sets theExpressionthat when evaluated will produce the name of the class containing a static factory method that will realize instances for thisParameterizedBuilder.
- setFactoryMethodName(Expression<String>) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Set theExpressionthat when evaluated will produce the name of the factory class static method that will realize instances for thisParameterizedBuilder.
- setFactoryMethodParameters(ParameterList) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Sets theParameterListto use to resolve factory method parameters when realizing the class.
- setFederateApplySynthetic(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Set whether incoming federated changes should be applied locally as synthetic updates.
- setFederated(boolean) - Method in class com.tangosol.coherence.config.CacheMapping
- 
Set true if this cache mapping is for federated caches.
- setFile(RandomAccessFile) - Method in class com.tangosol.io.nio.MappedBufferManager
- 
Specify the RandomAccessFile that the buffer will be constructed on.
- setFiles(List<String>) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the list of statement files to execute before the QueryPlus session starts.
- setFilter(Filter) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- 
Set the filter to listen on.
- setFilterBuilder(ParameterizedBuilder<Filter>) - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- setFilters(Filter[]) - Method in class com.tangosol.util.Listeners
- 
Set the array of filters associated with this Listeners object.
- setFinishing(boolean) - Method in class com.tangosol.util.TaskDaemon
- 
Specify whether the daemon will finish scheduled tasks before stopping.
- setFlushTime(long) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.as of Coherence 3.5
- setFreeBlockOffset(int, int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the head of the free block linked list for a certain size code.
- setFrontEvent(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
For internal use only, store the current event from the front Map.
- setFrontEvent(MapEvent) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
For internal use only, store the current event from the front Map.
- setFrontMapListener(MapListener) - Method in class com.tangosol.net.cache.OverflowMap
- 
Specify the MapListener for the front map.
- setFrontMapListener(MapListener) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Specify the MapListener for the front map.
- setFrontPutBlind(boolean) - Method in class com.tangosol.net.cache.OverflowMap
- 
Specify whether the front Map is more efficiently updated using putAll.
- setFrontPutBlind(boolean) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Specify whether the front Map is more efficiently updated using putAll.
- setFrontScheme(CachingScheme) - Method in class com.tangosol.coherence.config.scheme.AbstractCompositeScheme
- 
Set the front scheme.
- setFunctor(String) - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Set the receiver's functor to be the given String
- setFutureData(Binary) - Method in class com.tangosol.io.AbstractEvolvable
- 
Store the unknown remainder of the data stream from which this object is being deserialized.
- setFutureData(Binary) - Method in interface com.tangosol.io.Evolvable
- 
Store the unknown remainder of the data stream from which this object is being deserialized.
- setFutureData(Binary) - Method in class com.tangosol.io.SimpleEvolvable
- 
Store the unknown remainder of the data stream from which this object is being deserialized.
- setGarFileName(String) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the name of the GAR file to load before starting the QueryPlus session.
- setGetEntryAction(SegmentedHashMap.GetEntryAction) - Method in class com.tangosol.util.SegmentedHashMap
- 
Specify the action for getEntryInternal.
- setGlobalSocketProvider(SocketProviderBuilder) - Static method in class com.tangosol.net.SocketProviderFactory
- 
Set the globalSocketProviderBuilder.
- setGlobalSocketProviderBuilder(SocketProviderBuilder) - Static method in class com.tangosol.net.SocketProviderFactory
- 
Set the globalSocketProviderBuilder.
- setGrowthCount(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the level at which the modulo will increase.
- setGrowthThreshold(int) - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Specify the level (what number of bytes used) above which the current ByteBuffer will need to be "resized" upwards.
- setGuardableCount(int) - Method in class com.tangosol.net.GuardSupport
- 
Set the number of Guardables that are registered with this GuardSupport.
- setGuardContexts(GuardSupport.Context[]) - Method in class com.tangosol.net.GuardSupport
- 
Set the array of GuardContext objects for the Guardables that are managed by this GuardSupport.
- setGuardPolicy(Guardian, long, float) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadThread
- 
Set the Guardian and policy to guard this Daemon with.
- setGuardPolicy(Guardian, long, float) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteThread
- 
Set the Guardian and policy to guard this Daemon with.
- setGuardPolicy(Guardian, long, float) - Method in class com.tangosol.util.Daemon
- 
Set the Guardian and policy to guard this Daemon with.
- setGuardRegisterAction(Runnable) - Method in class com.tangosol.util.Daemon
- 
Set the Guardian registration action.
- setHashCode(int) - Method in class com.tangosol.run.xml.XmlBean
- 
Set the cached hash code.
- setHighUnits(int) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- setHighUnits(int) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Update the maximum size of the cache in units.
- setHighUnits(int) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Update the maximum size of the cache in units.
- setHighUnits(int) - Method in class com.tangosol.net.cache.SerializationCache
- 
Update the maximum size of the cache in units.
- setHighUnits(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Update the maximum size of the cache in units.
- setHighUnits(Expression<MemorySize>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the high-units
- setHighUnits(Expression<Units>) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Set the high units.
- setHighUnits(Expression<Units>) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Set the high units.
- setHighUnits(Expression<Units>) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Set the high units.
- setHighUnits(Expression<Units>) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Set the high units.
- setHostnameVerifierBuilder(ParameterizedBuilder<HostnameVerifier>) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set the customized HostnameVerifierBuilder
- setId(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Set the string representation of this token to the given id.
- setIdentityManager(DefaultManagerDependencies) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set the SSL identity manager dependencies.
- setIdleTimeout(long) - Method in class com.tangosol.util.TaskDaemon
- 
Configure the daemon's timeout.
- setIgnoreCase(boolean) - Method in class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Use given boolean to decide whether to ignore case for keyword operations
- setIncrementalEviction(boolean) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specify whether incremental eviction is enabled.
- setIndexFileName(String) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Set the Jandex index file name to use to discover portable types.
- setInitialSize(Expression<MemorySize>) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Return the initial buffer size in bytes for off-heap and file-mapped backup maps.
- setInitialSize(Expression<Megabytes>) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractNioManagerBuilder
- 
Set the initial buffer size.
- setInitParams(ResolvableParameterList) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Set the BDB init params needed to construct a BerkeleyDBBinaryStoreManager.
- setInnerScheme(CachingScheme) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Set the inner scheme.
- setInputStream(InputStream) - Method in class com.tangosol.io.WrapperInputStream
- 
Specify the underlying InputSream.
- setInsertAction(SegmentedHashMap.InsertAction) - Method in class com.tangosol.util.SegmentedHashMap
- 
Specify the action for insert.
- setInt(int) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the int value.
- setInt(int) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the int value.
- setInterceptor(EventInterceptor<E>) - Method in interface com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent
- 
Set theEventInterceptorthat should be registered in place of the EventInterceptor originally being registered.
- setInternal(boolean) - Method in class com.tangosol.coherence.config.CacheMapping
- setInternal(boolean) - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Set the flag to indicate if this mapping is for internal resources used by the service.
- setInternalMap(ObservableMap) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the internal map.
- setInternalMap(Map<K, V>) - Method in class com.tangosol.util.CopyOnWriteMap
- 
Set the internal map.
- setInternalScheme(CachingScheme) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the internal scheme.
- setInternalValue(Object) - Method in class com.tangosol.run.xml.SimpleValue
- 
Update the internal representation of the XmlValue.
- setInvalidationStrategy(Expression<String>) - Method in class com.tangosol.coherence.config.scheme.NearScheme
- 
Set the invalidation strategy.
- setKey(Key) - Method in interface com.tangosol.run.xml.Identifiable
- 
Set this value object to match to the specified Key
- setKey(Binary) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Update the Entry key in the block.
- setKey(K) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- 
Set the key to listen on.
- setKey(K) - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Set the key for this event.
- setKey(K) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Set the cached converted old value associated with this event.
- setKeyClass(Class) - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Set the key class.
- setKeyClassName(String) - Method in class com.tangosol.coherence.config.CacheMapping
- 
Sets the name of the key class forNamedCaches using thisCacheMapping.
- setKeyConverterClass(Class) - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Set the key converter class.
- setKeyHolder() - Method in class com.tangosol.net.cache.CachingMap
- 
Set up a thread local Set to hold all the keys that might be evicted from the front cache.
- setKeyMask(LocalCache.KeyMask) - Method in class com.tangosol.net.cache.LocalCache
- 
ThreadLocal: Set the key mask for the current thread.
- setLastAnalysisContext(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Set the last AnalysisContext.
- setLastBlockOffset(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the offset of the last block in the buffer.
- setLastOwnershipMembers(Set) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Record the set of ownership-enabled members present when the analysis was last considered.
- setLedASTName(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Set the led AST Name for this token to be the given string
- setLength(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Reconfigure the length of the buffer.
- setLength(int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Reconfigure the length of the buffer.
- setLink(BaseTokenStream) - Method in class com.tangosol.coherence.dsltools.base.BaseTokenStream
- 
Remember a BaseTokenStream that can be the target of streaming
- setListenBacklog(int) - Method in class com.tangosol.net.TcpDatagramSocket
- 
Specify the listen backlog for the server socket.
- setListenerBuilder(ParameterizedBuilder<MapListener>) - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- 
Set theParameterizedBuilderthat builds aMapListener.
- setLocalOnly(boolean) - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Set the local only flag to indicate that the change is not federated.
- setLockAction(SegmentedConcurrentMap.LockAction) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Specify the action for lock().
- setLockDelaySeconds(int) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Specify the number of seconds to wait for a lock in debug mode.
- setLockingEnforced(boolean) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Set the flag indicating whether or not the locking is enforced for put, remove and clear operations.
- setLog(PrintWriter) - Static method in class com.tangosol.util.Base
- 
Sets the current writer used for logging.
- setLogEcho(boolean) - Static method in class com.tangosol.util.Base
- 
Specify whether the log should echo to the console.
- setLoggingConfig(XmlElement) - Static method in class com.tangosol.net.CacheFactory
- 
Set the configuration info for the logging facility.
- setLoggingLevel(int) - Static method in class com.oracle.coherence.common.base.Logger
- 
Set the logging level.
- setLoggingLevel(Integer) - Static method in class com.tangosol.net.CacheFactory
- 
Set the Coherence logging level.
- setLong(long) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the long value.
- setLong(long) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the long value.
- setLowUnits(int) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- setLowUnits(int) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Specify the point to which the cache will shrink when it prunes.
- setLowUnits(int) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specify the point to which the cache will shrink when it prunes.
- setLowUnits(int) - Method in class com.tangosol.net.cache.SerializationCache
- 
Specify the point to which the cache will shrink when it prunes.
- setLowUnits(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Specify the point to which the cache will shrink when it prunes.
- setLowUnits(Expression<Units>) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Set the low units.
- setLowUnits(Expression<Units>) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Set the low units.
- setManagement(Registry) - Method in interface com.tangosol.net.Cluster
- 
Sets the current management registry.
- setManagementConfig(XmlElement) - Static method in class com.tangosol.net.CacheFactory
- 
Set the management framework configuration.
- setManagementEnabled(boolean) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Set JCache Management status.
- setManagementEnabled(boolean) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setManagementEnabled(boolean) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Set if JMX management is enabled for a configuration.
- setManagementEnabled(boolean) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- setManagementEnabled(boolean) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Sets management enablement
- setManagementEnabled(boolean) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- setManagementEnabled(boolean) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- setMap(Map<K, V>) - Method in class com.tangosol.net.cache.MapCacheStore
- 
Configures the Map that this CacheStore uses for its storage.
- SetMap<K,V> - Class in com.tangosol.util
- SetMap(Set<K>) - Constructor for class com.tangosol.util.SetMap
- 
Construct a SetMap.
- SetMap(Set<K>, Function<K, V>) - Constructor for class com.tangosol.util.SetMap
- 
Construct a SetMap.
- SetMap(Set<K>, Function<K, V>, Supplier<Map<K, V>>) - Constructor for class com.tangosol.util.SetMap
- 
Construct a SetMap.
- setMarkInternal(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Update the internal stream mark.
- setMarshallerMap(Map<String, Class>) - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Set the map of marshaller classes keyed by media type.
- setMaster() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Designate this Bundle as a "master" bundle.
- setMathContext(MathContext) - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Sets the MathContext (allowing you to work with precision instead of scale).
- setMaxCapacity(int) - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Specify the maximum size that the managed buffer can reach.
- setMaxCapacity(int) - Method in class com.tangosol.io.nio.AbstractStoreManager
- 
Specify the maximum size that the managed buffers can reach.
- setMaximumSize(Expression<MemorySize>) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Set the maximum buffer size in bytes for off-heap and file-mapped backup maps.
- setMaximumSize(Expression<Megabytes>) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractNioManagerBuilder
- 
Set the maximum buffer size.
- setMaxLoadFactor(double) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the load factor.
- setMaxResults(int) - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Set the max size of result set this resource is allowed to return.
- setMaxThreadCount(Expression<Integer>) - Method in class com.tangosol.coherence.config.builder.DaemonPoolBuilder
- setMBeanServer(MBeanServer) - Method in class com.tangosol.net.management.MBeanHelper.QueryExpFilter
- setMemberHealthCheck(boolean) - Method in class com.tangosol.coherence.config.xml.processor.HealthProcessor.XMLHealthCheckDependencies
- setMemberLocatorType(Expression<String>) - Method in class com.tangosol.coherence.config.builder.ReadLocatorBuilder
- 
Set the string that represents the member to target reads against.
- setMinCapacity(int) - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Specify the minimum size that the managed buffer can reach.
- setMinCapacity(int) - Method in class com.tangosol.io.nio.AbstractStoreManager
- 
Specify the minimum size that the managed buffers can reach.
- setMinLoadFactor(double) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the "unload factor".
- setMinThreadCount(Expression<Integer>) - Method in class com.tangosol.coherence.config.builder.DaemonPoolBuilder
- setMissCache(Map) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Set Miss Cache.
- setMissCacheScheme(LocalScheme) - Method in class com.tangosol.coherence.config.scheme.OverflowScheme
- 
Set the miss cache scheme.
- setMissCacheScheme(LocalScheme) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the miss cacheScheme.
- setMissedSoftTimeout(long) - Method in class com.tangosol.net.GuardSupport.Context
- 
Set the missed soft-timeout for this guardable.
- setModificationTime(long) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
Sets update the modification time for the meta data for a key and value pair.
- setModulo(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the new modulo.
- setMutable(boolean) - Method in class com.tangosol.run.xml.SimpleValue
- 
Specify whether this value can be modified or not.
- setMutable(boolean) - Method in class com.tangosol.run.xml.XmlBean
- 
Specify whether this value can be modified or not.
- setName(String) - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Set the logical name / identifier for thisEventInterceptor.
- setName(String) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.ProviderBuilder
- 
Provider name
- setName(String) - Method in class com.tangosol.run.xml.SimpleElement
- 
Set the Name of the element.
- setName(String) - Method in interface com.tangosol.run.xml.XmlElement
- 
Set the Name of the element.
- setNamedCacheName(String) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- 
Sets the desired CoherenceNamedCachename to map to when specifying a JCacheCachename
- setNamespacePrefix(String) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Set the default Namespace prefix for this property.
- setNamespacePrefix(String) - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Set the default Namespace prefix for this XML bean.
- setNest(NestedBaseTokens) - Method in class com.tangosol.coherence.dsltools.precedence.NestingOPToken
- 
Set the NestedBaseTokens to process.
- setNesting(String, String) - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Set the Strings used as nesting characters.
- setNewValue(V) - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Set the new value.
- setNewValue(V) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Set the cached converted new value associated with this event.
- setNext(SegmentedHashMap.Entry) - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Set the next entry in the linked list (open hash)
- setNextBlockOffset(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Specify the offset of the next Block in the Buffer.
- setNextCheckTime(long) - Method in class com.tangosol.net.GuardSupport
- 
Set the next time at which the Guardables should be checked.
- setNextCompactBlock(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the next block to compact.
- setNextEntry(SimpleElement.AttributeMap.Entry) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.Entry
- 
Set the next entry in the linked list.
- setNextNodeOffset(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Specify the offset of the next Block in the linked list.
- setNextRehashBucket(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the next bucket to rehash.
- setNextValidator(TransactionMap.Validator) - Method in class com.tangosol.run.jca.SimpleValidator
- 
Set the next Validator.
- setNextValidator(TransactionMap.Validator) - Method in interface com.tangosol.util.TransactionMap.Validator
- 
Set the next Validator.
- setNudASTName(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Set the nud AST Name for this token to be the given string
- setNullValuesAllowed(boolean) - Method in class com.tangosol.net.cache.OverflowMap
- 
Specify whether null values are permitted.
- setNullValuesAllowed(boolean) - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Specify whether null values are permitted.
- setObject(Object) - Method in class com.tangosol.util.SafeLinkedList.Node
- setObject(Object) - Method in class com.tangosol.util.ThreadLocalObject
- 
Set the value of the ThreadLocalObject for the current thread.
- setObjectInputFilter(Object) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- setObjectInputFilter(Object) - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Set theObjectInputFilterfor this stream.
- setObjectInputFilter(Object) - Method in class com.tangosol.io.WrapperBufferInput
- setObjectStreamFactory(ObjectStreamFactory) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Specify an ObjectStreamFactory that should be used to convert DataInput/Output into ObjectInput/Output streams.
- setObserved(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Specify whether theContinuousQueryCachehas any listeners that cannot be served by this Map listening to lite events.
- setOffset(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Specify the offset of the next byte to read from the underlying ReadBuffer.
- setOffset(int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Specify the offset of the next byte to write to the underlying WriteBuffer.
- setOffset(int) - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Specify the offset of the next byte to read from the underlying ReadBuffer.
- setOffset(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Specify the offset of the next byte to write to the underlying WriteBuffer.
- setOffset(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Specify the offset of this Block in the Buffer.
- setOffset(int) - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Specify the offset of the next byte to read from the underlying ReadBuffer.
- setOffset(int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- setOffset(int) - Method in class com.tangosol.io.WrapperBufferInput
- 
Specify the offset of the next byte to read from the underlying ReadBuffer.
- setOffset(int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Specify the offset of the next byte to write to the underlying WriteBuffer.
- setOffset(int) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Specify the offset of the next byte to write to the underlying WriteBuffer.
- setOffsetInternal(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Update the internal stream offset.
- setOffsetInternal(int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Update the internal stream offset.
- setOldValue(V) - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Set the old value.
- setOldValue(V) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent
- 
Set the cached converted old value associated with this event.
- setOperationName(Expression<String>) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Set the operation name for which calls performed concurrently on multiple threads are bundled.
- setOptimizeGetTime(boolean) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- 
Specify whether this cache is used in the environment, where theBase.getSafeTimeMillis()is used very frequently and as a result, theBase.getLastSafeTimeMillis()could be used without sacrificing the clock precision.
- setOptimizeGetTime(boolean) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specify whether or not this cache is used in the environment, where theBase.getSafeTimeMillis()is used very frequently and as a result, theBase.getLastSafeTimeMillis()could be used without sacrificing the clock precision.
- setOptimizeMV(boolean) - Method in class com.tangosol.util.SimpleMapIndex
- 
For an indexed value that is a multi-value (Collection or array) this flag specifies whether an attempt should be made to search the forward map for an existing reference that is "equal" to the specified mutli-value and use it instead (if available) to reduce the index memory footprint.
- setOption(int, Object) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- setOrder(Interceptor.Order) - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Set theEventInterceptor's order (HIGH || LOW), hence whether it should be at the start of the chain of interceptors.
- setOriginalBuffer(ReadBuffer) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Set the original buffer the changes should be applied to.
- setOrphanedPartitions(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Set the orphaned partitions that can be prioritized for transfer in order to reduce the transfer cost.
- setOut(PrintWriter) - Static method in class com.tangosol.util.Base
- 
Sets the current writer used for printing.
- setOutputStream(OutputStream) - Method in class com.tangosol.io.WrapperOutputStream
- 
Specify the underlying OutputStream.
- setOwner(int, int) - Method in class com.tangosol.net.partition.Ownership
- 
Specify a new owner id for the specified storage for this partition.
- setOwners(int[]) - Method in class com.tangosol.net.partition.Ownership
- 
Set the owner ids for this partition according to the specified array of member-ids.
- setOwners(Ownership) - Method in class com.tangosol.net.partition.Ownership
- 
Set the owner ids for this partition according to the specified Ownership.
- setOwnerThread(Thread) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Specify the thread that owns the Status object.
- setOwnerThread(Thread) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Specify the thread that owns the Status object.
- setPacketMagic(int, int) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Specify the packet header which is included at the start of every packet.
- setPacketMagic(int, int) - Method in class com.tangosol.net.TcpDatagramSocket
- 
Specify the packet header which is included at the start of every packet.
- setPage(int) - Method in class com.tangosol.util.filter.LimitFilter
- 
Set the page number (zero-based).
- setPageDuration(long) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Specify the length of time that the most recently created page is kept as the current page.
- setPageDurationSeconds(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Set the page duration.
- setPageLimit(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Set the page limit.
- setPageSize(int) - Method in class com.tangosol.util.filter.LimitFilter
- 
Set the page size (expressed as a number of entries per page).
- setPageSize(Expression<Units>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the page size.
- setParameterResolver(ParameterResolver) - Method in class com.tangosol.coherence.config.ResourceMapping
- setParent(XmlElement) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the parent element of this value.
- setParent(XmlElement) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the parent element of this value.
- setParentXmlBean(XmlBean) - Method in class com.tangosol.run.xml.XmlBean
- 
Specify the XmlBean that contains this XmlBean.
- setPartialClass(Class) - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Set the partial class for this property.
- setPartialResult(Object) - Method in exception com.tangosol.net.RequestIncompleteException
- 
Specify a partial execution result.
- setPartitioned(Expression<String>) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Set the partitioned string.
- setPartitionVersion(int, long) - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- 
Set the partition version.
- setPassivePagedBackup(boolean) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Specify whether this is just a passive backup for a paged cache.
- setPending(boolean) - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Set or clear the "pending" flag.
- setPersistenceEnvironment(AbstractPersistenceEnvironment) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Configure the environment that created this manager.
- setPersistenceMode(String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Set persistence mode.
- setPersistenceSnapshotDirectory(String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Set the persistence snapshot directory.
- setPersistenceTrashDirectory(String) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Set the persistence trash directory.
- setPofContext(PofContext) - Method in class com.tangosol.io.pof.PofBufferReader
- 
Configure the PofContext object used by this PofReader to deserialize user types from a POF stream.
- setPofContext(PofContext) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Configure the PofContext object used by this PofWriter to serialize user types to a POF stream.
- setPofContext(PofContext) - Method in interface com.tangosol.io.pof.PofReader
- 
Configure the PofContext object used by this PofReader to deserialize user types from a POF stream.
- setPofContext(PofContext) - Method in interface com.tangosol.io.pof.PofWriter
- 
Configure the PofContext object used by this PofWriter to serialize user types to a POF stream.
- setPortMax(int) - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
Set the maximum port number.
- setPortMin(int) - Method in class com.tangosol.coherence.config.builder.LocalAddressProviderBuilder
- 
Set the minimum port number.
- setPreferJavaTime(boolean) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Set the flag specifying if Java 8 date/time types (java.time.*) should be preferred over legacy types.
- setPreferJavaTime(boolean) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Set the flag specifying if Java 8 date/time types (java.time.*) should be preferred over legacy types.
- setPreferredSize(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Set the bundle size threshold.
- setPrefixAllowed(boolean) - Method in class com.tangosol.coherence.dsltools.precedence.InfixOPToken
- 
Set the flag that control whether the operator may be used as a prefix.
- setPreLoad(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Set the pre-load enabled flag.
- setPrevBlockOffset(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Specify the offset of the previous Block in the Buffer.
- setPreviousModulo(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the old modulo.
- setPrevNodeOffset(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Specify the offset of the previous Block in the linked list.
- setPrimaryOwner(int) - Method in class com.tangosol.net.partition.Ownership
- 
Specify a new primary owner id for this partition.
- setPrimitive(long, long) - Method in class com.tangosol.util.PrimitiveSparseArray
- 
Add the passed item to the PrimitiveSparseArray at the specified index.
- setPrimitiveValue(long) - Method in class com.tangosol.util.PrimitiveSparseArray.Iterator
- 
Stores a new value at the current value index, returning the value that was replaced.
- setPrimitiveValue(long) - Method in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
- 
Set the long value for the Node.
- setPrintWriter(PrintWriter) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Specify a PrintWriter to be used by this LoggingPofHandler.
- setProtocol(String) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set the SSL protocol name
- setProtocolVersionsNameList(SSLSocketProviderDependenciesBuilder.NameListDependencies) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set protocol-versions dependencies
- setProviderBuilder(SSLSocketProviderDependenciesBuilder.ProviderBuilder) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set the SSL provider builder.
- setPruneDelay(int) - Method in class com.tangosol.util.ThreadLocalObject
- 
Deprecated.as of Coherence 3.3 this method is a no-op
- setPunctuation(String) - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Set the String used to determine punctuation characters.
- setQueryConfig(QueryConfig) - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Set the query configuration for this resource.
- setQueueDaemon(AsyncBinaryStore.QueueDaemon) - Method in class com.tangosol.io.AsyncBinaryStore
- setQuorumRules(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule[]) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Set the quorum rules used by this policy.
- setReader(BufferedReader) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set theBufferedReaderthat should be used to obtain user input.
- setReadOnly(boolean) - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- setReadOnly(boolean) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Modify the read-only option for theContinuousQueryCache.
- setReadOnly(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the read-only flag.
- setReadThrough(boolean) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setReadThrough(boolean) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Set if read-through caching should be used.
- setReconnectInterval(long) - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- setReconnectInterval(long) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Specify the reconnection interval (in milliseconds).
- setReconnectRetryMillis(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the amount of time publishers and subscribers will wait between attempts to reconnect after being disconnected.
- setReconnectTimeoutMillis(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the maximum amount of time publishers and subscribers will attempt to reconnect after being disconnected.
- setReconnectWaitMillis(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the amount of time publishers and subscribers will wait before attempts to reconnect after being disconnected.
- setRecoveryMillis(long) - Method in class com.tangosol.net.GuardSupport.Context
- 
Set the recovery interval for this Guardable.
- setReferenceEnabled(boolean) - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Set the referenceEnabled flag.
- setReferenceEnabled(boolean) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Enable or disable POF Identity/Reference type support for this SimplePofContext.
- setRefreshAheadFactor(double) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the refresh-ahead factor, expressed as a percentage of the internal cache expiration interval.
- setRefreshAheadFactor(Expression<Double>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the refresh ahead factor.
- setRefreshFrequency(long) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics
- 
Set the max frequency to allow cache statistics refresh across all members.
- setRefreshPeriod(Seconds) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set the auto-refresh period.
- setRefreshPolicy(RefreshPolicy) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set theRefreshPolicyto use to determine whether keys and certs should be refreshed.
- setRegistrationBehavior(RegistrationBehavior) - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- 
Specifies the behavior upon duplicate registration.
- setRegistrationContext(String) - Method in class com.tangosol.net.cache.NearCache
- 
Set the context (tier) used to register a CacheMBean for this cache.
- setRegistry(Registry) - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- 
Set the managementRegistryto register the proxy MBean with.
- setRemoteCacheScheme(RemoteCacheScheme) - Method in class com.tangosol.coherence.config.scheme.CacheStoreScheme
- 
Set theRemoteCacheScheme.
- setRemoteScopeName(String) - Method in class com.tangosol.coherence.config.scheme.BaseGrpcScheme
- 
Set the scope name to use to access resources on the remote cluster.
- setRemoveAction(SegmentedHashMap.RemoveAction) - Method in class com.tangosol.util.SegmentedHashMap
- 
Specify the action for remove().
- setReported(boolean) - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Set of clear the "reported" flag.
- setRequestTimeoutMillis(long) - Method in class com.tangosol.net.AbstractPriorityTask
- 
Specify the maximum amount of time a calling thread is willing to wait for a result of the request execution.
- setResourceRegistry(ResourceRegistry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfigurationMapListener
- 
InjectResourceRegistryassociated with theConfigurableCacheFactorythat created the cache that this maplistener is added to.
- setResourceRegistry(ResourceRegistry) - Method in class com.tangosol.config.xml.DocumentProcessor.DefaultDependencies
- 
Sets theResourceRegistrythat will be used when processing a document.
- setResult(Object) - Method in class com.tangosol.net.AbstractInvocable
- 
Set the result of the invocation.
- setResult(T) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Set the holder's result value.
- setRetainConsumed(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set whether to retain consumed values.
- setRethrowExceptions(boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the value of the flag that determines if exceptions caught during synchronous CacheStore operations are rethrown to the calling thread; if false, exceptions are logged.
- setRipeMillis(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Specify the times when the entry has to be persisted.
- setRole(String) - Method in class com.tangosol.coherence.rest.providers.SecurityFilter.Authorizer
- setRollbackCacheStoreFailures(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the flag to indicate that cache store failures should be rolled back.
- setRollover(int) - Method in class com.tangosol.util.ThreadLocalObject
- 
Deprecated.as of Coherence 3.3 this method is a no-op
- setRoundingMode(RoundingMode) - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Sets theRoundingModefor the results, e.g. if scale is applied to the aggregation result.
- setRuleMask(int) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Set the numeric representation of the actions allowed by this rule.
- setSanityCheckingEnabled(boolean) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set whether sanity checking is enabled when executing commands.
- setSanityCheckingEnabled(boolean) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set whether sanity checking is enabled.
- setScale(Integer) - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Specifies the scale to be applied to the aggregated result.
- setSchedulingPriority(int) - Method in class com.tangosol.net.AbstractPriorityTask
- 
Specify this task's scheduling priority.
- setSchemeName(String) - Method in class com.tangosol.coherence.config.scheme.AbstractScheme
- 
Set the scheme name, trimming the name of starting and ending whitespace if necessary.
- setScopeName(String) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Deprecated.
- setScopeName(String) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Set the scope name.
- setScopeName(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Set the scope name for this ConfigurableCacheFactory.
- setSecurityConfig(XmlElement) - Static method in class com.tangosol.net.CacheFactory
- 
Set the security framework configuration.
- setSerializerFactory(NamedSerializerFactory) - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- 
Set theNamedSerializerFactory.
- setService(Service) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
Set the Cluster service.
- setService(Service) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Set the service that this policy applies to.
- setServiceConfig(String, XmlElement) - Static method in class com.tangosol.net.CacheFactory
- 
Set the configuration for the specified service type.
- setServiceDependencies(D) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Set theServiceDependenciesto be used by this scheme when configuring a newly realizedService.
- setServiceName(String) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Set the service name.
- setServiceSchemeRegistry(ServiceSchemeRegistry) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Set theServiceSchemeRegistryfor theCacheConfig.
- setSession(Session) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set theSessionthat will be used by commands executed under this context.
- setShrinkageCount(int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Set the level at which the modulo will decrease.
- setShrinkageThreshold(int) - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Specify the level (what number of bytes used) below which the current ByteBuffer will need to be "resized" downwards.
- setSilentMode(boolean) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set the flag indicating that the QueryPlus session is running in silent mode.
- setSilentMode(boolean) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the flag indicating that the QueryPlus session is running in silent mode.
- setSingletonFactory(ConfigurableCacheFactory) - Method in class com.tangosol.net.SingletonCacheFactoryBuilder
- 
Set the singleton cache factory (seeSingletonCacheFactoryBuilder.getSingletonFactory()).
- setSize(int) - Method in class com.tangosol.net.cache.OverflowMap
- 
Update the number of entries in the OverflowMap.
- setSizeAction(SegmentedConcurrentMap.SizeAction) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Specify the action for size().
- setSizeThreshold(int) - Method in class com.tangosol.net.cache.AbstractBundler
- 
Specify the bundle size threshold value.
- setSlidingExpiry(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Set the SlidingExpiry flag.
- setSocketOptions(SocketOptions) - Method in class com.tangosol.net.TcpDatagramSocket
- 
Specify SocketOptions to be used to configure each of the underlying TCP sockets.
- setSocketProviderFactory(SocketProviderFactory) - Method in class com.tangosol.net.SocketProviderFactory.DefaultDependencies
- 
Set the SocketProviderFactory referencing the Dependency object.
- setSocketProviderFactory(SocketProviderFactory) - Method in interface com.tangosol.net.SocketProviderFactory.Dependencies
- 
Set the SocketProviderFactory referencing the Dependency object.
- setSoftTimeout(long) - Method in class com.tangosol.net.GuardSupport.Context
- 
Set the next soft-timeout for this Guardable.
- setState(int) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Specify the state of the Status object.
- setState(int) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Specify the state of the Status object.
- setState(int) - Method in class com.tangosol.net.GuardSupport.Context
- 
Set the state of the GuardContext to the specified value.
- setState(int) - Method in class com.tangosol.net.partition.FailoverAccessPolicy
- 
Set the endangered state (one of the STATE_* constants).
- setState(int) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Set the state of this store.
- setStatementExecutor(StatementExecutor) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set theStatementExecutorto use to parse and execute statements.
- setStatementExecutor(StatementExecutor) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set theStatementExecutorto use to parse and execute statements.
- setStatements(List<String>) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the list of statements to execute before the QueryPlus session starts.
- setStatisticsEnabled(boolean) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- 
Set JCache statistics status
- setStatisticsEnabled(boolean) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setStatisticsEnabled(boolean) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Set if statistics gathering is enabled for a configuration.
- setStatisticsEnabled(boolean) - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- setStatisticsEnabled(boolean) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Sets m_stats
- setStatisticsEnabled(boolean) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCache
- setStatisticsEnabled(boolean) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- setStatus(int) - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Change the status of this Bundle.
- setStatus(int) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Determine the enumerated state of the Status object.
- setStatus(int) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Determine the enumerated state of the Status object.
- setStopOnError(boolean) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set the flag indicating whether CohQL should stop processing multiple statements if an error occurs (for example when processing a file), or whether errors should be logged and statement processing continue.
- setStorageAccessAuthorizer(Expression<String>) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Sets theExpressiondefining the name of theStorageAccessAuthorizer.
- setStorageAccessAuthorizer(Expression<String>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Sets theExpressiondefining the name of theStorageAccessAuthorizer.
- setStorageScheme(CachingScheme) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set theBackingMapSchemewhich builds the backing map for the internal caches used to implement this scheme.
- setStoreAllSupported(boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Set the flag that determines whether or not the wrapped store supports storeAll() operations.
- setStoreByValue(boolean) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setStoreByValue(boolean) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Set if a configured cache should use store-by-value or store-by-reference semantics.
- setStoreName(Expression<String>) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Set the BDB store (database table) name.
- setStoreSupported(boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Set the flag that determines whether or not the wrapped store supports store() operations.
- setStrength(int) - Method in class com.tangosol.util.CacheCollator
- 
Sets this Collator's strength property.
- setStrict(boolean) - Method in class com.tangosol.io.nio.BinaryMap
- 
Specify if the buffer should be initialized and if blocks should be cleared when not in use.
- setStrict(boolean) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Specify whether any access to data in missing partitions should be treated as an error.
- setStrictness(boolean) - Method in class com.tangosol.coherence.dsltools.precedence.OPScanner
- 
The given flag determines the strictness in that an unknown token throws an exception otherwise they are turned into an identifier.
- setString(String) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the String value.
- setString(String) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the String value.
- setStripTrailingZeros(boolean) - Method in class com.tangosol.util.aggregator.AbstractBigDecimalAggregator
- 
Allows you to set the property totrueto remove trailing zeros from the aggregation result.
- setSubscriberGroupBuilders(Collection<SubscriberGroupBuilder>) - Method in class com.tangosol.coherence.config.TopicMapping
- 
Set the durableSubscriberGroupBuilders for thisTopicMapping.
- setSubscriberGroupName(String) - Method in class com.tangosol.coherence.config.builder.SubscriberGroupBuilder
- 
Set the subscriber group name.
- setSubscriberTimeout(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the subscriber timeout value.
- setSynthetic(boolean) - Method in class com.tangosol.net.cache.LocalCache.KeyMask
- 
Specify whether or not the currently performed operation is internally initiated.
- setThread(Thread) - Method in class com.tangosol.util.Daemon.DaemonWorker
- setThreadContext(Guardian.GuardContext) - Static method in class com.tangosol.net.GuardSupport
- 
Associate the specified GuardContext with the current thread.
- setThreadContextClassLoader(ClassLoader) - Method in class com.tangosol.util.Daemon
- 
Configure the context ClassLoader for the daemon thread.
- setThreadThreshold(int) - Method in class com.tangosol.net.cache.AbstractBundler
- 
Specify the minimum number of threads that will trigger the bundler to switch from a pass through to a bundled mode.
- setThreadThreshold(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Set the thread threshold.
- setThreshold(int) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Set the size threshold for this rule.
- setThresholdFactor(float) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Set the percentage threshold for this rule.
- setTime(Time) - Method in class com.tangosol.run.xml.SimpleValue
- 
Set the Time value.
- setTime(Time) - Method in interface com.tangosol.run.xml.XmlValue
- 
Set the Time value.
- setTimeout(long) - Method in class com.tangosol.net.GuardSupport.Context
- 
Set the next timeout for this Guardable.
- setTimeout(Duration) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set theDurationto wait for aStatementto execute before timing out.
- setTimeout(Duration) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the timeout value for CohQL statement execution.
- SetTimeoutOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder.SetTimeoutOPToken
- 
Construct a SetTimeoutOPToken.
- SetTimeoutStatement(Duration) - Constructor for class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder.SetTimeoutStatement
- 
Construct a SetTimeoutStatement that will set the current timeout used by the QueryPlus session to the specified timeout.
- SetTimeoutStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
- 
A class that builds the QueryPlus "ALTER SESSION SET TIMEOUT millis" statement.
- SetTimeoutStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.SetTimeoutStatementBuilder
- SetTimeoutStatementBuilder.SetTimeoutOPToken - Class in com.tangosol.coherence.dslquery.queryplus
- 
A CohQL OPToken representing the QueryPlus "ALTER SESSION SET TIMEOUT" statement.
- SetTimeoutStatementBuilder.SetTimeoutStatement - Class in com.tangosol.coherence.dslquery.queryplus
- 
The implementation of the QueryPlus "ALTER SESSION SET TIMEOUT" statement.
- setTimeToLive(int) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- setTitle(String) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set the title that will be displayed as the results heading.
- setTitle(String) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set the title that will be displayed as the results heading.
- setTopAnchor(Object) - Method in class com.tangosol.util.filter.LimitFilter
- 
Set the top anchor object.
- setTraceEnabled(boolean) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set whether to display trace output when executing commands.
- setTraceEnabled(boolean) - Method in class com.tangosol.coherence.dslquery.QueryPlus.DefaultDependencies
- 
Set whether trace logging is enabled.
- setTraceLogging(boolean) - Method in interface com.oracle.coherence.concurrent.executor.management.ExecutorMBean
- 
Set the trace to true to enable executor trace logging; false to disable executor trace logging.
- setTransactionIsolation(int) - Method in interface com.tangosol.util.TransactionMap
- 
Attempt to change the transaction isolation level to the specified value.
- setTransactionTimeout(int) - Method in interface com.tangosol.util.TransactionMap
- 
Set transaction timeout value for this TransactionMap.
- setTransferThreshold(Long) - Method in class com.oracle.coherence.grpc.proxy.GrpcServiceDependencies.DefaultDependencies
- 
Set the transfer threshold.
- setTransformerBuilder(ParameterizedBuilder<ValueExtractor>) - Method in class com.tangosol.coherence.config.scheme.ContinuousQueryCacheScheme
- 
Set theParameterizedBuilderused to construct theValueExtractorto be used as a transformer by theContinuousQueryCache.
- setTransient(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Set the transient flag.
- setTransient(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.PagedTopicScheme
- 
Set the transient flag.
- setTranslateEvents(boolean) - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Specify whether or not an event source has to be translated by the wrapper.
- setTranslateEvents(boolean) - Method in class com.tangosol.util.WrapperObservableMap
- 
Specify whether or not an event source has to be translated by the wrapper.
- setTruncateAction(SegmentedConcurrentMap.TruncateAction) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Specify the action for truncate.
- setTrustManager(ManagerDependencies) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
Set the SSL trust manager
- setTTL(byte) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- setType(int) - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Set the event type.
- setType(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Set the Block type.
- setType(Expression<String>) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Set the type of storage to hold the backup data.
- setTypes(Class<K>, Class<V>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setTypes(Class<K>, Class<V>) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Sets the expected type of keys and values for aCoherenceBasedCache.
- setTypes(Class<K>, Class<V>) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheConfiguration
- 
Sets the expected type of keys and values for aPassThroughCacheconfigured with thisConfiguration.
- setUniformElementType(int) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Set the uniform element type for this collection.
- setUniformEncoded() - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Specifies that the buffer contains only a value, without a type identifier.
- setUnitCalculator(ConfigurableCacheMap.UnitCalculator) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- setUnitCalculator(ConfigurableCacheMap.UnitCalculator) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Set the UnitCalculator for the cache to use.
- setUnitCalculator(ConfigurableCacheMap.UnitCalculator) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Set the UnitCalculator for the cache to use.
- setUnitCalculator(ConfigurableCacheMap.UnitCalculator) - Method in class com.tangosol.net.cache.SerializationCache
- 
Set the UnitCalculator for the cache to use.
- setUnitCalculator(ConfigurableCacheMap.UnitCalculator) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Set the UnitCalculator for the cache to use.
- setUnitCalculatorBuilder(UnitCalculatorBuilder) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Set the UnitCalculatorBuilder.
- setUnitCalculatorBuilder(UnitCalculatorBuilder) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Set the UnitCalculatorBuilder.
- setUnitCalculatorBuilder(UnitCalculatorBuilder) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Set the UnitCalculatorBuilder.
- setUnitCalculatorBuilder(UnitCalculatorBuilder) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Set the UnitCalculatorBuilder.
- setUnitCalculatorType(int) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specify the unit calculator type for the cache.
- setUnitCalculatorType(Expression<String>) - Method in class com.tangosol.coherence.config.builder.UnitCalculatorBuilder
- 
Set theConfigurableCacheMap.UnitCalculatortype.
- setUnitFactor(int) - Method in class com.oracle.coherence.caffeine.CaffeineCache
- setUnitFactor(int) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap
- 
Determine the factor by which the Units, LowUnits and HighUnits properties are adjusted.
- setUnitFactor(int) - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Determine the factor by which the Units, LowUnits and HighUnits properties are adjusted.
- setUnitFactor(int) - Method in class com.tangosol.net.cache.SerializationCache
- 
Determine the factor by which the Units, LowUnits and HighUnits properties are adjusted.
- setUnitFactor(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache
- 
Determine the factor by which the Units, LowUnits and HighUnits properties are adjusted.
- setUnitFactor(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.AbstractJournalScheme
- 
Set the unit factor.
- setUnitFactor(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Set the unit factor.
- setUnitFactor(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Set the unit factor.
- setUnitFactor(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Set the unit factor.
- setUnits(int) - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
- 
Specify the number of cache units used by this Entry.
- setUnits(int) - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Specify the number of cache units used by this Entry.
- setUnits(int) - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Specify the number of cache units used by this Entry.
- setUnits(int) - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Specify the number of cache units used by this Entry.
- setUnits(int) - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- 
Specify the number of cache units used by this Entry.
- setUnits(long) - Method in class com.tangosol.util.SimpleMapIndex
- 
Set the size of this index in units (as defined by theUnitCalculator).
- setUnlockAction(SegmentedConcurrentMap.UnlockAction) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Specify the action for unlock().
- setURL(String) - Method in class com.tangosol.net.ssl.URLCertificateLoader
- setUsage(String) - Method in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
- setUserContext(Object) - Method in interface com.tangosol.net.Service
- 
Associate a user context object with this Service.
- setUserContext(Object) - Method in class com.tangosol.net.WrapperService
- 
Associate a user context object with this Service.
- setValidator(TransactionMap.Validator) - Method in interface com.tangosol.util.TransactionMap
- 
Add the specified Validator to the top of validation chain for this TransactionMap.
- setValue(Binary) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Update the Entry value in the block.
- setValue(Long) - Method in class com.tangosol.util.PrimitiveSparseArray.PrimitiveNode
- 
Set the value associated with the node.
- setValue(Object) - Method in class com.tangosol.coherence.rest.EntryResource
- 
Set the entry value.
- setValue(Object) - Method in class com.tangosol.io.pof.reflect.AbstractPofValue
- 
Update this PofValue.
- setValue(Object) - Method in class com.tangosol.io.pof.reflect.PofSparseArray.NilPofValue
- 
Update this PofValue.
- setValue(Object) - Method in interface com.tangosol.io.pof.reflect.PofValue
- 
Update this PofValue.
- setValue(Object) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Store the value corresponding to this entry.
- setValue(Object) - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Update the cached value.
- setValue(Object) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Store the value corresponding to this entry.
- setValue(Object) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.Entry
- setValue(Object) - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- setValue(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
- 
Replaces the value corresponding to this entry with the specified value.
- setValue(Object) - Method in class com.tangosol.util.SafeSortedMap.NullableEntry
- setValue(Object) - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Replaces the value corresponding to this entry with the specified value (writes through to the map).
- setValue(Object) - Method in class com.tangosol.util.SimpleLongArray.Iterator
- 
Stores a new value at the current value index, returning the value that was replaced.
- setValue(Object) - Method in class com.tangosol.util.ThreadLocalObject
- 
Set the value stored by this instance of ThreadLocalObject.
- setValue(Object, boolean) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Store the value corresponding to this entry.
- setValue(Object, boolean) - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- setValue(String) - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Set the AST Name for this token to be the given string
- setValue(String, String) - Method in class com.oracle.coherence.mp.config.CoherenceConfigSource
- 
Set the value of a configuration property.
- setValue(T) - Method in class com.tangosol.util.ConverterCollections.ConverterLongArray.ConverterLongArrayIterator
- setValue(TV) - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- setValue(V) - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Update the modifiedChangeRecord.Entryvalue.
- setValue(V) - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet.Entry
- 
Replaces the value corresponding to this entry with the specified value (optional operation).
- setValue(V) - Method in class com.tangosol.util.AbstractSafeLongArray.SafeIterator
- setValue(V) - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Stores a new value at the current value index, returning the value that was replaced.
- setValue(V) - Method in class com.tangosol.util.AbstractSparseArray.Node
- 
Set the value associated with the node.
- setValue(V) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry
- setValue(V) - Method in class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
Stores a new value at the current value index, returning the value that was replaced.
- setValue(V) - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Store the value corresponding to this entry.
- setValue(V) - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Replaces the value corresponding to this entry with the specified value (optional operation).
- setValue(V) - Method in interface com.tangosol.util.LongArray.Iterator
- 
Stores a new value at the current value index, returning the value that was replaced.
- setValue(V) - Method in class com.tangosol.util.ObservableHashMap.Entry
- 
Update the cached value.
- setValue(V) - Method in class com.tangosol.util.SafeHashMap.Entry
- 
Replaces the value corresponding to this entry with the specified value (optional operation).
- setValue(V) - Method in class com.tangosol.util.SimpleMapEntry
- 
Replaces the value corresponding to this entry with the specified value (optional operation).
- setValue(V) - Method in class com.tangosol.util.SparseArray.ObjectNode
- 
Set the value associated with the node.
- setValue(V) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- setValue(V) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- setValue(V, boolean) - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Update the modifiedChangeRecord.Entryvalue with a synthetic flag.
- setValue(V, boolean) - Method in interface com.tangosol.util.BinaryEntry
- 
Store the value corresponding to this entry.
- setValue(V, boolean) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Store the value corresponding to this entry.
- setValue(V, boolean) - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Store the value corresponding to this entry.
- setValue(V, boolean) - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Store the value corresponding to this entry.
- setValue(V, boolean) - Method in class com.tangosol.util.SimpleMapEntry
- 
Store the value corresponding to this entry.
- setValueClass(Class) - Method in class com.tangosol.coherence.rest.config.ResourceConfig
- 
Set the value class.
- setValueClassName(String) - Method in class com.tangosol.coherence.config.CacheMapping
- 
Sets the name of the value class forNamedCaches using thisCacheMapping.
- setValueClassName(String) - Method in class com.tangosol.coherence.config.TopicMapping
- 
Sets the name of the value class forNamedTopics using thisTopicMapping.
- setValueInternal(Object) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Replaces the value corresponding to this entry with the specified value (writes through to the map).
- setValueInternal(Object) - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Replaces the value corresponding to this entry with the specified value (writes through to the map).
- setValuesImmutable(boolean) - Method in interface com.tangosol.util.TransactionMap
- 
Specify whether or not the values stored in this TransactionMap are known to be immutable.
- setVersion(int) - Method in class com.tangosol.net.partition.VersionedOwnership
- 
Set the new ownership version.
- setVersionId(int) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Set the version identifier of the user type that is currently being written.
- setVersionId(int) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Set the version identifier of the user type that is currently being written.
- setVersionId(int) - Method in interface com.tangosol.io.pof.PofWriter
- 
Set the version identifier of the user type that is currently being written.
- SetView() - Constructor for class com.tangosol.util.ImmutableArrayList.SetView
- 
Create a SetView over this ImmutableArrayList.
- SetView() - Constructor for class com.tangosol.util.ImmutableMultiList.SetView
- 
Create a SetView over this ImmutableMultiList.
- setVirtualErase(boolean) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Specify whether BinaryStore erase commands will be done only in memory to the cached list of keys.
- setWaitingOnPending(boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Set the flag indicating whether any threads are waiting for the pending store operation to complete.
- setWaitMillis(long) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Specify the number of milliseconds to continue trying to obtain a lock in case when the locking is enforced.
- setWriteBatchFactor(double) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the write-batch factor, expressed as a percentage of the write-behind interval.
- setWriteBatchFactor(Expression<Double>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the write batch factor.
- setWriteBehindMillis(long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the number of milliseconds between write-behind writes to the CacheStore.
- setWriteBehindRemove(Expression<Boolean>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the write-behind-remove flag.
- setWriteBehindSeconds(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the number of seconds between write-behind writes to the CacheStore.
- setWriteDelay(Expression<Seconds>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the write behind delay.
- setWriteDelaySeconds(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the write behind delay seconds.
- setWriteMaxBatchSize(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the maximum size of a batch.
- setWriteMaxBatchSize(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the write max batch size.
- setWriter(PrintWriter) - Method in class com.tangosol.coherence.dslquery.ExecutionContext
- 
Set thePrintWriterthat can be used by commands to display output.
- setWriteRequeueThreshold(int) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Set the maximum size of the write-behind queue for which failed CacheStore write operations are requeued.
- setWriteRequeueThreshold(Expression<Integer>) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Set the size of the write-behind queue at which additional actions could be taken.
- setWriteThrough(boolean) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- setWriteThrough(boolean) - Method in interface com.tangosol.coherence.jcache.CoherenceBasedCompleteConfiguration
- 
Set if write-through caching should be used.
- setXml(XmlElement) - Method in interface com.tangosol.coherence.config.builder.ServiceBuilder
- 
Deprecated.
- setXml(XmlElement) - Method in class com.tangosol.coherence.config.scheme.AbstractServiceScheme
- 
Deprecated.
- setXmlConfig(ClassLoader, URL, XmlElement) - Method in class com.tangosol.net.ScopedCacheFactoryBuilder
- 
Register the providedXML configwith the ClassLoader and URL.
- setXmlInitParams(Expression<String>) - Method in class com.tangosol.coherence.config.builder.storemanager.BdbStoreManagerBuilder
- 
Set the BDB init params needed to construct a BerkeleyDBBinaryStoreManager.
- ShieldedDataOutputStream(DataOutput) - Constructor for class com.tangosol.util.ExternalizableHelper.ShieldedDataOutputStream
- ShieldedInputStream(InputStream) - Constructor for class com.tangosol.util.ExternalizableHelper.ShieldedInputStream
- ShieldedObjectOutputStream(ObjectOutput) - Constructor for class com.tangosol.util.ExternalizableHelper.ShieldedObjectOutputStream
- ShieldedOutputStream(OutputStream) - Constructor for class com.tangosol.util.ExternalizableHelper.ShieldedOutputStream
- SHORT_ARRAY_EMPTY - Static variable in class com.tangosol.io.pof.PofHelper
- 
An empty array of shorts.
- ShortAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.ShortAdapter
- 
Construct a SimpleAdapter.
- ShortArrayAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Construct a ShortArrayAdapter.
- SHORTLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
The numberic code for a short literal
- SHORTLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
The numberic code for a symbol literal
- shortValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Returns the current value of thisAsyncAtomicIntegeras ashortafter a narrowing primitive conversion.
- shortValue() - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Returns the value of the specified number as ashort.
- shortValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- shortValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- shortValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- shortValue() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- shortValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Returns the current value of thisAtomicIntegeras ashortafter a narrowing primitive conversion.
- shortValue() - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Returns the current value of thisAtomicLongas ashortafter a narrowing primitive conversion.
- shortValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- shortValue() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- shouldDispatch(MapListener) - Method in class com.tangosol.net.cache.CacheEvent
- shouldDispatch(MapListener) - Method in class com.tangosol.util.MapEvent
- 
Return true if the providedMapListenershould receive this event.
- shouldFire(EntryProcessorEvent) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EntryProcessorEventHandler
- shouldFire(E) - Method in class com.oracle.coherence.cdi.events.EventObserverSupport.EventHandler
- 
Returntrueif the event should fire.
- shouldRefresh(SSLSocketProvider.Dependencies, ManagerDependencies, ManagerDependencies) - Method in interface com.tangosol.net.ssl.RefreshPolicy
- 
Returntrueif the keys and certs should be refreshed.
- show(int, String) - Method in class com.tangosol.io.pof.LoggingPofHandler
- 
Log information related to the POF stream.
- showInstructions() - Static method in class com.tangosol.net.LoadBalancer
- 
Display the instructions for the command-line utility.
- showPlan() - Method in class com.tangosol.util.filter.LikeFilter
- 
Display the execution plan that the LikeFilter has selected.
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.queryplus.AbstractQueryPlusStatementBuilder.AbstractStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.BackupStatementBuilder.BackupStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.CreateCacheStatementBuilder.CreateCacheStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.CreateIndexStatementBuilder.CreateIndexStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.DeleteStatementBuilder.DeleteStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.DropCacheStatementBuilder.DropCacheStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.DropIndexStatementBuilder.DropIndexStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.InsertStatementBuilder.InsertStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ForceRecoveryStatementBuilder.ForceRecoveryStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListArchiverStatementBuilder.ListArchiverStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListServicesStatementBuilder.ListServicesStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ListSnapshotsStatementBuilder.ListSnapshotsStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ResumeServiceStatementBuilder.ResumeServiceStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder.SuspendServiceStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder.ValidateSnapshotStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder.QueryRecorderStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.RestoreStatementBuilder.RestoreStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.SelectStatementBuilder.SelectStatement
- showPlan(PrintWriter) - Method in interface com.tangosol.coherence.dslquery.Statement
- 
Output to the providedPrintWritera human readable trace of the actions that will be taken by this statement if or when executed.
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder.TruncateCacheStatement
- showPlan(PrintWriter) - Method in class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
- showUsage() - Static method in class com.tangosol.net.management.MBeanConnector
- 
Output usage instructions.
- shrink(int) - Method in class com.tangosol.io.nio.AbstractBufferManager
- 
Request that the buffer be shrunk based on the number of bytes currently required.
- shrink(int) - Method in interface com.tangosol.io.nio.ByteBufferManager
- 
Request that the buffer be shrunk based on the number of bytes currently required.
- shutdown() - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
- shutdown() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- shutdown() - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- shutdown() - Static method in class com.tangosol.net.CacheFactory
- 
Shutdown all clustered services.
- shutdown() - Static method in class com.tangosol.net.DefaultCacheServer
- 
Shutdown the cache server.
- shutdown() - Method in class com.tangosol.net.WrapperService
- 
Stop the controllable service.
- shutdown() - Method in interface com.tangosol.util.Controllable
- 
Stop the controllable service.
- shutdown(long) - Method in class com.tangosol.util.Daemon
- 
Request the daemon to stop and wait up to the specified number of milliseconds for it to exit.
- SHUTDOWN_FORCE - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Forcefully shutdown all running services before exiting the JVM.
- SHUTDOWN_GRACEFUL - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Gracefully shutdown all running services before exiting the JVM.
- SHUTDOWN_NONE - Static variable in interface com.tangosol.net.ClusterDependencies
- 
Perform no local shutdown logic before exiting the JVM.
- shutdownEventQueue() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Shut down running event queue.
- shutdownNow() - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Attempts to stop all actively executing tasks, halts the processing of waiting tasks, and returns a list of the tasks that were awaiting execution.
- shutdownServer() - Method in class com.tangosol.net.DefaultCacheServer
- 
Shutdown the DefaultCacheServer and Coherence cluster.
- signal() - Method in class com.oracle.coherence.common.base.ConcurrentNotifier
- signal() - Method in interface com.oracle.coherence.common.base.Notifier
- 
Notifies the waiting thread(s), waking them up if awaiting.
- signal() - Method in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- signal() - Method in class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
- signalInternal() - Method in class com.oracle.coherence.common.base.ConcurrentNotifier
- 
Full version of signal.
- signalInternal() - Method in class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
- 
Signal the notifier returning any thread which needs to be unparked.
- signalLocalThreads() - Method in class com.oracle.coherence.concurrent.RemoteCountDownLatch
- 
It is called by the delete event handler to release all waiting threads on the local member if the count reaches zero.
- SIGNATURE_ALGORITHM - Static variable in class com.tangosol.net.security.DefaultController
- 
Digital signature algorithm used by this implementation.
- SIGNATURE_ENGINE - Static variable in class com.tangosol.net.security.DefaultController
- 
The Signature object used by this implementation.
- SilentEmitter(Class) - Constructor for class com.tangosol.net.management.AnnotatedStandardEmitterMBean.SilentEmitter
- 
Construct a SilentEmitter.
- SimpleAdapter - Class in com.tangosol.run.xml
- 
A SimpleAdapter supports Java intrinsic types and a common set of Java classes: java.lang.Boolean java.lang.Byte java.lang.Character java.lang.Short java.lang.Integer java.lang.Long java.lang.Float java.lang.Double java.lang.String java.math.BigDecimal java.math.BigInteger java.sql.Date java.sql.Time java.sql.Timestamp java.util.Date
- SimpleAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter
- 
Construct a SimpleAdapter.
- SimpleAdapter.BigDecimalAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for BigDecimal.
- SimpleAdapter.BigIntegerAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for BigInteger.
- SimpleAdapter.BooleanAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for boolean.
- SimpleAdapter.ByteAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for byte.
- SimpleAdapter.CharAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for char.
- SimpleAdapter.DateAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for Date.
- SimpleAdapter.DoubleAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for double.
- SimpleAdapter.FloatAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for float.
- SimpleAdapter.IntAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for int.
- SimpleAdapter.LongAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for long.
- SimpleAdapter.OldDateAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for the Date class from the java/util package.
- SimpleAdapter.ShortAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for short.
- SimpleAdapter.StringAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for String.
- SimpleAdapter.SystemTimeAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for Java long and java.lang.Long values that is string-formatted as a date/time, assuming that the long value is actualy a system time.
- SimpleAdapter.TimeAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for Time.
- SimpleAdapter.TimestampAdapter - Class in com.tangosol.run.xml
- 
A simple property adapter for Timestamp.
- SimpleAssignmentStrategy - Class in com.tangosol.net.partition
- 
SimpleAssignmentStrategy is a PartitionAssignmentStrategy that attempts to balance the partition distribution based on the number of primary and backup partitions owned.
- SimpleAssignmentStrategy() - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Default constructor.
- SimpleAssignmentStrategy.AnalysisContext - Class in com.tangosol.net.partition
- 
AnalysisContext holds the working view of the partition ownership that is used throughout the analysis and is used to reflect changes made during this analysis.
- SimpleAssignmentStrategy.AnalysisContext.LoadComparator - Class in com.tangosol.net.partition
- 
LoadComparator is a Comparator that can be used to compare two Member objects based on their partition load (as defined by the LoadCalculator).
- SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter - Class in com.tangosol.net.partition
- 
NotOwnedFilter is a Filter implementation used to evaluate Member objects, and selects members who are not represented in the reference ownership object.
- SimpleAssignmentStrategy.AnalysisContext.SafetyFilter - Class in com.tangosol.net.partition
- 
SafetyFilter is a Filter implementation used to evaluate Member objects, and selects members that are "strong" with respect to the reference ownership, as defined by the backup-strength.
- SimpleAssignmentStrategy.AnalysisContext.StrengthComparator - Class in com.tangosol.net.partition
- 
StrengthComparator is an Comparator that can be used to compare two Member objects based on their "distance" from a given set of members (as represented by an Ownership object).
- SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter - Class in com.tangosol.net.partition
- 
UnderloadedFilter is a Filter implementation that is used to evaluate Member objects, and selects those whose partition load is "underloaded" in comparison to the fair-share load.
- SimpleAssignmentStrategy.BackupStrength - Class in com.tangosol.net.partition
- 
BackupStrength represents a level of "strength" or "resiliency" between the primary and backup owners of a partition.
- SimpleAssignmentStrategy.JMXPartitionStats - Class in com.tangosol.net.partition
- 
A class that calculate MBean attribute values from last sampled PartitionStats
- SimpleAssignmentStrategy.LoadCalculator - Interface in com.tangosol.net.partition
- 
LoadCalculator is used to calculate the scalar load (expressed as an integer) of a partition (or set of partitions).
- SimpleAssignmentStrategy.SimpleLoadCalculator - Class in com.tangosol.net.partition
- 
SimpleLoadCalculator defines a "count-based" load (e.g. the load of each partition is defined to be 1).
- SimpleAttribute - Class in com.tangosol.run.xml
- 
ASimpleAttributeprovides a basic implementation of anXmlAttribute.
- SimpleAttribute(XmlElement, String, XmlValue) - Constructor for class com.tangosol.run.xml.SimpleAttribute
- 
Standard Constructor.
- SimpleAttributeProcessor<T> - Class in com.tangosol.config.xml
- 
ASimpleAttributeProcessoris a simpleAttributeProcessorimplementation that will construct, initialize (via constructor injection) and return a specific type of object based on information in anXmlAttribute.
- SimpleAttributeProcessor(Class<T>) - Constructor for class com.tangosol.config.xml.SimpleAttributeProcessor
- 
Construct aSimpleAttributeProcessor.
- SimpleBuilderProcessor<T> - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat returns a simpleParameterizedBuilder.
- SimpleBuilderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SimpleBuilderProcessor
- 
Constructs aSimpleBuilderProcessor.
- SimpleCacheStatistics - Class in com.tangosol.net.cache
- 
Implementation of the CacheStatistics interface intended for use by a cache to maintain its statistics.
- SimpleCacheStatistics() - Constructor for class com.tangosol.net.cache.SimpleCacheStatistics
- 
Default constructor.
- SimpleDaemonPoolExecutor - Class in com.oracle.coherence.grpc
- 
AnExecutorthat uses aDaemonPoolto execute tasks.
- SimpleDaemonPoolExecutor(DaemonPool) - Constructor for class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- 
Create aSimpleDaemonPoolExecutor.
- SimpleDaemonPoolExecutor(DefaultDaemonPoolDependencies) - Constructor for class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- SimpleDaemonPoolExecutor(String) - Constructor for class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- SimpleDaemonPoolExecutor(String, int, int, int) - Constructor for class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- SimpleDocument - Class in com.tangosol.run.xml
- 
A simple implementation of the XmlElement interface.
- SimpleDocument() - Constructor for class com.tangosol.run.xml.SimpleDocument
- 
Construct an empty SimpleDocument.
- SimpleDocument(String) - Constructor for class com.tangosol.run.xml.SimpleDocument
- 
Construct a SimpleDocument.
- SimpleDocument(String, String, String) - Constructor for class com.tangosol.run.xml.SimpleDocument
- 
Construct a SimpleDocument.
- SimpleElement - Class in com.tangosol.run.xml
- 
A simple implementation of the XmlElement interface.
- SimpleElement() - Constructor for class com.tangosol.run.xml.SimpleElement
- 
Construct an empty SimpleElement.
- SimpleElement(String) - Constructor for class com.tangosol.run.xml.SimpleElement
- 
Construct a SimpleElement.
- SimpleElement(String, Object) - Constructor for class com.tangosol.run.xml.SimpleElement
- 
Construct a SimpleElement.
- SimpleElement.AttributeMap - Class in com.tangosol.run.xml
- 
A Map implementation using a list that can be a read-only map that supports only Strings for keys and XmlValue for values.
- SimpleElement.AttributeMap.Entry - Class in com.tangosol.run.xml
- 
An implementation of Entry that supports keeping them in a list.
- SimpleElement.AttributeMap.EntrySet - Class in com.tangosol.run.xml
- 
A Set implementation to hold Entry objects.
- SimpleElement.AttributeMap.EntrySet.EntrySetIterator - Class in com.tangosol.run.xml
- 
An Iterator over the Entry objects in the EntrySet.
- SimpleElement.ElementIterator - Class in com.tangosol.run.xml
- 
Provides an Iterator implementation that exposes only those Elements from the Element list that match a certain name.
- SimpleElement.ElementList - Class in com.tangosol.run.xml
- 
An implementation of List that only supports XmlElements as the content of the List.
- SimpleElementProcessor<T> - Class in com.tangosol.config.xml
- 
ASimpleElementProcessoris anElementProcessorimplementation that will construct, initialize (via constructor injection) and return a specific type of object based on information in anXmlElement.
- SimpleElementProcessor(Class<T>) - Constructor for class com.tangosol.config.xml.SimpleElementProcessor
- 
Construct aSimpleElementProcessor.
- SimpleEntry(Map<K, V>, K, boolean) - Constructor for class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Construct a SimpleEntry for a given map and a key.
- SimpleEntry(Map<K, V>, K, V, boolean) - Constructor for class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Construct a SimpleEntry for a given key and value.
- SimpleEntry(K, V) - Constructor for class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Construct a SimpleEntry for a given key and value.
- SimpleEnumerator<E> - Class in com.tangosol.util
- 
Provide a generic implementation of an array enumerator.
- SimpleEnumerator(E[]) - Constructor for class com.tangosol.util.SimpleEnumerator
- 
Construct the simple enumerator based on an array of objects.
- SimpleEnumerator(E[], int, int) - Constructor for class com.tangosol.util.SimpleEnumerator
- 
Construct the simple enumerator based on an array of objects.
- SimpleEnumerator(E[], int, int, boolean, boolean) - Constructor for class com.tangosol.util.SimpleEnumerator
- 
Construct the simple enumerator based on an array of objects, making a copy of the array if specified.
- SimpleEnumerator(Collection<E>) - Constructor for class com.tangosol.util.SimpleEnumerator
- 
Construct a simple enumerator based on a collection.
- SimpleEnumerator(Enumeration<E>) - Constructor for class com.tangosol.util.SimpleEnumerator
- 
Construct a simple enumerator based on another Enumeration.
- SimpleEnumerator(Iterator<E>) - Constructor for class com.tangosol.util.SimpleEnumerator
- 
Construct a simple enumerator based on another Iterator.
- SimpleEvolvable - Class in com.tangosol.io
- 
Simple implementation ofEvolvableinterface.
- SimpleEvolvable(int) - Constructor for class com.tangosol.io.SimpleEvolvable
- 
Create SimpleEvolvable instance.
- SimpleHandler - Class in com.tangosol.net.security
- 
The SimpleHandler class is a CallbackHandler implementation based on a specified user name and password.
- SimpleHandler(String, char[]) - Constructor for class com.tangosol.net.security.SimpleHandler
- 
Construct a SimpleHandler.
- SimpleHandler(String, char[], boolean) - Constructor for class com.tangosol.net.security.SimpleHandler
- 
Construct a SimpleHandler.
- SimpleHandler(String, String, boolean) - Constructor for class com.tangosol.net.security.SimpleHandler
- 
Construct a SimpleHandler.
- SimpleHolder<V> - Class in com.oracle.coherence.common.base
- 
SimpleHolder is a basic implementation of the Holder interface.
- SimpleHolder<V> - Class in com.tangosol.util
- 
General purpose container that can be used as an accumulator for any reference type.
- SimpleHolder() - Constructor for class com.oracle.coherence.common.base.SimpleHolder
- 
Construct a SimpleHolder with no value.
- SimpleHolder() - Constructor for class com.tangosol.util.SimpleHolder
- 
Deserialization constructor.
- SimpleHolder(V) - Constructor for class com.oracle.coherence.common.base.SimpleHolder
- 
Construct a SimpleHolder with an initial value.
- SimpleHolder(V) - Constructor for class com.tangosol.util.SimpleHolder
- 
Construct SimpleHolder instance.
- SimpleListener() - Constructor for class com.tangosol.net.cache.CachingMap.SimpleListener
- SimpleLoadCalculator() - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.SimpleLoadCalculator
- SimpleLongArray - Class in com.tangosol.util
- 
An implementation of LongArray that stores values in an array, thus is actually an "IntArray".
- SimpleLongArray() - Constructor for class com.tangosol.util.SimpleLongArray
- 
Construct an empty SimpleLongArray.
- SimpleLongArray(Object) - Constructor for class com.tangosol.util.SimpleLongArray
- 
Create aSimpleLongArraywith a single entry at index zero.
- SimpleLongArray.Iterator - Class in com.tangosol.util
- 
An Iterator that adds a "current element" concept, similar to theMap.Entryinterface.
- SimpleMapEntry<K,V> - Class in com.tangosol.util
- 
A map entry (key-value pair).
- SimpleMapEntry() - Constructor for class com.tangosol.util.SimpleMapEntry
- 
Default constructor.
- SimpleMapEntry(Map.Entry<K, V>) - Constructor for class com.tangosol.util.SimpleMapEntry
- 
Copy constructor.
- SimpleMapEntry(K) - Constructor for class com.tangosol.util.SimpleMapEntry
- 
Construct a SimpleMapEntry with just a key.
- SimpleMapEntry(K, V) - Constructor for class com.tangosol.util.SimpleMapEntry
- 
Construct a SimpleMapEntry with a key and a value.
- SimpleMapEntry(K, V, V) - Constructor for class com.tangosol.util.SimpleMapEntry
- 
Construct a SimpleMapEntry with a key, value and original value.
- SimpleMapEvent<K,V> - Class in com.tangosol.coherence.rest.events
- 
Simple representation ofMapEventthat can be marshalled to JSON.
- SimpleMapEvent() - Constructor for class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Deserialization constructor.
- SimpleMapEvent(MapEvent<? extends K, ? extends V>) - Constructor for class com.tangosol.coherence.rest.events.SimpleMapEvent
- 
Construct SimpleMapEvent instance.
- SimpleMapIndex - Class in com.tangosol.util
- 
SimpleMapIndex is a MapIndex implementation used to correlate property values extracted from resource map entries with corresponding keys using what is commonly known as an Inverted Index algorithm.
- SimpleMapIndex(ValueExtractor, boolean, Comparator, boolean, BackingMapContext) - Constructor for class com.tangosol.util.SimpleMapIndex
- 
Construct an index for the given map.
- SimpleMapIndex(ValueExtractor, boolean, Comparator, BackingMapContext) - Constructor for class com.tangosol.util.SimpleMapIndex
- 
Construct an index for the given map.
- SimpleMapIndex.IndexCalculator - Class in com.tangosol.util
- 
A statefulcalculatorused to calculate the cost of a homogeneous index (holding all values of a single type).
- SimpleMapIndex.IndexCalculator.CalculatorState - Enum in com.tangosol.util
- 
The CalculatorState identifies the method used by the calculator to calculate the cost of a key or a value type.
- SimpleMemoryCalculator - 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.
- SimpleMemoryCalculator() - Constructor for class com.tangosol.net.cache.SimpleMemoryCalculator
- SimpleModel<S extends Enum<S>> - Class in com.tangosol.util.fsm
- SimpleModel(Class<S>) - Constructor for class com.tangosol.util.fsm.SimpleModel
- 
Constructs aSimpleModelgiven an Enum of the possible states of aFiniteStateMachine.
- SimpleOverflowMap - Class in com.tangosol.net.cache
- 
A non-observable Map implementation that wraps two maps - a front map (assumed to be fast but limited in its maximum size) and a back map (assumed to be slower but much less limited in its maximum size).
- SimpleOverflowMap(ObservableMap, Map) - Constructor for class com.tangosol.net.cache.SimpleOverflowMap
- 
Construct a SimpleOverflowMap using two specified maps: FrontMap (aka "cache" or "shallow") and BackMap (aka "file" or "deep")
- SimpleOverflowMap(ObservableMap, Map, Map) - Constructor for class com.tangosol.net.cache.SimpleOverflowMap
- 
Construct a SimpleOverflowMap using three specified maps: Front Map (aka "cache" or "shallow") and Back Map (aka "file" or "deep") Miss Cache
- SimpleOverflowMap.FrontFilterConverter - Class in com.tangosol.net.cache
- 
A combination Filter and Converter used to iterate through the status map in order to iterate through the front keys.
- SimpleOverflowMap.FrontMapListener - Class in com.tangosol.net.cache
- 
A listener for the front map that moves evictions to the back map.
- SimpleOverflowMap.HashcodeComparator - Class in com.tangosol.net.cache
- 
A stateless Comparator that comparesObject.hashCode()values.
- SimpleOverflowMap.KeyIterator - Class in com.tangosol.net.cache
- 
An Iterator implementation that attempts to provide the most resilient and most up-to-date view of the keys in the OverflowMap.
- SimpleOverflowMap.Status - Class in com.tangosol.net.cache
- 
The Status object is used to manage concurrency at the key level for the key-level operations against the Map, to track all the items in the front Map, to manage the state transition for operations occurring against the Map, and to coordinate events across multiple threads.
- SimpleParameterizedBuilderRegistry - Class in com.tangosol.coherence.config.builder
- 
A basic implementation of aParameterizedBuilderRegistry.
- SimpleParameterizedBuilderRegistry() - Constructor for class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- 
Constructs aSimpleParameterizedBuilderRegistry.
- SimpleParameterizedBuilderRegistry(ParameterizedBuilderRegistry) - Constructor for class com.tangosol.coherence.config.builder.SimpleParameterizedBuilderRegistry
- 
Constructs aSimpleParameterizedBuilderRegistrygiven another one.
- SimpleParameterizedBuilderRegistry.BuilderRegistration - Class in com.tangosol.coherence.config.builder
- 
An internalParameterizedBuilderRegistry.Registrationimplementation.
- SimpleParameterizedBuilderRegistry.RegistryKey - Class in com.tangosol.coherence.config.builder
- 
Key class for a registered resource.
- SimpleParameterizedBuilderRegistry.RegistryValue - Class in com.tangosol.coherence.config.builder
- 
A holder for aParameterizedBuilder.
- SimpleParameterList - Class in com.tangosol.coherence.config
- 
ASimpleParameterListis a simple implementation ofParameterList.
- SimpleParameterList() - Constructor for class com.tangosol.coherence.config.SimpleParameterList
- 
Constructs an emptySimpleParameterList.
- SimpleParameterList(ParameterList) - Constructor for class com.tangosol.coherence.config.SimpleParameterList
- 
Constructs aSimpleParameterListbased on aParameterList.
- SimpleParameterList(Object...) - Constructor for class com.tangosol.coherence.config.SimpleParameterList
- 
Constructs aSimpleParameterListbased on the specified array of objects, each object becoming it's ownParameterin the resulting list.
- SimpleParser - Class in com.tangosol.run.xml
- 
This class uses the XmlTokenizer to produce an XmlDocument from XML text.
- SimpleParser() - Constructor for class com.tangosol.run.xml.SimpleParser
- 
Construct an XML SimpleParser.
- SimpleParser(boolean) - Constructor for class com.tangosol.run.xml.SimpleParser
- 
Construct an XML SimpleParser.
- SimplePartitionKey - Class in com.tangosol.net.partition
- 
SimplePartitionKey is a trivialPartitionAwareKeyimplementation.
- SimplePartitionKey() - Constructor for class com.tangosol.net.partition.SimplePartitionKey
- 
Default constructor is defined for serialization purposes only.
- SimplePartitionKey(int) - Constructor for class com.tangosol.net.partition.SimplePartitionKey
- 
Construct a SimplePartitionKey representing the specified partition.
- SimplePofContext - Class in com.tangosol.io.pof
- 
BasicPofContextimplementation.
- SimplePofContext() - Constructor for class com.tangosol.io.pof.SimplePofContext
- 
Create a new SimplePofContext.
- SimplePofPath - Class in com.tangosol.io.pof.reflect
- 
A staticPofNavigatorimplementation which uses an array of integer indices to navigate the PofValue hierarchy.
- SimplePofPath() - Constructor for class com.tangosol.io.pof.reflect.SimplePofPath
- 
Default constructor (necessary for the PortableObject interface).
- SimplePofPath(int) - Constructor for class com.tangosol.io.pof.reflect.SimplePofPath
- 
Construct a SimplePofPath using a single index as a path.
- SimplePofPath(int[]) - Constructor for class com.tangosol.io.pof.reflect.SimplePofPath
- 
Construct a SimplePofPath using an array of indices as a path.
- SimplePofValue - Class in com.tangosol.io.pof.reflect
- 
SimplePofValue represents POF values which do not contain children (e.g.
- SimplePofValue(PofValue, ReadBuffer, PofContext, int, int) - Constructor for class com.tangosol.io.pof.reflect.SimplePofValue
- 
Construct a SimplePofValue instance wrapping the supplied buffer.
- SimpleQueryRecord - Class in com.tangosol.util
- 
Simple QueryRecord implementation.
- SimpleQueryRecord() - Constructor for class com.tangosol.util.SimpleQueryRecord
- 
Default constructor (necessary for the ExternalizableLite interface).
- SimpleQueryRecord(QueryRecorder.RecordType, Collection) - Constructor for class com.tangosol.util.SimpleQueryRecord
- 
Construct a SimpleQueryRecord from the given collection of partial results.
- SimpleQueryRecord.PartialResult - Class in com.tangosol.util
- 
Simple QueryRecord.PartialResult implementation.
- SimpleQueryRecord.PartialResult.AbstractRecordableStep - Class in com.tangosol.util
- 
Simple abstract RecordableStep implementation.
- SimpleQueryRecord.PartialResult.ExplainStep - Class in com.tangosol.util
- 
Simple QueryRecord.PartialResult.ExplainStep implementation.
- SimpleQueryRecord.PartialResult.IndexLookupRecord - Class in com.tangosol.util
- 
Simple QueryRecord.PartialResult.IndexLookupRecord implementation.
- SimpleQueryRecord.PartialResult.Step - Class in com.tangosol.util
- 
Simple QueryRecord.PartialResult.Step implementation.
- SimpleQueryRecord.PartialResult.TraceStep - Class in com.tangosol.util
- 
Simple QueryRecord.PartialResult.TraceStep implementation.
- SimpleQueryRecordReporter - Class in com.tangosol.util
- 
Simple query record reporter used to obtain a string representation ofQueryRecordobject.
- SimpleQueryRecordReporter() - Constructor for class com.tangosol.util.SimpleQueryRecordReporter
- SimpleResourceRegistry - Class in com.tangosol.util
- 
ASimpleResourceRegistryis a basic implementation of aResourceRegistry.
- SimpleResourceRegistry() - Constructor for class com.tangosol.util.SimpleResourceRegistry
- 
Construct aSimpleResourceRegistry.
- SimpleResourceRegistry.RegistryKey - Class in com.tangosol.util
- 
Key class for a registered resource.
- SimpleResourceRegistry.RegistryValue - Class in com.tangosol.util
- 
A holder for resource objects and their (optional) respectiveResourceLifecycleObservers.
- SimpleResourceResolver - Class in com.tangosol.util
- 
A simple implementation of aResourceResolver.
- SimpleResourceResolver() - Constructor for class com.tangosol.util.SimpleResourceResolver
- SimpleSerializationMap - Class in com.tangosol.net.cache
- 
Map implementation that stores and accesses its contents through an underlying BinaryStore.
- SimpleSerializationMap(BinaryStore) - Constructor for class com.tangosol.net.cache.SimpleSerializationMap
- 
Construct a SimpleSerializationMap on top of a BinaryStore.
- SimpleSerializationMap(BinaryStore, boolean) - Constructor for class com.tangosol.net.cache.SimpleSerializationMap
- 
Construct a SimpleSerializationMap on top of a BinaryStore, optionally storing only Binary keys and values.
- SimpleSerializationMap(BinaryStore, ClassLoader) - Constructor for class com.tangosol.net.cache.SimpleSerializationMap
- 
Construct a SimpleSerializationMap on top of a BinaryStore, using the passed ClassLoader for deserialization.
- SimpleServiceLoadBalancer<S extends Service,T extends ServiceLoad> - Class in com.tangosol.net
- 
A simple ServiceLoadBalancer implementation.
- SimpleServiceLoadBalancer() - Constructor for class com.tangosol.net.SimpleServiceLoadBalancer
- 
Default constructor.
- SimpleServiceLoadBalancer(Comparator<T>) - Constructor for class com.tangosol.net.SimpleServiceLoadBalancer
- 
Create a new SimpleServiceLoadBalancer that will order ServiceLoad objects using the specified Comparator.
- SimpleServiceMonitor - Class in com.tangosol.net
- 
TheSimpleServiceMonitorstarts and monitors services that are registered for monitoring.
- SimpleServiceMonitor() - Constructor for class com.tangosol.net.SimpleServiceMonitor
- 
Construct a SimpleServiceMonitor with the default interval to check that the registered services are running (SimpleServiceMonitor.DEFAULT_WAIT_MILLIS).
- SimpleServiceMonitor(long) - Constructor for class com.tangosol.net.SimpleServiceMonitor
- 
Construct a SimpleServiceMonitor with the provided interval to check that the registered services are running.
- SimpleStack - Class in com.tangosol.util
- 
A LIFO (last in, first out) unbounded stack of objects.
- SimpleStack() - Constructor for class com.tangosol.util.SimpleStack
- 
Create a new empty SimpleStack.
- SimpleStack(int) - Constructor for class com.tangosol.util.SimpleStack
- 
Create a new empty SimpleStack with the specified initial capacity.
- SimpleStrategyMBean - Interface in com.tangosol.net.partition
- 
Standard MBean interface that exposes management attributes and operations for aSimpleAssignmentStrategyused by aPartitionedService.
- SimpleStrategyMBean.HAStatus - Enum in com.tangosol.net.partition
- 
HAStatus represents the possible values to represent the High Availability Status of the associated PartitionedService.
- SimpleStreamer<T> - Class in com.tangosol.util
- 
Simple implementation of aStreamer.
- SimpleStreamer(Iterable<T>) - Constructor for class com.tangosol.util.SimpleStreamer
- 
Construct Streamer based onIterable.
- SimpleStreamer(Collection<T>) - Constructor for class com.tangosol.util.SimpleStreamer
- 
Construct Streamer based onCollection.
- SimpleStreamer(Iterator<T>) - Constructor for class com.tangosol.util.SimpleStreamer
- 
Construct Streamer based onIterator.
- SimpleStreamer(Iterator<T>, long, int) - Constructor for class com.tangosol.util.SimpleStreamer
- 
Construct Streamer instance.
- SimpleStreamer(Stream<T>) - Constructor for class com.tangosol.util.SimpleStreamer
- 
Construct Streamer based onStream.
- SimpleValidator - Class in com.tangosol.run.jca
- 
Simple generic Validator implementation that uses hashCode values for the enlisted resources to resolve optimistic transaction conflicts.
- SimpleValidator() - Constructor for class com.tangosol.run.jca.SimpleValidator
- 
Default constructor.
- SimpleValue - Class in com.tangosol.run.xml
- 
A simple implementation of the XmlValue interface.
- SimpleValue() - Constructor for class com.tangosol.run.xml.SimpleValue
- 
Construct an empty SimpleValue.
- SimpleValue(Object) - Constructor for class com.tangosol.run.xml.SimpleValue
- 
Construct a SimpleValue.
- SimpleValue(Object, boolean) - Constructor for class com.tangosol.run.xml.SimpleValue
- 
Construct a SimpleValue.
- SimpleValue(Object, boolean, boolean) - Constructor for class com.tangosol.run.xml.SimpleValue
- 
Construct a SimpleValue.
- SimpleXmlBeanClassCache() - Constructor for class com.tangosol.util.ExternalizableHelper.SimpleXmlBeanClassCache
- simplifyFilters(Filter<?>[]) - Method in class com.tangosol.util.filter.AllFilter
- simplifyFilters(Filter<?>[]) - Method in class com.tangosol.util.filter.AnyFilter
- 
Simplify internal filter array by merging and replacing filters if possible to reduce the overall number and nesting of the filters.
- simplifyFilters(Filter<?>[]) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Simplify internal filter array by merging and replacing filters if possible to reduce the overall number and nesting of the filters.
- singleEntryAsynchronous(InvocableMap.EntryProcessor<K, V, R>) - Static method in class com.tangosol.util.Processors
- 
Construct a single entry asynchronous processor for a given processor.
- singleEntryAsynchronous(InvocableMap.EntryProcessor<K, V, R>, int) - Static method in class com.tangosol.util.Processors
- 
Construct a single entry asynchronous for a given processor with unit-of-order id.
- SingleEntryAsynchronousProcessor<K,V,R> - Class in com.tangosol.util.processor
- 
AnEntryProcessorwrapper class that allows for an asynchronous invocation of the underlying processor against a single cache entry.
- SingleEntryAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>) - Constructor for class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- 
Construct a SingleEntryAsynchronousProcessor for a given processor.
- SingleEntryAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int) - Constructor for class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- 
Construct a SingleEntryAsynchronousProcessor for a given processor.
- SingleEntryAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int, Executor) - Constructor for class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- 
Construct a SingleEntryAsynchronousProcessor for a given processor.
- SingleEntryAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, Executor) - Constructor for class com.tangosol.util.processor.SingleEntryAsynchronousProcessor
- 
Construct a SingleEntryAsynchronousProcessor for a given processor.
- SingleProvider(InetSocketAddress) - Constructor for class com.tangosol.net.CompositeAddressProvider.SingleProvider
- 
Constructor
- singleton(V) - Static method in interface com.tangosol.util.LongArray
- SingletonCacheFactoryBuilder - Class in com.tangosol.net
- 
Implementation ofCacheFactoryBuilderthat maintains a singleConfigurableCacheFactoryinstance regardless of the requesting ClassLoader if a URI is not provided.
- SingletonCacheFactoryBuilder() - Constructor for class com.tangosol.net.SingletonCacheFactoryBuilder
- SingleWaiterCooperativeNotifier - Class in com.oracle.coherence.common.base
- 
SingleWaiterCooperativeNotifier is an extension of the SingleWaiterMultiNotifier which attempts to offload potentially expensive "notification" work from signaling threads onto the waiting threads.
- SingleWaiterCooperativeNotifier() - Constructor for class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- SingleWaiterMultiNotifier - Class in com.oracle.coherence.common.base
- 
A Condition-like object, used by a single thread to block for a notification, and optimized for many concurrent notifications by other threads.
- SingleWaiterMultiNotifier() - Constructor for class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
- SITE_SAFE - com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
The cluster nodes running at a site can be stopped simultaneously without any data loss.
- SITE_SAFE - Static variable in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- 
Site-safety (members are on different sites).
- SITES - Static variable in class com.tangosol.net.ConfigurableQuorumPolicy.ClusterQuorumPolicy
- 
The role prefix to use for the "timeout-site-quorum".
- SITTING - Static variable in class com.tangosol.util.AbstractSparseArray.Crawler
- Sizable - Interface in com.tangosol.util
- 
The Sizable interface is implemented by types that are capable of calculating the memory footprint of an instance.
- size() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- size() - Method in class com.tangosol.coherence.config.CacheMappingRegistry
- 
Deprecated.Determines the number ofCacheMappings in theCacheMappingRegistry.
- size() - Method in interface com.tangosol.coherence.config.ParameterList
- 
Obtains the number ofParameters in theParameterList.
- size() - Method in class com.tangosol.coherence.config.ResolvableParameterList
- 
Obtains the number ofParameters in theParameterList.
- size() - Method in interface com.tangosol.coherence.config.ResourceMappingRegistry
- 
Determines the number ofResourceMappings in thisResourceMappingRegistry.
- size() - Method in class com.tangosol.coherence.config.SchemeMappingRegistry
- size() - Method in class com.tangosol.coherence.config.ServiceSchemeRegistry
- 
Determines the number ofSchemes registered with theServiceSchemeRegistry.
- size() - Method in class com.tangosol.coherence.config.SimpleParameterList
- 
Obtains the number ofParameters in theParameterList.
- size() - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
- 
Return the size of the collection of BaseTokens making up the receiver.
- size() - Method in interface com.tangosol.io.BinaryStore.SizeAware
- 
Determine the number of keys in the BinaryStore.
- size() - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.io.nio.BinaryMap.KeySet
- 
Determine the number of keys in the Set.
- size() - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.io.nio.BinaryMap.ValuesCollection
- 
Determine the number of values in the Collection.
- size() - Method in class com.tangosol.io.nio.BinaryMapStore
- 
Determine the number of keys in the BinaryStore.
- size() - Method in interface com.tangosol.net.AsyncNamedMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.cache.CachingMap
- 
Return the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.cache.OldCache.KeySet
- 
Deprecated.Determine the number of keys in the Set.
- size() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.cache.OldCache.ValuesCollection
- 
Deprecated.Determine the number of values in the Collection.
- size() - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- size() - Method in class com.tangosol.net.cache.OverflowMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- 
Determine the number of keys in the Set.
- size() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
Return the length of the queue.
- size() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ValuesCollection
- 
Determine the number of values in the Collection.
- size() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- size() - Method in class com.tangosol.net.cache.SerializationCache
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.CompositeAddressProvider
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.net.LoadBalancer.Queue
- 
Determine the number of items in the queue.
- size() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.MaskedPartitionMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap.EntrySet
- size() - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- size() - Method in class com.tangosol.util.AbstractKeyBasedMap.EntrySet
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.util.AbstractKeyBasedMap.KeySet
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.util.AbstractKeySetBasedMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.ChainedCollection
- size() - Method in class com.tangosol.util.ChainedMap.EntrySet
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.util.ChainedMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.ChainedSet
- size() - Method in class com.tangosol.util.CircularArrayList
- size() - Method in interface com.tangosol.util.ConcurrentMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- size() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- size() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- size() - Method in class com.tangosol.util.CopyOnWriteMap.EntrySet
- size() - Method in class com.tangosol.util.CopyOnWriteMap.KeySet
- size() - Method in class com.tangosol.util.CopyOnWriteMap
- size() - Method in class com.tangosol.util.DeltaSet
- 
Returns the number of elements in this Collection.
- size() - Method in class com.tangosol.util.Dequeue
- 
Determine the current number of objects in this dequeue.
- size() - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns the number of elements in this List.
- size() - Method in class com.tangosol.util.ImmutableMultiList
- 
Returns the number of elements in this List.
- size() - Method in class com.tangosol.util.InflatableCollection
- size() - Method in class com.tangosol.util.KeyValueArrayMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.LiteSet
- 
Returns the number of elements in this Set (its cardinality).
- size() - Method in class com.tangosol.util.MapSet
- 
Returns the number of elements in this Set.
- size() - Method in class com.tangosol.util.NullImplementation.NullMap
- size() - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- size() - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Returns the number of elements in this Collection.
- size() - Method in class com.tangosol.util.OpenHashMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.OpenHashSet
- size() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Returns the number of elements in this Collection.
- size() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Returns the number of elements in this Collection.
- size() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.SafeHashMap.EntrySet
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.util.SafeHashMap.KeySet
- 
Determine the number of keys in the Set.
- size() - Method in class com.tangosol.util.SafeHashMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.SafeHashMap.ValuesCollection
- 
Determine the number of values in the Collection.
- size() - Method in class com.tangosol.util.SafeLinkedList
- 
Returns the number of elements in this List.
- size() - Method in class com.tangosol.util.SafeSortedMap.EntrySet
- size() - Method in class com.tangosol.util.SafeSortedMap.KeySet
- size() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- size() - Method in class com.tangosol.util.SafeSortedMap.Values
- size() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
- 
Returns the number of elements in this collection.
- size() - Method in class com.tangosol.util.SegmentedHashMap.KeySet
- 
Determine the number of keys in the Set.
- size() - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns the number of key-value mappings in this map.
- size() - Method in class com.tangosol.util.SegmentedHashMap.ValuesCollection
- 
Determine the number of values in the Collection.
- size() - Method in class com.tangosol.util.SetMap
- size() - Method in class com.tangosol.util.SimpleStreamer
- size() - Method in class com.tangosol.util.SortedBag
- size() - Method in interface com.tangosol.util.Streamer
- 
Return the exact size of the data set thisStreamerwill iterate over, or negative integer if the exact size is unknown.
- size() - Method in class com.tangosol.util.SubList
- size() - Method in class com.tangosol.util.SubSet
- size() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- size() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- size() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- size() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- size(SizeRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Determine the number of entries in a cache.
- size(SizeRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- size(SizeRequest, StreamObserver<Int32Value>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- size(Object) - Method in class com.tangosol.util.SegmentedConcurrentMap.SizeAction
- 
Return the number of Entry objects found while applying this action.
- size(String, String) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aSizeRequest.
- size(Map[]) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Return the number of key-value mappings in a subset of the maps that belong to specified partitions.
- SIZE_BASIC_OBJECT - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The unaligned size of the simplest object.
- SIZE_BIGDECIMAL - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aBigDecimalobject.
- SIZE_BIGINTEGER - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aBigIntegerobject.
- SIZE_BINARY - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The minimum size (in bytes) of aBinaryobject.
- SIZE_BOOLEAN - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aBooleanobject.
- SIZE_BYTE - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aByteobject.
- SIZE_CHARACTER - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aCharacterobject.
- SIZE_COPY_BUFFER - Static variable in class com.tangosol.io.nio.BinaryMap
- 
Copy buffer size.
- SIZE_DATE - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- SIZE_DOUBLE - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aDoubleobject.
- SIZE_ENTRY - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The minimum size (in bytes) of anLocalCache.Entryobject.
- SIZE_FLOAT - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aFloatobject.
- SIZE_INTEGER - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aIntegerobject.
- SIZE_LONG - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aLongobject.
- SIZE_OBJECT - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of anObject.
- SIZE_OBJECT_REF - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of an object reference.
- SIZE_SHORT - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aShortobject.
- SIZE_STRING - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The minimum size (in bytes) of aStringobject.
- SIZE_TIMESTAMP - Static variable in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
The size (in bytes) of aTimestampobject.
- SizeAction() - Constructor for class com.tangosol.util.SegmentedConcurrentMap.SizeAction
- SIZED - Static variable in interface com.tangosol.util.Streamer
- 
Characteristic value signifying that the value returned fromsize()prior to traversal represents a finite size that, in the absence of structural source modification, represents an exact count of the number of elements that would be encountered by a complete traversal.
- sizeDir(File) - Static method in class com.tangosol.io.FileHelper
- 
Return the approximate disk usage in bytes for a given directory.
- SizeEstimatingBufferOutput - Class in com.tangosol.io
- 
SizeEstimatingBufferOutput is a WriteBuffer.BufferOutput implementation which writes nothing, and simply maintains an estimated byte count of how much would have been written.
- SizeEstimatingBufferOutput() - Constructor for class com.tangosol.io.SizeEstimatingBufferOutput
- sizeOf(Class) - Method in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
Determine the minimum number of bytes required to store an instance of the given fixed-sized class in memory.
- sizeOf(Object) - Method in class com.tangosol.net.cache.SimpleMemoryCalculator
- 
Estimate the number of bytes of memory consumed by the given object.
- sizeOf(Object) - Method in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
Estimate the number of bytes of memory consumed by the given object.
- sizeofPackedInt(int) - Static method in class com.tangosol.io.AbstractReadBuffer
- 
Return the number of bytes that would be required to store the given int using the variable-length storage format as described byWriteBuffer.BufferOutput.writePackedInt(int).
- skip(long) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Skips over up to the specified number of bytes of data from this InputStream.
- skip(long) - Method in class com.tangosol.io.MultiByteArrayInputStream
- 
Skips over and discardsnbytes of data from this input stream.
- skip(long) - Method in class com.tangosol.io.nio.ByteBufferInputStream
- 
Skips over and discardsnbytes of data from this input stream.
- skip(long) - Method in class com.tangosol.io.pof.PofInputStream
- 
Skips over up to the specified number of bytes of data from this InputStream.
- skip(long) - Method in class com.tangosol.io.Utf8Reader
- 
Skip characters.
- skip(long) - Method in class com.tangosol.io.WrapperDataInputStream
- 
Skips over up to the specified number of bytes of data from this InputStream.
- skip(long) - Method in class com.tangosol.io.WrapperInputStream
- 
Skips over up to the specified number of bytes of data from this InputStream.
- skip(long) - Method in class com.tangosol.io.WrapperObjectInputStream
- 
Skips over up to the specified number of bytes of data from this InputStream.
- skip(long) - Method in class com.tangosol.util.NullImplementation.NullReader
- skip(long) - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the remaining elements of this stream after discarding the firstnelements of the stream.
- skip(long) - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the remaining elements of this stream after discarding the firstnelements of the stream.
- skip(long) - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the remaining elements of this stream after discarding the firstnelements of the stream.
- skip(long) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the remaining elements of this stream after discarding the firstnelements of the stream.
- skipBOM(InputStream) - Method in class com.tangosol.run.xml.SimpleParser
- 
Read the providedInputStreamto determine if the stream starts with a UTF-8 BOM (http://www.unicode.org/faq/utf_bom.html#BOM).
- skipBytes(int) - Method in class com.tangosol.io.AbstractReadBuffer.AbstractBufferInput
- 
Skips over up to the specified number of bytes of data.
- skipBytes(int) - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
Skips over up to the specified number of bytes of data.
- skipBytes(int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer.ByteBufferInput
- 
Skips over up to the specified number of bytes of data.
- skipBytes(int) - Method in class com.tangosol.io.PackedDataInputStream
- 
Skips over up to the specified number of bytes of data.
- skipBytes(int) - Method in class com.tangosol.io.pof.PofInputStream
- 
Skips over up to the specified number of bytes of data.
- skipBytes(int) - Method in interface com.tangosol.io.ReadBuffer.BufferInput
- 
Skips over up to the specified number of bytes of data.
- skipBytes(int) - Method in class com.tangosol.io.WrapperDataInputStream
- 
Skips over up to the specified number of bytes of data.
- skipChild(ReadBuffer.BufferInput) - Method in class com.tangosol.io.pof.reflect.ComplexPofValue
- 
Skip a single child value.
- skipPackedInts(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Skip the specified number of packed integers in the passed POF stream.
- skipUniformValue(ReadBuffer.BufferInput, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Within the POF stream, skip the next POF value of the specified type.
- skipValue(ReadBuffer.BufferInput) - Static method in class com.tangosol.io.pof.PofHelper
- 
Within the POF stream, skip the next POF value.
- skipWhiteSpace() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Skip over any whitespace characters.
- sleep(long) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Invoke Thread.sleep() while still respecting the calling thread'stimeout.
- sleep(long) - Static method in class com.tangosol.util.Base
- 
Convenience method forThread.sleep(long).
- sleep(long, int) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Invoke Thread.sleep() while still respecting the calling thread'stimeout.
- SLEEP_TIME - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Sleep time between checking operation completion.
- SLEEPYCAT_JE_PROPERTY_PREFIX - Static variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Another prefix for Berkeley DB JE configuration settings.
- Snapshot - Class in com.tangosol.persistence
- 
A Snapshot is the abstraction of a full or partial snapshot representation for the purposes of archiving.
- Snapshot(String, String[]) - Constructor for class com.tangosol.persistence.Snapshot
- 
Create a new Snapshot with the given name and set of PersistentStore identifiers.
- SnapshotArchiver - Interface in com.tangosol.persistence
- 
An interface for archiving and restoring snapshots.
- SnapshotArchiverFactory - Interface in com.tangosol.persistence
- 
A factory forSnapshotArchiverobjects.
- SocketAddressProvider - Interface in com.tangosol.net
- 
The SocketAddressProvider is an interface that serves as a means to provide addresses to a consumer.
- SocketHandler(String) - Constructor for class com.tangosol.net.LoadBalancer.SocketHandler
- 
Construct a SocketHandler with a given daemon thread name.
- SocketOptions - Class in com.tangosol.net
- 
SocketOptions provides a means to configure the various aspects of Sockets.
- SocketOptions() - Constructor for class com.tangosol.net.SocketOptions
- SocketOptionsProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorforSocketOptions.
- SocketOptionsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SocketOptionsProcessor
- SocketProvider - Interface in com.tangosol.net
- 
SocketProvider defines an abstraction for creating various types of sockets.
- SocketProviderBuilder - Class in com.tangosol.coherence.config.builder
- 
SocketProviderBuilderenables lazy instantiation of SocketProvider.
- SocketProviderBuilder(SocketProvider, boolean) - Constructor for class com.tangosol.coherence.config.builder.SocketProviderBuilder
- 
Wrapper an existingSocketProviderinto a Builder so it can be registered in cluster BuilderRegistry.
- SocketProviderBuilder(String, SocketProviderFactory.Dependencies, boolean) - Constructor for class com.tangosol.coherence.config.builder.SocketProviderBuilder
- 
Construct aSocketProviderBuilderfrom its definition id and its dependencies.
- SocketProviderFactory - Class in com.tangosol.net
- 
The SocketProviderFactory produces SocketProviders.
- SocketProviderFactory() - Constructor for class com.tangosol.net.SocketProviderFactory
- 
Construct a SocketProviderFactory
- SocketProviderFactory(SocketProviderFactory.Dependencies) - Constructor for class com.tangosol.net.SocketProviderFactory
- 
Construct a SocketProviderFactory.
- SocketProviderFactory.DefaultDependencies - Class in com.tangosol.net
- 
DefaultDependencies is a basic implementation of the Dependencies interface.
- SocketProviderFactory.Dependencies - Interface in com.tangosol.net
- 
Dependencies specifies all dependency requirements of the SocketProviderFactory.
- SocketProviderFactory.Dependencies.ProviderType - Enum in com.tangosol.net
- 
Enumeration of Provider types.
- SocketProviderProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse a <socket-provider> and produce aSocketProviderBuilder.
- SocketProviderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SocketProviderProcessor
- SocketProvidersProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnSocketProvidersProcessoris responsible for processing <socket-provider>XmlElements SocketProvider definitions.
- SocketProvidersProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SocketProvidersProcessor
- sort(Comparator<? super E>) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- sorted() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns a stream consisting of the elements of this stream in sorted order.
- sorted() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns a stream consisting of the elements of this stream in sorted order.
- sorted() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns a stream consisting of the elements of this stream in sorted order.
- sorted() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, sorted according to natural order.
- sorted(Remote.Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, sorted according to the providedComparator.
- sorted(Remote.Comparator<? super T>, boolean) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, sorted according to the providedComparator.
- sorted(ValueExtractor<? super U, ? extends Comparable>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, sorted according to attribute extracted by the providedValueExtractor.
- sorted(ValueExtractor<? super U, ? extends Comparable>, boolean) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, sorted according to attribute extracted by the providedValueExtractor.
- sorted(Comparator<? super T>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns a stream consisting of the elements of this stream, sorted according to the providedComparator.
- SORTED_ENTRY_OVERHEAD - Static variable in class com.tangosol.util.SimpleMapIndex.IndexCalculator
- 
The memory cost of creating NullableSortedMap.Entry.
- SortedBag<E> - Class in com.tangosol.util
- 
SortedBag is a multiset or bag implementation that supports sorted traversal of the contained elements and is optimized for insertions and removals.
- SortedBag() - Constructor for class com.tangosol.util.SortedBag
- 
Default constructor.
- SortedBag(Comparator<? super E>) - Constructor for class com.tangosol.util.SortedBag
- 
Construct a SortedBag whose elements are to be ordered by the specified comparator.
- SortedBag.UniqueElement<E> - Class in com.tangosol.util
- 
UniqueElement represents a unique instance of a logical element in the bag.
- SortedBag.ViewBag - Class in com.tangosol.util
- 
A range-limited view of the SortedBag.
- SortedBag.WrapperComparator - Class in com.tangosol.util
- 
WrapperComparator is a Comparator implementation that is aware ofSortedBag.UniqueElementwrappers and will delegate the comparison of the elements in both forms to the wrapped comparator.
- SortedEnumerator - Class in com.tangosol.util
- 
Sorts the contents of the passed enumerator then enumerates those contents.
- SortedEnumerator(Enumeration) - Constructor for class com.tangosol.util.SortedEnumerator
- 
Construct a Sorted enumerator.
- SortedEnumerator(Iterator) - Constructor for class com.tangosol.util.SortedEnumerator
- 
Construct a Sorted enumerator.
- SortedSetView() - Constructor for class com.tangosol.util.ImmutableArrayList.SortedSetView
- 
Create a SortedSetView over this ImmutableArrayList.
- sortHolders(List) - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Sort the holders in the order to be returned by theConfigurableAddressProvider.getNextAddress()method.
- source(String, ExecutionContext) - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
- 
Attempt to parse, build, and execute from the given file of statements tracing on the given PrintWriter if the given flag indicates the need to trace.
- SourceStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
- 
Construct a SourceStatement that will execute commands from the specified file.
- SourceStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aSourceStatementBuilder.SourceStatement.
- SourceStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder
- SourceStatementBuilder.SourceStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "source" command.
- SpaceDefaultDelimiterExpansionProcessor() - Constructor for class com.tangosol.config.expression.ValueMacroExpression.SpaceDefaultDelimiterExpansionProcessor
- 
Construct a {@link SpaceDefaultDelimiterExpansionProcessor.
- SparseArray<V> - Class in com.tangosol.util
- 
A data structure resembling an Object array indexed by long values.
- SparseArray() - Constructor for class com.tangosol.util.SparseArray
- SparseArray.ObjectNode<V> - Class in com.tangosol.util
- 
Node mapping long key to Object value.
- SpecificInstanceProcessor<T> - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will process anXmlElementdefining aParameterizedBuilder, after which it will eagerly realized to produce an instance of the required type.
- SpecificInstanceProcessor(Class<T>) - Constructor for class com.tangosol.coherence.config.xml.processor.SpecificInstanceProcessor
- 
Constructs aSpecificInstanceProcessorfor the specifiedClass.
- SpecificInstanceProcessor(Class<T>, AbstractEmptyElementProcessor.EmptyElementBehavior) - Constructor for class com.tangosol.coherence.config.xml.processor.SpecificInstanceProcessor
- 
Constructs aSpecificInstanceProcessorfor the specifiedClass.
- SpecificInstanceProcessor(Class<T>, T) - Constructor for class com.tangosol.coherence.config.xml.processor.SpecificInstanceProcessor
- 
Constructs aSpecificInstanceProcessorfor the specifiedClass.
- split() - Method in class com.tangosol.net.partition.PartitionSet
- 
Split this partition set into two partition sets that are mutually exclusive.
- split(int) - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
If possible, chop a free block into two free blocks, or chop the end of an Entry block to make a free block.
- split(int) - Method in class com.tangosol.util.Binary
- 
Split a Binary into an array of Binaries each of which does not exceed the specified size.
- SPLIT - Static variable in class com.tangosol.net.NonBlockingTcpDatagramSocket
- 
Flag indicating if split sockets should be used for TcpDatagram sockets.
- splitByOwner(PartitionSet) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Split the partition set scheduled for distribution by the current primary owner (all transfers originate from the primary owner).
- spliterator() - Method in class com.tangosol.util.ImmutableArrayList
- spliterator() - Method in class com.tangosol.util.ImmutableMultiList
- spliterator() - Method in class com.tangosol.util.SafeSortedMap.Values
- spliterator() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- spliterator() - Method in interface com.tangosol.util.stream.RemoteIntStream
- spliterator() - Method in interface com.tangosol.util.stream.RemoteLongStream
- spliterator() - Method in interface com.tangosol.util.Streamer
- 
Return aSpliteratorover the elements described by thisStreamer.
- spliterator() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- SQLArchiveSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLArchiveSnapshotOPToken is used for parsing and specifying the AST used for archiving snapshots.
- SQLArchiveSnapshotOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLArchiveSnapshotOPToken
- 
Construct a new SQLArchiveSnapshotOPToken.
- SQLBackupOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLBackupOPToken is used for parsing and specifying the AST used for backing up a cache.
- SQLBackupOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLBackupOPToken
- 
Construct a new SQLBackupOPToken with the given parameters.
- SQLCreateCacheOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLCreateOPToken is used for parsing and specifying the AST used for a create cache.
- SQLCreateCacheOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.SQLCreateCacheOPToken
- 
Construct a new SQLCreateCacheOPToken with the given parameters.
- SQLCreateIndexOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLCreateOPToken is used for parsing and specifying the AST used for a create index query.
- SQLCreateIndexOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.SQLCreateIndexOPToken
- 
Construct a new SQLCreateIndexOPToken with the given parameters.
- SQLCreateSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLCreateSnapshotOPToken is used for parsing and specifying the AST used for creating snapshots.
- SQLCreateSnapshotOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLCreateSnapshotOPToken
- 
Construct a new SQLCreateSnapshotOPToken.
- SQLDeleteOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLDeleteOPToken is used for parsing and specifying the AST used for a delete query.
- SQLDeleteOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLDeleteOPToken
- 
Construct a new SQLDeleteOPToken with the given parameters.
- SQLDropCacheOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLDropCacheOPToken is used for parsing and specifying the AST used for drop cache
- SQLDropCacheOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.SQLDropCacheOPToken
- 
Construct a new SQLDropCacheOPToken with the given parameters.
- SQLDropIndexOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLDropIndexOPToken is used for parsing and specifying the AST used for drop index.
- SQLDropIndexOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.SQLDropIndexOPToken
- 
Construct a new SQLDropIndexOPToken.
- SQLExplainOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLExplainOPToken is used for parsing and specifying the AST used for an explain plan statement.
- SQLExplainOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLExplainOPToken
- 
Construct a new SQLExplainOPToken with the given parameters.
- SQLForceRecoveryOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLForceRecoveryOPToken is used for parsing and specifying the AST used for forcing recovery.
- SQLForceRecoveryOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLForceRecoveryOPToken
- 
Construct a new SQLForceRecoveryOPToken.
- SQLInsertOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLInsertOPToken is used for parsing and specifying the AST used for a insert statment.
- SQLInsertOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLInsertOPToken
- 
Construct a new SQLInsertOPToken with the given parameters.
- SQLListArchivedSnapshotsOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLListArchivedSnapshotsOPToken is used for parsing and specifying the AST used for listing archived snapshots.
- SQLListArchivedSnapshotsOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLListArchivedSnapshotsOPToken
- 
Construct a new SQLListArchivedSnapshotsOPToken.
- SQLListArchiverOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLListArchiverOPToken is used for parsing and specifying the AST used for showing the archiver implementation for a service.
- SQLListArchiverOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLListArchiverOPToken
- 
Construct a new SQLListArchiverOPToken.
- SQLListServicesOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLListServicesOPToken is used for parsing and specifying the AST used for listing services and their persistence mode.
- SQLListServicesOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLListServicesOPToken
- 
Construct a new SQLListServicesOPToken.
- SQLListSnapshotsOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLConnectOPToken is used for parsing and specifying the AST used for listing snapshots.
- SQLListSnapshotsOPToken() - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLListSnapshotsOPToken
- 
Construct a new SQLListServicesOPToken.
- SQLOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLOPToken provides useful convenience methods for subclasses.
- SQLOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLOPToken
- 
Construct a new SQLOPToken with the given parameters.
- SQLOPToken(String, String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLOPToken
- 
Construct a new SQLOPToken with the given parameters.
- SQLPeekOPToken - Class in com.tangosol.coherence.dslquery.token
- 
An CohQL implementation of aPeekOPToken.
- SQLPeekOPToken(String, OPToken...) - Constructor for class com.tangosol.coherence.dslquery.token.SQLPeekOPToken
- 
Construct a SQLPeekOPToken.
- SQLRecoverSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLRecoverSnapshotOPToken is used for parsing and specifying the AST used for creating snapshots.
- SQLRecoverSnapshotOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLRecoverSnapshotOPToken
- 
Construct a new SQLRecoverSnapshotOPToken.
- SQLRemoveSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLRemoveSnapshotOPToken is used for parsing and specifying the AST used for creating snapshots.
- SQLRemoveSnapshotOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLRemoveSnapshotOPToken
- 
Construct a new SQLListServicesOPToken.
- SQLRestoreOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLRestoreOPToken is used for parsing and specifying the AST used for restoring a cache.
- SQLRestoreOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLRestoreOPToken
- 
Construct a new SQLRestoreOPToken with the given parameters.
- SQLResumeServiceOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLResumeServiceOPToken is used for parsing and specifying the AST used for resuming services.
- SQLResumeServiceOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLResumeServiceOPToken
- 
Construct a new SQLResumeServiceOPToken.
- SQLRetrieveSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLRetrieveSnapshotOPToken is used for parsing and specifying the AST used for retrieving snapshots.
- SQLRetrieveSnapshotOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLRetrieveSnapshotOPToken
- 
Construct a new SQLRetrieveSnapshotOPToken.
- SQLSelectOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLSelectOPToken is used for parsing and specifying the AST used for a select statement.
- SQLSelectOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLSelectOPToken
- 
Construct a new SQLSelectOPToken with the given parameters.
- SQLSourceOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLSourceOPToken is used for parsing and specifying the AST used for sourcing (including) a file.
- SQLSourceOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLSourceOPToken
- 
Construct a new SQLSourceOPToken with the given parameters.
- SQLSuspendServiceOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLSuspendServiceOPToken is used for parsing and specifying the AST used for suspending services.
- SQLSuspendServiceOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLSuspendServiceOPToken
- 
Construct a new SQLListServicesOPToken.
- sqlTokenTable() - Method in class com.tangosol.coherence.dslquery.CoherenceQueryLanguage
- 
Return an initialized extendedTokenTableknown by this CoherenceQueryLanguage.
- SQLTraceOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLTraceOPToken is used for parsing and specifying the AST used for a trace statement.
- SQLTraceOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLTraceOPToken
- 
Construct a new SQLTraceOPToken with the given parameters.
- SQLTruncateCacheOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLTruncateCacheOPToken is used for parsing and specifying the AST used for truncate cache.
- SQLTruncateCacheOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLTruncateCacheOPToken
- 
Construct a new SQLTruncateCacheOPToken with the given parameters.
- SQLUpdateOPToken - Class in com.tangosol.coherence.dslquery.token
- 
SQLUpdateOPToken is used for parsing and specifying the AST used for an update statement.
- SQLUpdateOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.SQLUpdateOPToken
- 
Construct a new SQLUpdateOPToken with the given parameters.
- SQLValidateSnapshotOPToken - Class in com.tangosol.coherence.dslquery.token.persistence
- 
SQLValidateSnapshotOPToken is used for parsing and specifying the AST used for creating snapshots.
- SQLValidateSnapshotOPToken(String) - Constructor for class com.tangosol.coherence.dslquery.token.persistence.SQLValidateSnapshotOPToken
- 
Construct a new SQLValidateSnapshotOPToken.
- SSL - com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
- SSLHostnameVerifierProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse and produce aHostnameVerifierbased on hostname-verifier configuration element.
- SSLHostnameVerifierProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SSLHostnameVerifierProcessor
- SSLManagerProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse and produce a DefaultManagerDependencies based on a identity-manager/trust-manager configuration element.
- SSLManagerProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SSLManagerProcessor
- SSLNameListProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse and produce a NameListDependencies based on a protocol-versions or cipher-suites configuration element.
- SSLNameListProcessor(String) - Constructor for class com.tangosol.coherence.config.xml.processor.SSLNameListProcessor
- SSLProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse an <ssl> and produce aSSLSocketProviderDependenciesBuilderobject.
- SSLProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SSLProcessor
- SSLSocketProviderDependenciesBuilder - Class in com.tangosol.coherence.config.builder
- 
SSLSocketProviderDependenciesBuilderenables lazy instantiation of SSL SocketProvider.
- SSLSocketProviderDependenciesBuilder(SSLSocketProviderDefaultDependencies) - Constructor for class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder
- 
ConstructsSSLSocketProviderDependenciesBuilder
- SSLSocketProviderDependenciesBuilder.DependenciesAware - Interface in com.tangosol.coherence.config.builder
- 
Implemented byProviderclasses that need to be aware of the SSL dependencies.
- SSLSocketProviderDependenciesBuilder.HostnameVerifierBuilder - Class in com.tangosol.coherence.config.builder
- 
HostnameVerifier dependencies
- SSLSocketProviderDependenciesBuilder.NameListDependencies - Class in com.tangosol.coherence.config.builder
- 
SSL encipher-suites and protocol-versions are both a list of names with a usage attribute of the value "white-list" or "black-list"
- SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE - Enum in com.tangosol.coherence.config.builder
- SSLSocketProviderDependenciesBuilder.ProviderBuilder - Class in com.tangosol.coherence.config.builder
- 
Provider dependencies
- StackFrame(String) - Constructor for class com.oracle.coherence.common.base.StackTrace.StackFrame
- 
Construct a StackFrame object from a line of a stack trace.
- StackFrame(String, String, String, int) - Constructor for class com.oracle.coherence.common.base.StackTrace.StackFrame
- 
Construct a StackFrame object from its constituent data members.
- StackTrace - Class in com.oracle.coherence.common.base
- 
Class for providing StackTrace functionality.
- StackTrace() - Constructor for class com.oracle.coherence.common.base.StackTrace
- StackTrace.StackFrame - Class in com.oracle.coherence.common.base
- 
A class that provides "stack frame" information from a line of a stack trace.
- STANDARD - com.tangosol.util.SimpleMapIndex.IndexCalculator.CalculatorState
- start() - Method in class com.oracle.coherence.cdi.server.Server
- 
Starts CDI, which will indirectly startDefaultCacheServer.
- start() - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- start() - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Start the gRPC server.
- start() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- start() - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- start() - Method in class com.tangosol.net.Coherence
- 
Asynchronously start thisCoherenceinstance.
- start() - Static method in class com.tangosol.net.DefaultCacheServer
- 
Start all services that are declared as requiring an "autostart" in the default configurable factory XML descriptor.
- start() - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Start monitoring the services.
- start() - Method in class com.tangosol.net.WrapperService
- 
Start the controllable service.
- start() - Method in interface com.tangosol.util.Controllable
- 
Start the controllable service.
- start() - Method in class com.tangosol.util.Daemon
- 
Performs a synchronized start of the thread if the thread is not already started.
- start() - Method in interface com.tangosol.util.fsm.FiniteStateMachine
- 
Start theFiniteStateMachineand enter the initial state.
- start() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Start theFiniteStateMachineand enter the initial state.
- start(boolean, boolean) - Method in class com.tangosol.net.management.MBeanConnector
- 
Start the RMI and/or HTTP agents.
- start(ConfigurableCacheFactory) - Static method in class com.tangosol.net.DefaultCacheServer
- 
Start all services that are declared as requiring an "autostart" in the configurable factory XML descriptor.
- startAndMonitor(long) - Method in class com.tangosol.net.DefaultCacheServer
- 
Start the cache server and check the service status periodically, restarting any stopped services.
- startAndWait() - Method in class com.tangosol.net.Coherence
- 
Start thisCoherenceinstance and block until Coherence has started.
- startAndWait(Duration) - Method in class com.tangosol.net.Coherence
- 
Start thisCoherenceinstance and block until Coherence has started.
- startDaemon() - Static method in class com.tangosol.net.DefaultCacheServer
- 
Deprecated.useDefaultCacheServer.startServerDaemon()instead
- startDaemon(long) - Method in class com.tangosol.net.DefaultCacheServer
- 
Start the cache server and asynchronously check the service status periodically, restarting any services that have stopped.
- startDaemon(DefaultCacheServer) - Static method in class com.tangosol.net.DefaultCacheServer
- 
Start the provided cache server on a dedicated daemon thread.
- Started - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any STARTED event.
- STARTED - com.tangosol.net.events.CoherenceLifecycleEvent.Type
- STARTED - com.tangosol.net.events.SessionLifecycleEvent.Type
- Started.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theStartedannotation.
- startHttpConnector() - Method in class com.tangosol.net.management.MBeanConnector
- 
Starts the HTTP connector using the values of the HTTP_* system properties.
- startHttpConnector(int, MBeanServer) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Start a com.sun.jdmk.comm.HtmlAdaptorServer, which is a part of the Sun JMX reference implementation.
- Starting - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any STARTING event.
- STARTING - com.tangosol.net.events.CoherenceLifecycleEvent.Type
- STARTING - com.tangosol.net.events.SessionLifecycleEvent.Type
- Starting.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theStartingannotation.
- startOnCallingThread() - Method in class com.tangosol.net.Coherence
- 
Start thisCoherenceinstance.
- startRmiConnector() - Method in class com.tangosol.net.management.MBeanConnector
- 
Starts the RMI connector using the values of the RMI_* system properties.
- startRmiConnector(String, int, int, MBeanServer, Map) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Start aJMXConnectorServer.
- startServerDaemon() - Static method in class com.tangosol.net.DefaultCacheServer
- 
Start the cache server on a dedicated daemon thread, using defaultConfigurableCacheFactory.
- startServerDaemon(ConfigurableCacheFactory) - Static method in class com.tangosol.net.DefaultCacheServer
- 
Start the cache server on a dedicated daemon thread, using specifiedConfigurableCacheFactory.
- startService(Service) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Start the givenService.
- startService(Service) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Start the givenService.
- startServices() - Method in class com.tangosol.net.DefaultCacheServer
- 
Start all services that are declared as requiring an "autostart" in the configurable factory XML descriptor.
- startServices() - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Start all services that are declared as requiring an "autostart".
- startServicesInternal() - Method in class com.tangosol.net.DefaultCacheServer
- 
Starts the services marked with autostart returning a map of a service name to the started service.
- startsWith(Binary) - Method in class com.tangosol.util.Binary
- 
Tests if this Binary object starts with the specified prefix.
- startsWith(Binary, int) - Method in class com.tangosol.util.Binary
- 
Tests if this Binary object starts with the specified prefix beginning a specified offset.
- startTracking() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Start tracking changes by the BinaryEntryStore.
- STATE_CONFIGURED - Static variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
State: TheContinuousQueryCachehas been configured.
- STATE_CONFIGURING - Static variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
State: TheContinuousQueryCacheis configuring or re-configuring its listeners and content.
- STATE_DISCONNECTED - Static variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
State: Disconnected state.
- STATE_ENDANGERED - Static variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
Constant used to indicate that the service is in an endangered state.
- STATE_HEALTHY - Static variable in interface com.tangosol.net.Guardian.GuardContext
- 
State value indicating the Guardable is healthy/responsive.
- STATE_MASK_BACK - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Bitmask for entry in back.
- STATE_MASK_EXISTS - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Bitmask for fields that would indicate that the Status represents an existent entry in the OverflowMap.
- STATE_MASK_FRONT - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Bitmask for entry in front.
- STATE_MASK_FRONT - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Bitmask for entry in front.
- STATE_MASK_INSYNC - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Bitmask for value in front and back being in sync.
- STATE_MASK_INSYNC - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Bitmask for value in front and back being in sync.
- STATE_MASK_RETAIN - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Bitmask for fields that would indicate that the Status must not be discarded.
- STATE_MASK_RETAIN - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Bitmask for fields that would indicate that the Status must not be discarded.
- STATE_MASK_STATUS - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Bitmask for status (least significant three bits reserved).
- STATE_MASK_STATUS - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Bitmask for status (least significant three bits reserved).
- STATE_RECOVERY - Static variable in interface com.tangosol.net.Guardian.GuardContext
- 
State value indicating that recovery of the Guardable is underway.
- STATE_SAFE - Static variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
Constant used to indicate that the service is "safe" (non-endangered).
- STATE_SYNCHRONIZED - Static variable in class com.tangosol.net.cache.ContinuousQueryCache
- 
State: TheContinuousQueryCachehas been configured and fully synchronized.
- STATE_TERMINATING - Static variable in interface com.tangosol.net.Guardian.GuardContext
- 
State value indicating that the Guardable is being terminated.
- STATE_UNKNOWN - Static variable in class com.tangosol.net.partition.FailoverAccessPolicy
- 
Constant used to indicate that the service is in an unknown (possibly endangered) state.
- STATE_VALUE_RETAIN - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Bit values for fields that would indicate that the Status can be discarded.
- StateEntryAction<S extends Enum<S>> - Interface in com.tangosol.util.fsm
- 
AStateEntryActionencapsulates the actions to be performed by aFiniteStateMachinewhen a particular state is entered.
- StateExitAction<S extends Enum<S>> - Interface in com.tangosol.util.fsm
- 
AStateExitActionencapsulates the actions to be performed by aFiniteStateMachinewhen leaving a known state.
- Statement - Interface in com.tangosol.coherence.dslquery
- 
Implementations of this interface are able to execute CohQL statements, for example a Select, Update, a backup command etc.
- StatementBuilder<T extends Statement> - Interface in com.tangosol.coherence.dslquery
- 
Classes implementing this interface build instances ofStatementimplementations.
- StatementExecutor - Class in com.tangosol.coherence.dslquery
- 
A class that parses and executes CohQL statements read from an instance of aReader.
- StatementExecutor() - Constructor for class com.tangosol.coherence.dslquery.StatementExecutor
- 
Create a StatementExecutor
- StatementResult - Interface in com.tangosol.coherence.dslquery
- 
The result of executing a CohQLStatement.
- StaticContent - Class in com.tangosol.coherence.rest.util
- 
A simple representation of static content, which is used as a pass-through storage format for content other than JSON.
- StaticContent() - Constructor for class com.tangosol.coherence.rest.util.StaticContent
- 
Deserialization constructor.
- StaticContent(Binary, String) - Constructor for class com.tangosol.coherence.rest.util.StaticContent
- 
Construct StaticContent instance.
- StaticContentMarshaller - Class in com.tangosol.coherence.rest.io
- 
A pass-through marshaller that simply converts HTTP entities into aStaticContentand vice versa.
- StaticContentMarshaller() - Constructor for class com.tangosol.coherence.rest.io.StaticContentMarshaller
- StaticFactoryInstanceBuilder<T> - Class in com.tangosol.coherence.config.builder
- 
AStaticFactoryInstanceBuilderis aParameterizedBuilderthat has been configured to realize objects based on the properties defined by an <instance> configuration element that uses the static <class-factory-name> approach.
- StaticFactoryInstanceBuilder() - Constructor for class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Construct aStaticFactoryInstanceBuilder.
- Statistics - com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility.ObjectNameType
- 
Cache Statistics
- Statistics() - Constructor for class com.tangosol.net.cache.AbstractBundler.Statistics
- Stats() - Constructor for class com.tangosol.util.ExternalizableHelper.Stats
- StatsVisitor(PersistenceStatistics) - Constructor for class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
- 
Construct a new Stats visitor.
- Status() - Constructor for class com.tangosol.net.cache.OverflowMap.Status
- 
Construct a Status object.
- Status() - Constructor for class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Construct a Status object for a specific key.
- STATUS_AVAILABLE - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Status: The Status object exists and no thread is currently performing processing against the associated entry.
- STATUS_AVAILABLE - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Status: The Status object exists and no thread is currently performing processing against the associated entry.
- STATUS_COMMITTING - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Status: The Status object represents an Entry that was very recently being processed, and is currently finalizing the results of that processing.
- STATUS_COMMITTING - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Status: The Status object represents an Entry that was very recently being processed, and is currently finalizing the results of that processing.
- STATUS_EXCEPTION - Static variable in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Attempt to bundle encountered and exception; the execution has to be de-optimized and performed by individual threads.
- STATUS_INVALIDATED - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Status: The Status object has been discarded.
- STATUS_INVALIDATED - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Status: The Status object has been discarded.
- STATUS_OPEN - Static variable in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
This Bundle accepting additional items.
- STATUS_PENDING - Static variable in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
This Bundle is closed for accepting additional items and awaiting for the execution results.
- STATUS_PROCESSED - Static variable in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
This Bundle is in process of returning the result of execution back to the client.
- STATUS_PROCESSING - Static variable in class com.tangosol.net.cache.OverflowMap.Status
- 
Status: The Status object represents an Entry that is currently being processed.
- STATUS_PROCESSING - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Status: The Status object represents an Entry that is currently being processed.
- STATUS_RESERVED - Static variable in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Status: The Status object has been reserved for processing by a thread but is not yet processing.
- Step() - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Default constructor (necessary for the ExternalizableLite interface).
- Step(Filter) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Construct a step.
- Step(QueryRecord.PartialResult.Step) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Copy constructor for a Step.
- stop() - Method in class com.oracle.coherence.grpc.proxy.DefaultGrpcAcceptorController
- stop() - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Stop the server.
- stop() - Method in class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- stop() - Method in class com.oracle.coherence.grpc.SimpleDaemonPoolExecutor
- stop() - Method in class com.tangosol.net.DefaultCacheServer
- 
Stop this DefaultCacheServer and dispose theConfigurableCacheFactorythat this server wraps.
- stop() - Method in class com.tangosol.net.WrapperService
- 
Hard-stop the controllable service.
- stop() - Method in interface com.tangosol.util.Controllable
- 
Hard-stop the controllable service.
- stop() - Method in class com.tangosol.util.Daemon
- 
Request the daemon to stop.
- stop() - Method in interface com.tangosol.util.fsm.FiniteStateMachine
- 
Stops theFiniteStateMachineas soon as possible.
- stop() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- 
Stops theFiniteStateMachineas soon as possible.
- stop(boolean) - Method in class com.tangosol.util.TaskDaemon
- 
Request the daemon to stop, optionally completing tasks that have already been scheduled and are ready to be run.
- Stop - com.tangosol.net.topic.Publisher.OnFailure
- 
If an individualPublisher.publish(V)fails then stop any further publishing and close thePublisher.
- STOP - Static variable in interface com.tangosol.util.fsm.Instruction
- 
TheInstructionfor aFiniteStateMachineto stop.
- stopMonitoring() - Method in class com.tangosol.net.DefaultCacheServer
- 
Ensures the DCS instance has shutdown and the associated ServiceMonitor is no longer monitoring services.
- stopMonitoring() - Method in interface com.tangosol.net.ServiceMonitor
- 
Stop monitoring all registered services.
- stopMonitoring() - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Stop monitoring all registered services.
- Stopped - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any STOPPED event.
- STOPPED - com.tangosol.net.events.CoherenceLifecycleEvent.Type
- STOPPED - com.tangosol.net.events.SessionLifecycleEvent.Type
- Stopped.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theStoppedannotation.
- Stopping - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any STOPPING event.
- STOPPING - com.tangosol.net.events.CoherenceLifecycleEvent.Type
- STOPPING - com.tangosol.net.events.SessionLifecycleEvent.Type
- Stopping.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theStoppingannotation.
- stopServiceMonitor() - Method in class com.tangosol.net.DefaultCacheServer
- 
Stop the ServiceMonitor.
- stopTracking() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Stop tracking changes by the BinaryEntryStore.
- STORAGE_MANAGER_QUERY - Static variable in class com.tangosol.net.management.MBeanAccessor
- 
MBean query to filter out StorageManager MBean of a specific cache and service, running on a specific node.
- STORAGE_MANAGER_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the StorageManagerMBean.
- StorageAccessAuthorizer - Interface in com.tangosol.net.security
- 
A pluggable facility for the server side access control authorization.
- StorageAccessAuthorizerBuilderProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor <storage-authorizer> elements defined by a Coherence Operational Configuration file.
- StorageAccessAuthorizerBuilderProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.StorageAccessAuthorizerBuilderProcessor
- 
Constructs aStorageAccessAuthorizerBuilderProcessor.
- StorageAccessAuthorizersProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorfor the <storage-authorizers%gt; element of Coherence Operational Configuration files.
- StorageAccessAuthorizersProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.StorageAccessAuthorizersProcessor
- StorageProcessor - Class in com.tangosol.coherence.config.xml.processor
- StorageProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.StorageProcessor
- store(long, ReadBuffer, ReadBuffer) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask
- 
Queue a store operation.
- store(long, ReadBuffer, ReadBuffer, Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Store the specified value under the specific key in the underlying store.
- store(long, R, R, Object) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Store the specified value under the specific key in the underlying store.
- store(long, R, R, Object) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- store(ReadWriteBackingMap.Entry, boolean) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Store the specified entry in the underlying store.
- store(BinaryEntry) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
- store(BinaryEntry<K, V>) - Method in interface com.tangosol.net.cache.BinaryEntryStore
- 
Store the specified entry in the underlying store.
- store(BinaryEntry<K, V>, StoreObserver<K, V>) - Method in interface com.tangosol.net.cache.NonBlockingEntryStore
- 
Store the specified entry in the underlying store, in an asynchronous fashion.
- store(Binary, Binary) - Method in class com.tangosol.io.AbstractBinaryStore
- 
Store the specified value under the specific key in the underlying store.
- store(Binary, Binary) - Method in class com.tangosol.io.AsyncBinaryStore
- 
Store the specified value under the specific key in the underlying store.
- store(Binary, Binary) - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Store the specified value under the specific key in the underlying store.
- store(Binary, Binary) - Method in interface com.tangosol.io.BinaryStore
- 
Store the specified value under the specific key in the underlying store.
- store(Binary, Binary) - Method in class com.tangosol.io.nio.BinaryMapStore
- 
Store the specified value under the specific key in the underlying store.
- store(Binary, Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
- 
Store the specified value under the specific key in the underlying store.
- store(Binary, Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Store the specified value under the specific key in the underlying store.
- store(Binary, Binary) - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Store the specified value under the specific key in the underlying store.
- store(Object, Object) - Method in class com.tangosol.util.NullImplementation.NullCacheStore
- 
Store the specified value under the specified key in the underlying store.
- store(K, V) - Method in class com.tangosol.net.cache.AbstractCacheStore
- 
Store the specified value under the specified key in the underlying store.
- store(K, V) - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Store the specified value under the specified key in the underlying store.
- store(K, V) - Method in interface com.tangosol.net.cache.CacheStore
- 
Store the specified value under the specified key in the underlying store.
- store(K, V) - Method in class com.tangosol.net.cache.MapCacheStore
- 
Store the specified value under the specified key in the underlying store.
- STORE_STATE_CLOSED - Static variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The state of a PersistenceStore once it has been released and closed.
- STORE_STATE_INITIALIZED - Static variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The initial state of a PersistenceStore.
- STORE_STATE_OPENING - Static variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The state of a PersistenceStore when it is in the process of being opened.
- STORE_STATE_READY - Static variable in class com.tangosol.persistence.AbstractPersistenceManager
- 
The state of a PersistenceStore once it has been opened and is ready to process requests.
- storeAll(Map) - Method in class com.tangosol.util.NullImplementation.NullCacheStore
- 
Store the specified values under the specified keys in the underlying store.
- storeAll(Map<? extends K, ? extends V>) - Method in interface com.tangosol.net.cache.CacheStore
- 
Store the specified values under the specified keys in the underlying store.
- storeAll(Map<? extends K, ? extends V>) - Method in class com.tangosol.net.cache.MapCacheStore
- 
Store the specified values under the specified keys in the underlying store.
- storeAll(Set) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheBinaryEntryStore
- storeAll(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Store the entries in the specified set in the underlying store.
- storeAll(Set<? extends BinaryEntry<K, V>>) - Method in interface com.tangosol.net.cache.BinaryEntryStore
- 
Store the entries in the specified set in the underlying store.
- storeAll(Set<? extends BinaryEntry<K, V>>, StoreObserver<K, V>) - Method in interface com.tangosol.net.cache.NonBlockingEntryStore
- 
Asynchronously store the entries in the specified set in the underlying store.
- storeAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Store the entries in the specified set in the underlying store.
- storeAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Store the entries in the specified set in the underlying store.
- storeAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Store the entries in the specified set in the underlying store.
- storeAllInternal(Set) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Store the entries in the specified set in the underlying store.
- storeCacheNames(PersistentStore, LongArray) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Persist the specified cache names in the persistent store.
- storeInternal(long, ReadBuffer, ReadBuffer, Object) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Store the specified value under the specific key in the underlying persistent storage.
- storeInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Store the specified entry in the underlying store.
- storeInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Store the specified entry in the underlying store.
- storeInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Store the specified entry in the underlying store.
- storeInternal(ReadWriteBackingMap.Entry) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- 
Store the specified entry in the underlying store.
- StoreObserver<K,V> - Interface in com.tangosol.net.cache
- 
StoreObserver implementations provide a means for receivers, such asNonBlockingEntryStore, to notify the provider of successful completion (StoreObserver.onNext(com.tangosol.util.BinaryEntry<K, V>)) or unsuccessful completion (StoreObserver.onError(com.tangosol.util.BinaryEntry<K, V>, java.lang.Exception)).
- StoreOperation(long, ReadBuffer, ReadBuffer) - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore.BatchTask.StoreOperation
- 
Create a new StoreOperation.
- StoreOperationObserver() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.StoreOperationObserver
- 
Default constructor.
- StoreOperationObserver(Set) - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.StoreOperationObserver
- 
Constructor with initial set of entries to be stored.
- StoreWrapper() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.StoreWrapper
- str(Object) - Static method in class com.tangosol.io.nio.BinaryMap
- 
Internal debugging support: Turn a Binary into a String.
- stream() - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return a stream of all entities in this repository.
- stream() - Method in interface com.tangosol.util.InvocableMap
- 
Return a stream of all entries in this map.
- stream() - Method in interface com.tangosol.util.Streamer
- 
Return aStreambased on thisStreamer.
- stream() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- stream(Filter) - Method in interface com.tangosol.util.InvocableMap
- 
Return a filtered stream of entries in this map.
- stream(Filter<?>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return a stream of all entities in this repository that satisfy the specified criteria.
- stream(Filter, ValueExtractor<T, ? extends E>) - Method in interface com.tangosol.util.InvocableMap
- 
Return a stream of values extracted from all the entries that satisfy the specified filter.
- stream(ValueExtractor<T, ? extends E>) - Method in interface com.tangosol.util.InvocableMap
- 
Return a stream of values extracted from the entries of this map.
- stream(Collection<? extends ID>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return a stream of entities with the specified identifiers.
- stream(Collection<? extends K>) - Method in interface com.tangosol.util.InvocableMap
- 
Return a stream of entries with the specified keys.
- stream(Collection<? extends K>, ValueExtractor<T, ? extends E>) - Method in interface com.tangosol.util.InvocableMap
- 
Return a stream of values extracted from the entries with the specified keys.
- Streamer<T> - Interface in com.tangosol.util
- 
Enables traversal of elements in the underlying data set using eitherIterator,Spliteratoror aStream, while allowing implementors to provide additional metadata, such as the size and other characteristics of the underlying data set.
- streaming(InvocableMap.EntryAggregator<? super K, ? super V, R>) - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Convert the specified aggregator to StreamingAggregator.
- streamingAsynchronous(InvocableMap.EntryProcessor<K, V, R>, int, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Static method in class com.tangosol.util.Processors
- 
Construct a streaming asynchronous processor for a given processor and one or more callbacks.
- streamingAsynchronous(InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Static method in class com.tangosol.util.Processors
- 
Construct a streaming asynchronous processor for a given processor and one or more callbacks.
- StreamingAsynchronousProcessor<K,V,R> - Class in com.tangosol.util.processor
- 
AnEntryProcessorwrapper class that allows for an asynchronous invocation of the underlying processor.
- StreamingAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Constructor for class com.tangosol.util.processor.StreamingAsynchronousProcessor
- 
Construct a StreamingAsynchronousProcessor for a given processor and one or more callbacks.
- StreamingAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, int, Consumer<? super Map.Entry<? extends K, ? extends R>>, Executor) - Constructor for class com.tangosol.util.processor.StreamingAsynchronousProcessor
- 
Construct a StreamingAsynchronousProcessor for a given processor and one or more callbacks.
- StreamingAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>) - Constructor for class com.tangosol.util.processor.StreamingAsynchronousProcessor
- 
Construct a StreamingAsynchronousProcessor for a given processor and one or more callbacks.
- StreamingAsynchronousProcessor(InvocableMap.EntryProcessor<K, V, R>, Consumer<? super Map.Entry<? extends K, ? extends R>>, Executor) - Constructor for class com.tangosol.util.processor.StreamingAsynchronousProcessor
- 
Construct a StreamingAsynchronousProcessor for a given processor and one or more callbacks.
- StrengthComparator(Ownership) - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.StrengthComparator
- 
Construct a StrengthComparator for the specified reference ownership.
- StringAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.StringAdapter
- 
Construct a SimpleAdapter.
- STRINGLITERAL - Static variable in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
The numberic code for a string literal
- STRINGLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
The numberic code for a string literal
- StringMarshaller - Class in com.tangosol.coherence.rest.io
- 
Marshaller that marshalls String object.
- StringMarshaller() - Constructor for class com.tangosol.coherence.rest.io.StringMarshaller
- strings() - Method in class com.tangosol.util.StringTable
- 
Get the table's strings.
- stringsStartingWith(String) - Method in class com.tangosol.util.StringTable
- 
Get the table's strings that start with a specific string.
- StringTable - Class in com.tangosol.util
- 
Like a hash table, but built specifically for strings.
- StringTable() - Constructor for class com.tangosol.util.StringTable
- 
Construct a string table using all defaults.
- StringTable(int) - Constructor for class com.tangosol.util.StringTable
- 
Construct a string table using the specified collator strength.
- StringTable(Collator) - Constructor for class com.tangosol.util.StringTable
- 
Construct a string table using the specified collator.
- stripDomain(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Remove the domain prefix from the canonical name if one exists.
- SUB_DIR_NAME - Static variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Default directory name for berkeley db environments.
- subBag(E, E) - Method in class com.tangosol.util.SortedBag
- 
Returns a view of the portion of this bag whose elements range from fromElement, inclusive, to toElement, exclusive.
- subBag(E, E) - Method in class com.tangosol.util.SortedBag.ViewBag
- 
Returns a view of the portion of this bag whose elements range from fromElement, inclusive, to toElement, exclusive.
- SUBJECT_SCOPED - Static variable in class com.tangosol.net.security.Security
- 
Indicates if subject scope is enabled by the operational configuration.
- SubjectPofSerializer - Class in com.tangosol.io.pof
- 
PofSerializer implementation that can serialize and deserialize aSubjectto/from a POF stream.
- SubjectPofSerializer() - Constructor for class com.tangosol.io.pof.SubjectPofSerializer
- 
Default constructor.
- subList(int, int) - Method in class com.tangosol.util.ConverterCollections.ConverterList
- subList(int, int) - Method in class com.tangosol.util.ImmutableMultiList
- subList(int, int) - Method in class com.tangosol.util.InflatableList
- subList(int, int) - Method in class com.tangosol.util.RestrictedCollections.RestrictedList
- 
Returns a view of the portion of this list between the specified fromIndex, inclusive, and toIndex, exclusive.
- subList(int, int) - Method in class com.tangosol.util.SubList
- subList(int, int) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperList
- SubList<T> - Class in com.tangosol.util
- 
Implements a list which is based on another list, represents a sub-list of the underlying list.
- SubList(List<T>, int, int) - Constructor for class com.tangosol.util.SubList
- 
Construct a SubList from provided list.
- subMap(Object, boolean, Object, boolean) - Method in class com.tangosol.util.SafeSortedMap
- subMap(Object, boolean, Object, boolean) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- subMap(Object, Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedMap
- 
Returns a view of the portion of this sorted map whose keys range from fromKey, inclusive, to toKey, exclusive.
- subMap(Object, Object) - Method in class com.tangosol.util.SafeSortedMap
- subMap(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- subMap(Set<TK>) - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- subMap(K, K) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- subMap(TK, TK) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- submit(Remote.Callable<T>) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
- submit(Remote.Runnable) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Submits a Runnable task for execution and returns a Future representing that task.
- submit(Remote.Runnable, T) - Method in interface com.oracle.coherence.concurrent.executor.RemoteExecutor
- 
Submits a Runnable task for execution and returns a Future representing that task.
- submit(Runnable) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- 
Requests aFutureTaskto be performed.
- submitOpen(PersistentStore<ReadBuffer>, Collector<Object>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Open this store either asynchronously, iff both a store to open from and a collector have been provided, or synchronously.
- submitTask(AbstractPersistenceManager.Task) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Submit the given task for execution by the daemon pool.
- submitTasks(List<? extends AbstractPersistenceManager.Task>) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Submit the provided list of tasks for execution to the pool or execute directly.
- SubnetMaskFilter(String) - Constructor for class com.tangosol.net.InetAddressHelper.SubnetMaskFilter
- 
Construct a SubnetMaskFilter for the given pattern and slash mask.
- SubnetMaskFilter(InetAddress, int) - Constructor for class com.tangosol.net.InetAddressHelper.SubnetMaskFilter
- 
Construct a SubnetMaskFilter for the given pattern and mask bit count.
- SubnetMaskFilter(InetAddress, InetAddress) - Constructor for class com.tangosol.net.InetAddressHelper.SubnetMaskFilter
- 
Construct a SubnetMaskFilter for the given pattern and mask.
- Subscriber<V> - Interface in com.tangosol.net.topic
- SUBSCRIBER_ANONYMOUS_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "subtype" part of ObjectName for an Anonymous Subscriber MBean.
- SUBSCRIBER_DURABLE_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "subtype" part of ObjectName for a Durable Subscriber MBean.
- SUBSCRIBER_GROUP_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the Subscriber Group MBean.
- SUBSCRIBER_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the Subscriber MBean.
- Subscriber.Channel - Interface in com.tangosol.net.topic
- 
A representation of a topic channel within subscriber.
- Subscriber.Channel.EmptyChannel - Class in com.tangosol.net.topic
- 
A default empty channel implementation.
- Subscriber.ChannelOwnershipListener - Interface in com.tangosol.net.topic
- 
A listener that receives notification of channel ownership changes.
- Subscriber.ChannelOwnershipListeners<V> - Class in com.tangosol.net.topic
- 
A subscriberSubscriber.Optionthat allows one or morelistenersto be added to the subscriber, that will be notified of changes to the subscribers channel ownership.
- Subscriber.CommitResult - Class in com.tangosol.net.topic
- 
The result of a commit request.
- Subscriber.CommitResultStatus - Enum in com.tangosol.net.topic
- 
The different result statuses for a commit request.
- Subscriber.CompleteOnEmpty<V> - Class in com.tangosol.net.topic
- 
The CompleteOnEmpty option indicates that theCompletableFuturereturned from theSubscriber.receive()operation should complete with a nullSubscriber.Elementupon identifying that the topic is or has become empty.
- Subscriber.Convert<V,U> - Class in com.tangosol.net.topic
- 
The Convert option specifies aValueExtractorthat will convert topic values that a subscriber is interested in receiving prior to sending them to the subscriber.
- Subscriber.Element<V> - Interface in com.tangosol.net.topic
- 
Element represents a container for returned values.
- Subscriber.Filtered<V> - Class in com.tangosol.net.topic
- 
The Filtered option specifies a filter that will determine which topic values a subscriber is interested in receiving.
- Subscriber.Id - Interface in com.tangosol.net.topic
- 
A marker interface forSubscriberidentifiers.
- Subscriber.Name<V> - Class in com.tangosol.net.topic
- 
The Name option is used to specify a subscriber group name.
- Subscriber.Option<V,U> - Interface in com.tangosol.net.topic
- 
A marker interface to indicate that a class is a validSubscriber.Optionfor aSubscriber.
- SubscriberGroup - Annotation Type in com.oracle.coherence.cdi
- 
A qualifier annotation used when injectingSubscriberto aNamedTopicto indicate the name of the subscriber group that the subscriber should belong to.
- SubscriberGroup.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theSubscriberGroupannotation.
- SubscriberGroupBuilder<V> - Class in com.tangosol.coherence.config.builder
- 
TheSubscriberGroupBuilderbuilds aSubscribergroup.
- SubscriberGroupBuilder() - Constructor for class com.tangosol.coherence.config.builder.SubscriberGroupBuilder
- SubscriberGroupProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AElementProcessorfor the <subscriber-group> element.
- SubscriberGroupProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SubscriberGroupProcessor
- SubscriberGroupsProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AElementProcessorfor the <subscriber-groups> element.
- SubscriberGroupsProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.SubscriberGroupsProcessor
- subSequence(int, int) - Method in class com.tangosol.io.AbstractReadBuffer
- 
Returns a newByteSequencethat is a subsequence of this sequence.
- subSequence(int, int) - Method in interface com.tangosol.io.ReadBuffer
- 
Returns a newByteSequencethat is a subsequence of this sequence.
- subSequence(int, int) - Method in class com.tangosol.util.AbstractByteSequence.AggregateByteSequence
- 
Returns a newByteSequencethat is a subsequence of this sequence.
- subSequence(int, int) - Method in class com.tangosol.util.AbstractByteSequence
- 
Returns a newByteSequencethat is a subsequence of this sequence.
- subSequence(int, int) - Method in interface com.tangosol.util.ByteSequence
- 
Returns a newByteSequencethat is a subsequence of this sequence.
- SubsequentEvent(Event<S>) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.SubsequentEvent
- 
Constructs aNonBlockingFiniteStateMachine.SubsequentEvent.
- subSet(E, E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
- subSet(Object, boolean, Object, boolean) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- subSet(Object, Object) - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns a view of the portion of this sorted set whose elements are found in the set in a position at and after the position of fromElement and in a position before toElement.
- subSet(Object, Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedSet
- 
Returns a view of the portion of this sorted set whose elements range from fromElement, inclusive, to toElement, exclusive.
- subSet(Object, Object) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- subSet(T, T) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- SubSet<E> - Class in com.tangosol.util
- 
Implements a set which is based on another set, which is assumed to be immutable.
- SubSet(Set<? extends E>) - Constructor for class com.tangosol.util.SubSet
- 
Construct this set based on an existing set.
- SubSet.SubSetIterator - Class in com.tangosol.util
- 
Iterator for the contents of a subset in the "removed" mode.
- SubSetIterator() - Constructor for class com.tangosol.util.SubSet.SubSetIterator
- 
Construct an iterator for a subset.
- substitute(String, ParameterResolver, int) - Method in class com.tangosol.config.expression.ValueMacroExpression
- 
Return a string value containing no outstanding macro parameters.
- SUBSTRING_OFFSET_LENGTH_EXPANSION - Static variable in class com.tangosol.config.expression.ValueMacroExpression
- 
Delimiter introducing substring expansion of optional :offset and/or :length in a macro parameter.
- SubtractionOperator - Class in com.tangosol.coherence.dslquery.operator
- 
An operator representing the conditional mathematical subtraction operation.
- SubtractionOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.SubtractionOperator
- 
Constructs a SubtractionOperator.
- SUCCESS - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Result to output on command success.
- suggest(PartitionSet, Ownership) - Method in interface com.tangosol.net.partition.DistributionManager
- 
Suggest a distribution change for the specified set of partitions, indicating either primary or backup transfer (or both).
- suggestDistribution() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Suggest any distribution that may have been collected by this analysis context to the DistributionManager.
- sum() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns the sum of elements in this stream.
- sum() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns the sum of elements in this stream.
- sum() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns the sum of elements in this stream.
- sum(Filter<?>, Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the sum of the specified function.
- sum(Filter<?>, Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the sum of the specified function.
- sum(Filter<?>, Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the sum of the specified function.
- sum(Filter<?>, Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the sum of the specified function.
- sum(Filter<?>, Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the sum of the specified function.
- sum(Filter<?>, Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the sum of the specified function.
- sum(Filter<?>, Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the sum of the specified function.
- sum(Filter<?>, Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the sum of the specified function.
- sum(Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the sum of the specified function.
- sum(Remote.ToBigDecimalFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the sum of the specified function.
- sum(Remote.ToBigDecimalFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a sum of the BigDecimal values extracted from a set of entries in a Map.
- sum(Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the sum of the specified function.
- sum(Remote.ToDoubleFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the sum of the specified function.
- sum(Remote.ToDoubleFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a sum of the double values extracted from a set of entries in a Map.
- sum(Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the sum of the specified function.
- sum(Remote.ToIntFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the sum of the specified function.
- sum(Remote.ToIntFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a sum of the int values extracted from a set of entries in a Map.
- sum(Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the sum of the specified function.
- sum(Remote.ToLongFunction<? super T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the sum of the specified function.
- sum(Remote.ToLongFunction<? super T>) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates a sum of the long values extracted from a set of entries in a Map.
- summarizingDouble(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorwhich applies andouble-producing mapping function to each input element, and returns summary statistics for the resulting values.
- summarizingInt(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorwhich applies anint-producing mapping function to each input element, and returns summary statistics for the resulting values.
- summarizingLong(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorwhich applies anlong-producing mapping function to each input element, and returns summary statistics for the resulting values.
- summaryStatistics() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns aDoubleSummaryStatisticsdescribing various summary data about the elements of this stream.
- summaryStatistics() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns anIntSummaryStatisticsdescribing various summary data about the elements of this stream.
- summaryStatistics() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns aLongSummaryStatisticsdescribing various summary data about the elements of this stream.
- summingDouble(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat produces the sum of a double-valued function applied to the input elements.
- summingInt(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat produces the sum of a integer-valued function applied to the input elements.
- summingLong(ValueExtractor<? super U, ? extends Number>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat produces the sum of a long-valued function applied to the input elements.
- supplier(Remote.Supplier<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable Supplier.
- supply() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- supply() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- supply() - Method in class com.tangosol.util.aggregator.AbstractAggregator
- supply() - Method in class com.tangosol.util.aggregator.BigDecimalAverage
- supply() - Method in class com.tangosol.util.aggregator.BigDecimalMax
- supply() - Method in class com.tangosol.util.aggregator.BigDecimalMin
- supply() - Method in class com.tangosol.util.aggregator.BigDecimalSum
- supply() - Method in class com.tangosol.util.aggregator.ComparableMax
- supply() - Method in class com.tangosol.util.aggregator.ComparableMin
- supply() - Method in class com.tangosol.util.aggregator.CompositeAggregator
- supply() - Method in class com.tangosol.util.aggregator.Count
- supply() - Method in class com.tangosol.util.aggregator.DistinctValues
- supply() - Method in class com.tangosol.util.aggregator.DoubleAverage
- supply() - Method in class com.tangosol.util.aggregator.DoubleMax
- supply() - Method in class com.tangosol.util.aggregator.DoubleMin
- supply() - Method in class com.tangosol.util.aggregator.DoubleSum
- supply() - Method in class com.tangosol.util.aggregator.GroupAggregator
- supply() - Method in class com.tangosol.util.aggregator.LongMax
- supply() - Method in class com.tangosol.util.aggregator.LongMin
- supply() - Method in class com.tangosol.util.aggregator.LongSum
- supply() - Method in class com.tangosol.util.aggregator.PriorityAggregator
- supply() - Method in class com.tangosol.util.aggregator.QueryRecorder
- supply() - Method in class com.tangosol.util.aggregator.ReducerAggregator
- supply() - Method in class com.tangosol.util.aggregator.ScriptAggregator
- supply() - Method in class com.tangosol.util.aggregator.TopNAggregator
- supply() - Method in interface com.tangosol.util.InvocableMap.StreamingAggregator
- 
Create a new instance of this aggregator.
- supports(Class<?>) - Method in class com.tangosol.config.expression.Value
- 
Determines if theValuesupports conversion/coercion to the specified type.
- SuspectConnectionException - Exception in com.tangosol.net.messaging
- 
Signals that an underlying communication channel used by a Connection may have been closed, severed, or become unusable because the suspect protocol has disconnected the client.
- SuspectConnectionException() - Constructor for exception com.tangosol.net.messaging.SuspectConnectionException
- 
Construct a SuspectConnectionException with no detail message.
- SuspectConnectionException(String) - Constructor for exception com.tangosol.net.messaging.SuspectConnectionException
- 
Construct a SuspectConnectionException with the specified detail message.
- SuspectConnectionException(String, Connection) - Constructor for exception com.tangosol.net.messaging.SuspectConnectionException
- 
Construct a SuspectConnectionException with the specified detail message and Connection.
- SuspectConnectionException(String, Throwable) - Constructor for exception com.tangosol.net.messaging.SuspectConnectionException
- 
Construct a SuspectConnectionException from a Throwable and an additional description.
- SuspectConnectionException(String, Throwable, Connection) - Constructor for exception com.tangosol.net.messaging.SuspectConnectionException
- 
Construct a SuspectConnectionException from a Throwable, additional description, and a Connection.
- SuspectConnectionException(Throwable) - Constructor for exception com.tangosol.net.messaging.SuspectConnectionException
- 
Construct a SuspectConnectionException from a Throwable.
- SuspectConnectionException(Throwable, Connection) - Constructor for exception com.tangosol.net.messaging.SuspectConnectionException
- 
Construct a SuspectConnectionException from a Throwable and Connection.
- suspend() - Method in class com.tangosol.io.IndentingWriter
- 
Suspends indentation.
- suspendService(String) - Method in interface com.tangosol.net.Cluster
- 
Suspend all members of the service identified by the specified name.
- SuspendServiceStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder.SuspendServiceStatement
- 
Create a SuspendServiceStatement that will suspend a service.
- SuspendServiceStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aSuspendServiceStatementBuilder.SuspendServiceStatement.
- SuspendServiceStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.SuspendServiceStatementBuilder
- SuspendServiceStatementBuilder.SuspendServiceStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "SUSPEND SERVICE" command.
- SYMBOLLITERAL - Static variable in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
The numberic code for a symbol literal
- sync() - Method in class com.tangosol.io.MultiBufferReadBuffer.MultiBufferInput
- 
After traversing an underlying WriteBuffer boundary, or otherwise changing the offset significantly, sync between this BufferOutput's absolute position and an underlying BufferOutput's relative position.
- sync() - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
After traversing an underlying WriteBuffer boundary, or otherwise changing the offset significantly, sync between this BufferOutput's absolute position and an underlying BufferOutput's relative position.
- syncAssignments(SimpleAssignmentStrategy.AnalysisContext, PartitionedService) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Update the analysis context to reflect the partition assignments of the specified associated service.
- Synced - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any SYNCED event.
- Synced.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theSyncedannotation.
- synchronous() - Method in interface com.tangosol.util.MapListener
- 
Make this MapListener synchronous.
- Synchronous - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation that can be applied toMapListenerCDI observers to register them asMapListener.synchronous()listeners.
- SYNCHRONOUS - Static variable in interface com.tangosol.util.MapListener
- 
A flag that indicates this MapListener should be fired synchronously.
- Synchronous.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theSynchronousannotation.
- SynchronousListener<K,V> - Interface in com.tangosol.util
- 
A tag interface indicating that a listener implementation has to receive the event notifications synchronously on the corresponding service's thread.
- Syncing - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any SYNCING event.
- Syncing.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theSyncingannotation.
- SYNTHETIC - Static variable in class com.tangosol.net.cache.CacheEvent
- 
Flag indicating whether or not the event is synthetic.
- SYS_CCF_URI - Static variable in class com.tangosol.net.Coherence
- 
The name of the System configuration uri.
- SYSTEM - com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
- SYSTEM - Static variable in annotation type com.oracle.coherence.cdi.Scope
- 
Predefined constant for system scope.
- SYSTEM_SCOPE - Static variable in class com.tangosol.net.Coherence
- 
The System scope name.
- SYSTEM_SESSION - Static variable in class com.tangosol.net.Coherence
- 
The System session name.
- SystemDatagramSocketProvider - Class in com.tangosol.net
- 
SystemDatagramSocketProvider produces JVM default datagram sockets
- SystemDatagramSocketProvider() - Constructor for class com.tangosol.net.SystemDatagramSocketProvider
- SystemEnvironmentParameterResolver - Class in com.tangosol.config.expression
- 
ASystemEnvironmentParameterResolveris aParameterResolverthat is an environment getter for Coherence environment properties implemented usingSystem.getenv(String).
- SystemEnvironmentParameterResolver() - Constructor for class com.tangosol.config.expression.SystemEnvironmentParameterResolver
- SystemPropertyParameterResolver - Class in com.tangosol.config.expression
- 
ASystemPropertyParameterResolveris aParameterResolverthat is based on property methods onSystem.
- SystemPropertyParameterResolver() - Constructor for class com.tangosol.config.expression.SystemPropertyParameterResolver
- SystemPropertyPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
ASystemPropertyPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat will replaceXmlElementcontent annotated with "system-property" attributes with appropriateSystem.getProperties().
- SystemPropertyPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.SystemPropertyPreprocessor
- SystemPropertyResolver - Interface in com.tangosol.coherence.config
- 
An abstraction that allows us to make system property resolution customizable.
- SystemPropertyResolver.Default - Class in com.tangosol.coherence.config
- 
DefaultSystemPropertyResolverimplementation.
- SystemTimeAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.SystemTimeAdapter
- 
Construct a SystemTimeAdapter, which formats a long number of milliseconds as a SQL Timestamp string for XML purposes.
T
- T_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- T_BOOLEAN - Static variable in interface com.tangosol.io.pof.PofConstants
- T_CHAR - Static variable in interface com.tangosol.io.pof.PofConstants
- T_CHAR_STRING - Static variable in interface com.tangosol.io.pof.PofConstants
- T_COLLECTION - Static variable in interface com.tangosol.io.pof.PofConstants
- T_DATE - Static variable in interface com.tangosol.io.pof.PofConstants
- T_DATETIME - Static variable in interface com.tangosol.io.pof.PofConstants
- T_DAY_TIME_INTERVAL - Static variable in interface com.tangosol.io.pof.PofConstants
- T_DECIMAL128 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_DECIMAL32 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_DECIMAL64 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_FLOAT128 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_FLOAT32 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_FLOAT64 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_IDENTITY - Static variable in interface com.tangosol.io.pof.PofConstants
- T_INT128 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_INT16 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_INT32 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_INT64 - Static variable in interface com.tangosol.io.pof.PofConstants
- T_MAP - Static variable in interface com.tangosol.io.pof.PofConstants
- T_OCTET - Static variable in interface com.tangosol.io.pof.PofConstants
- T_OCTET_STRING - Static variable in interface com.tangosol.io.pof.PofConstants
- T_REFERENCE - Static variable in interface com.tangosol.io.pof.PofConstants
- T_SPARSE_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- T_TIME - Static variable in interface com.tangosol.io.pof.PofConstants
- T_TIME_INTERVAL - Static variable in interface com.tangosol.io.pof.PofConstants
- T_UNIFORM_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- T_UNIFORM_COLLECTION - Static variable in interface com.tangosol.io.pof.PofConstants
- T_UNIFORM_KEYS_MAP - Static variable in interface com.tangosol.io.pof.PofConstants
- T_UNIFORM_MAP - Static variable in interface com.tangosol.io.pof.PofConstants
- T_UNIFORM_SPARSE_ARRAY - Static variable in interface com.tangosol.io.pof.PofConstants
- T_UNKNOWN - Static variable in interface com.tangosol.io.pof.PofConstants
- T_YEAR_MONTH_INTERVAL - Static variable in interface com.tangosol.io.pof.PofConstants
- tailBag(E) - Method in class com.tangosol.util.SortedBag
- 
Returns a view of the portion of this bag whose elements are greater than or equal to fromElement.
- tailBag(E) - Method in class com.tangosol.util.SortedBag.ViewBag
- 
Returns a view of the portion of this bag whose elements are greater than or equal to fromElement.
- tailMap(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedMap
- 
Returns a view of the portion of this sorted map whose keys are greater than or equal to fromKey.
- tailMap(Object) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- tailMap(Object) - Method in class com.tangosol.util.SafeSortedMap
- tailMap(Object, boolean) - Method in class com.tangosol.util.SafeSortedMap.SubMap
- tailMap(Object, boolean) - Method in class com.tangosol.util.SafeSortedMap
- tailMap(K) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedMap
- tailMap(TK) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedMap
- tailSet(E) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperSortedSet
- tailSet(Object) - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns a view of the portion of this sorted set whose elements are found in the set in a position at and after the position of fromElement.
- tailSet(Object) - Method in class com.tangosol.util.RestrictedCollections.RestrictedSortedSet
- 
Returns a view of the portion of this sorted set whose elements are greater than or equal to fromElement.
- tailSet(Object) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- tailSet(Object, boolean) - Method in class com.tangosol.util.SafeSortedMap.KeySet
- tailSet(T) - Method in class com.tangosol.util.ConverterCollections.ConverterSortedSet
- takeBackEvent() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Obtain the most recent back Map event that has occurred against the Entry for which this Status exists.
- takeBreak() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Take a short break before plowing into the pending work again.
- takeCurrentChar() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Add the current character to buffer that builds the current token.
- takeCurrentCharAndAdvance() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Add the current character to buffer that builds the current token and advance.
- takeEvent() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Obtain the most recent event that has occurred against the Entry for which this Status exists.
- takeEvent() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Obtain the most recent front Map event that has occurred against the Entry for which this Status exists.
- takeFrontEvent() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Obtain the most recent front Map event that has occurred against the Entry for which this Status exists.
- takeNap() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Take a nap before checking for more pending work.
- takeNextRipeTask() - Method in class com.tangosol.util.TaskDaemon
- 
Wait for the next scheduled task is ripe (due or overdue), then remove it from the pending schedule and return it.
- takeVacation() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Go on an extended vacation until there is any pending work.
- Task() - Constructor for class com.tangosol.persistence.AbstractPersistenceManager.Task
- Task(Event<S>, NonBlockingFiniteStateMachine.TaskDependencies) - Constructor for class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.Task
- 
Create a Task with given event.
- TaskDaemon - Class in com.tangosol.util
- 
A Daemon thread handler that asynchronously executes Runnable tasks, either at a scheduled time or "as soon as possible".
- TaskDaemon() - Constructor for class com.tangosol.util.TaskDaemon
- 
Default constructor.
- TaskDaemon(String) - Constructor for class com.tangosol.util.TaskDaemon
- 
Creates a TaskDaemon with the specified name.
- TaskDaemon(String, int, boolean) - Constructor for class com.tangosol.util.TaskDaemon
- 
Creates a TaskDaemon with a specified name and priority.
- TaskDaemon(String, int, boolean, boolean, int) - Constructor for class com.tangosol.util.TaskDaemon
- 
Creates a TaskDaemon with a specified name and priority.
- TaskDaemon.PeriodicTask - Class in com.tangosol.util
- 
A PeriodicTask is a task that automatically reschedules itself so that it executes on a periodic basis.
- TCP - com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
- TCPAcceptorPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
ATCPAcceptorPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat introduces re-writes <tcp-acceptor> configuration elements, in particular <local-address> declarations into an <address-provider> containing a <local-address>.
- TCPAcceptorPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.TCPAcceptorPreprocessor
- TcpAcceptorProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse an <tcp-acceptor> and produce a TcpAcceptorDependencies object.
- TcpAcceptorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.TcpAcceptorProcessor
- TcpDatagramSocket - Class in com.tangosol.net
- 
TCP based datagram socket implementation.
- TcpDatagramSocket() - Constructor for class com.tangosol.net.TcpDatagramSocket
- 
Create a new TcpDatagramSocket that with a wildcard address bound to an ephemeral port.
- TcpDatagramSocket(int) - Constructor for class com.tangosol.net.TcpDatagramSocket
- 
Creates a new TcpDatagramSocket using the wildcard address and the specified port.
- TcpDatagramSocket(int, InetAddress) - Constructor for class com.tangosol.net.TcpDatagramSocket
- 
Creates a new TcpDatagramSocket using anaddressand a port number.
- TcpDatagramSocket(SocketProvider) - Constructor for class com.tangosol.net.TcpDatagramSocket
- 
Creates a new TcpDatagramSocket using theprovider.
- TcpDatagramSocket(TcpDatagramSocket.Impl) - Constructor for class com.tangosol.net.TcpDatagramSocket
- 
Creates a new TcpDatagramSocket using anTcpDatagramSocket.Impl.
- TcpDatagramSocket(SocketAddress) - Constructor for class com.tangosol.net.TcpDatagramSocket
- 
Creates a new TcpDatagramSocket which will be bound to the specifiedaddress.
- TcpDatagramSocket.Impl - Class in com.tangosol.net
- 
A specialized version ofDatagramSocketImpl.
- TcpDatagramSocketProvider - Class in com.tangosol.net
- 
TcpDatagramSocketProvider produces datagram sockets that uses TCP sockets underneath for unicast communication.
- TcpDatagramSocketProvider() - Constructor for class com.tangosol.net.TcpDatagramSocketProvider
- 
Construct a TcpDatagramSocketProvider.
- TcpDatagramSocketProvider(TcpDatagramSocketProvider.Dependencies) - Constructor for class com.tangosol.net.TcpDatagramSocketProvider
- 
Construct a TcpDatagramSocketProvider
- TcpDatagramSocketProvider.DefaultDependencies - Class in com.tangosol.net
- 
DefaultDependenceis is a basic implementation of the Dependencies interface providing "setter" methods for each property.
- TcpDatagramSocketProvider.Dependencies - Interface in com.tangosol.net
- 
Dependencies specifies all dependency requirements of the TcpDatagramSocketProvider.
- TcpInitiatorProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat will parse an <tcp-initiator> and produce a TcpInitiatorDependencies object.
- TcpInitiatorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.TcpInitiatorProcessor
- TEMP_FILE_NAME_PREFIX - Static variable in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Prefix for temporary file names.
- Term - Class in com.tangosol.coherence.dsltools.termtrees
- 
Term is the abstract class used to represent trees of Terms (term-trees).
- Term() - Constructor for class com.tangosol.coherence.dsltools.termtrees.Term
- Term.TermIterator - Class in com.tangosol.coherence.dsltools.termtrees
- termAt(int) - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Obtain the child term at the given index.
- termAt(int) - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Obtain the child term at the given index.
- termAt(int) - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Obtain the child term at the given index.
- termEqual(Term) - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Answer whether the receiver is equal to the given Term.
- termEqual(Term) - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Answer whether the receiver is equal to the given Term.
- termEqual(Term) - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Answer whether the receiver is equal to the given Term.
- terminate() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadThread
- 
Terminate this Guardable.
- terminate() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.WriteThread
- 
Terminate this Guardable.
- terminate() - Method in interface com.tangosol.net.Guardable
- 
Terminate this Guardable.
- terminate() - Method in class com.tangosol.util.Daemon
- 
Terminate this Guardable.
- terminateReadThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Terminate the refresh-ahead thread.
- terminateWriteThread() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Terminate the write-behind thread.
- TermIterator(Term) - Constructor for class com.tangosol.coherence.dsltools.termtrees.Term.TermIterator
- TermLanguage - Class in com.tangosol.coherence.dsltools.termlanguage
- 
TermLanguage is a simple language for building Terms.
- TermLanguage() - Constructor for class com.tangosol.coherence.dsltools.termlanguage.TermLanguage
- Terms - Class in com.tangosol.coherence.dsltools.termtrees
- 
Terms is a utility class that provides static convenience methods for the construction of Terms.
- Terms() - Constructor for class com.tangosol.coherence.dsltools.termtrees.Terms
- TermWalker - Interface in com.tangosol.coherence.dsltools.termtrees
- 
TermWalker is a visitor class that provides a framework for walking Term Trees
- thenComparing(Remote.Comparator<? super T>) - Method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a lexicographic-order comparator with another comparator.
- thenComparing(Remote.Function<? super T, ? extends U>) - Method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a lexicographic-order comparator with a function that extracts aComparablesort key.
- thenComparing(Remote.Function<? super T, ? extends U>, Remote.Comparator<? super U>) - Method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a lexicographic-order comparator with a function that extracts a key to be compared with the givenComparator.
- thenComparingDouble(Remote.ToDoubleFunction<? super T>) - Method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a lexicographic-order comparator with a function that extracts adoublesort key.
- thenComparingInt(Remote.ToIntFunction<? super T>) - Method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a lexicographic-order comparator with a function that extracts aintsort key.
- thenComparingLong(Remote.ToLongFunction<? super T>) - Method in interface com.tangosol.util.function.Remote.Comparator
- 
Returns a lexicographic-order comparator with a function that extracts alongsort key.
- thread() - Static method in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
Return the order that will ensure that all operations invoked from the same client thread are executed on the server sequentially, using the sameunit-of-order.
- thread() - Static method in class com.tangosol.net.topic.Publisher.OrderBy
- 
Return an OrderBy that will ensure that allvalues sentfrom the same thread are stored sequentially.
- THREAD - Static variable in class com.tangosol.net.AsyncNamedMap.OrderBy
- 
The thread-order singleton.
- ThreadFactory - Interface in com.tangosol.util
- 
Factory interface for Thread creation.
- ThreadGate<R> - Class in com.tangosol.util
- 
A thin extension ofThreadGate.
- ThreadGate() - Constructor for class com.tangosol.util.ThreadGate
- 
Default constructor.
- ThreadGate(R) - Constructor for class com.tangosol.util.ThreadGate
- 
Construct a gate protecting the specified resource.
- ThreadGateLite<R> - Class in com.tangosol.util
- 
ThreadGateLite is a Gate implementation built around theReentrantReadWriteLock.
- ThreadGateLite() - Constructor for class com.tangosol.util.ThreadGateLite
- 
Default constructor.
- ThreadGateLite(R) - Constructor for class com.tangosol.util.ThreadGateLite
- 
Construct a ThreadGateLite protected the specified resource.
- ThreadGateLite.Bar - Class in com.tangosol.util
- 
Bar represents the state of thebarsplaced on this gate.
- ThreadLocalObject - Class in com.tangosol.util
- 
This class provides an implementation of thread local storage.
- ThreadLocalObject() - Constructor for class com.tangosol.util.ThreadLocalObject
- 
Create a ThreadLocalObject.
- ThreadLocalObject(Object) - Constructor for class com.tangosol.util.ThreadLocalObject
- 
Create a ThreadLocalObject with an initial value.
- ThreadPoolManager - Interface in com.tangosol.net
- 
A ThreadPoolManager manages the thread pool information for a Coherence service thread pool.
- ThreadPoolSizingStrategy - Interface in com.tangosol.net
- 
A ThreadPoolSizingStrategy is a pluggable strategy used by a Coherence service thread pool to manage its size.
- THROW_EXCEPTION - com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor.EmptyElementBehavior
- 
When an emptyXmlElementis encountered, raise aConfigurationException.
- ThrowablePofSerializer - Class in com.tangosol.io.pof
- ThrowablePofSerializer() - Constructor for class com.tangosol.io.pof.ThrowablePofSerializer
- 
Default constructor.
- throwIfFatal(Throwable) - Static method in class com.oracle.coherence.common.base.Exceptions
- 
Re-throw the specified exception if it is a fatal unrecoverable exception.
- throwing(Class<?>, String, Throwable, Object...) - Static method in class com.oracle.coherence.common.base.Logger
- 
Throwable logging.
- throwingMerger() - Static method in class com.tangosol.util.aggregator.GroupAggregator
- TIER - Static variable in class com.tangosol.net.management.MBeanAccessor
- 
The "tier" key in the ObjectName.
- TIME - com.tangosol.io.pof.DateMode
- TimeAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.TimeAdapter
- 
Construct a SimpleAdapter.
- TimeHelper - Class in com.oracle.coherence.common.base
- 
Class for providing time functionality.
- TimeHelper() - Constructor for class com.oracle.coherence.common.base.TimeHelper
- Timeout - Class in com.oracle.coherence.common.base
- 
Timeout provides a mechanism for allowing a thread to interrupt itself if it doesn't return to a specific call site within a given timeout.
- Timeout(long, boolean) - Constructor for class com.oracle.coherence.common.base.Timeout
- 
Specify a new timeout.
- TIMEOUT_DEFAULT - Static variable in interface com.tangosol.net.PriorityTask
- 
A special timeout value to indicate that the corresponding service's default timeout value should be used.
- TIMEOUT_NONE - Static variable in interface com.tangosol.net.PriorityTask
- 
A special timeout value to indicate that this task or request can run indefinitely.
- TimestampAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- 
Construct a SimpleAdapter.
- tmpbuf() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Get a small buffer for formating data to bytes.
- tmpbuf(int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Get a buffer for formating data to bytes.
- toArray() - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
- 
Returns an array containing all of the elements in this collection.
- toArray() - Method in class com.tangosol.io.nio.BinaryMap.KeySet
- 
Returns an array containing all of the keys in this set.
- toArray() - Method in class com.tangosol.io.nio.BinaryMap.ValuesCollection
- 
Returns an array containing all of the values in the Collection.
- toArray() - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- toArray() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- 
Returns an array containing all of the elements in this collection.
- toArray() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- 
Returns an array containing all of the keys in this set.
- toArray() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ValuesCollection
- 
Returns an array containing all of the keys in this collection.
- toArray() - Method in class com.tangosol.net.partition.PartitionSet
- 
Convert the partition set to an array of partition identifiers.
- toArray() - Method in class com.tangosol.util.AbstractKeySetBasedMap.EntrySet
- toArray() - Method in class com.tangosol.util.AbstractKeySetBasedMap.KeySet
- toArray() - Method in class com.tangosol.util.AbstractKeySetBasedMap.ValuesCollection
- toArray() - Method in class com.tangosol.util.ChainedCollection
- toArray() - Method in class com.tangosol.util.ChainedMap.EntrySet
- 
Returns an array containing all of the elements in this collection.
- toArray() - Method in class com.tangosol.util.ChainedSet
- toArray() - Method in class com.tangosol.util.CircularArrayList
- toArray() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- toArray() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- toArray() - Method in class com.tangosol.util.DeltaSet
- 
Returns an array containing all of the elements in this Set.
- toArray() - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns an array containing all of the elements in this List in the order that the elements occur in the List.
- toArray() - Method in class com.tangosol.util.ImmutableMultiList
- 
Returns an array containing all of the elements in this List in the order that the elements occur in the List.
- toArray() - Method in class com.tangosol.util.InflatableCollection
- toArray() - Method in class com.tangosol.util.LiteSet
- 
Returns an array containing all of the elements in this Set.
- toArray() - Method in class com.tangosol.util.MapSet
- 
Returns an array containing all of the elements in this Set.
- toArray() - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Returns an array containing all of the elements in this Set.
- toArray() - Method in class com.tangosol.util.OpenHashMap.EntrySet
- toArray() - Method in class com.tangosol.util.OpenHashMap.KeySet
- toArray() - Method in class com.tangosol.util.OpenHashSet
- toArray() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Returns an array containing all of the elements in this Collection.
- toArray() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Returns an array containing all of the elements in this Collection.
- toArray() - Method in class com.tangosol.util.SafeHashMap.EntrySet
- 
Returns an array containing all of the elements in this collection.
- toArray() - Method in class com.tangosol.util.SafeHashMap.KeySet
- 
Returns an array containing all of the keys in this set.
- toArray() - Method in class com.tangosol.util.SafeHashMap.ValuesCollection
- 
Returns an array containing all of the values in the Collection.
- toArray() - Method in class com.tangosol.util.SafeLinkedList
- 
Returns an array containing all of the elements in this List in the order that the elements occur in the List.
- toArray() - Method in class com.tangosol.util.SafeSortedMap.Values
- toArray() - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
- 
Returns an array containing all of the elements in this collection.
- toArray() - Method in class com.tangosol.util.SegmentedHashMap.KeySet
- 
Returns an array containing all of the keys in this set.
- toArray() - Method in class com.tangosol.util.SegmentedHashMap.ValuesCollection
- 
Returns an array containing all of the values in the Collection.
- toArray() - Method in class com.tangosol.util.SimpleEnumerator
- 
Return the remaining contents of this SimpleEnumerator as an array.
- toArray() - Method in interface com.tangosol.util.stream.RemoteDoubleStream
- 
Returns an array containing the elements of this stream.
- toArray() - Method in interface com.tangosol.util.stream.RemoteIntStream
- 
Returns an array containing the elements of this stream.
- toArray() - Method in interface com.tangosol.util.stream.RemoteLongStream
- 
Returns an array containing the elements of this stream.
- toArray() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns an array containing the elements of this stream.
- toArray() - Method in class com.tangosol.util.SubList
- toArray() - Method in class com.tangosol.util.SubSet
- toArray() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- toArray() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- toArray(E[]) - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- toArray(Object[]) - Method in class com.tangosol.io.nio.BinaryMap.EntrySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the keys in this Set.
- toArray(Object[]) - Method in class com.tangosol.io.nio.BinaryMap.KeySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the keys in this Set.
- toArray(Object[]) - Method in class com.tangosol.io.nio.BinaryMap.ValuesCollection
- 
Returns an array with a runtime type is that of the specified array and that contains all of the values in the Collection.
- toArray(Object[]) - Method in class com.tangosol.net.cache.OldCache.EntrySet
- 
Deprecated.Returns an array with a runtime type is that of the specified array and that contains all of the elements in this collection.
- toArray(Object[]) - Method in class com.tangosol.net.cache.OldCache.KeySet
- 
Deprecated.Returns an array with a runtime type is that of the specified array and that contains all of the elements in this collection.
- toArray(Object[]) - Method in class com.tangosol.net.cache.OldCache.ValuesCollection
- 
Deprecated.Returns an array with a runtime type is that of the specified array and that contains all of the elements in this collection.
- toArray(Object[]) - Method in class com.tangosol.net.cache.OverflowMap.InternalKeySet
- toArray(Object[]) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.EntrySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the elements in this collection.
- toArray(Object[]) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.KeySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the keys in this Set.
- toArray(Object[]) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ValuesCollection
- 
Returns an array with a runtime type is that of the specified array and that contains all of the keys in this Collection.
- toArray(Object[]) - Method in class com.tangosol.util.AbstractKeySetBasedMap.EntrySet
- toArray(Object[]) - Method in class com.tangosol.util.AbstractKeySetBasedMap.KeySet
- toArray(Object[]) - Method in class com.tangosol.util.AbstractKeySetBasedMap.ValuesCollection
- toArray(Object[]) - Method in class com.tangosol.util.ChainedMap.EntrySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the elements in this collection.
- toArray(Object[]) - Method in class com.tangosol.util.CircularArrayList
- toArray(Object[]) - Method in class com.tangosol.util.ImmutableArrayList
- 
Returns an array with ao runtime type is that of the specified array and that contains all of the elements in this List.
- toArray(Object[]) - Method in class com.tangosol.util.ImmutableMultiList
- 
Returns an array with ao runtime type is that of the specified array and that contains all of the elements in this List.
- toArray(Object[]) - Method in class com.tangosol.util.InflatableCollection
- toArray(Object[]) - Method in class com.tangosol.util.LiteSet
- 
Returns an array (whose runtime type is that of the specified array) containing all of the elements in this Set.
- toArray(Object[]) - Method in class com.tangosol.util.MapSet
- 
Returns an array containing all of the elements in this set whose runtime type is that of the specified array.
- toArray(Object[]) - Method in class com.tangosol.util.OpenHashMap.EntrySet
- toArray(Object[]) - Method in class com.tangosol.util.OpenHashMap.KeySet
- toArray(Object[]) - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Returns an array containing all of the elements in this Collection whose runtime type is that of the specified array.
- toArray(Object[]) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Returns an array containing all of the elements in this Collection whose runtime type is that of the specified array.
- toArray(Object[]) - Method in class com.tangosol.util.SafeLinkedList
- 
Returns an array with a runtime type is that of the specified array and that contains all of the elements in this List.
- toArray(Object[]) - Method in class com.tangosol.util.SegmentedHashMap.EntrySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the elements in this collection.
- toArray(Object[]) - Method in class com.tangosol.util.SegmentedHashMap.KeySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the keys in this Set.
- toArray(Object[]) - Method in class com.tangosol.util.SegmentedHashMap.ValuesCollection
- 
Returns an array with a runtime type is that of the specified array and that contains all of the values in the Collection.
- toArray(Object[]) - Method in class com.tangosol.util.SubSet
- toArray(Object[], Converter) - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns an array with a runtime type is that of the specified array and that contains data from all of the entries in this Map.
- toArray(Enumeration) - Static method in class com.tangosol.util.SortedEnumerator
- 
Return the contents of the passed Enumeration as a sorted array.
- toArray(Enumeration<T>) - Static method in class com.tangosol.util.SimpleEnumerator
- 
Turns an enumeration into an array.
- toArray(Enumeration<T>, T[]) - Static method in class com.tangosol.util.SimpleEnumerator
- 
Turns an enumeration into an array.
- toArray(IntFunction<A[]>) - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns an array containing the elements of this stream, using the providedgeneratorfunction to allocate the returned array, as well as any additional arrays that might be required for a partitioned execution or for resizing.
- toArray(IntFunction<T[]>) - Method in class com.tangosol.util.ChainedCollection
- toArray(IntFunction<T[]>) - Method in class com.tangosol.util.ChainedSet
- toArray(Iterator) - Static method in class com.tangosol.util.SortedEnumerator
- 
Return the contents of the passed Iterator as a sorted array.
- toArray(Iterator<T>) - Static method in class com.tangosol.util.SimpleEnumerator
- 
Turns an Iterator into an array.
- toArray(Iterator<T>, T[]) - Static method in class com.tangosol.util.SimpleEnumerator
- 
Turns an Iterator into an array.
- toArray(T[]) - Method in class com.tangosol.util.ChainedCollection
- toArray(T[]) - Method in class com.tangosol.util.ChainedSet
- toArray(T[]) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- toArray(T[]) - Method in class com.tangosol.util.OpenHashSet
- toArray(T[]) - Method in class com.tangosol.util.SafeHashMap.EntrySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the elements in this collection.
- toArray(T[]) - Method in class com.tangosol.util.SafeHashMap.KeySet
- 
Returns an array with a runtime type is that of the specified array and that contains all of the keys in this Set.
- toArray(T[]) - Method in class com.tangosol.util.SafeHashMap.ValuesCollection
- 
Returns an array with a runtime type is that of the specified array and that contains all of the values in the Collection.
- toArray(T[]) - Method in class com.tangosol.util.SimpleEnumerator
- 
Return the remaining contents of this SimpleEnumerator as an array of the type specified by the passed array, and use that passed array to store the values if it is big enough, putting a null in the first unused element if the size of the passed array is bigger than the number of remaining elements in this enumerator, as per the contract of theCollection.toArray(Object[])method.
- toArray(T[]) - Method in class com.tangosol.util.SubList
- toArray(T[]) - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- toArray(T[]) - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- toArrayInternal(SegmentedHashMap.IterableEntryAction, Object[]) - Method in class com.tangosol.util.SegmentedHashMap
- 
Apply the specified toArray() action to the entries in the map.
- toBandwidthString(long) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the passed bandwidth (in bytes per second) as a String that can be parsed byFormatting.parseBandwidth(java.lang.String)such that cb==parseBandwidth(toBandwidthString(cb)) holds true for all legal values of cbps.
- toBandwidthString(long) - Static method in class com.tangosol.util.Base
- 
Format the passed bandwidth (in bytes per second) as a String that can be parsed byBase.parseBandwidth(java.lang.String)such that cb==parseBandwidth(toBandwidthString(cb)) holds true for all legal values of cbps.
- toBandwidthString(long, boolean) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the passed bandwidth (in bytes per second) as a String.
- toBandwidthString(long, boolean) - Static method in class com.tangosol.util.Base
- 
Format the passed bandwidth (in bytes per second) as a String.
- toBinary() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Return a new Binary object that holds the complete contents of this ReadBuffer.
- toBinary() - Method in class com.tangosol.io.AbstractReadBuffer
- 
Return a new Binary object that holds the complete contents of this ReadBuffer.
- toBinary() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Returns a new Binary object that holds the complete contents of this WriteBuffer.
- toBinary() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Returns a new Binary object that holds the complete contents of this WriteBuffer.
- toBinary() - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Returns a new Binary object that holds the complete contents of this WriteBuffer.
- toBinary() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Returns a new Binary object that holds the complete contents of this WriteBuffer.
- toBinary() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Returns a new Binary object that holds the complete contents of this WriteBuffer.
- toBinary() - Method in interface com.tangosol.io.ReadBuffer
- 
Return a new Binary object that holds the complete contents of this ReadBuffer.
- toBinary() - Method in interface com.tangosol.io.WriteBuffer
- 
Returns a new Binary object that holds the complete contents of this WriteBuffer.
- toBinary() - Method in class com.tangosol.util.AbstractByteSequence
- 
Returns a Binary object that holds the contents of this ByteSequence.
- toBinary() - Method in class com.tangosol.util.Binary
- 
Return a new Binary object that holds the complete contents of this ReadBuffer.
- toBinary() - Method in class com.tangosol.util.BinaryWriteBuffer
- 
Returns a new Binary object that holds the complete contents of this WriteBuffer.
- toBinary() - Method in interface com.tangosol.util.ByteSequence
- 
Returns a Binary object that holds the contents of this ByteSequence.
- toBinary(int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Return a Binary object that holds the specified portion of this ReadBuffer.
- toBinary(int, int) - Method in class com.tangosol.io.AbstractReadBuffer
- 
Return a Binary object that holds the specified portion of this ReadBuffer.
- toBinary(int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Return a Binary object that holds the specified portion of this ReadBuffer.
- toBinary(int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Return a Binary object that holds the specified portion of this ReadBuffer.
- toBinary(int, int) - Method in interface com.tangosol.io.ReadBuffer
- 
Return a Binary object that holds the specified portion of this ReadBuffer.
- toBinary(int, int) - Method in class com.tangosol.util.Binary
- 
Return a Binary object that holds the specified portion of this ReadBuffer.
- toBinary(ByteString) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Convert aByteStringto aBinary.
- toBinary(BytesValue) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Convert aBytesValueto aBinary.
- toBinary(Object) - Method in class com.tangosol.net.cache.BinaryStoreCacheStore
- 
Translate the passed Object object into an Binary object.
- toBinary(Object) - Method in class com.tangosol.net.cache.SerializationMap
- 
Translate the passed Object object into an Binary object.
- toBinary(Object) - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Translate the passed Object object into an Binary object.
- toBinary(Object) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an object into a Binary object.
- toBinary(Object, Serializer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an object into a Binary object using the specified Serializer.
- toBinary(Object, Serializer, WriteBuffer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an object into a Binary object using the specified Serializer.
- toBitString(byte) - Static method in class com.tangosol.util.BitHelper
- 
Convert a byte to a String of ones and zeros.
- toBitString(int) - Static method in class com.tangosol.util.BitHelper
- 
Convert an int to a String of ones and zeros.
- toBitString(long) - Static method in class com.tangosol.util.BitHelper
- 
Convert a long to a String of ones and zeros.
- toBooleanArray(String) - Static method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- toBoolValue(Binary, Serializer) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Deserialize aBinaryto a boolean value.
- toBoxedTypeField(String) - Static method in class com.oracle.coherence.common.base.Classes
- 
Provide a boxed version of the given primitive in binary format.
- toByteArray() - Method in class com.tangosol.io.AbstractReadBuffer
- 
Get the contents of the ReadBuffer as a byte array.
- toByteArray() - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Returns a new byte array that holds the complete contents of this WriteBuffer.
- toByteArray() - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Returns a new byte array that holds the complete contents of this WriteBuffer.
- toByteArray() - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Returns a new byte array that holds the complete contents of this WriteBuffer.
- toByteArray() - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Returns a new byte array that holds the complete contents of this WriteBuffer.
- toByteArray() - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Returns a new byte array that holds the complete contents of this WriteBuffer.
- toByteArray() - Method in interface com.tangosol.io.ReadBuffer
- 
Get the contents of the ReadBuffer as a byte array.
- toByteArray() - Method in class com.tangosol.io.Utf8Writer
- 
If the underlying stream is a ByteArrayOutputStream (such as with the no-parameter constructor), this will return the binary UTF8-encoded data that resulted from the character data written to this Writer.
- toByteArray() - Method in interface com.tangosol.io.WriteBuffer
- 
Returns a new byte array that holds the complete contents of this WriteBuffer.
- toByteArray() - Method in class com.tangosol.util.UID
- 
Convert the UID to a byte array of 16 bytes.
- toByteArray() - Method in class com.tangosol.util.UUID
- 
Convert the UUID to a byte array of 32 bytes.
- toByteArray(int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Get a portion of the contents of the ReadBuffer as a byte array.
- toByteArray(int, int) - Method in class com.tangosol.io.AbstractReadBuffer
- 
Get a portion of the contents of the ReadBuffer as a byte array.
- toByteArray(int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Get a portion of the contents of the ReadBuffer as a byte array.
- toByteArray(int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Get a portion of the contents of the ReadBuffer as a byte array.
- toByteArray(int, int) - Method in interface com.tangosol.io.ReadBuffer
- 
Get a portion of the contents of the ReadBuffer as a byte array.
- toByteArray(long, byte[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Convert a long to an 8-byte byte array.
- toByteArray(Object) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an object to a byte array.
- toByteArray(Object, Serializer) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an object to a byte array using the specified Serializer.
- toByteBuffer() - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Return a read-only ByteBuffer view of this ReadBuffer.
- toByteBuffer() - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Return a read-only ByteBuffer view of this ReadBuffer.
- toByteBuffer() - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Return a read-only ByteBuffer view of this ReadBuffer.
- toByteBuffer() - Method in interface com.tangosol.io.ReadBuffer
- 
Return a read-only ByteBuffer view of this ReadBuffer.
- toByteBuffer(int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Return a read-only ByteBuffer view of the specified portion of this ReadBuffer.
- toByteBuffer(int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Return a read-only ByteBuffer view of the specified portion of this ReadBuffer.
- toByteBuffer(int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Return a read-only ByteBuffer view of the specified portion of this ReadBuffer.
- toByteBuffer(int, int) - Method in interface com.tangosol.io.ReadBuffer
- 
Return a read-only ByteBuffer view of the specified portion of this ReadBuffer.
- toBytes(int) - Static method in class com.tangosol.util.BitHelper
- 
Convert the specified int into a byte array containing a series of eight bytes in big-endian form (MSB first).
- toBytes(int, byte[], int) - Static method in class com.tangosol.util.BitHelper
- 
Convert the specified int into a series of eight bytes, and write them to the specified byte-array in big-endian form (MSB first).
- toBytes(long) - Static method in class com.tangosol.util.BitHelper
- 
Convert the specified long into a byte array containing a series of eight bytes in big-endian form (MSB first).
- toBytes(long, byte[], int) - Static method in class com.tangosol.util.BitHelper
- 
Convert the specified long into a series of eight bytes, and write them to the specified byte-array in big-endian form (MSB first).
- toByteString(Binary) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Convert aBinaryto aByteString.
- toByteString(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Convert theBinaryserialized in the cache's serialization format to aByteStringserialized in the request's serialization format.
- toByteString(Object, Serializer) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Serialize the specified value to aByteString.
- toBytesValue(Binary) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Convert aBinaryto aBytesValue.
- toBytesValue(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- 
Convert theBinaryserialized in the cache's serialization format to aBytesValueserialized in the request's serialization format.
- toBytesValue(Object, Serializer) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Serialize the specified value to aBytesValue.
- toCharArray() - Method in class com.tangosol.util.UID
- 
Convert the UID to a character array of 32 hex digits.
- toCharEscape(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format a char to a printable escape if necessary.
- toCharEscape(char) - Static method in class com.tangosol.util.Base
- 
Format a char to a printable escape if necessary.
- toCollection(Remote.Supplier<C>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newCollection, in encounter order.
- toCrc(byte[]) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Calculate a CRC32 value from a byte array.
- toCrc(byte[]) - Static method in class com.tangosol.util.Base
- 
Calculate a CRC32 value from a byte array.
- toCrc(byte[], int, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Calculate a CRC32 value from a portion of a byte array.
- toCrc(byte[], int, int) - Static method in class com.tangosol.util.Base
- 
Calculate a CRC32 value from a portion of a byte array.
- toCrc(byte[], int, int, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Continue to calculate a CRC32 value from a portion of a byte array.
- toCrc(byte[], int, int, int) - Static method in class com.tangosol.util.Base
- 
Continue to calculate a CRC32 value from a portion of a byte array.
- toCrc(ByteSequence) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Calculate a CRC32 value from a ByteSequence.
- toCrc(ByteSequence) - Static method in class com.tangosol.util.Base
- 
Calculate a CRC32 value from a ByteSequence.
- toCrc(ByteSequence, int, int, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Continue to calculate a CRC32 value from a portion of a ByteSequence .
- toCrc(ByteSequence, int, int, int) - Static method in class com.tangosol.util.Base
- 
Continue to calculate a CRC32 value from a portion of a ByteSequence .
- toDecString(int, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the passed non-negative integer as a fixed-length decimal string.
- toDecString(int, int) - Static method in class com.tangosol.util.Base
- 
Format the passed non-negative integer as a fixed-length decimal string.
- toDelimitedString(int[], String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the content of the passed integer array as a delimited string.
- toDelimitedString(int[], String) - Static method in class com.tangosol.util.Base
- 
Format the content of the passed integer array as a delimited string.
- toDelimitedString(long[], String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the content of the passed long array as a delimited string.
- toDelimitedString(long[], String) - Static method in class com.tangosol.util.Base
- 
Format the content of the passed long array as a delimited string.
- toDelimitedString(Object[], String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the content of the passed Object array as a delimited string.
- toDelimitedString(Object[], String) - Static method in class com.tangosol.util.Base
- 
Format the content of the passed Object array as a delimited string.
- toDelimitedString(Iterator<?>, String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the content of the passed Iterator as a delimited string.
- toDelimitedString(Iterator<?>, String) - Static method in class com.tangosol.util.Base
- 
Format the content of the passed Iterator as a delimited string.
- toDoubleBiFunction(Remote.ToDoubleBiFunction<T, U>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ToDoubleBiFunction.
- toDoubleFunction(Remote.ToDoubleFunction<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ToDoubleFunction.
- toDoubleStream(RemoteStream<T>) - Static method in interface com.tangosol.util.stream.RemoteStream
- 
Convert stream of numbers intoRemoteDoubleStream.
- toEntry(ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Create anEntrycontaining the specified key and value.
- toEntry(Binary, Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- toEntry(Map.Entry<?, ?>, Serializer) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Create anEntryfrom aMap.Entry.
- toEntryList(Map<?, ?>, Serializer) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Create aMapto a list ofEntryinstances.
- toEntryResult(Map.Entry<Binary, Binary>) - Method in class com.oracle.coherence.grpc.RequestHolder
- toExpression() - Method in class com.tangosol.util.filter.AlwaysFilter
- toExpression() - Method in class com.tangosol.util.filter.ArrayFilter
- toExpression() - Method in class com.tangosol.util.filter.BetweenFilter
- toExpression() - Method in class com.tangosol.util.filter.ComparisonFilter
- toExpression() - Method in class com.tangosol.util.filter.InKeySetFilter
- toExpression() - Method in class com.tangosol.util.filter.IsNotNullFilter
- toExpression() - Method in class com.tangosol.util.filter.IsNullFilter
- toExpression() - Method in class com.tangosol.util.filter.NeverFilter
- toExpression() - Method in class com.tangosol.util.filter.NotFilter
- toExpression() - Method in class com.tangosol.util.filter.PresentFilter
- toExpression() - Method in interface com.tangosol.util.Filter
- 
Return a string expression for this filter.
- toExternalUnits(long, int) - Static method in class com.oracle.coherence.caffeine.CaffeineCache
- 
Convert from an internal 64-bit unit value to an external 32-bit unit value using the configured units factor.
- toExternalUnits(long, int) - Static method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Convert from an internal 64-bit unit value to an external 32-bit unit value using the configured units factor.
- toFilename(String) - Static method in class com.tangosol.io.FileHelper
- 
Given a string, return a derivative version that is safe to use for a filename.
- toHex(byte[]) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Convert a byte array to the hex sequence of 2 hex digits per byte.
- toHex(byte[]) - Static method in class com.tangosol.util.Base
- 
Convert a byte array to the hex sequence of 2 hex digits per byte.
- toHex(int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Convert a byte to the hex sequence of 2 hex digits.
- toHex(int) - Static method in class com.tangosol.util.Base
- 
Convert a byte to the hex sequence of 2 hex digits.
- toHexDump(byte[], int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Convert a byte array to a hex dump.
- toHexDump(byte[], int) - Static method in class com.tangosol.util.Base
- 
Convert a byte array to a hex dump.
- toHexEscape(byte) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Convert a byte to a hex sequence of '0' + 'x' + 2 hex digits.
- toHexEscape(byte) - Static method in class com.tangosol.util.Base
- 
Convert a byte to a hex sequence of '0' + 'x' + 2 hex digits.
- toHexEscape(byte[]) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Convert a byte array to a hex sequence of '0' + 'x' + 2 hex digits per byte.
- toHexEscape(byte[]) - Static method in class com.tangosol.util.Base
- 
Convert a byte array to a hex sequence of '0' + 'x' + 2 hex digits per byte.
- toHexEscape(byte[], int, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Convert a byte array to a hex sequence of '0' + 'x' + 2 hex digits per byte.
- toHexEscape(byte[], int, int) - Static method in class com.tangosol.util.Base
- 
Convert a byte array to a hex sequence of '0' + 'x' + 2 hex digits per byte.
- toHexEscape(ByteSequence, int, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Convert a ByteSequence to a hex sequence of '0' + 'x' + 2 hex digits per byte.
- toHexEscape(ByteSequence, int, int) - Static method in class com.tangosol.util.Base
- 
Convert a ByteSequence to a hex sequence of '0' + 'x' + 2 hex digits per byte.
- toHexString(int, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the passed integer as a fixed-length hex string.
- toHexString(int, int) - Static method in class com.tangosol.util.Base
- 
Format the passed integer as a fixed-length hex string.
- toInt() - Method in enum com.tangosol.util.aggregator.QueryRecorder.RecordType
- 
Convert an RecordType to an integer.
- toInt(byte[]) - Static method in class com.tangosol.util.BitHelper
- 
Return the int represented by the sequence of eight bytes (in big-endian form) in the specified byte-array.
- toInt(byte[], int) - Static method in class com.tangosol.util.BitHelper
- 
Return the int represented by the sequence of eight bytes (in big-endian form) in the specified byte-array starting at the given offset.
- toInt32Value(Object) - Static method in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
Convert a value to anInt32Value.
- toIntBiFunction(Remote.ToIntBiFunction<T, U>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ToIntBiFunction.
- toInternal(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Serialize the provided value into aBinary.
- toInternal(T) - Method in class com.tangosol.coherence.jcache.common.CoherenceConverterAdapter
- toInternal(T) - Method in interface com.tangosol.coherence.jcache.common.InternalConverter
- 
Converts a value to an internal representation.
- toInternal(T) - Method in class com.tangosol.coherence.jcache.common.ReferenceInternalConverter
- toInternal(T) - Method in class com.tangosol.coherence.jcache.common.SerializingInternalConverter
- toInternalUnits(int, int) - Static method in class com.oracle.coherence.caffeine.CaffeineCache
- 
Convert from an external 32-bit unit value to an internal 64-bit unit value using the configured units factor.
- toInternalUnits(int, int) - Static method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Convert from an external 32-bit unit value to an internal 64-bit unit value using the configured units factor.
- toIntFunction(Remote.ToIntFunction<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ToIntFunction.
- toIntStream(RemoteStream<T>) - Static method in interface com.tangosol.util.stream.RemoteStream
- 
Convert stream of numbers intoRemoteIntStream.
- toJavaDate() - Method in class com.tangosol.io.pof.RawDate
- 
Create a Java Date from the raw date information.
- toJavaDate() - Method in class com.tangosol.io.pof.RawDateTime
- 
Create a Java Date from the raw date/time information.
- toJavaDate() - Method in class com.tangosol.io.pof.RawTime
- 
Create a Java Date from the raw time information.
- Token(Collector<Object>, Object) - Constructor for class com.tangosol.util.NullImplementation.NullPersistentStore.Token
- 
Construct a new Token.
- tokenString() - Method in class com.tangosol.coherence.dsltools.base.BaseTokenScanner
- 
Convert the buffered characters into a String representing a token.
- tokenTable() - Static method in class com.tangosol.coherence.dsltools.termlanguage.TermLanguage
- 
Return an initialized TokenTable for the Term Language.
- TokenTable - Class in com.tangosol.coherence.dsltools.precedence
- 
TokenTable is a helper class used by Scanners to convert BaseTokens to to OPTokens.
- TokenTable() - Constructor for class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Construct a new OPToken.
- TokenTable(String, String) - Constructor for class com.tangosol.coherence.dsltools.precedence.TokenTable
- 
Construct a new TokenTable with the given parameters to set the ast names for identifiers and literals.
- toKeyByteString(Binary, Object, Serializer) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- toList() - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newList.
- toLiteBinary(ExternalizableLite) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an ExternalizableLite object into a Binary object.
- toLocalDate() - Method in class com.tangosol.io.pof.RawDate
- 
Create a LocalDate from the raw date information.
- toLocalDateTime() - Method in class com.tangosol.io.pof.RawDateTime
- 
Create a LocalDateTime from the raw date/time information.
- toLocalTime() - Method in class com.tangosol.io.pof.RawTime
- 
Create a LocalTime from the raw time information.
- toLong(byte[]) - Static method in class com.tangosol.util.BitHelper
- 
Return the long represented by the sequence of eight bytes (in big-endian form) in the specified byte-array.
- toLong(byte[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Convert a byte array to a long.
- toLong(byte[], int) - Static method in class com.tangosol.util.BitHelper
- 
Return the long represented by the sequence of eight bytes (in big-endian form) in the specified byte-array starting at the given offset.
- toLong(InetAddress) - Static method in class com.tangosol.util.UID
- 
Converts and IP address to a long value.
- toLongBiFunction(Remote.ToLongBiFunction<T, U>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ToLongBiFunction.
- toLongFunction(Remote.ToLongFunction<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable ToLongFunction.
- toLongStream(RemoteStream<T>) - Static method in interface com.tangosol.util.stream.RemoteStream
- 
Convert stream of numbers intoRemoteLongStream.
- toMap() - Method in class com.tangosol.util.Fragment
- 
Convert thisFragmentinto aMap.
- toMap(ValueExtractor<? super U1, ? extends K>, ValueExtractor<? super U2, ? extends V>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates elements into aMapwhose keys and values are the result of applying the provided mapping functions to the input elements.
- toMap(ValueExtractor<? super U1, ? extends K>, ValueExtractor<? super U2, ? extends V>, Remote.BinaryOperator<V>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates elements into aMapwhose keys and values are the result of applying the provided mapping functions to the input elements.
- toMap(ValueExtractor<? super U1, ? extends K>, ValueExtractor<? super U2, ? extends V>, Remote.BinaryOperator<V>, Remote.Supplier<M>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates elements into aMapwhose keys and values are the result of applying the provided mapping functions to the input elements.
- toMemorySizeString(long) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the passed memory size (in bytes) as a String that can be parsed byFormatting.parseMemorySize(java.lang.String)such that cb==parseMemorySize(toMemorySizeString(cb)) holds true for all legal values of cb.
- toMemorySizeString(long) - Static method in class com.tangosol.util.Base
- 
Format the passed memory size (in bytes) as a String that can be parsed byBase.parseMemorySize(java.lang.String)such that cb==parseMemorySize(toMemorySizeString(cb)) holds true for all legal values of cb.
- toMemorySizeString(long, boolean) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format the passed memory size (in bytes) as a String.
- toMemorySizeString(long, boolean) - Static method in class com.tangosol.util.Base
- 
Format the passed memory size (in bytes) as a String.
- toNumber(String) - Static method in class com.tangosol.coherence.rest.util.processor.NumberIncrementorFactory
- 
Convert the given string into a number.
- toNumber(String) - Static method in class com.tangosol.coherence.rest.util.processor.NumberMultiplierFactory
- 
Convert the given string into a number.
- toOffsetDateTime() - Method in class com.tangosol.io.pof.RawDateTime
- 
Create an OffsetDateTime from the raw date/time information.
- toOffsetTime() - Method in class com.tangosol.io.pof.RawTime
- 
Create a OffsetTime from the raw time information.
- toOptionalValue(Binary) - Method in class com.oracle.coherence.grpc.RequestHolder
- top(Filter<?>, ValueExtractor<? super T, ? extends R>, int) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the top N highest values for the specified extractor.
- top(Filter<?>, ValueExtractor<? super T, ? extends R>, int) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the top N highest values for the specified extractor.
- top(Filter<?>, ValueExtractor<? super T, ? extends R>, Remote.Comparator<? super R>, int) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the top N highest values for the specified extractor.
- top(Filter<?>, ValueExtractor<? super T, ? extends R>, Remote.Comparator<? super R>, int) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the top N highest values for the specified extractor.
- top(ValueExtractor<? super T, ? extends R>, int) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the top N highest values for the specified extractor.
- top(ValueExtractor<? super T, ? extends R>, int) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the top N highest values for the specified extractor.
- top(ValueExtractor<? super T, ? extends R>, Remote.Comparator<? super R>, int) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the top N highest values for the specified extractor.
- top(ValueExtractor<? super T, ? extends R>, Remote.Comparator<? super R>, int) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the top N highest values for the specified extractor.
- TOP_LEVEL_ELEMENT_NAME - Static variable in class com.tangosol.coherence.config.CacheConfig
- 
Top-level element name.
- toPageIndex(int) - Method in class com.tangosol.net.cache.SerializationPagedCache.PagedBinaryStore
- 
Translate a page number to an index into the PageArray.
- topBy(Filter<?>, Remote.Comparator<? super T>, int) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the top N entities with the highest values for the specified extractor.
- topBy(Filter<?>, Remote.Comparator<? super T>, int) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the top N entities with the highest values for the specified extractor.
- topBy(Filter<?>, ValueExtractor<? super T, ? extends R>, int) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the top N entities with the highest values for the specified extractor.
- topBy(Filter<?>, ValueExtractor<? super T, ? extends R>, int) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the top N entities with the highest values for the specified extractor.
- topBy(Remote.Comparator<? super T>, int) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the top N entities with the highest values for the specified extractor.
- topBy(Remote.Comparator<? super T>, int) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the top N entities with the highest values for the specified extractor.
- topBy(ValueExtractor<? super T, ? extends R>, int) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Return the top N entities with the highest values for the specified extractor.
- topBy(ValueExtractor<? super T, ? extends R>, int) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Return the top N entities with the highest values for the specified extractor.
- TopicBackingMapManager<D extends TopicDependencies,S extends NamedTopicScheme> - Class in com.tangosol.net.topic
- 
A base class for topic backing map managers.
- TopicBackingMapManager(ExtensibleConfigurableCacheFactory) - Constructor for class com.tangosol.net.topic.TopicBackingMapManager
- 
Create aTopicBackingMapManager.
- TopicDependencies - Interface in com.tangosol.net.topic
- 
The dependencies for a topic.
- TopicException - Exception in com.tangosol.net.topic
- 
A exception that occurred during an operation on aNamedTopic.
- TopicException(String) - Constructor for exception com.tangosol.net.topic.TopicException
- 
Create aTopicException.
- TopicException(String, Throwable) - Constructor for exception com.tangosol.net.topic.TopicException
- 
Create aTopicException.
- TopicException(Throwable) - Constructor for exception com.tangosol.net.topic.TopicException
- 
Create aTopicException.
- TopicMapping - Class in com.tangosol.coherence.config
- 
ATopicMappingcaptures configuration information for a pattern-match-based mapping from a proposedNamedTopicname to a topic scheme.
- TopicMapping(String, String, Class<? extends TopicScheme>) - Constructor for class com.tangosol.coherence.config.TopicMapping
- 
Construct aTopicMappingfor topics that will use raw types by default.
- TopicMappingProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnTopicMappingProcessoris responsible for processing <topic-mapping>XmlElements to produce aTopicMapping.
- TopicMappingProcessor(String, Class<? extends TopicScheme>) - Constructor for class com.tangosol.coherence.config.xml.processor.TopicMappingProcessor
- 
Create aTopicMappingProcessor.
- TopicPublisherException - Exception in com.tangosol.net.topic
- 
An exception that occurred during publishing of a message on a topic.
- TopicPublisherException(String, Binary, Serializer) - Constructor for exception com.tangosol.net.topic.TopicPublisherException
- 
Create aTopicPublisherException.
- TopicPublisherException(String, Throwable, Binary, Serializer) - Constructor for exception com.tangosol.net.topic.TopicPublisherException
- 
Create aTopicPublisherException.
- TopicPublisherException(Throwable, Binary, Serializer) - Constructor for exception com.tangosol.net.topic.TopicPublisherException
- 
Create aTopicPublisherException.
- TopicScheme<C extends NamedCollection,S> - Interface in com.tangosol.coherence.config.scheme
- 
TheTopicSchemeclass is responsible for building a fully configured instance of a topic.
- TopicSchemeMappingProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnTopicSchemeMappingProcessoris responsible for processing <topic-scheme-mapping>XmlElements to update theResourceMappingRegistrywithResourceMappings.
- TopicSchemeMappingProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.TopicSchemeMappingProcessor
- TopicService - Interface in com.tangosol.net
- 
A TopicService is a service providing Topics that can be used for publish/subscribe functionality and message queue processing.
- topN(ValueExtractor<? super T, ? extends R>, int) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the top n of theComparablevalues extracted from a set of entries in a Map.
- topN(ValueExtractor<? super T, ? extends R>, Comparator<? super R>, int) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the top n of the values extracted from a set of entries in a Map.
- topN(String, int) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the top n of theComparablevalues extracted from a set of entries in a Map.
- topN(String, Comparator<? super R>, int) - Static method in class com.tangosol.util.Aggregators
- 
Return an aggregator that calculates the top n of the values extracted from a set of entries in a Map.
- TopNAggregator<K,V,T,E> - Class in com.tangosol.util.aggregator
- 
TopNAggregator is a ParallelAwareAggregator that aggregates the top N extracted values into an array.
- TopNAggregator() - Constructor for class com.tangosol.util.aggregator.TopNAggregator
- 
Default constructor.
- TopNAggregator(ValueExtractor<? super T, ? extends E>, Comparator<? super E>, int) - Constructor for class com.tangosol.util.aggregator.TopNAggregator
- 
Construct a TopNAggregator that will aggregate the top extracted values, as determined by the specified comparator.
- TopNAggregator.PartialResult<E> - Class in com.tangosol.util.aggregator
- 
The sorted partial result.
- toQuotedCharEscape(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format a char to a printable escape if necessary as it would appear (quoted) in Java source code.
- toQuotedCharEscape(char) - Static method in class com.tangosol.util.Base
- 
Format a char to a printable escape if necessary as it would appear (quoted) in Java source code.
- toQuotedStringEscape(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format a String as it would appear (quoted) in Java source code, escaping characters as necessary.
- toQuotedStringEscape(String) - Static method in class com.tangosol.util.Base
- 
Format a String as it would appear (quoted) in Java source code, escaping characters as necessary.
- toReadBuffer(ByteString) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- 
Convert aByteStringto aReadBuffer.
- toResponse(SecurityException) - Method in class com.tangosol.coherence.rest.providers.SecurityExceptionMapper
- toSet() - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSet.
- toShortString() - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- toSortedBag() - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSortedBag.
- toSortedBag(Remote.Comparator<? super T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSortedBag.
- toSortedBag(ValueExtractor<? super T, ? extends E>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSortedBag.
- toSortedBag(Comparator<? super T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSortedBag.
- toSortedSet() - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSortedSet.
- toSortedSet(Remote.Comparator<? super T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSortedSet.
- toSortedSet(ValueExtractor<? super T, ? extends E>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSortedSet.
- toSortedSet(Comparator<? super T>) - Static method in class com.tangosol.util.stream.RemoteCollectors
- 
Returns aCollectorthat accumulates the input elements into a newSortedSet.
- toSqlDate() - Method in class com.tangosol.io.pof.RawDate
- 
Create a JDBC Date from the raw date information.
- toSqlString(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Escapes the string for SQL.
- toSqlString(String) - Static method in class com.tangosol.util.Base
- 
Escapes the string for SQL.
- toSqlTime() - Method in class com.tangosol.io.pof.RawTime
- 
Create a JDBC Time from the raw time information.
- toSqlTimestamp() - Method in class com.tangosol.io.pof.RawDateTime
- 
Create a JDBC Timestamp from the raw date/time information.
- toStateString(int) - Static method in class com.tangosol.util.Daemon
- 
Convert a state value to a human-readable String.
- toString() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- toString() - Method in class com.oracle.coherence.cdi.AnnotationInstance
- toString() - Method in class com.oracle.coherence.cdi.CdiMapEventObserver
- toString() - Method in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- toString() - Method in class com.oracle.coherence.common.base.MutableLong
- toString() - Method in class com.oracle.coherence.common.base.SingleWaiterCooperativeNotifier
- toString() - Method in class com.oracle.coherence.common.base.SingleWaiterMultiNotifier
- toString() - Method in class com.oracle.coherence.common.base.StackTrace.StackFrame
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicBoolean
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicMarkableReference
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicStampedReference
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicBoolean
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicMarkableReference
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicStampedReference
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicBoolean
- toString() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- toString() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- toString() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicMarkableReference
- toString() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- toString() - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicStampedReference
- toString() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicBoolean
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicMarkableReference
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicStampedReference
- 
Returns the String representation of the current value.
- toString() - Method in class com.oracle.coherence.concurrent.LocalCountDownLatch
- 
Returns a string identifying this latch, as well as its state.
- toString() - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- 
Returns a string identifying this semaphore, as well as its state.
- toString() - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- toString() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Returns a string identifying this lock, as well as its lock state.
- toString() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.ReadLock
- 
Returns a string identifying this lock, as well as its lock state.
- toString() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Returns a string identifying this lock, as well as its lock state.
- toString() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Returns a string identifying this lock, as well as its lock state.
- toString() - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- toString() - Method in class com.oracle.coherence.concurrent.RemoteCountDownLatch
- 
Returns a string identifying this latch, as well as its state.
- toString() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Returns a string identifying this semaphore, as well as its state.
- toString() - Method in class com.oracle.coherence.mp.config.ConfigPropertyChanged
- toString() - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- toString() - Method in class com.tangosol.coherence.config.builder.NamedEventInterceptorBuilder
- toString() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder.PersistenceEnvironmentInfo
- toString() - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- toString() - Method in enum com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
- toString() - Method in class com.tangosol.coherence.config.builder.SubscriberGroupBuilder
- toString() - Method in class com.tangosol.coherence.config.ParameterMacroExpression
- toString() - Method in class com.tangosol.coherence.config.ResolvableParameterList
- toString() - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.DataStructureRefExpression
- toString() - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.ResourceRefExpression
- toString() - Method in class com.tangosol.coherence.config.xml.processor.InitParamProcessor.SchemeRefExpression
- toString() - Method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- toString() - Method in class com.tangosol.coherence.dsltools.base.CompoundBaseToken
- 
Return a human-readable description for this token.
- toString() - Method in class com.tangosol.coherence.dsltools.base.LeafBaseToken
- 
Return a human-readable description for this token.
- toString() - Method in class com.tangosol.coherence.dsltools.base.LiteralBaseToken
- 
Return a human-readable description for this token.
- toString() - Method in class com.tangosol.coherence.dsltools.base.NestedBaseTokens
- 
Return a human-readable description for this token.
- toString() - Method in class com.tangosol.coherence.dsltools.base.PunctuationBaseToken
- 
Return a human-readable description for this token.
- toString() - Method in class com.tangosol.coherence.dsltools.precedence.LiteralOPToken
- 
Return a human-readable description for this token.
- toString() - Method in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
Return a human-readable description for this token.
- toString() - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Return a human-readable description for this Node.
- toString() - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Return a human-readable description for this Node.
- toString() - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- toString() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- toString() - Method in class com.tangosol.coherence.jcache.common.AbstractJCacheStatistics
- toString() - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
- toString() - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- toString() - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- toString() - Method in class com.tangosol.coherence.jcache.localcache.LocalCache
- toString() - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheAsynchronousMapListener
- toString() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCache
- toString() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheAsynchronousMapListener
- toString() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener
- toString() - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- toString() - Method in class com.tangosol.coherence.rest.events.SimpleMapEvent
- toString() - Method in class com.tangosol.coherence.rest.server.DefaultResourceConfig
- toString() - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Provide a human-readable description of this MvelExtractor object.
- toString() - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Provide a human-readable description of this MvelManipulator object.
- toString() - Method in class com.tangosol.coherence.rest.util.PartialObject
- toString() - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Return string representation of this object.
- toString() - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Return string representation of this object.
- toString() - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Provide a human-readable description of this MvelUpdater object.
- toString() - Method in class com.tangosol.config.expression.LiteralExpression
- toString() - Method in class com.tangosol.config.expression.Parameter
- toString() - Method in class com.tangosol.config.expression.Value
- toString() - Method in class com.tangosol.config.expression.ValueMacroExpression
- toString() - Method in class com.tangosol.io.AsyncBinaryStore
- 
Return a human readable description of the AsyncBinaryStore.
- toString() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore.DatabaseHolder
- 
Return the Holder's human readable description.
- toString() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStore
- 
Return a human readable description of the BinaryStore.
- toString() - Method in class com.tangosol.io.bdb.BerkeleyDBBinaryStoreManager
- 
Return a human readable description of the BinaryStoreManager.
- toString() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Return a human readable description of the EnvironmentHolder.
- toString() - Method in class com.tangosol.io.bdb.DatabaseFactory
- 
Output the DatabaseFactory state as a String.
- toString() - Method in class com.tangosol.io.bdb.DatabaseFactoryManager
- 
Return a human readable description of the DatabaseFactoryManager.
- toString() - Method in class com.tangosol.io.ByteArrayReadBuffer
- 
Provide a human-readable representation of the Binary object.
- toString() - Method in class com.tangosol.io.ConfigurableSerializerFactory
- 
Deprecated.
- toString() - Method in class com.tangosol.io.DecoratedBinaryDeltaCompressor
- toString() - Method in class com.tangosol.io.DefaultSerializer
- 
Return a description of this DefaultSerializer.
- toString() - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Create a human readable string representing the data written to the stream.
- toString() - Method in class com.tangosol.io.MultiplexingSerializer
- toString() - Method in class com.tangosol.io.pof.ConfigurablePofContext
- 
Return a description of this ConfigurablePofContext.
- toString() - Method in class com.tangosol.io.pof.PofPrincipal
- 
Return a string representation of this Principal.
- toString() - Method in exception com.tangosol.io.pof.PortableException
- 
Return a human-readable description for this exception.
- toString() - Method in class com.tangosol.io.pof.RawDate
- 
Format this object's data as a human-readable string.
- toString() - Method in class com.tangosol.io.pof.RawDateTime
- 
Format this object's data as a human-readable string.
- toString() - Method in class com.tangosol.io.pof.RawDayTimeInterval
- toString() - Method in class com.tangosol.io.pof.RawQuad
- 
Format this object's data as a human-readable string.
- toString() - Method in class com.tangosol.io.pof.RawTime
- 
Format this object's data as a human-readable string.
- toString() - Method in class com.tangosol.io.pof.RawTimeInterval
- toString() - Method in class com.tangosol.io.pof.RawYearMonthInterval
- toString() - Method in class com.tangosol.io.pof.reflect.SimplePofPath
- 
Return a human-readable description for this SimplePofPath.
- toString() - Method in interface com.tangosol.net.ActionPolicy
- 
Return a human-readable String representation of this ActionPolicy.
- toString() - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Provide a human readable description for the Bundle object (for debugging).
- toString() - Method in class com.tangosol.net.cache.AbstractBundler.Statistics
- 
Provide a human readable description for the Statistics object.
- toString() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Provide a human readable description for the Bundler object (for debugging).
- toString() - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Render the entry as a String.
- toString() - Method in class com.tangosol.net.cache.CachingMap
- 
For debugging purposes, format the contents of the CachingMap in a human readable format.
- toString() - Method in class com.tangosol.net.cache.ContinuousQueryCache.AddListener
- 
Produce a human-readable description of this object.
- toString() - Method in class com.tangosol.net.cache.ContinuousQueryCache.EventRouter
- 
Produce a human-readable description of this EventRouter.
- toString() - Method in class com.tangosol.net.cache.ContinuousQueryCache.RemoveListener
- 
Produce a human-readable description of this object.
- toString() - Method in class com.tangosol.net.cache.ContinuousQueryCache.ServiceListener
- 
Produce a human-readable description of this object.
- toString() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Render the cache entry as a String.
- toString() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.For debugging purposes, format the contents of the cache as a String.
- toString() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Returns a string representation of the object.
- toString() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.BinaryEntryStoreWrapper
- 
Return a String representation of the BinaryEntryStoreWrapper object that will be used as a part of the write-behind thread name.
- toString() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.CacheStoreWrapper
- 
Return a String representation of the CacheStoreWrapper object that will be used as a part of the write-behind thread name.
- toString() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper
- 
Return a String representation of the NonBlockingEntryStoreWrapper object that will be used as a part of the write-behind thread name.
- toString() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.ReadQueue
- 
For debugging purposes, present the queue in human-readable format.
- toString() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
For debugging purposes, format the contents of the Map in a human- readable format.
- toString() - Method in class com.tangosol.net.cache.SerializationCache
- 
Returns a string representation of this Map.
- toString() - Method in class com.tangosol.net.cache.SerializationMap
- 
Returns a string representation of this Map.
- toString() - Method in class com.tangosol.net.cache.SerializationPagedCache.FakeBinaryStore
- 
Returns a string representation of the object.
- toString() - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Returns a string representation of this Map.
- toString() - Method in class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Returns a string representation of the object.
- toString() - Method in class com.tangosol.net.cache.SimpleCacheStatistics
- 
For debugging purposes, format the contents of the SimpleCachingStatistics in a human readable format.
- toString() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Returns a string representation of the object.
- toString() - Method in class com.tangosol.net.cache.SimpleSerializationMap
- 
Returns a string representation of this Map.
- toString() - Method in class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
- toString() - Method in class com.tangosol.net.Coherence
- toString() - Method in class com.tangosol.net.CompositeSocketAddressProvider
- toString() - Method in class com.tangosol.net.ConfigurableAddressProvider
- 
Return a string representation of this ConfigurableAddressProvider.
- toString() - Method in class com.tangosol.net.ConfigurableAddressProviderFactory
- 
Deprecated.
- toString() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- toString() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Return a human-readable String representation of this ActionPolicy.
- toString() - Method in class com.tangosol.net.events.NamedEventInterceptor
- toString() - Method in class com.tangosol.net.GuardSupport.Context
- 
Return a human-readable description.
- toString() - Method in class com.tangosol.net.LoadBalancer.AddressPort
- 
Return a human readable description of this AddressPort object.
- toString() - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- toString() - Method in class com.tangosol.net.management.ObjectNameExcludeFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.net.management.ViewMBeanImpl
- toString() - Method in class com.tangosol.net.MemberEvent
- 
Returns a String representation of this MemberEvent object.
- toString() - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- toString() - Method in class com.tangosol.net.partition.ObservableSplittingBackingMap
- 
Return a human-readable description for this ObservableSplittingBackingMap.
- toString() - Method in class com.tangosol.net.partition.Ownership
- 
Returns a string representation of this Ownership.
- toString() - Method in class com.tangosol.net.partition.PartitionEvent
- 
Return a String representation of this PartitionEvent object.
- toString() - Method in class com.tangosol.net.partition.PartitionSet
- 
Returns a string representation of this PartitionSet.
- toString() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap.AggregatingCacheStatistics
- 
For debugging purposes, format the statistics information into a human-readable format.
- toString() - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Return a human-readable description for this PartitionBackingMap.
- toString() - Method in class com.tangosol.net.partition.PartitionStatistics
- toString() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.BackupStrength
- toString() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- toString() - Method in class com.tangosol.net.partition.SimplePartitionKey
- toString() - Method in class com.tangosol.net.security.SimpleHandler
- 
Return a string representation of this principal.
- toString() - Method in class com.tangosol.net.SessionConfiguration.ConfigurableCacheFactorySessionConfig
- toString() - Method in class com.tangosol.net.SocketProviderFactory
- toString() - Method in class com.tangosol.net.ssl.AbstractCertificateLoader
- toString() - Method in class com.tangosol.net.ssl.AbstractKeyStoreLoader
- toString() - Method in class com.tangosol.net.ssl.AbstractPrivateKeyLoader
- toString() - Method in class com.tangosol.net.ssl.URLCertificateLoader
- toString() - Method in class com.tangosol.net.ssl.URLKeyStoreLoader
- toString() - Method in class com.tangosol.net.ssl.URLPrivateKeyLoader
- toString() - Method in class com.tangosol.net.SystemDatagramSocketProvider
- toString() - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- toString() - Method in class com.tangosol.net.TcpDatagramSocket
- toString() - Method in class com.tangosol.net.TcpDatagramSocketProvider
- toString() - Method in class com.tangosol.net.topic.Publisher.OrderById
- toString() - Method in class com.tangosol.net.topic.Publisher.OrderByNone
- toString() - Method in class com.tangosol.net.topic.Publisher.OrderByThread
- toString() - Method in class com.tangosol.net.topic.Publisher.OrderByValue
- toString() - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- toString() - Method in class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
- toString() - Method in class com.tangosol.net.WrapperCacheService
- toString() - Method in class com.tangosol.net.WrapperInvocationService
- toString() - Method in class com.tangosol.net.WrapperService
- toString() - Method in class com.tangosol.net.WrapperSessionConfiguration
- toString() - Method in class com.tangosol.persistence.AbstractPersistenceEnvironment
- 
Return a human readable description of this AbstractPersistenceManager.
- toString() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Return a human readable description of this AbstractPersistentStore.
- toString() - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Return a human readable description of this AbstractPersistenceManager.
- toString() - Method in class com.tangosol.persistence.AbstractPersistenceTools
- toString() - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- toString() - Method in class com.tangosol.persistence.ConfigurableSnapshotArchiverFactory
- toString() - Method in class com.tangosol.persistence.DirectorySnapshotArchiver
- toString() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Return a human readable description of this SafePersistenceEnvironment.
- toString() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Return a human readable description of this SafePersistenceManager.
- toString() - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Return a human readable description of this SafePersistentStore.
- toString() - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Debugging support.
- toString() - Method in class com.tangosol.run.xml.QualifiedName
- toString() - Method in class com.tangosol.run.xml.SimpleElement
- 
Format the XML element and all its contained information into a String in a display format.
- toString() - Method in class com.tangosol.run.xml.SimpleValue
- 
Format the XML value into a String in a display format.
- toString() - Method in class com.tangosol.run.xml.XmlBean.BeanInfo
- 
Debugging support.
- toString() - Method in class com.tangosol.run.xml.XmlBean
- 
To assist in debugging, provide a clear indication of the key's state.
- toString() - Method in interface com.tangosol.run.xml.XmlDocument
- 
Format the XML document and all its contained information into a String in a display format.
- toString() - Method in interface com.tangosol.run.xml.XmlElement
- 
Format the XML element and all its contained information into a String in a display format.
- toString() - Method in interface com.tangosol.run.xml.XmlValue
- 
Format the XML value into a String in a display format.
- toString() - Method in class com.tangosol.util.AbstractByteSequence
- toString() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns a string representation of this Map.
- toString() - Method in class com.tangosol.util.AbstractLongArray
- 
Provide a string representation of the LongArray.
- toString() - Method in class com.tangosol.util.AbstractSafeLongArray
- toString() - Method in class com.tangosol.util.AbstractSparseArray.Crawler
- 
Provide a string representation of this node's value.
- toString() - Method in class com.tangosol.util.AbstractSparseArray.Node
- 
Provide a string representation of this node's value.
- toString() - Method in class com.tangosol.util.aggregator.AbstractAggregator
- 
Provide a human-readable representation of this object.
- toString() - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Return a human-readable description for this ValueExtractor.
- toString() - Method in class com.tangosol.util.aggregator.GroupAggregator
- 
Return a human-readable description for this GroupAggregator.
- toString() - Method in class com.tangosol.util.aggregator.PriorityAggregator
- 
Return a human-readable description for this PriorityAggregator.
- toString() - Method in class com.tangosol.util.Binary
- 
Provide a human-readable representation of the Binary object.
- toString() - Method in class com.tangosol.util.ClassFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Return a human-readable description for this ChainedComparator.
- toString() - Method in class com.tangosol.util.comparator.SafeComparator
- 
Return a human-readable description for this Comparator.
- toString() - Method in class com.tangosol.util.CompositeKey
- 
Returns a string representation of the object.
- toString() - Method in class com.tangosol.util.ConditionalIndex
- 
Returns a string representation of this ConditionalIndex.
- toString() - Method in class com.tangosol.util.ConverterCollections.AbstractConverterEntry
- toString() - Method in class com.tangosol.util.ConverterCollections.ConverterCollection
- 
Return a String description for this collection.
- toString() - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- toString() - Method in class com.tangosol.util.ConverterCollections.ConverterHolder
- toString() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- toString() - Method in class com.tangosol.util.CopyOnWriteMap
- toString() - Method in class com.tangosol.util.Daemon
- 
Return a human-readable String representation of the Daemon.
- toString() - Method in class com.tangosol.util.ExternalizableHelper.FormatAwareCompressor
- 
Returns a string representation of the object.
- toString() - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
Return a human-readable description for this ValueExtractor.
- toString() - Method in class com.tangosol.util.extractor.CompositeUpdater
- 
Return a human-readable description for this CompositeUpdater.
- toString() - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Return a human-readable description for this ConditionalExtractor.
- toString() - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Return a human-readable description for this DeserializationAccelerator.
- toString() - Method in class com.tangosol.util.extractor.IdentityExtractor
- 
Provide a human-readable description of this IdentityExtractor object.
- toString() - Method in class com.tangosol.util.extractor.KeyExtractor
- 
Return a human-readable description for this KeyExtractor.
- toString() - Method in class com.tangosol.util.extractor.PofExtractor
- 
Return a human-readable description for this PofExtractor.
- toString() - Method in class com.tangosol.util.extractor.PofUpdater
- 
Return a human-readable description for this PofUpdater.
- toString() - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Provide a human-readable description of this ReflectionExtractor object.
- toString() - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Provide a human-readable description of this ValueUpdater object.
- toString() - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Provide a human-readable description of thisUniversalExtractorobject.
- toString() - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Provide a human-readable description of this ValueUpdater object.
- toString() - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.ArrayFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.BetweenFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.FilterTrigger
- 
Return a human-readable description for this FilterTrigger.
- toString() - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.KeyFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.LimitFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.MapEventFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Provide a human-readable representation of this object.
- toString() - Method in class com.tangosol.util.filter.NeverFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.NotFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.PresentFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.PriorityFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Returns a string representation of this SimpleMapIndex.
- toString() - Method in class com.tangosol.util.Fragment
- toString() - Method in class com.tangosol.util.fsm.Instruction.TransitionTo
- toString() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent
- toString() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine.SubsequentEvent
- toString() - Method in class com.tangosol.util.fsm.NonBlockingFiniteStateMachine
- toString() - Method in class com.tangosol.util.fsm.Transition
- toString() - Method in class com.tangosol.util.ImmutableArrayList.ListView
- toString() - Method in class com.tangosol.util.ImmutableArrayList.SetView
- toString() - Method in class com.tangosol.util.ImmutableArrayList.SortedSetView
- toString() - Method in class com.tangosol.util.InvocableMapHelper.SimpleEntry
- 
Provide a human-readable representation of the SimpleEntry object.
- toString() - Method in class com.tangosol.util.Listeners
- 
Return a string representation of the Listeners object.
- toString() - Method in interface com.tangosol.util.LongArray
- 
Provide a string representation of the LongArray.
- toString() - Method in class com.tangosol.util.MapEvent
- 
Return a String representation of this MapEvent object.
- toString() - Method in class com.tangosol.util.MapListenerSupport
- 
Provide a string representation of the MapListenerSupport object.
- toString() - Method in class com.tangosol.util.MapListenerSupport.WrapperListener
- toString() - Method in class com.tangosol.util.NullFilter
- 
Return a human-readable description for this Filter.
- toString() - Method in class com.tangosol.util.NullImplementation.NullActionPolicy
- 
Return a human-readable String representation of this ActionPolicy.
- toString() - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Provide a human-readable description of this ValueExtractor object.
- toString() - Method in class com.tangosol.util.processor.CompositeProcessor
- 
Return a human-readable description for this ConditionalProcessor.
- toString() - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Return a human-readable description for this ConditionalProcessor.
- toString() - Method in class com.tangosol.util.processor.ConditionalPut
- 
Return a human-readable description for this ConditionalPut.
- toString() - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Return a human-readable description for this ConditionalPutAll.
- toString() - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Return a human-readable description for this ConditionalRemove.
- toString() - Method in class com.tangosol.util.processor.ExtractorProcessor
- 
Return a human-readable description for this ExtractorProcessor.
- toString() - Method in class com.tangosol.util.processor.PreloadRequest
- 
Return a human-readable description for this PreloadRequest processor.
- toString() - Method in class com.tangosol.util.processor.PriorityProcessor
- 
Return a human-readable description for this PriorityProcessor.
- toString() - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Return a human-readable description for this PropertyManipulator.
- toString() - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Return a human-readable description for this PropertyProcessor.
- toString() - Method in class com.tangosol.util.processor.UpdaterProcessor
- 
Return a human-readable description for this UpdaterProcessor.
- toString() - Method in class com.tangosol.util.processor.VersionedPut
- 
Return a human-readable description for this VersionedPut.
- toString() - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Return a human-readable description for this VersionedPutAll.
- toString() - Method in class com.tangosol.util.RestrictedCollections.RestrictedCollection
- 
Return a String description for this collection.
- toString() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedEntry
- 
Return a String description for this Entry.
- toString() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet.RestrictedIterator
- 
Return a String description for this Iterator.
- toString() - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Return a String description for this collection.
- toString() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Return a String description for this Map.
- toString() - Method in class com.tangosol.util.SafeHashMap.Entry
- 
Render the map entry as a String.
- toString() - Method in class com.tangosol.util.SafeLinkedList.Node
- 
Render the Node as a String.
- toString() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Render the map entry as a String.
- toString() - Method in class com.tangosol.util.SegmentedHashMap.Entry
- 
Render the map entry as a String.
- toString() - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns a String representation of this map.
- toString() - Method in class com.tangosol.util.ServiceEvent
- 
Returns a String representation of this ServiceEvent object.
- toString() - Method in class com.tangosol.util.SimpleHolder
- toString() - Method in class com.tangosol.util.SimpleMapEntry
- 
Render the map entry as a String.
- toString() - Method in class com.tangosol.util.SimpleMapIndex
- 
Returns a string representation of this SimpleMapIndex.
- toString() - Method in class com.tangosol.util.SimpleQueryRecord
- toString() - Method in class com.tangosol.util.StringTable
- 
Provide a string representation of the string table.
- toString() - Method in class com.tangosol.util.TaskDaemon
- 
Return a human-readable String representation of the Daemon.
- toString() - Method in class com.tangosol.util.ThreadGateLite.Bar
- toString() - Method in class com.tangosol.util.ThreadGateLite
- toString() - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Provide a human-readable representation of this object.
- toString() - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
- 
Provide a human-readable representation of this object.
- toString() - Method in class com.tangosol.util.Tree
- 
Provide a string representation of the tree.
- toString() - Method in class com.tangosol.util.UID
- 
Convert the UID to a printable String.
- toString() - Method in class com.tangosol.util.UUID
- 
Convert the UUID to a printable String.
- toString() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperCollection
- toString() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperEntry
- toString() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperIterator
- toString() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- toString() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperCollection
- toString() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperEntry
- toString() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- toString() - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Return a human readable description of the Lock.
- toString() - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Returns a string representation of this Map.
- toString() - Method in exception com.tangosol.util.WrapperException
- 
Returns a short description of this WrapperException object.
- toString() - Method in class com.tangosol.util.WrapperObservableMap
- 
Returns a string representation of this Map.
- toString(boolean) - Method in class com.tangosol.net.partition.PartitionSet
- 
Returns a string representation of this PartitionSet.
- toString(boolean) - Method in class com.tangosol.net.partition.PartitionSplittingBackingMap
- 
Return a human-readable description for this PartitionBackingMap.
- toString(boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Format the XML element and all its contained information into a String in a display format.
- toString(boolean) - Method in class com.tangosol.util.SimpleMapIndex
- 
Returns a string representation of this SimpleMapIndex.
- toString(boolean[]) - Static method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- toString(byte[]) - Static method in class com.tangosol.net.InetAddressHelper
- 
Converts a byte array to a raw IP address string representation.
- toString(byte[]) - Static method in class com.tangosol.util.Binary
- 
For debugging purposes, convert the passed byte array into a string that contains the information regarding whether the reference is null, and if it is not null, what the length of the byte array is.
- toString(double, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format a double value as a String.
- toString(double, int) - Static method in class com.tangosol.util.Base
- 
Format a double value as a String.
- toString(int) - Static method in class com.tangosol.net.InetAddressHelper
- 
Format a port string representing the specified port number.
- toString(long) - Static method in class com.tangosol.util.UID
- 
Converts a long value to an address string in the form returned by InetAddress#getHostAddress.
- toString(XmlSerializable) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Return the XML of an XmlSerializable object as a String.
- toString(Class) - Static method in class com.oracle.coherence.common.base.Classes
- 
Formats Class information for debug output purposes.
- toString(Class<?>) - Static method in class com.tangosol.util.Base
- 
Formats Class information for debug output purposes.
- toString(Object) - Method in class com.tangosol.coherence.rest.DefaultKeyConverter
- 
Convert an object representation of a key into its string form.
- toString(Object) - Method in interface com.tangosol.coherence.rest.KeyConverter
- 
Convert an object representation of a key into its string form.
- toString(InetAddress) - Static method in class com.tangosol.net.InetAddressHelper
- 
Format an IP address string representing the specified InetAddress object.
- toString(Timestamp) - Static method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- toStringEscape(String) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format a String escaping characters as necessary.
- toStringEscape(String) - Static method in class com.tangosol.util.Base
- 
Format a String escaping characters as necessary.
- toStringValue() - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Return the string representation of the value.
- toStringValue() - Method in class com.tangosol.util.filter.ContainsAllFilter
- 
Return the string representation of the value.
- toStringValue() - Method in class com.tangosol.util.filter.ContainsAnyFilter
- 
Return the string representation of the value.
- toStringValue() - Method in class com.tangosol.util.filter.InFilter
- 
Return the string representation of the value.
- toStringValueStream(Iterable<?>) - Static method in class com.oracle.coherence.grpc.BinaryHelper
- toTimestamp(String) - Static method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- toTypes(String) - Static method in class com.oracle.coherence.common.base.Classes
- 
Parse the method signature into discrete return type and parameter signatures as they appear in Java .class structures.
- toTypeStringField(String) - Static method in class com.oracle.coherence.common.base.Classes
- 
Provide a Java source representation of a JVM type signature.
- touch() - Method in interface com.tangosol.net.cache.ConfigurableCacheMap.Entry
- 
Indicate to the entry that it has been touched, such as when it is accessed or modified.
- touch() - Method in class com.tangosol.net.cache.OldCache.Entry
- 
Deprecated.Called each time the entry is accessed or modified.
- touch() - Method in class com.tangosol.net.cache.SerializationCache.EntrySet.Entry
- 
Indicate to the entry that it has been touched, such as when it is accessed or modified.
- touch() - Method in class com.tangosol.net.partition.ObservableSplittingBackingCache.EntrySet.Entry
- 
Indicate to the entry that it has been touched, such as when it is accessed or modified.
- touch() - Method in class com.tangosol.util.ConverterCollections.ConverterCacheEntry
- 
Indicate to the entry that it has been touched, such as when it is accessed or modified.
- touch() - Static method in class com.tangosol.util.Processors
- 
Construct a touch processor.
- touch(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Touch an object to pop it to the top of the LRU
- TouchProcessor - Class in com.tangosol.util.processor
- 
Touches an entry (if present) in order to trigger interceptor re-evaluation and possibly increment expiry time.
- TouchProcessor() - Constructor for class com.tangosol.util.processor.TouchProcessor
- toUnicodeEscape(char) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Format a Unicode character to the Unicode escape sequence of '\' + 'u' + 4 hex digits.
- toUnicodeEscape(char) - Static method in class com.tangosol.util.Base
- 
Format a Unicode character to the Unicode escape sequence of '\' + 'u' + 4 hex digits.
- toUri() - Method in interface com.tangosol.run.xml.UriSerializable
- 
Serialize the object into a URI.
- toUri(Object) - Method in class com.tangosol.run.xml.DateTimeAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.RestrictedStringAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SerializableAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.BigDecimalAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.BigIntegerAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.BooleanAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.ByteAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.CharAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.DoubleAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.FloatAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.IntAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.LongAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.ShortAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.StringAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.SystemTimeAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.TimeAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- 
Serialize an object into a URI element.
- toUri(Object) - Method in class com.tangosol.run.xml.SimpleAdapter
- 
Serialize an object into a URI element.
- toXml() - Method in class com.tangosol.run.xml.SimpleDocument
- 
Serialize the object into an XmlElement.
- toXml() - Method in class com.tangosol.run.xml.SimpleElement
- 
Serialize the object into an XmlElement.
- toXml() - Method in class com.tangosol.run.xml.XmlBean
- 
Serialize the object into an XmlElement.
- toXml() - Method in interface com.tangosol.run.xml.XmlSerializable
- 
Serialize the object into an XmlElement.
- toXml(Object) - Method in class com.tangosol.run.xml.DateFormatAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.DateTimeAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.IterableAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.QNameAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.RestrictedStringAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SerializableAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.BigIntegerAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.ByteAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.CharAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.FloatAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.ShortAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SimpleAdapter.SystemTimeAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.SimpleAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.XmlElementAdapter
- 
Serialize an object into an XML element.
- toXml(Object) - Method in class com.tangosol.run.xml.XmlSerializableAdapter
- 
Serialize an object into an XML element.
- toXmlString(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Serialize a primitive array into a single XML element.
- toXmlString(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Serialize a primitive array into a single XML element.
- toXmlString(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Serialize a primitive array into a single XML element.
- toXmlString(Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Serialize a primitive array into a single XML element.
- trace(boolean) - Static method in class com.tangosol.util.Base
- 
Display the value of a boolean expression.
- trace(byte[]) - Static method in class com.tangosol.util.Base
- 
Display the value of a byte array expression.
- trace(char) - Static method in class com.tangosol.util.Base
- 
Display the value of a char expression.
- trace(double) - Static method in class com.tangosol.util.Base
- 
Display the value of a double expression.
- trace(float) - Static method in class com.tangosol.util.Base
- 
Display the value of a float expression.
- trace(int) - Static method in class com.tangosol.util.Base
- 
Display the value of an int expression.
- trace(long) - Static method in class com.tangosol.util.Base
- 
Display the value of a long expression.
- trace(Filter<T>, Map.Entry, QueryRecord.PartialResult.TraceStep) - Static method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
- 
Record the actual cost of query execution for a given filter.
- trace(Filter<T>, Map, Set, QueryRecord.PartialResult.TraceStep) - Static method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
- 
Record the actual cost of applying the specified filter to the specified keySet.
- trace(Filter<T>, Map, Set, QueryRecord.PartialResult.TraceStep, ValueExtractor) - Static method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
- 
Record the actual cost of applying the specified filter to the specified keySet.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Map.Entry) - Method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
- 
Evaluate the specified entry against this filter and record the evaluation cost on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Map.Entry) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Evaluate the specified entry against this filter and record the evaluation cost on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Map.Entry) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Evaluate the specified entry against this filter and record the evaluation cost on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Map.Entry) - Method in interface com.tangosol.util.filter.QueryRecorderFilter
- 
Evaluate the specified entry against this filter and record the evaluation cost on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Map.Entry) - Method in class com.tangosol.util.filter.WrapperQueryRecorderFilter
- 
Evaluate the specified entry against this filter and record the evaluation cost on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Set) - Method in class com.tangosol.util.filter.AbstractQueryRecorderFilter
- 
Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Set) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Set) - Method in class com.tangosol.util.filter.BetweenFilter
- 
Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Set) - Method in interface com.tangosol.util.filter.QueryRecorderFilter
- 
Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord.
- trace(QueryContext, QueryRecord.PartialResult.TraceStep, Set) - Method in class com.tangosol.util.filter.WrapperQueryRecorderFilter
- 
Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord.
- trace(Object) - Static method in class com.tangosol.util.Base
- 
Display the value of an Object expression.
- trace(String) - Static method in class com.tangosol.util.Base
- 
Display the value of a String expression.
- TRACE - com.tangosol.util.aggregator.QueryRecorder.RecordType
- 
Produce aQueryRecordobject that contains the actual cost of the query execution.
- TRACE_ID_KEY - Static variable in class com.oracle.coherence.grpc.proxy.ServerLoggingInterceptor
- TRACE_INSTANCE - Static variable in class com.tangosol.coherence.dslquery.statement.QueryRecorderStatementBuilder
- 
An instance of a QueryRecorderStatementBuilder that builds TRACE queries.
- TraceCommandOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder.TraceCommandOPToken
- 
Construct a TraceCommandOPToken.
- traceout(String, PrintWriter, boolean) - Method in class com.tangosol.coherence.dslquery.statement.SourceStatementBuilder.SourceStatement
- 
Write the given line on the give PrintWriter if the trace flag is true.
- TraceQueryPlusStatement(boolean) - Constructor for class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder.TraceQueryPlusStatement
- 
Construct a command to turn on or off QueryPlus tracing.
- TraceStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
- 
AStatementBuilderthat builds the QueryPlus "TRACE" command.
- TraceStatementBuilder(OPToken) - Constructor for class com.tangosol.coherence.dslquery.queryplus.TraceStatementBuilder
- 
Construct a TraceStatementBuilder.
- TraceStatementBuilder.TraceCommandOPToken - Class in com.tangosol.coherence.dslquery.queryplus
- 
A CohQL OPToken representing the QueryPlus "trace" command.
- TraceStatementBuilder.TraceQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
- 
A command that turns on or off QueryPlus trace.
- TraceStep(Filter) - Constructor for class com.tangosol.util.SimpleQueryRecord.PartialResult.TraceStep
- 
Construct a TraceStep
- TracingDaemonPool - Class in com.oracle.coherence.grpc.proxy
- 
ADaemonPoolimplementation that wraps anotherDaemonPooland adds activation of tracing spans for theRunnables executed by this pool.
- TracingDaemonPool(DaemonPool) - Constructor for class com.oracle.coherence.grpc.proxy.TracingDaemonPool
- 
Create aTracingDaemonPool.
- TracingDaemonPool.TracingRunnable - Class in com.oracle.coherence.grpc.proxy
- 
ARunnablethat executes another runnable after activating a tracing span.
- TracingRunnable(Span, Runnable) - Constructor for class com.oracle.coherence.grpc.proxy.TracingDaemonPool.TracingRunnable
- 
Constructs a newTracingRunnablefor the provided span andRunnabledelegate.
- trackDatabase(Database) - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder
- 
Add a database handle to the tracking list.
- TRANSACTION_GET_COMMITTED - Static variable in interface com.tangosol.util.TransactionMap
- 
Dirty gets are prevented; non-repeatable gets and phantom gets can occur.
- TRANSACTION_MANAGER_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the TransactionManagerMBean.
- TRANSACTION_REPEATABLE_GET - Static variable in interface com.tangosol.util.TransactionMap
- 
Dirty gets and non-repeatable gets are prevented; phantom gets can occur.
- TRANSACTION_SERIALIZABLE - Static variable in interface com.tangosol.util.TransactionMap
- 
Dirty gets, non-repeatable gets and phantom gets are prevented.
- TransactionalPreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
ATransactionalPreprocessoris anDocumentElementPreprocessor.ElementPreprocessorthat introduces (via cloning) internal cache-config xml content for xml elements.
- TransactionalPreprocessor() - Constructor for class com.tangosol.coherence.config.xml.preprocessor.TransactionalPreprocessor
- TransactionalScheme - Class in com.tangosol.coherence.config.scheme
- 
TheTransactionalSchemeclass builds a transactional cache.
- TransactionalScheme() - Constructor for class com.tangosol.coherence.config.scheme.TransactionalScheme
- TransactionEvent - Interface in com.tangosol.net.events.partition
- 
A TransactionEvent captures information pertaining to all mutations performed within the context of a single request.
- TransactionEvent.Type - Enum in com.tangosol.net.events.partition
- 
The TransactionEvent types.
- TransactionEventHandler(EventObserverSupport.EventObserver<TransactionEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.TransactionEventHandler
- TransactionEvents - Annotation Type in com.tangosol.net.events.annotation
- 
TransactionEventInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveTransactionEvents.
- TransactionMap - Interface in com.tangosol.util
- 
ConcurrentMap with additional transaction support.
- TransactionMap.Validator - Interface in com.tangosol.util
- 
A callback interface used by TransactionMap implementations.
- transferBytes(ByteBuffer, ByteBuffer) - Method in class com.tangosol.net.TcpDatagramSocket.Impl
- 
Transfer bytes from the source to the destination buffer based on their limits.
- TransferEvent - Interface in com.tangosol.net.events.partition
- 
A TransferEvent captures information concerning the transfer of a partition for a storage enabled member.
- TransferEvent.RecoveryTransferEvent - Interface in com.tangosol.net.events.partition
- 
A RecoveryTransferEvent is raised due to the recovery of a partition from a persistent store.
- TransferEvent.Type - Enum in com.tangosol.net.events.partition
- 
TheTransferEventtypes.
- TransferEventHandler(EventObserverSupport.EventObserver<TransferEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.TransferEventHandler
- TransferEvents - Annotation Type in com.tangosol.net.events.annotation
- 
TransferEventInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveTransferEvents.
- transferThreshold - Variable in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
The transfer threshold used for paged requests.
- transform(MapEvent) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Remove an old value from the specified MapEvent.
- transform(MapEvent<K, V>) - Method in interface com.tangosol.util.MapEventTransformer
- 
Transform the specified MapEvent.
- transform(MapEvent<K, V>) - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Transform the specified MapEvent using the corresponding extractors.
- transform(MapEvent<K, V>) - Method in class com.tangosol.util.transformer.SamplingEventTransformer
- transform(MapEvent<K, V>) - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
- 
Remove an old value from the specified MapEvent.
- transform(Set<Map.Entry<K, V_BACK>>, ValueExtractor<? super V_BACK, ? extends V_FRONT>) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Transform a set of entries.
- TRANSFORMABLE - com.tangosol.net.cache.CacheEvent.TransformationState
- 
Value used to indicate that an event is transformable and could be passed to transformer-based listeners.
- TRANSFORMED - com.tangosol.net.cache.CacheEvent.TransformationState
- 
Value used to indicate that an event has been transformed, and should only be passed to transformer-based listeners.
- TransformerProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
Responsible for processingview-filterelements.
- TransformerProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.TransformerProcessor
- transformIdentity(Subject, Service) - Method in class com.tangosol.net.security.DefaultIdentityTransformer
- 
Transform a Subject to a token that asserts an identity.
- transformIdentity(Subject, Service) - Method in interface com.tangosol.net.security.IdentityTransformer
- 
Transform a Subject to a token that asserts an identity.
- transformInitParams(XmlElement, XmlElement) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Transform the specified "init-params" element of the following structure:
- Transition<S extends Enum<S>> - Class in com.tangosol.util.fsm
- 
ATransitionrepresents a transition in aFiniteStateMachinefrom one or more possible states to a desired state.
- Transition(String, EnumSet<S>, S) - Constructor for class com.tangosol.util.fsm.Transition
- 
Constructs aTransition(without anTransitionAction).
- Transition(String, EnumSet<S>, S, TransitionAction<S>) - Constructor for class com.tangosol.util.fsm.Transition
- 
Constructs aTransition.
- Transition(String, S, S) - Constructor for class com.tangosol.util.fsm.Transition
- 
Constructs aTransition(without anTransitionAction).
- Transition(String, S, S, TransitionAction<S>) - Constructor for class com.tangosol.util.fsm.Transition
- 
Constructs aTransition.
- TransitionAction<S extends Enum<S>> - Interface in com.tangosol.util.fsm
- 
ATransitionActionencapsulates the actions to be performed as part of theTransitionfrom one state to another.
- transitionPartition(int, int, Member, Member) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext
- 
Update the analysis context to reflect the suggested transfer of the specified number of primary partitions between the specified members.
- TransitionTo(S) - Constructor for class com.tangosol.util.fsm.Instruction.TransitionTo
- 
Constructs aInstruction.TransitionTo.
- translateSchemeType(String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Translate the scheme name into the scheme type.
- translateStandardSchemeType(String) - Static method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Translate the scheme name into the scheme type.
- translateStandardSchemeType(String) - Static method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Translate the scheme name into the scheme type.
- translateType(String) - Method in class com.tangosol.coherence.config.scheme.DistributedScheme.BackupConfig
- 
Translate the backup map type string.
- Tree - Class in com.tangosol.util
- 
A thread-safe balanced binary search tree.
- Tree() - Constructor for class com.tangosol.util.Tree
- 
Default constructor.
- trigger(String, String, String) - Method in interface com.tangosol.net.management.NotificationManager
- 
Trigger the notification on subscribers for a given MBean.
- trigger(String, Notification) - Method in interface com.tangosol.net.management.NotificationManager
- 
Trigger the notification on subscribers for a given MBean.
- trim(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Trim XML whitespace.
- trimb(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Trim trailing XML whitespace.
- trimf(String) - Static method in class com.tangosol.run.xml.XmlHelper
- 
Trim leading XML whitespace.
- trimToSize() - Method in class com.tangosol.util.CircularArrayList
- 
Trim the capacity of this list instance to be as small as possible.
- TRINT_DOMAIN_SPAN - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Trints use 6 hexits (3 bytes), so the trint domain span is 0x01000000.
- TRINT_MAX_VALUE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Trints use 6 hexits (3 bytes), so the trint maximum is 0x00FFFFFF.
- TRINT_MAX_VARIANCE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Trints use 6 hexits (3 bytes), so the trint maximum variance (from a "current" value) is half the trint domain span, or 0x00800000.
- TRUE - Static variable in class com.tangosol.util.Binary
- 
A Binary representation ofBoolean.TRUEvalue.
- truncate() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- truncate() - Method in class com.tangosol.net.cache.NearCache
- 
Removes all mappings from this map.
- truncate() - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- truncate() - Method in class com.tangosol.net.cache.WrapperNamedCache
- 
Removes all mappings from this map.
- truncate() - Method in interface com.tangosol.net.NamedMap
- 
Removes all mappings from this map.
- truncate() - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Removes all mappings from this map.
- truncate() - Method in class com.tangosol.util.ObservableHashMap
- 
Removes all mappings from this map.
- truncate() - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Truncate operation for control map.
- truncate(TruncateRequest) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Removes all mappings from this map.
- truncate(TruncateRequest) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- truncate(TruncateRequest, StreamObserver<Empty>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- truncate(String, String) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aTruncateRequest.
- TruncateAction() - Constructor for class com.tangosol.util.SegmentedConcurrentMap.TruncateAction
- TruncateCacheStatement(String) - Constructor for class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder.TruncateCacheStatement
- 
Construct a TruncateCacheStatement.
- TruncateCacheStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aTruncateCacheStatementBuilder.TruncateCacheStatement.
- TruncateCacheStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.TruncateCacheStatementBuilder
- TruncateCacheStatementBuilder.TruncateCacheStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "TRUNCATE CACHE" command.
- Truncated - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any TRUNCATED event.
- TRUNCATED - com.tangosol.net.events.partition.cache.CacheLifecycleEvent.Type
- 
CacheLifecycleEvents of the typeTRUNCATEDare raised when a storage for a given cache is truncated as a result of a call totruncate.
- Truncated.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theTruncatedannotation.
- truncateExtent(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Truncate the specified extent from the persistent store, ensuring that any key-value mappings associated with the extent are removed.
- truncateExtent(long) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistentStore
- 
Truncate the specified extent from the persistent store, ensuring that any key-value mappings associated with the extent are removed.
- truncateExtent(long) - Method in class com.tangosol.util.NullImplementation.NullPersistentStore
- truncateExtentInternal(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Truncate the specified extent from the persistent store.
- truncateString(String, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Truncate a string to the specified character count.
- truncateString(String, int) - Static method in class com.tangosol.util.Base
- 
Truncate a string to the specified character count.
- truncateString(Collection<?>, int) - Static method in class com.oracle.coherence.common.base.Formatting
- 
Provide a string representation of elements within the collection until the concatenated string length exceedscLimit.
- truncateString(Collection<?>, int) - Static method in class com.tangosol.util.Base
- 
Provide a string representation of elements within the collection until the concatenated string length exceedscLimit.
- tryAcquire() - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- tryAcquire() - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Acquires a permit from this semaphore, only if one is available at the time of invocation.
- tryAcquire() - Method in interface com.oracle.coherence.concurrent.Semaphore
- 
Acquires a permit from this semaphore, only if one is available at the time of invocation.
- tryAcquire(int) - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- tryAcquire(int) - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Acquires the given number of permits from this semaphore, only if all are available at the time of invocation.
- tryAcquire(int) - Method in interface com.oracle.coherence.concurrent.Semaphore
- 
Acquires the given number of permits from this semaphore, only if all are available at the time of invocation.
- tryAcquire(int, long, TimeUnit) - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- tryAcquire(int, long, TimeUnit) - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Acquires the given number of permits from this semaphore, if all become available within the given waiting time and the current thread has not been interrupted.
- tryAcquire(int, long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.Semaphore
- 
Acquires the given number of permits from this semaphore, if all become available within the given waiting time and the current thread has not been interrupted.
- tryAcquire(long, TimeUnit) - Method in class com.oracle.coherence.concurrent.LocalSemaphore
- tryAcquire(long, TimeUnit) - Method in class com.oracle.coherence.concurrent.RemoteSemaphore
- 
Acquires a permit from this semaphore, if one becomes available within the given waiting time and the current thread has not been interrupted.
- tryAcquire(long, TimeUnit) - Method in interface com.oracle.coherence.concurrent.Semaphore
- 
Acquires a permit from this semaphore, if one becomes available within the given waiting time and the current thread has not been interrupted.
- tryEvict() - Method in class com.tangosol.net.cache.OldCache
- 
Deprecated.Attempt to call evict() when no one else is, to avoid contention on opportunistic attempts at evicting.
- tryLock() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Acquires the lock only if it is not held by another thread at the time of invocation.
- tryLock() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.ReadLock
- 
Acquires the read lock only if the write lock is not held by another thread at the time of invocation.
- tryLock() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Acquires the write lock only if it is not held by another thread at the time of invocation.
- tryLock() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
Try to lock the directory.
- tryLock(long, TimeUnit) - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Acquires the lock if it is not held by another thread within the given waiting time and the current thread has not been interrupted.
- tryLock(long, TimeUnit) - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.ReadLock
- 
Acquires the read lock if the write lock is not held by another thread within the given waiting time and the current thread has not been interrupted.
- tryLock(long, TimeUnit) - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Acquires the write lock if it is not held by another thread within the given waiting time and the current thread has not been interrupted.
- tryLock(Lock, long, TimeUnit) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Attempt to acquire a lock while still respecting the calling thread'stimeout.
- tryLock(Set<K>) - Method in class com.tangosol.net.cache.CachingMap
- 
Lock the keys in the given set without blocking.
- tryUnlock() - Method in class com.tangosol.io.bdb.DatabaseFactory.EnvironmentHolder.DirectoryLock
- 
Try to unlock the directory.
- type() - Method in class com.oracle.coherence.cdi.PofExtractor.Literal
- 
The type being extracted.
- type() - Method in annotation type com.oracle.coherence.cdi.PofExtractor
- 
Returns the root type to extract property from.
- TYPE - Static variable in class com.tangosol.net.management.MBeanAccessor
- 
The "type" key in the ObjectName.
- TYPE_BINARY - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_BOOLEAN - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_DATE - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_DATETIME - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_DECIMAL - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_DEFAULT - Static variable in interface com.tangosol.net.InvocationService
- 
Invocation service type constant.
- TYPE_DEFAULT - Static variable in interface com.tangosol.net.ProxyService
- 
Proxy service type constant.
- TYPE_DISTRIBUTED - Static variable in interface com.tangosol.net.CacheService
- 
DistributedCache service type constant.
- TYPE_DOUBLE - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_INT - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_LOCAL - Static variable in interface com.tangosol.net.CacheService
- 
LocalCache service type constant.
- TYPE_LONG - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_NEAR - Static variable in class com.tangosol.coherence.config.scheme.NearScheme
- 
Service type for near caches.
- TYPE_OPTIMISTIC - Static variable in interface com.tangosol.net.CacheService
- 
OptimisticCache service type constant.
- TYPE_PAGED_TOPIC - Static variable in interface com.tangosol.net.CacheService
- 
PagedTopic service type constant.
- TYPE_PORTABLE - Static variable in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
The type identifier for objects that implement the PortableObject interface.
- TYPE_REMOTE - Static variable in interface com.tangosol.net.CacheService
- 
RemoteCache service type constant.
- TYPE_REMOTE - Static variable in interface com.tangosol.net.InvocationService
- 
Remote invocation service type constant.
- TYPE_REMOTE - Static variable in interface com.tangosol.net.NameService
- 
Remote name service type constant.
- TYPE_REMOTE_GRPC - Static variable in interface com.tangosol.net.CacheService
- 
RemoteGrpcCache service type constant.
- TYPE_REPLICATED - Static variable in interface com.tangosol.net.CacheService
- 
ReplicatedCache service type constant.
- TYPE_SERIALIZABLE - Static variable in class com.tangosol.io.pof.SafeConfigurablePofContext
- 
The type identifier for Java Serializable (including the ExternalizableLite format) objects.
- TYPE_STRING - Static variable in interface com.tangosol.run.xml.XmlValue
- TYPE_TIME - Static variable in interface com.tangosol.run.xml.XmlValue
- TypeAssertion<K,V> - Interface in com.tangosol.net.cache
- 
Defines aNamedMap.Optionfor asserting the type of keys and values used with aNamedCache.
- TypeAssertion.WithTypesAssertion<K,V> - Class in com.tangosol.net.cache
- types() - Method in annotation type com.tangosol.net.management.annotation.Notification
- 
The notification event types the MBean may emit.
U
- UID - Class in com.tangosol.util
- 
A UID is a 128-bit identifier that is almost guaranteed to be unique.
- UID() - Constructor for class com.tangosol.util.UID
- 
Construct a UID (default constructor).
- UID(byte[]) - Constructor for class com.tangosol.util.UID
- 
Construct a UID from a byte array.
- UID(int, long, int) - Constructor for class com.tangosol.util.UID
- 
Construct a UID from its constituent members (advanced constructor).
- UID(DataInput) - Constructor for class com.tangosol.util.UID
- 
Construct a UID from a stream.
- UID(String) - Constructor for class com.tangosol.util.UID
- 
Construct a UID from a String.
- UNARY_OPERATOR_NODE - Static variable in class com.tangosol.coherence.dsltools.precedence.OPToken
- 
The AST node name for a Unary Operator Node.
- unaryOperator(Remote.UnaryOperator<T>) - Static method in class com.tangosol.util.function.Remote
- 
Capture serializable UnaryOperator.
- unbind(String) - Method in interface com.tangosol.net.NameService
- 
Unbinds the named object.
- unbundle(BinaryEntry) - Method in class com.tangosol.net.cache.AbstractBinaryEntryBundler
- 
Un-bundle bundled operation.
- unbundle(Object) - Method in class com.tangosol.net.cache.AbstractKeyBundler
- 
Un-bundle bundled operation.
- unbundle(Object) - Method in class com.tangosol.net.cache.BundlingNamedCache.GetBundler
- 
A pass through the the underlying get operation.
- unbundle(Object) - Method in class com.tangosol.net.cache.BundlingNamedCache.RemoveBundler
- 
A pass through the the underlying remove() operation.
- undecorate(ReadBuffer, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Remove the specified decoration from the passed ReadBuffer and return the resulting contents (which may be undecorated, or contain the remaining decorations).
- undecorate(Binary, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Deprecated.as of Coherence 3.7.2
- UnderloadedFilter(boolean) - Constructor for class com.tangosol.net.partition.SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
- 
Construct an UnderloadedFilter.
- UNENCODED - Static variable in interface com.tangosol.util.HashEncoded
- 
A reserved value that suggests the absence of the encoded hash.
- UNINITIALIZED - com.tangosol.util.SimpleMapIndex.IndexCalculator.CalculatorState
- union(ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule) - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy.QuorumRule
- 
Return a quorum rule composed from this and the specified rule that reflects the "union" of the two rules.
- union(PartitionSet, PartitionSet) - Static method in class com.tangosol.net.partition.PartitionSet
- 
Return a union of the two provided PartitionSets.
- UniqueElement(E) - Constructor for class com.tangosol.util.SortedBag.UniqueElement
- 
Create a UniqueElement to represent the specified element.
- UNIT_CALCULATOR_BINARY - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specifies a unit calculator that assigns an object a weight equal to the number of bytes of memory required to cache the object.
- UNIT_CALCULATOR_EXTERNAL - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specifies a external (custom) unit calculator implementation.
- UNIT_CALCULATOR_FIXED - Static variable in class com.tangosol.net.cache.OldCache
- 
Deprecated.Specifies the default unit calculator that weighs all entries equally as 1.
- UNIT_D - Static variable in class com.tangosol.util.Base
- 
Integer constant representing a unit of days.
- UNIT_H - Static variable in class com.tangosol.util.Base
- 
Integer constant representing a unit of hours.
- UNIT_M - Static variable in class com.tangosol.util.Base
- 
Integer constant representing a unit of minutes.
- UNIT_MS - Static variable in class com.tangosol.util.Base
- 
Integer constant representing a unit of milliseconds.
- UNIT_NS - Static variable in class com.tangosol.util.Base
- 
Integer constant representing a unit of nanoseconds.
- UNIT_S - Static variable in class com.tangosol.util.Base
- 
Integer constant representing a unit of seconds.
- UNIT_US - Static variable in class com.tangosol.util.Base
- 
Integer constant representing a unit of microseconds.
- UnitCalculatorBuilder - Class in com.tangosol.coherence.config.builder
- 
TheUnitCalculatorBuilderclass builds aConfigurableCacheMap.UnitCalculator.
- UnitCalculatorBuilder() - Constructor for class com.tangosol.coherence.config.builder.UnitCalculatorBuilder
- UnitCalculatorProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AUnitCalculatorProcessoris responsible for processing a unit-calculatorXmlElementto produce aUnitCalculatorBuilder.
- UnitCalculatorProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.UnitCalculatorProcessor
- Units - Class in com.tangosol.coherence.config.unit
- 
Unitsis a union ofMemorySizeand unit count.
- Units(long) - Constructor for class com.tangosol.coherence.config.unit.Units
- 
Construct a Units object with the given unit count.
- Units(MemorySize) - Constructor for class com.tangosol.coherence.config.unit.Units
- 
Construct a Units object with the givenMemorySize.
- Units(String) - Constructor for class com.tangosol.coherence.config.unit.Units
- 
Construct a Units object.
- UniversalExtractor<T,E> - Class in com.tangosol.util.extractor
- 
Universal ValueExtractor implementation.
- UniversalExtractor() - Constructor for class com.tangosol.util.extractor.UniversalExtractor
- 
Default constructor (necessary for the ExternalizableLite interface).
- UniversalExtractor(String) - Constructor for class com.tangosol.util.extractor.UniversalExtractor
- 
Construct a UniversalExtractor based on syntax ofsName.
- UniversalExtractor(String, Object[]) - Constructor for class com.tangosol.util.extractor.UniversalExtractor
- 
Construct a UniversalExtractor based on a name and optional parameters.
- UniversalExtractor(String, Object[], int) - Constructor for class com.tangosol.util.extractor.UniversalExtractor
- 
Construct a UniversalExtractor based on a name, optional parameters and the entry extraction target.
- UniversalExtractorBuilder - Class in com.tangosol.coherence.dslquery
- 
AnExtractorBuilderimplementation that will build instances ofUniversalExtractors.
- UniversalExtractorBuilder() - Constructor for class com.tangosol.coherence.dslquery.UniversalExtractorBuilder
- UniversalExtractorsSupplier() - Constructor for class com.oracle.coherence.cdi.ExtractorProducer.UniversalExtractorsSupplier
- UniversalExtractorSupplier() - Constructor for class com.oracle.coherence.cdi.ExtractorProducer.UniversalExtractorSupplier
- UniversalUpdater - Class in com.tangosol.util.extractor
- 
Universal ValueUpdater implementation.
- UniversalUpdater() - Constructor for class com.tangosol.util.extractor.UniversalUpdater
- 
Default constructor (necessary for the ExternalizableLite interface).
- UniversalUpdater(String) - Constructor for class com.tangosol.util.extractor.UniversalUpdater
- 
Construct a UniversalUpdater for the provided name.
- UNKNOWN - com.tangosol.util.SimpleMapIndex.IndexCalculator.CalculatorState
- UNKNOWN - Static variable in class com.oracle.coherence.common.base.StackTrace.StackFrame
- unlink() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Unlink this block (either an Entry or free block) from the appropriate data structures (either the hash bucket or the free list.)
- unlock() - Method in class com.oracle.coherence.concurrent.locks.RemoteLock
- 
Attempts to release this lock.
- unlock() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.ReadLock
- 
Attempts to release this lock.
- unlock() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Attempts to release this lock.
- unlock() - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Unlock this entry.
- unlock(Object) - Method in class com.tangosol.net.cache.ContinuousQueryCache
- unlock(Object) - Method in class com.tangosol.net.cache.NearCache
- 
Unlock the specified item.
- unlock(Object) - Method in class com.tangosol.net.cache.ReadonlyNamedCache
- 
Should not be called.
- unlock(Object) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Unlock the specified item.
- unlock(Object) - Method in interface com.tangosol.util.ConcurrentMap
- 
Unlock the specified item.
- unlock(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterConcurrentMap
- 
Unlock the specified item.
- unlock(Object) - Method in class com.tangosol.util.ConverterCollections.ConverterNamedCache
- 
Unlock the specified item.
- unlock(Object) - Method in class com.tangosol.util.SegmentedConcurrentMap
- 
Unlock the specified item.
- unlock(Object) - Method in class com.tangosol.util.WrapperConcurrentMap
- 
Unlock the specified item.
- UnlockAction() - Constructor for class com.tangosol.util.SegmentedConcurrentMap.UnlockAction
- unlockAll(ConcurrentMap, Collection) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Unlock all the specified keys.
- unlockAllBuckets() - Method in class com.tangosol.util.SegmentedHashMap
- 
Unlock everything.
- unlockAllBuckets(int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Unlock everything, leaving only the segment for the specified bucket locked.
- unlockAllSegments(long) - Method in class com.tangosol.util.SegmentedHashMap
- 
Unlock all segments, except the segment-locks indicated by the specified bit-vector.
- unlockBucket(int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Unlock the segment corresponding to the specified bucket that was previously locked using theSegmentedHashMap.lockBucket(int)method.
- unlockFile(FileLock) - Static method in class com.tangosol.io.FileHelper
- 
Release anexclusive lockon a file.
- unlockInternal(Object) - Method in class com.tangosol.net.cache.SerializationPagedCache
- 
Release the lock on the specified key.
- unlockRead() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Release a read lock on this persistent store.
- unlockSegment(int) - Method in class com.tangosol.util.SegmentedHashMap
- 
Unlock the specified segment previously locked using theSegmentedHashMap.lockSegment(int, boolean)method.
- unlockStorage() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Release an exclusive lock on the data directory underlying this persistent store.
- unlockWrite() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Release a write lock on this persistent store.
- unmarshal(InputStream, MediaType) - Method in class com.tangosol.coherence.rest.io.BinaryMarshaller
- unmarshal(InputStream, MediaType) - Method in class com.tangosol.coherence.rest.io.JacksonJsonMarshaller
- unmarshal(InputStream, MediaType) - Method in class com.tangosol.coherence.rest.io.JaxbXmlMarshaller
- unmarshal(InputStream, MediaType) - Method in class com.tangosol.coherence.rest.io.KeyConverterAdapter
- unmarshal(InputStream, MediaType) - Method in interface com.tangosol.coherence.rest.io.Marshaller
- 
Read an object from the specified stream.
- unmarshal(InputStream, MediaType) - Method in class com.tangosol.coherence.rest.io.StaticContentMarshaller
- unmarshal(InputStream, MediaType) - Method in class com.tangosol.coherence.rest.io.StringMarshaller
- UnmodifiableIterator(LongArray.Iterator<V>) - Constructor for class com.tangosol.util.CopyOnWriteLongArray.UnmodifiableIterator
- 
Construct a wrapper for the specified Iterator.
- unmodifiableSet(Object) - Static method in class com.tangosol.coherence.dslquery.operator.BaseOperator
- 
Return an immutable Set accounting for the provided object being an array, a Collection or a single item in the returned Set.
- UNNAMED_PROVIDER_ID - Static variable in class com.tangosol.coherence.config.builder.SocketProviderBuilder
- 
Default id for unnamed socket providers.
- UNNAMED_PROVIDER_ID - Static variable in class com.tangosol.net.SocketProviderFactory
- 
Default id for unnamed socket and datagram socket providers
- unordered() - Method in interface com.tangosol.util.stream.RemoteStream
- 
Returns an equivalent stream that is unordered.
- Unowned - com.tangosol.net.topic.Subscriber.CommitResultStatus
- 
The position was successfully committed but the committing subscriber does not own the committed channel.
- unquote(String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Convert a string returned from theMBeanHelper.quote(java.lang.String)method to the original string.
- unregister() - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- 
Unregister this listener.
- unregister() - Method in class com.tangosol.net.cache.CachingMap.FrontMapListener
- 
Unregister this listener with the "front" map.
- unregister(CacheService, String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.as of Coherence 3.7.1; useMBeanHelper.unregisterCacheMBean(CacheService, String, String)instead
- unregister(HealthCheck) - Method in interface com.tangosol.net.management.Registry
- 
Unregister a previously registeredHealthCheck.
- unregister(ResourceRegistry, JCacheIdentifier) - Static method in class com.tangosol.coherence.jcache.common.JCacheContext
- unregister(String) - Method in interface com.tangosol.net.management.Registry
- 
Unregister managed objects that match the specified object name or name pattern (query name).
- unregister(String, String) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.as of Coherence 3.7.1; useMBeanHelper.unregisterCacheMBean(String, String)instead
- unregisterBackServiceListener() - Method in class com.tangosol.net.cache.NearCache
- 
Unregister back cache service member listener.
- unregisterCacheMBean(CacheService, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects that are related to the specified cache from the registry.
- unregisterCacheMBean(CacheService, String, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects that are related to the specified cache from the registry.
- unregisterCacheMBean(Cluster, String, String, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects that are related to the specified cache from the registry.
- unregisterCacheMBean(NamedCache, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects related to the given cache name and context from the cluster registry.
- unregisterCacheMBean(String, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects related to the given cache name and context from the cluster registry.
- unregisterCacheMBean(String, String, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects that are related to the specified cache from the registry.
- unregisterCacheObject(CoherenceBasedCacheManager, JCacheIdentifier, MBeanServerRegistrationUtility.ObjectNameType) - Static method in class com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility
- 
Removes registered JCache MBean for a Cache
- unregisterCacheObject(Cache, MBeanServerRegistrationUtility.ObjectNameType) - Static method in class com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility
- 
Removes registered JCache MBean for a Cache
- unregisterDeactivationListener() - Method in class com.tangosol.net.cache.CachingMap
- 
Unregister back cache deactivation listener.
- unregisterDeactivationListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Unregister underlying cache service member listener.
- unregisterEventDispatcher(EventDispatcher) - Method in interface com.tangosol.net.events.EventDispatcherRegistry
- 
Remove the specifiedEventDispatcherfrom the list of known EventDispatchers.
- unregisterEventInterceptor(String) - Method in interface com.tangosol.net.events.InterceptorRegistry
- 
Unregister anEventInterceptor, and remove it from allEventDispatchers.
- unregisterExpiry(Object, long) - Method in class com.tangosol.net.cache.OverflowMap
- 
Unregister the specified key expiry that is registered to expire at the specified time.
- unregisterFrontListener() - Method in class com.tangosol.net.cache.CachingMap
- 
Unregister the global front map listener.
- unregisterIndex(PersistentStore<ReadBuffer>, long, Binary, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Clear the index registration from the specified persistent store.
- unregisterIndices(PersistentStore<ReadBuffer>, long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Clear all index registrations for the specified cache from the specified persistent store.
- unregisterKey(Object) - Method in class com.tangosol.net.cache.SerializationCache
- 
Unregister a key from the SerializationMap.
- unregisterKey(Object) - Method in class com.tangosol.net.cache.SerializationMap
- 
Unregister a key from the SerializationMap.
- unregisterListener() - Method in class com.tangosol.net.cache.CachingMap
- 
Unregister the global back map listener.
- unregisterListener(PersistentStore<ReadBuffer>, long, Binary, long, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Clear the listener registration from the specified persistent store.
- unregisterListener(Object) - Method in class com.tangosol.net.cache.CachingMap
- 
Unregister the back map listener for the specified key.
- unregisterListeners(PersistentStore<ReadBuffer>, long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Clear all listener registrations for the specified cache from the specified persistent store.
- unregisterListeners(Set<K>) - Method in class com.tangosol.net.cache.CachingMap
- 
Unregister the back map listener for the specified keys.
- unregisterLock(PersistentStore<ReadBuffer>, long, Binary, long, long, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Clear the cache entry lock from the specified persistent store.
- unregisterLocks(PersistentStore<ReadBuffer>, long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Clear all cache entry locks for the specified cache from the specified persistent store.
- unregisterMBean() - Method in class com.tangosol.net.cache.CachingMap
- 
Unregister an associated CacheMBean.
- unregisterMBean() - Method in class com.tangosol.net.cache.NearCache
- 
Unregister an associated CacheMBean.
- unregisterMBean() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Unregister the MBean representing this SimpleAssignmentStrategy.
- unregisterPagedTopicMBean(Service, NamedTopic<?>) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects related to the given topic name from the cluster registry.
- unregisterPagedTopicMBean(Service, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects related to the given topic name from the cluster registry.
- unregisterResource(Class<R>, String) - Method in class com.tangosol.util.NullImplementation.NullResourceRegistry
- unregisterResource(Class<R>, String) - Method in interface com.tangosol.util.ResourceRegistry
- 
Unregisters the resource that was previously registered of the specified class and name.
- unregisterResource(Class<R>, String) - Method in class com.tangosol.util.SimpleResourceRegistry
- 
Unregisters the resource that was previously registered of the specified class and name.
- unregisterResource(String) - Method in interface com.tangosol.net.Cluster
- 
Deprecated.UseCluster.getResourceRegistry()to manage resources.
- unregisterServiceListener() - Method in class com.tangosol.net.cache.ContinuousQueryCache
- 
Unregister underlying cache servicemember listener.
- unregisterServices(Set<Service>) - Method in interface com.tangosol.net.ServiceMonitor
- 
Removes the supplied set ofServices from monitoring.
- unregisterServices(Set<Service>) - Method in class com.tangosol.net.SimpleServiceMonitor
- 
Removes the supplied set ofServices from monitoring.
- unregisterSubscriberGroupMBean(PagedTopicService, PagedTopicSubscription) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects related to the given topic subscriber group name from the cluster registry.
- unregisterSubscriberMBean(PagedTopicSubscriber<?>) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects related to the given topic subscriber from the cluster registry.
- unregisterTrigger(PersistentStore<ReadBuffer>, long, Binary, Object) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Clear the trigger registration from the specified persistent store.
- unregisterTriggers(PersistentStore<ReadBuffer>, long) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Clear all trigger registrations for the specified cache from the specified persistent store.
- unregisterUserType(int) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Unregister a user type that was previously registered using the specified type identifier.
- unregisterViewMBean(Cluster, String, String) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects related to the given view cache and context from the cluster registry.
- unregisterViewMBean(NamedCache) - Static method in class com.tangosol.net.management.MBeanHelper
- 
Unregister all managed objects related to the given view cache and context from the cluster registry.
- UNRESOLVED - Static variable in interface com.tangosol.run.xml.XmlHelper.ParameterResolver
- 
A constant that indicates that the parameter cannot be resolved.
- Unsafe - Class in com.tangosol.util
- 
A collection of "back-door" utilities and helpers used internally.
- unscaledValue() - Method in class com.tangosol.io.pof.RawQuad
- 
Get the base-2 unscaled value (mantissa) of the quad value.
- unseal(PersistentStore<ReadBuffer>) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Remove a seal from a PersistentStore.
- UnsolicitedCommitEvent - Interface in com.tangosol.net.events.partition
- 
An UnsolicitedCommitEvent captures changes pertaining to all observed mutations performed against caches that were not directly caused (solicited) by the partitioned service.
- UnsolicitedCommitEvent.Type - Enum in com.tangosol.net.events.partition
- 
The UnsolicitedCommitEvent types.
- UnsolicitedCommitEventHandler(EventObserverSupport.EventObserver<UnsolicitedCommitEvent>) - Constructor for class com.oracle.coherence.cdi.events.EventObserverSupport.UnsolicitedCommitEventHandler
- UnsolicitedCommitEvents - Annotation Type in com.tangosol.net.events.annotation
- 
UnsolicitedCommitInterceptor is an annotation that should be applied toEventInterceptorimplementations that want to receiveUnsolicitedCommitEvents.
- UnsupportedFeatureProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
UnsupportedFeatureProcessor is an ElementProcessor that fails fast highlighting which feature is not supported in this edition of the product.
- UnsupportedFeatureProcessor(String) - Constructor for class com.tangosol.coherence.config.xml.processor.UnsupportedFeatureProcessor
- 
Construct ElementProcessor that reports which feature is not support.
- unwrap(PersistenceEnvironment<R>) - Static method in class com.tangosol.persistence.SafePersistenceWrappers
- 
Return the underlying (non-"Safe") PersistenceEnvironment.
- unwrap(PersistenceManager<R>) - Static method in class com.tangosol.persistence.SafePersistenceWrappers
- 
Return the underlying (non-"Safe") PersistenceManager.
- unwrap(PersistentStore<R>) - Static method in class com.tangosol.persistence.SafePersistenceWrappers
- 
Return the underlying (non-"Safe") PersistentStore.
- unwrap(MapListener<K, V>) - Static method in class com.tangosol.util.MapListenerSupport
- 
Return the inner MapListener skipping any wrapper listeners.
- unwrap(Class[]) - Static method in class com.oracle.coherence.common.base.Classes
- 
Replace wrapper types with appropriate primitive types.
- unwrap(Class[]) - Static method in class com.tangosol.util.ClassHelper
- 
Replace wrapper types with appropriate primitive types.
- unwrap(Class<T>) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCache
- unwrap(Class<T>) - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- unwrap(Class<T>) - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntry
- unwrap(Class<T>) - Method in class com.tangosol.coherence.jcache.common.CoherenceCacheEntryEvent
- unwrap(Class<T>) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughCacheEntryEvent
- unwrap(Class<T>) - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCache
- unwrap(Object) - Method in class com.tangosol.util.SortedBag
- 
Unwrap the specified element (which could be awrappedor an "actual") element.
- unwrap(Throwable) - Static method in class com.tangosol.coherence.jcache.common.Helper
- 
Unwraps a potentially CoherenceWrapperExceptionorPortableExceptionto produce the underlyingThrowable.
- unwrapEvent(MapEvent) - Static method in class com.tangosol.util.MapListenerSupport
- 
Unwrap the specified map event and return the underlying source event.
- UpConverter(Serializer, Serializer) - Constructor for class com.oracle.coherence.grpc.RequestHolder.UpConverter
- update(MBeanAccessor.QueryBuilder.ParsedQuery, Map<String, Object>) - Method in class com.tangosol.net.management.MBeanAccessor
- 
Update all JMX MBeans determined by evaluating the providedMBeanAccessor.QueryBuilder.
- update(Member, ProxyServiceLoad) - Method in class com.tangosol.net.proxy.DefaultProxyServiceLoadBalancer
- update(Member, T) - Method in interface com.tangosol.net.ServiceLoadBalancer
- 
Update the load balancing strategy in response to a change in a Service utilization.
- update(Member, T) - Method in class com.tangosol.net.SimpleServiceLoadBalancer
- 
Update the load balancing strategy in response to a change in a Service utilization.
- update(ValueUpdater<V, T>, T) - Method in interface com.tangosol.coherence.federation.ChangeRecord
- 
Update the modified Entry's value using the givenValueUpdater.
- update(ValueUpdater<V, T>, T) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Update the Entry's value.
- update(ValueUpdater<V, T>, T) - Method in interface com.tangosol.util.InvocableMap.Entry
- 
Update the Entry's value.
- update(ValueUpdater<V, T>, T) - Static method in class com.tangosol.util.Processors
- 
Construct an update processor based on the specifiedValueUpdater.
- update(ValueUpdater<V, U>, U) - Method in class com.tangosol.util.SimpleMapEntry
- 
Update the Entry's value.
- update(ValueUpdater, Object) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Update the Entry's value.
- update(ValueUpdater, Object) - Method in class com.tangosol.util.InvocableMapHelper.RoutingMapTriggerEntry
- update(ID, Remote.BiFunction<? super T, ? super U, ? extends R>, U) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update an entity using specified updater and the new value.
- update(ID, Remote.BiFunction<? super T, ? super U, ? extends R>, U) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update an entity using specified updater and the new value.
- update(ID, Remote.BiFunction<? super T, ? super U, ? extends R>, U, EntityFactory<? super ID, ? extends T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update an entity using specified updater function, and optionalEntityFactorythat will be used to create entity instance if it doesn't already exist in the repository.
- update(ID, Remote.BiFunction<? super T, ? super U, ? extends R>, U, EntityFactory<? super ID, ? extends T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update an entity using specified updater function, and optionalEntityFactorythat will be used to create entity instance if it doesn't already exist in the repository.
- update(ID, Remote.Function<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update an entity using specified updater function.
- update(ID, Remote.Function<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update an entity using specified updater function.
- update(ID, Remote.Function<? super T, ? extends R>, EntityFactory<? super ID, ? extends T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update an entity using specified updater function, and optionalEntityFactorythat will be used to create entity instance if it doesn't already exist in the repository.
- update(ID, Remote.Function<? super T, ? extends R>, EntityFactory<? super ID, ? extends T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update an entity using specified updater function, and optionalEntityFactorythat will be used to create entity instance if it doesn't already exist in the repository.
- update(ID, ValueUpdater<? super T, ? super U>, U) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update an entity using specified updater and the new value.
- update(ID, ValueUpdater<? super T, ? super U>, U) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update an entity using specified updater and the new value.
- update(ID, ValueUpdater<? super T, ? super U>, U, EntityFactory<? super ID, ? extends T>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update an entity using specified updater and the new value, and optionalEntityFactorythat will be used to create entity instance if it doesn't already exist in the repository.
- update(ID, ValueUpdater<? super T, ? super U>, U, EntityFactory<? super ID, ? extends T>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update an entity using specified updater and the new value, and optionalEntityFactorythat will be used to create entity instance if it doesn't already exist in the repository.
- update(Object, Object) - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Update the state of the passed target object using the passed value.
- update(Object, Object) - Method in class com.tangosol.util.extractor.CompositeUpdater
- 
Update the state of the passed target object using the passed value.
- update(Object, Object) - Method in class com.tangosol.util.extractor.PofUpdater
- 
Update the state of the passed target object using the passed value.
- update(Object, Object) - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Update the state of the passed target object using the passed value.
- update(Object, Object) - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Update the state of the passed target object using the passed value.
- update(Object, U) - Method in class com.tangosol.util.extractor.AbstractUpdater
- 
Update the state of the passed target object using the passed value.
- update(String, String, ChangeRecord<K, V>) - Method in interface com.tangosol.coherence.federation.ChangeRecordUpdater
- 
Update theChangeRecord.
- update(String, T) - Static method in class com.tangosol.util.Processors
- 
Construct an update processor for a given method name.
- update(Map.Entry) - Method in class com.tangosol.util.ConditionalIndex
- 
Update this index in response to an update operation on a cache.
- update(Map.Entry) - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Update this index in response to an update operation on a cache.
- update(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
- 
Update this index in response to an update operation on a cache.
- update(Map.Entry<? extends K, ? extends V>) - Method in interface com.tangosol.util.MapIndex
- 
Update this index in response to an update operation on a cache.
- update(T, U) - Method in interface com.tangosol.util.ValueUpdater
- 
Update the state of the passed target object using the passed value.
- updateAll(Filter<?>, Remote.BiFunction<? super T, ? super U, ? extends R>, U) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update multiple entities using specified updater and the new value.
- updateAll(Filter<?>, Remote.BiFunction<? super T, ? super U, ? extends R>, U) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update multiple entities using specified updater and the new value.
- updateAll(Filter<?>, Remote.Function<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update multiple entities using specified updater function.
- updateAll(Filter<?>, Remote.Function<? super T, ? extends R>) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update multiple entities using specified updater function.
- updateAll(Filter<?>, ValueUpdater<? super T, ? super U>, U) - Method in class com.oracle.coherence.repository.AbstractAsyncRepository
- 
Update multiple entities using specified updater and the new value.
- updateAll(Filter<?>, ValueUpdater<? super T, ? super U>, U) - Method in class com.oracle.coherence.repository.AbstractRepository
- 
Update multiple entities using specified updater and the new value.
- updateAndGet(Remote.IntUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(Remote.IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- updateAndGet(Remote.IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- updateAndGet(Remote.IntUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(Remote.IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- updateAndGet(Remote.IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- updateAndGet(Remote.LongUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(Remote.LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- updateAndGet(Remote.LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- updateAndGet(Remote.LongUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(Remote.LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- updateAndGet(Remote.LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- updateAndGet(Remote.UnaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(Remote.UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- updateAndGet(Remote.UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- updateAndGet(Remote.UnaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(Remote.UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- updateAndGet(Remote.UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- updateAndGet(IntUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicInteger
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicInteger
- updateAndGet(IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicInteger
- updateAndGet(IntUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicInteger
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicInteger
- updateAndGet(IntUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicInteger
- updateAndGet(LongUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicLong
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicLong
- updateAndGet(LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicLong
- updateAndGet(LongUnaryOperator) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicLong
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicLong
- updateAndGet(LongUnaryOperator) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicLong
- updateAndGet(UnaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AsyncAtomicReference
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncLocalAtomicReference
- updateAndGet(UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.AsyncRemoteAtomicReference
- updateAndGet(UnaryOperator<V>) - Method in interface com.oracle.coherence.concurrent.atomic.AtomicReference
- 
Atomically updates the current value with the results of applying the given function, returning the updated value.
- updateAndGet(UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.LocalAtomicReference
- updateAndGet(UnaryOperator<V>) - Method in class com.oracle.coherence.concurrent.atomic.RemoteAtomicReference
- updateBinaryValue(Binary) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Update the binary value for this entry.
- updateBinaryValue(Binary) - Method in class com.tangosol.net.cache.ReadWriteBackingMap.Entry
- 
Update the binary value for this entry.
- updateBinaryValue(Binary) - Method in interface com.tangosol.util.BinaryEntry
- 
Update the binary value for this entry.
- updateBinaryValue(Binary) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Update the binary value for this entry.
- updateBinaryValue(Binary) - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- updateBinaryValue(Binary, boolean) - Method in class com.tangosol.net.cache.BackingMapBinaryEntry
- 
Update the binary value for this entry.
- updateBinaryValue(Binary, boolean) - Method in interface com.tangosol.util.BinaryEntry
- 
Update the binary value for this entry.
- updateBinaryValue(Binary, boolean) - Method in class com.tangosol.util.ConverterCollections.ConverterMapEvent.ConverterMapEventBinaryEntry
- 
Update the binary value for this entry.
- updateBinaryValue(Binary, boolean) - Method in class com.tangosol.util.InvocableMapHelper.RoutingBinaryEntry
- updateComplex(Object, Object) - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Implement update of target using reflection or property setter.
- updateCompositeStats() - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Return a JMXPartitionStats that contains calculated MBean Attributes, updated periodically.
- updateCurrentRule() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.MembershipQuorumPolicy
- 
Update the currently applicable quorum rule, possibly changing it to reflect growth or shrinkage of the membership size.
- updateCurrentRule() - Method in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy
- Updated - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any UPDATED event.
- UPDATED - com.tangosol.net.events.partition.cache.EntryEvent.Type
- 
ThisEntryEventis dispatched after one or moreBinaryEntry(s) have been updated in the backing-map.
- Updated.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theUpdatedannotation.
- updateEntry(ValueUpdater<V, U>, Map.Entry<K, V>, U) - Static method in class com.tangosol.util.InvocableMapHelper
- 
Update the specified entry using the specified updater and value.
- updateEntry(Map.Entry<K, V>, U) - Method in class com.tangosol.util.extractor.AbstractUpdater
- 
Update the state of the passed entry using the passed value.
- updateEntry(Map.Entry, Object) - Method in class com.tangosol.util.extractor.PofUpdater
- 
Update the passed entry using the specified value.
- updateExcludedKeys(Map.Entry, boolean) - Method in class com.tangosol.util.SimpleMapIndex
- 
Check the entry against the set of entries not included in the index and update the set if necessary.
- updateFlag(int, boolean) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Update a particular masked flag within the state of the Status object.
- updateFlag(int, boolean) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Update a particular masked flag within the state of the Status object.
- updateForwardEntry(Object, Object) - Method in class com.tangosol.util.SimpleMapIndex
- 
Update a mapping in the forward index map.
- updateInternal(Map.Entry) - Method in class com.tangosol.util.ConditionalIndex
- 
Update this index in response to an update operation on a cache.
- updateInternal(Map.Entry) - Method in class com.tangosol.util.ForwardOnlyMapIndex
- 
Update this index in response to an update operation on a cache.
- updateInternal(Map.Entry) - Method in class com.tangosol.util.SimpleMapIndex
- 
Update this index in response to an update operation on a cache.
- updateInternalValue(Object, long, ExpiryPolicy) - Method in class com.tangosol.coherence.jcache.localcache.LocalCacheValue
- 
Sets the internal value with the additional side-effect of updating the modification time to that which is specified and incrementing the modification count.
- updateLength(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Update the length if the passed length is greater than the current buffer length.
- updateLength(int) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Update the length if the passed length is greater than the current buffer length.
- updateMostRecentTaskTime() - Method in class com.tangosol.util.TaskDaemon
- 
Set the time that the most recent task was run to the current time.
- updatePersistentVersion(Object, Comparable) - Method in class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Update the persistent version of the specified key.
- updateQueuedSize(int) - Method in class com.tangosol.io.AsyncBinaryStore
- 
Update the number of bytes that are pending to be written.
- UpdaterProcessor<K,V,T> - Class in com.tangosol.util.processor
- 
UpdaterProcessor is an EntryProcessor implementations that updates an attribute of an object cached in an InvocableMap.
- UpdaterProcessor() - Constructor for class com.tangosol.util.processor.UpdaterProcessor
- 
Default constructor (necessary for the ExternalizableLite interface).
- UpdaterProcessor(ValueUpdater<V, T>, T) - Constructor for class com.tangosol.util.processor.UpdaterProcessor
- 
Construct an UpdaterProcessor based on the specified ValueUpdater.
- UpdaterProcessor(String, T) - Constructor for class com.tangosol.util.processor.UpdaterProcessor
- 
Construct an UpdaterProcessor for a given method name.
- updateState(int, int) - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Update a particular masked value within the state of the Status object.
- updateState(int, int) - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Update a particular masked value within the state of the Status object.
- UpdateStatement(String, Filter, InvocableMap.EntryProcessor) - Constructor for class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder.UpdateStatement
- 
Construct a UpdateStatement that will update the specified cache.
- UpdateStatementBuilder - Class in com.tangosol.coherence.dslquery.statement
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aUpdateStatementBuilder.UpdateStatement.
- UpdateStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.UpdateStatementBuilder
- UpdateStatementBuilder.UpdateStatement - Class in com.tangosol.coherence.dslquery.statement
- 
Implementation of the CohQL "UPDATE" command.
- updateStatistics() - Method in class com.tangosol.net.cache.AbstractBundler
- 
Update the statistics for this Bundle.
- updateThreadName(Daemon, String) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Append the provided name to the Daemon's thread name if not already appended.
- updateTransientVersion(Object, Comparable) - Method in class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Update the transient version of the specified key.
- updateVersion(Object, Object) - Method in class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Update value's version in the version cache.
- Updating - Annotation Type in com.oracle.coherence.cdi.events
- 
A qualifier annotation used for any UPDATING event.
- UPDATING - com.tangosol.net.events.partition.cache.EntryEvent.Type
- 
ThisEntryEventis dispatched before aBinaryEntryis updated in backing-map.
- Updating.Literal - Class in com.oracle.coherence.cdi.events
- 
An annotation literal for theUpdatingannotation.
- URI_DEFAULT - Static variable in interface com.tangosol.net.CacheFactoryBuilder
- 
Default URI identifier.
- URI_DELIM - Static variable in interface com.tangosol.run.xml.UriSerializable
- 
Delimiter between multiple fields in a URI.
- URI_NULL - Static variable in interface com.tangosol.run.xml.UriSerializable
- 
Token to signify a null field in a URI.
- UriSerializable - Interface in com.tangosol.run.xml
- 
An interface for URI serialization.
- URLCertificateLoader - Class in com.tangosol.net.ssl
- 
APrivateKeyLoaderthat loads aCertificatefile from a URL.
- URLCertificateLoader(XmlValue) - Constructor for class com.tangosol.net.ssl.URLCertificateLoader
- 
Create aURLCertificateLoader.
- URLCertificateLoader(String) - Constructor for class com.tangosol.net.ssl.URLCertificateLoader
- 
Create aURLCertificateLoader.
- URLKeyStoreLoader - Class in com.tangosol.net.ssl
- 
AKeyStoreLoaderthat loads aKeyStorefile from a URL.
- URLKeyStoreLoader(XmlValue) - Constructor for class com.tangosol.net.ssl.URLKeyStoreLoader
- 
Create aURLKeyStoreLoader.
- URLKeyStoreLoader(String) - Constructor for class com.tangosol.net.ssl.URLKeyStoreLoader
- 
Create aURLKeyStoreLoader.
- URLMemberIdentityProvider - Class in com.tangosol.net
- 
AMemberIdentityProviderthat retrieves identity values from URLs, files, or class path resources.
- URLMemberIdentityProvider() - Constructor for class com.tangosol.net.URLMemberIdentityProvider
- URLPasswordProvider - Class in com.tangosol.net
- 
APasswordProviderthat reads the contents of a URL to obtain a password.
- URLPasswordProvider(String) - Constructor for class com.tangosol.net.URLPasswordProvider
- 
Create aURLPasswordProviderthat reads a password from the specified URL.
- URLPasswordProvider(String, boolean) - Constructor for class com.tangosol.net.URLPasswordProvider
- 
Create aURLPasswordProviderthat reads a password from the specified URL.
- URLPrivateKeyLoader - Class in com.tangosol.net.ssl
- 
APrivateKeyLoaderthat loads aPrivateKeyfile in PEM format from a URL.
- URLPrivateKeyLoader(XmlValue) - Constructor for class com.tangosol.net.ssl.URLPrivateKeyLoader
- 
Create aURLPrivateKeyLoader.
- URLPrivateKeyLoader(String) - Constructor for class com.tangosol.net.ssl.URLPrivateKeyLoader
- 
Create aURLPrivateKeyLoader.
- usage(PrintWriter) - Static method in class com.tangosol.coherence.dslquery.QueryPlus.DependenciesHelper
- 
Print the command line usage message to the specified writer.
- USAGE_DEFAULT - Static variable in class com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies
- use() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Increment the use count for this block.
- USE_DEFAULT_VALUE - com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor.EmptyElementBehavior
- 
When an emptyXmlElementis encountered, return a default value.
- USE_POF_STREAMS - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Option: Use POF as the default serialization format.
- USE_XMLBEAN_CLASS_CACHE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Option: Use an XmlBean class cache.
- useBackIterator() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
- 
Switch to an iterator over the back map.
- useDoneIterator() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
- 
Switch to an iterator over nothing.
- useFrontIterator() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
- 
Switch to a snapshot iterator.
- UserData - Variable in class com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.Notification
- useReservation() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
After having successfully made a reservation, this method completes the reservation process by setting the status to processing for the thread that made the reservation.
- UsernameAndPassword - Class in com.tangosol.net.security
- 
Security token containing a username and password.
- UsernameAndPassword(String, char[]) - Constructor for class com.tangosol.net.security.UsernameAndPassword
- 
Construct a new UsernameAndPassword instance.
- UsernameAndPassword(String, String) - Constructor for class com.tangosol.net.security.UsernameAndPassword
- 
Construct a new UsernameAndPassword instance.
- UserTypeReader(PofBufferReader, ReadBuffer.BufferInput, PofContext, int, int) - Constructor for class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Construct a parser for parsing the property values of a user type.
- UserTypeReader(ReadBuffer.BufferInput, PofContext, int, int) - Constructor for class com.tangosol.io.pof.PofBufferReader.UserTypeReader
- 
Construct a parser for parsing the property values of a user type.
- UserTypeWriter(PofBufferWriter, WritingPofHandler, PofContext, int, int) - Constructor for class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Construct a UserTypeWriter for writing the property values of a user type.
- UserTypeWriter(PofBufferWriter, WritingPofHandler, PofContext, int, int, int) - Constructor for class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Construct a UserTypeWriter for writing the property values of a user type.
- UserTypeWriter(PofBufferWriter, WriteBuffer.BufferOutput, PofContext, int, int) - Constructor for class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Construct a UserTypeWriter for writing the property values of a user type.
- UserTypeWriter(WritingPofHandler, PofContext, int, int) - Constructor for class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Construct a UserTypeWriter for writing the property values of a user type.
- UserTypeWriter(WriteBuffer.BufferOutput, PofContext, int, int) - Constructor for class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Construct a UserTypeWriter for writing the property values of a user type.
- useScopeInConfig() - Method in interface com.tangosol.net.ScopeResolver
- 
Returnstrueif any scope set in the defaults section of the XML configuration file should take precedence over any scope decoded from the URI.
- useSnapshotIterator() - Method in class com.tangosol.net.cache.SimpleOverflowMap.KeyIterator
- 
Switch to a snapshot iterator.
- usesRawTypes() - Method in class com.tangosol.coherence.config.CacheMapping
- 
Determines if theCacheMappingis configured to use raw-types (ie: no type checking or constraints)
- usesRawTypes() - Method in class com.tangosol.coherence.config.TopicMapping
- 
Determines if theTopicMappingis configured to use raw-types (ie: no type checking or constraints)
- usesWildcard() - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Determines if theResourceMappingpattern contains a * wildcard.
- using(ParameterizedBuilder<T>, ParameterResolver, ClassLoader, ParameterList) - Static method in class com.tangosol.util.BuilderHelper
- 
Adapts aParameterizedBuilderinto aBuilder.
- using(ValueExtractor<? super V, U>) - Static method in class com.tangosol.net.topic.Subscriber.Convert
- 
Return a Convert option with the specified extractor.
- using(Executor) - Static method in class com.tangosol.net.AsyncNamedMap.Complete
- 
Return aAsyncNamedMap.Completeoption that completes futures using the specifiedExecutor.
- using(T) - Static method in class com.tangosol.util.BuilderHelper
- 
Creates aBuilderthat returns a specified object, for each invocation ofBuilder.realize().
- usingCommonPool() - Static method in class com.tangosol.net.AsyncNamedMap.Complete
- 
Return aAsyncNamedMap.Completeoption that completes futures on the Coherence common thread pool.
- Utf8Reader - Class in com.tangosol.io
- 
A Utf8Reader is used to read character data from an underlying stream.
- Utf8Reader(byte[]) - Constructor for class com.tangosol.io.Utf8Reader
- 
Construct a Utf8Reader that reads the input from a byte array.
- Utf8Reader(InputStream) - Constructor for class com.tangosol.io.Utf8Reader
- 
Construct a Utf8Reader that reads the input from an InputStream.
- Utf8Writer - Class in com.tangosol.io
- 
A Utf8Writer is used to write character data onto an underlying stream.
- Utf8Writer() - Constructor for class com.tangosol.io.Utf8Writer
- 
Construct a Utf8Writer that buffers the output.
- Utf8Writer(OutputStream) - Constructor for class com.tangosol.io.Utf8Writer
- 
Construct a Utf8Writer that puts the output into an OutputStream.
- UUID - Class in com.tangosol.util
- 
A UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique.
- UUID() - Constructor for class com.tangosol.util.UUID
- 
Generate a UUID.
- UUID(byte[]) - Constructor for class com.tangosol.util.UUID
- 
Construct a UUID from a byte array.
- UUID(long, byte[], int, int) - Constructor for class com.tangosol.util.UUID
- 
Build a UUID from its constituent members (advanced constructor).
- UUID(long, InetAddress, int, int) - Constructor for class com.tangosol.util.UUID
- 
Build a UUID from its constituent members (advanced constructor).
- UUID(DataInput) - Constructor for class com.tangosol.util.UUID
- 
Construct a UUID from a stream.
- UUID(String) - Constructor for class com.tangosol.util.UUID
- 
Construct a UUID from a String.
V
- V_BOOLEAN_FALSE - Static variable in interface com.tangosol.io.pof.PofConstants
- V_BOOLEAN_TRUE - Static variable in interface com.tangosol.io.pof.PofConstants
- V_COLLECTION_EMPTY - Static variable in interface com.tangosol.io.pof.PofConstants
- V_FP_NAN - Static variable in interface com.tangosol.io.pof.PofConstants
- V_FP_NEG_INFINITY - Static variable in interface com.tangosol.io.pof.PofConstants
- V_FP_POS_INFINITY - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_0 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_1 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_10 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_11 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_12 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_13 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_14 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_15 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_16 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_17 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_18 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_19 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_2 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_20 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_21 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_22 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_3 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_4 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_5 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_6 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_7 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_8 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_9 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_INT_NEG_1 - Static variable in interface com.tangosol.io.pof.PofConstants
- V_REFERENCE_NULL - Static variable in interface com.tangosol.io.pof.PofConstants
- V_STRING_ZERO_LENGTH - Static variable in interface com.tangosol.io.pof.PofConstants
- VALID_COMMANDS - Static variable in class com.tangosol.net.management.MBeanConnector
- 
Array that contains all valid command line arguments.
- validate() - Method in class com.tangosol.coherence.config.builder.ActionPolicyBuilder.QuorumRule
- 
Throw ConfigurationException if thisActionPolicyBuilder.QuorumRule.m_xmlElementconfiguration violates constraints.
- validate() - Method in class com.tangosol.coherence.config.scheme.AbstractScheme
- 
Validate the properties.
- validate() - Method in class com.tangosol.coherence.config.scheme.ClassScheme
- 
Validate the ClassScheme properties.
- validate() - Method in class com.tangosol.coherence.config.scheme.CustomScheme
- 
Validate the builder properties.
- validate() - Method in class com.tangosol.coherence.jcache.CoherenceBasedCacheManager
- 
Validate if configurations map is valid with this instance.
- validate() - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheConfiguration
- 
Validates thePartitionedCacheConfiguration.
- validate() - Method in class com.tangosol.coherence.jcache.remotecache.RemoteCacheConfiguration
- 
Validates theRemoteCacheConfiguration.
- validate() - Method in class com.tangosol.net.ConfigurableAddressProvider.AddressHolder
- 
Throw IllegalArgumentException if any values are invalid.
- validate() - Method in class com.tangosol.net.TcpDatagramSocketProvider.DefaultDependencies
- 
Validate the dependencies.
- validate() - Method in class com.tangosol.util.AbstractSparseArray.Node
- 
Validate the tree rooted at node is a proper AVL tree.
- validate() - Method in class com.tangosol.util.AbstractSparseArray
- 
Validate that the tree is a proper AVL tree.* Note, Java assertions must be enabled for this to be effective.
- validate() - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- validate(PersistentStore, PartitionedService) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Validate the specified store to check that it has been sealed, indicating that it is eligible to be recovered by the specified service.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractNioManagerBuilder
- 
Validate the builder.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AbstractStoreManagerBuilder
- 
Validate the builder.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.builder.storemanager.AsyncStoreManagerBuilder
- 
Validate the builder.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractCachingScheme
- 
Validate the properties.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.AbstractCompositeScheme
- 
Validate the properties.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BackingMapScheme
- 
Validate the properties.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.BundleManager.BundleConfig
- 
Validate the bundle configuration.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.CaffeineScheme
- 
Validate the properties.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ExternalScheme
- 
Validate the properties.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.LocalScheme
- 
Validate the properties.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.PagedExternalScheme
- 
Validate the properties.
- validate(ParameterResolver) - Method in class com.tangosol.coherence.config.scheme.ReadWriteBackingMapScheme
- 
Validate the properties.
- validate(MapEvent) - Method in class com.tangosol.net.cache.CachingMap
- 
Validate the front map entry for the specified back map event.
- validate(ResourceRegistry) - Method in class com.tangosol.coherence.config.CacheConfig
- 
Validate the cache configuration.
- validate(TransactionMap, Set, Set, Set, Set, Set) - Method in class com.tangosol.run.jca.SimpleValidator
- 
Validate that the content of the TransactionMap is "fit" to be committed into the base map.
- validate(TransactionMap, Set, Set, Set, Set, Set) - Method in interface com.tangosol.util.TransactionMap.Validator
- 
Validate that the content of the TransactionMap is "fit" to be committed into the base map.
- validate(Object, Object) - Method in class com.tangosol.net.cache.SeppukuMapListener
- 
Validate the specified entry and remove it from the Map object affected by this listener if and only if the value is different (implying that the entry has been modified elsewhere).
- validateArchivedSnapshotExistsForService(PersistenceToolsHelper) - Method in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Validate that an archived snapshot f_sSnapshotName exists for the given service f_sServiceName.
- validateAssociated(Associated) - Method in class com.oracle.coherence.common.base.NaturalAssociator
- 
Check if given Associated object generates a circular association.
- validateAssociatedService(PartitionedService) - Method in class com.tangosol.net.partition.MirroringAssignmentStrategy
- 
Validate that the distribution for the specified service is compatible with this service.
- validateBackingMapManager(CacheService) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Ensures that the backing map manager of the specified service was configured by this (or equivalent) factory.
- validateBackingMapManager(CacheService) - Method in class com.tangosol.net.ExtensibleConfigurableCacheFactory
- 
Ensures that the backing map manager of the specified service was configured by this (or equivalent) factory.
- validateBackups(SimpleAssignmentStrategy.AnalysisContext) - Method in class com.tangosol.net.partition.SimpleAssignmentStrategy
- 
Check if there are enough ownership members to maintain the configured backup count, reducing the number of backups otherwise.
- validateBufferSize(int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Verify that the requested buffer size is smaller than the configured maximum.
- validateDir(File) - Static method in class com.tangosol.io.FileHelper
- 
Validate that the given File exists and represents a directory.
- validateEntry(Object, Object, RuntimeException) - Method in class com.tangosol.io.nio.BinaryMap
- 
If the passed key and/or value is not a Binary object, then throw an exception to specify that the key is not Binary, otherwise throw the original exception.
- validateExtentId(long) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Validate the given extent identifier.
- validateGUID(String) - Static method in class com.tangosol.persistence.GUIDHelper
- 
Validate the given GUID.
- validateInsert(TransactionMap, Set) - Method in class com.tangosol.run.jca.SimpleValidator
- 
Validate the set of the inserts.
- validateKey(Object, RuntimeException) - Method in class com.tangosol.io.nio.BinaryMap
- 
If the passed key is not Binary, then throw an exception to specify that the key is not Binary, otherwise throw the original exception.
- validateLoadArray(Class, int, DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Validate that the given class and array length is permitted to be deserialized by consulting any associated ObjectInputFilters.
- validateLoadClass(Class, DataInput) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Validate that the given class is permitted to be deserialized by consulting any associated ObjectInputFilters.
- validateMacroExpansion(String, String, String, int) - Method in class com.tangosol.config.expression.ValueMacroExpression.MacroExpansionProcessor
- 
Validate macro expansion is not self referencing or contain circular references that will never complete expansion.
- validateMetadata() - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistentStore
- 
Validate the metadata
- validatePersistentStoreId(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Validate that the given identifier can be used for a persistent store.
- validateScheme(Scheme) - Method in class com.tangosol.coherence.config.CacheMapping
- validateScheme(Scheme) - Method in class com.tangosol.coherence.config.ResourceMapping
- 
Determine whether the specified schem is valid for this mapping type.
- validateScheme(Scheme) - Method in class com.tangosol.coherence.config.TopicMapping
- validateServiceExists(PersistenceToolsHelper) - Method in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Validate that the service f_sServiceName exists.
- validateSnapshotExistsForService(PersistenceToolsHelper) - Method in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Validate that a snapshot f_sSnapshotName exists for the given service f_sServiceName.
- validateSnapshotName(String) - Method in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Validate that the snapshot name conforms to standard.
- ValidateSnapshotStatement(String, boolean, boolean, String, String) - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder.ValidateSnapshotStatement
- 
Create a ValidateSnapshotStatement the will validate a snapshot on disk to ensure the files are consistent.
- ValidateSnapshotStatementBuilder - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
An implementation of aStatementBuilderthat parses a CohQL term tree to produce an instance of aValidateSnapshotStatementBuilder.ValidateSnapshotStatement.
- ValidateSnapshotStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.statement.persistence.ValidateSnapshotStatementBuilder
- ValidateSnapshotStatementBuilder.ValidateSnapshotStatement - Class in com.tangosol.coherence.dslquery.statement.persistence
- 
Implementation of the CohQL "VALIDATE [ARCHIVED] SNAPSHOT" command.
- validateStoreSealed(PersistentStore<ReadBuffer>) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistenceSnapshotTools
- 
Validate the given store is sealed.
- validateStoreSealed(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager.AbstractPersistenceSnapshotTools
- 
Validate the given store within the GUID is sealed.
- validateTypeId(int) - Method in class com.tangosol.io.pof.SimplePofContext
- 
Ensure that the given user type identifier is valid.
- validateValue(TransactionMap, Set) - Method in class com.tangosol.run.jca.SimpleValidator
- 
Validate the set of the read values.
- validateVersion(TransactionMap, Set) - Method in class com.tangosol.run.jca.SimpleValidator
- 
Validate the set of the updates or deletes.
- validateXsd(String, XmlDocument) - Method in class com.tangosol.run.xml.SaxParser
- 
XSD aware parsing routine; if XML contains an XSD reference to a schemeLocation/noNamespaceSchemaLocation then parse XML using provided XSD for validation.
- ValidatingPofHandler - Class in com.tangosol.io.pof
- 
An implementation of PofHandler that validates a POF stream.
- ValidatingPofHandler() - Constructor for class com.tangosol.io.pof.ValidatingPofHandler
- 
Default constructor.
- ValidatingPofHandler.Complex - Class in com.tangosol.io.pof
- 
A Complex object represents the current complex data structure in the POF stream.
- ValidatingPofHandler.ComplexMap - Class in com.tangosol.io.pof
- 
A ComplexMap object represents a map data structure (potentially with uniform keys or with uniform keys and values) in the POF stream.
- ValidationHandler() - Constructor for class com.tangosol.run.xml.SaxParser.ValidationHandler
- value - Variable in class com.tangosol.util.AnyEvent
- 
The value associated with this event.
- value() - Method in class com.oracle.coherence.cdi.ChainedExtractor.Extractors.Literal
- 
The extractor annotations contained in this annotation.
- value() - Method in annotation type com.oracle.coherence.cdi.ChainedExtractor.Extractors
- 
An array ofChainedExtractors.
- value() - Method in class com.oracle.coherence.cdi.ChainedExtractor.Literal
- 
The value used for the where clause when creating aChainedExtractor.
- value() - Method in annotation type com.oracle.coherence.cdi.ChainedExtractor
- 
Returns the a method or property name to use when creating aChainedExtractor.
- value() - Method in class com.oracle.coherence.cdi.ConfigUri.Literal
- 
The name used to identify a specific resource.
- value() - Method in annotation type com.oracle.coherence.cdi.ConfigUri
- 
The URI used to identify a specific config resource.
- value() - Method in class com.oracle.coherence.cdi.events.Backlog.Literal
- 
The backlog event type.
- value() - Method in annotation type com.oracle.coherence.cdi.events.Backlog
- 
Obtain the type of backlog event.
- value() - Method in class com.oracle.coherence.cdi.events.CacheName.Literal
- 
The name used to identify a specific cache.
- value() - Method in annotation type com.oracle.coherence.cdi.events.CacheName
- 
Obtain the value used to identify a specific cache.
- value() - Method in class com.oracle.coherence.cdi.events.MapName.Literal
- 
The name used to identify a specific map.
- value() - Method in annotation type com.oracle.coherence.cdi.events.MapName
- 
Obtain the value used to identify a specific map.
- value() - Method in class com.oracle.coherence.cdi.events.ParticipantName.Literal
- 
The participant name.
- value() - Method in annotation type com.oracle.coherence.cdi.events.ParticipantName
- 
The participant name.
- value() - Method in class com.oracle.coherence.cdi.events.Processor.Literal
- 
The processor class.
- value() - Method in annotation type com.oracle.coherence.cdi.events.Processor
- 
The processor class.
- value() - Method in class com.oracle.coherence.cdi.events.ScopeName.Literal
- 
The name used to identify a specific scope.
- value() - Method in annotation type com.oracle.coherence.cdi.events.ScopeName
- 
Obtain the value used to identify a specific scope.
- value() - Method in class com.oracle.coherence.cdi.events.ServiceName.Literal
- 
The name used to identify a specific service.
- value() - Method in annotation type com.oracle.coherence.cdi.events.ServiceName
- 
The value used to identify a specific service.
- value() - Method in class com.oracle.coherence.cdi.Name.Literal
- 
The name used to identify a specific resource.
- value() - Method in annotation type com.oracle.coherence.cdi.Name
- 
The name used to identify a specific resource.
- value() - Method in class com.oracle.coherence.cdi.PofExtractor.Extractors.Literal
- 
The extractor annotations contained in this annotation.
- value() - Method in annotation type com.oracle.coherence.cdi.PofExtractor.Extractors
- value() - Method in class com.oracle.coherence.cdi.PropertyExtractor.Extractors.Literal
- 
Obtain the extractor annotations contained in this annotation.
- value() - Method in annotation type com.oracle.coherence.cdi.PropertyExtractor.Extractors
- value() - Method in class com.oracle.coherence.cdi.PropertyExtractor.Literal
- 
The name of the property to extract.
- value() - Method in annotation type com.oracle.coherence.cdi.PropertyExtractor
- 
Returns the a method or property name to use when creating aUniversalExtractor.
- value() - Method in class com.oracle.coherence.cdi.Scope.Literal
- 
Obtain the name value.
- value() - Method in annotation type com.oracle.coherence.cdi.Scope
- 
The scope name or URI used to identify a specificConfigurableCacheFactory.
- value() - Method in class com.oracle.coherence.cdi.SerializerFormat.Literal
- 
The name of the serializer.
- value() - Method in annotation type com.oracle.coherence.cdi.SerializerFormat
- 
Obtain the value used to identify a specific serializer.
- value() - Method in class com.oracle.coherence.cdi.SessionName.Literal
- 
The name used to identify a specific session.
- value() - Method in annotation type com.oracle.coherence.cdi.SessionName
- 
The name used to identify a specific session.
- value() - Method in class com.oracle.coherence.cdi.SubscriberGroup.Literal
- 
The name of the subscriber group.
- value() - Method in annotation type com.oracle.coherence.cdi.SubscriberGroup
- 
The name of the subscriber group.
- value() - Method in class com.oracle.coherence.cdi.WhereFilter.Literal
- 
The CohQL query expression.
- value() - Method in annotation type com.oracle.coherence.cdi.WhereFilter
- 
The CohQL query expression.
- value() - Method in class com.oracle.coherence.concurrent.cdi.Count.Literal
- 
The count for the countdown latch.
- value() - Method in annotation type com.oracle.coherence.concurrent.cdi.Count
- 
The latch count
- value() - Method in class com.oracle.coherence.concurrent.cdi.Permits.Literal
- 
The permits count for the semaphore.
- value() - Method in annotation type com.oracle.coherence.concurrent.cdi.Permits
- 
The permits count
- value() - Method in annotation type com.tangosol.config.annotation.Injectable
- 
The optional name that of which may be used to choose the appropriate value to inject when multiple values of the same type are available to be injected.
- value() - Method in annotation type com.tangosol.config.xml.XmlSimpleName
- 
The simple name of the Xml element or attribute being associated with the class for processing.
- value() - Method in annotation type com.tangosol.io.pof.annotation.PortableProperty
- 
Deprecated.The index of this property.
- value() - Method in annotation type com.tangosol.net.events.annotation.CacheLifecycleEvents
- 
This element specifies all types ofCacheLifecycleEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.CoherenceLifecycleEvents
- 
This element specifies all types ofCoherenceLifecycleEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.EntryEvents
- 
This element specifies all types ofEntryEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.EntryProcessorEvents
- 
This element specifies all types ofEntryProcessorEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.FederatedChangeEvents
- 
This element specifies all types ofFederatedChangeEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.FederatedConnectionEvents
- 
This element specifies all types ofFederatedConnectionEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.FederatedPartitionEvents
- 
This element specifies all types ofFederatedPartitionEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.LifecycleEvents
- 
This element specifies all types ofLifecycleEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.SessionLifecycleEvents
- 
This element specifies all types ofSessionLifecycleEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.TransactionEvents
- 
This element specifies all types ofTransactionEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.TransferEvents
- 
This element specifies all types ofTransferEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.events.annotation.UnsolicitedCommitEvents
- 
This element specifies all types ofUnsolicitedCommitEvent.Types the interceptor would like to be invoked on.
- value() - Method in annotation type com.tangosol.net.management.annotation.Description
- 
Returns the value of the annotation.
- value() - Method in annotation type com.tangosol.net.management.annotation.MetricsLabels
- 
Returns the additional metric tags.
- value() - Method in annotation type com.tangosol.net.management.annotation.MetricsScope
- value() - Method in annotation type com.tangosol.net.management.annotation.MetricsTag
- 
Returns the metrics name, expected to be in snake case, for the MBean attribute.
- value() - Method in annotation type com.tangosol.net.management.annotation.MetricsValue
- value(Remote.ToIntFunction<? super V>) - Static method in class com.tangosol.net.topic.Publisher.OrderBy
- 
Return an OrderBy which will compute the unit-of-order based on thesent value.
- value(ToIntFunction<? super V>) - Static method in class com.tangosol.net.topic.Publisher.OrderBy
- 
Return an OrderBy which will compute the unit-of-order based on thesent value.
- Value - Class in com.tangosol.config.expression
- 
AValueis an immutable object that represents a value whose type is unknown at compile time.
- Value() - Constructor for class com.tangosol.config.expression.Value
- 
Construct anullValue.
- Value(Value) - Constructor for class com.tangosol.config.expression.Value
- Value(XmlValue) - Constructor for class com.tangosol.config.expression.Value
- Value(Object) - Constructor for class com.tangosol.config.expression.Value
- Value(String) - Constructor for class com.tangosol.config.expression.Value
- VALUE - Static variable in class com.tangosol.util.extractor.AbstractExtractor
- 
Indicates that theAbstractExtractor.extractFromEntry(java.util.Map.Entry)operation should use the Entry's value.
- VALUE_FUNCTION_BUILDER - Static variable in class com.tangosol.coherence.dslquery.function.FunctionBuilders
- 
This builder will realize instances of theIdentityExtractoraggregator.
- VALUE_UPDATER - Static variable in class com.tangosol.util.InflatableCollection
- 
Atomic updater for collection values.
- ValueChangeEventFilter<V,E> - Class in com.tangosol.util.filter
- 
Filter which evaluates the content of a MapEvent values based on the specified value extractor.
- ValueChangeEventFilter() - Constructor for class com.tangosol.util.filter.ValueChangeEventFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- ValueChangeEventFilter(ValueExtractor<? super V, ? extends E>) - Constructor for class com.tangosol.util.filter.ValueChangeEventFilter
- 
Construct a ValueChangeEventFilter that evaluates MapEvent values based on the specified extractor.
- ValueChangeEventFilter(String) - Constructor for class com.tangosol.util.filter.ValueChangeEventFilter
- 
Construct a ValueChangeEventFilter that evaluates MapEvent values based on the specified method name.
- ValueExtractor<T,E> - Interface in com.tangosol.util
- 
ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.
- ValueMacroExpression - Class in com.tangosol.config.expression
- 
AValueMacroExpressionis a string value potentially containing expandable macros.
- ValueMacroExpression() - Constructor for class com.tangosol.config.expression.ValueMacroExpression
- 
Default constructor needed for serialization.
- ValueMacroExpression(String) - Constructor for class com.tangosol.config.expression.ValueMacroExpression
- 
Construct aValueMacroExpression.
- ValueMacroExpression.DefaultDelimiterExpansionProcessor - Class in com.tangosol.config.expression
- 
Process macro parameter default delimiter expansion.
- ValueMacroExpression.MacroExpansionProcessor - Class in com.tangosol.config.expression
- 
A Macro Expansion Processor for a macro not containing any registered delimiters.
- ValueMacroExpression.OffsetLengthSubstringExpansionProcessor - Class in com.tangosol.config.expression
- 
Process:offsetand:lengthsubstring expansion.
- ValueMacroExpression.SpaceDefaultDelimiterExpansionProcessor - Class in com.tangosol.config.expression
- 
ValueMacroExpression.SpaceDefaultDelimiterExpansionProcessorperforms DefaultDelimiter expansion processing and disambiguates: -for offset and length from space for default delimiter.
- ValueManipulator<T,V> - Interface in com.tangosol.util
- 
ValueManipulator represents a composition ofValueExtractorandValueUpdaterimplementations.
- valueOf(String) - Static method in enum com.oracle.coherence.cdi.events.Backlog.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor.EmptyElementBehavior
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility.ObjectNameType
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.coherence.jcache.localcache.LocalCacheValue.JCacheSyntheticKind
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.io.pof.DateMode
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.cache.CacheEvent.TransformationState
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.Coherence.Mode
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.annotation.Interceptor.Order
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.application.LifecycleEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.CoherenceLifecycleEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.partition.cache.CacheLifecycleEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.partition.cache.EntryEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.partition.cache.EntryProcessorEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.partition.TransactionEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.partition.TransferEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.partition.UnsolicitedCommitEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.events.SessionLifecycleEvent.Type
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.topic.Publisher.OnFailure
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.net.topic.Subscriber.CommitResultStatus
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.util.aggregator.QueryRecorder.RecordType
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent.Process
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.util.RegistrationBehavior
- 
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.tangosol.util.SimpleMapIndex.IndexCalculator.CalculatorState
- 
Returns the enum constant of this type with the specified name.
- values() - Method in class com.oracle.coherence.caffeine.CaffeineCache
- values() - Static method in enum com.oracle.coherence.cdi.events.Backlog.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.coherence.config.xml.processor.AbstractEmptyElementProcessor.EmptyElementBehavior
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.coherence.jcache.common.MBeanServerRegistrationUtility.ObjectNameType
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.coherence.jcache.localcache.LocalCacheValue.JCacheSyntheticKind
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.tangosol.coherence.rest.EntrySetResource
- 
Get the entries' values.
- values() - Method in class com.tangosol.io.nio.BinaryMap
- 
Returns a collection view of the values contained in this map.
- values() - Static method in enum com.tangosol.io.pof.DateMode
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return a collection of all the values contained in this map.
- values() - Static method in enum com.tangosol.net.cache.CacheEvent.TransformationState
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.tangosol.net.cache.CachingMap
- 
Obtain an collection of the values contained in this map.
- values() - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Returns a collection view of the values contained in this map.
- values() - Static method in enum com.tangosol.net.Coherence.Mode
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.annotation.Interceptor.Order
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.application.LifecycleEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.CoherenceLifecycleEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.EventDispatcher.InterceptorRegistrationEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.partition.cache.CacheLifecycleEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.partition.cache.EntryEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.partition.cache.EntryProcessorEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.partition.TransactionEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.partition.TransferEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.partition.UnsolicitedCommitEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.events.SessionLifecycleEvent.Type
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.tangosol.net.MapViewBuilder
- 
The resultingviewwith both map keys and values.
- values() - Static method in enum com.tangosol.net.partition.SimpleStrategyMBean.HAStatus
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.SocketProviderFactory.Dependencies.ProviderType
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.topic.Publisher.OnFailure
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.tangosol.net.topic.Subscriber.CommitResultStatus
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.tangosol.net.ViewBuilder
- 
The resultingviewwith cache both keys and values.
- values() - Method in class com.tangosol.util.AbstractKeyBasedMap
- 
Returns a collection view of the values contained in this map.
- values() - Static method in enum com.tangosol.util.aggregator.QueryRecorder.RecordType
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.tangosol.util.ConverterCollections.ConverterMap
- values() - Method in class com.tangosol.util.CopyOnWriteMap
- values() - Static method in enum com.tangosol.util.fsm.NonBlockingFiniteStateMachine.CoalescedEvent.Process
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.tangosol.util.NullImplementation.NullMap
- values() - Static method in enum com.tangosol.util.RegistrationBehavior
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.tangosol.util.RestrictedCollections.RestrictedMap
- 
Returns a collection view of the values contained in this map.
- values() - Method in class com.tangosol.util.SafeHashMap
- 
Returns a collection view of the values contained in this map.
- values() - Method in class com.tangosol.util.SafeSortedMap.SubMap
- values() - Method in class com.tangosol.util.SafeSortedMap
- values() - Method in class com.tangosol.util.SegmentedHashMap
- 
Returns a collection view of the values contained in this map.
- values() - Static method in enum com.tangosol.util.SimpleMapIndex.IndexCalculator.CalculatorState
- 
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class com.tangosol.util.WrapperCollections.AbstractWrapperMap
- values() - Method in class com.tangosol.util.WrapperCollections.ConcurrentWrapperMap
- values(CacheRequestHolder<ValuesRequest, Void>, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theValuesRequestrequest passing the results to the providedStreamObserver.
- values(ValuesRequest, StreamObserver<BytesValue>) - Method in interface com.oracle.coherence.grpc.proxy.NamedCacheService
- 
Stream a set of cache values to aStreamObserver.
- values(ValuesRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceGrpcImpl
- values(ValuesRequest, StreamObserver<BytesValue>) - Method in class com.oracle.coherence.grpc.proxy.NamedCacheServiceImpl
- 
Execute theValuesRequestrequest passing the results to the providedStreamObserver.
- values(NamedCache, String, int, int) - Method in interface com.tangosol.coherence.rest.query.Query
- 
Deprecated.As of Coherence 12.2.1. UseQuery.execute(NamedCache, ValueExtractor, String, int, int)instead.
- values(Filter) - Method in interface com.tangosol.util.QueryMap
- 
Return an immutable collection of the values contained in this map that satisfy the criteria expressed by the filter.
- values(Filter<?>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return a collection of the values contained in this map that satisfy the criteria expressed by the filter.
- values(Filter<?>, Comparator<? super V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Return a collection of the values contained in this map that satisfy the criteria expressed by the filter.
- values(Filter<?>, Consumer<? super V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream the values for the entries that satisfy the specified filter to the provided callback.
- values(Filter, Comparator) - Method in interface com.tangosol.util.QueryMap
- 
Return an immutable collection of the values contained in this map that satisfy the criteria expressed by the filter.
- values(InvocableMap<K, V>) - Static method in interface com.tangosol.util.stream.RemoteStream
- 
Create aRemoteStreamof specified map's values.
- values(String, String, String, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aValuesRequest.
- values(String, String, String, ByteString, ByteString) - Static method in class com.oracle.coherence.grpc.Requests
- 
Create aValuesRequest.
- values(Consumer<? super V>) - Method in interface com.tangosol.net.AsyncNamedMap
- 
Stream the values of all the entries contained in this map to the provided callback.
- ValuesCollection() - Constructor for class com.tangosol.io.nio.BinaryMap.ValuesCollection
- ValuesCollection() - Constructor for class com.tangosol.net.cache.OldCache.ValuesCollection
- 
Deprecated.
- ValuesCollection() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.ValuesCollection
- ValuesCollection() - Constructor for class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection
- ValuesCollection() - Constructor for class com.tangosol.util.AbstractKeySetBasedMap.ValuesCollection
- ValuesCollection() - Constructor for class com.tangosol.util.SafeHashMap.ValuesCollection
- ValuesCollection() - Constructor for class com.tangosol.util.SegmentedHashMap.ValuesCollection
- ValuesIterator() - Constructor for class com.tangosol.util.AbstractKeyBasedMap.ValuesCollection.ValuesIterator
- ValueStorageSchemeProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
AnElementProcessorthat creates aBackingMapSchemefor use in a collection scheme.
- ValueStorageSchemeProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.ValueStorageSchemeProcessor
- ValueTypeAssertion<V> - Interface in com.tangosol.net
- 
Defines aNamedCollection.Optionfor asserting the type of values used with aNamedTopic.
- ValueTypeAssertion.WithValueTypeAssertion<V> - Class in com.tangosol.net
- 
Defines aNamedCollection.Optionfor asserting the type of values used with aNamedTopic.
- ValueUpdater<T,U> - Interface in com.tangosol.util
- 
ValueUpdater is used to update an object's state.
- VENDOR - Static variable in annotation type com.tangosol.net.management.annotation.MetricsScope
- 
The full descriptor value to use for vendor scoped metrics.
- verifyMapListener(DefaultConfigurableCacheFactory.CacheInfo, Map, XmlElement, BackingMapManagerContext, ClassLoader, Map) - Method in class com.tangosol.net.DefaultConfigurableCacheFactory
- 
Deprecated.Check whether or not a MapListener has to be instantiated and added to a Map according to a scheme definition.
- verifyNoNulls(Collection, String) - Static method in class com.tangosol.net.cache.OverflowMap
- 
Check the passed collection for nulls, and fail if it contains any.
- verifyNoNulls(Collection, String) - Static method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Check the passed collection for nulls, and fail if it contains any.
- VERSION - Static variable in class com.tangosol.net.CacheFactory
- 
Software version string.
- VERSION_AWARE - Static variable in interface com.tangosol.util.MapListener
- 
A flag that indicates this MapListener should track versions thus allow missed versions to be replayed if supported by the source of events.
- VERSION_ENCODED - Static variable in class com.tangosol.net.CacheFactory
- 
Software version encoded to an int.
- Versionable<T extends Comparable<? super T>> - Interface in com.tangosol.util
- 
An interface for versionable data.
- VersionAwareBufferInput(DataInput, ClassLoader, MessageComponent) - Constructor for class com.tangosol.io.WrapperBufferInput.VersionAwareBufferInput
- 
Construct a WrapperBufferInput that will read from the specified object implementing the DataInput interface.
- VersionAwareBufferOutput(DataOutput, MessageComponent) - Constructor for class com.tangosol.io.WrapperBufferOutput.VersionAwareBufferOutput
- 
Construct a VersionAwareBufferOutput that will write to the specified object implementing the DataOutput interface.
- VersionAwareMapListener<K,V> - Interface in com.tangosol.net.partition
- 
Direct implementations of this interface are generally considered advanced use cases, such as handling event receiver (client process) restarts.
- VersionCacheListener() - Constructor for class com.tangosol.net.cache.VersionedNearCache.VersionCacheListener
- 
Deprecated.
- VersionedBackingMap - Class in com.tangosol.net.cache
- 
Deprecated.as of Coherence 3.2 all the functionality of this class has been superceded by the ReadWriteBackingMap implementation
- VersionedBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheLoader, NamedCache, NamedCache, boolean) - Constructor for class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Construct a VersionedBackingMap using a CacheLoader object.
- VersionedBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheStore, boolean, int, double, NamedCache, NamedCache, boolean) - Constructor for class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Construct a VersionedBackingMap using a CacheStore object.
- VersionedBackingMap(BackingMapManagerContext, ObservableMap, Map, CacheStore, boolean, int, double, NamedCache, NamedCache, boolean, boolean) - Constructor for class com.tangosol.net.cache.VersionedBackingMap
- 
Deprecated.Construct a VersionedBackingMap using a CacheStore object.
- VersionedBackingMap.CacheStoreWrapper - Class in com.tangosol.net.cache
- 
Deprecated.A wrapper around the original CacheStore to allow operations to be overridden and extended.
- VersionedBackingMap.InternalMapListener - Class in com.tangosol.net.cache
- 
Deprecated.A MapListener implementation that listens to the internal cache and routes those events to anyone listening to this VersionedBackingMap.
- VersionedNearCache - Class in com.tangosol.net.cache
- 
Deprecated.as of Coherence 3.2 all the functionality of this class has been superceded by the NearCache implementation
- VersionedNearCache(Map, NamedCache, NamedCache) - Constructor for class com.tangosol.net.cache.VersionedNearCache
- 
Deprecated.Construct a VersionedNearCache.
- VersionedNearCache.VersionCacheListener - Class in com.tangosol.net.cache
- 
Deprecated.A map listener that listens to the VersionCache and invalidates local entries accordingly.
- VersionedOwnership - Class in com.tangosol.net.partition
- 
An extension of the partition Ownership object which also carries a change version.
- VersionedOwnership() - Constructor for class com.tangosol.net.partition.VersionedOwnership
- 
Default constructor (needed for serialization).
- VersionedOwnership(int, int) - Constructor for class com.tangosol.net.partition.VersionedOwnership
- 
Constructs a VersionedOwnership with the provided backup count and version.
- VersionedOwnership(VersionedOwnership) - Constructor for class com.tangosol.net.partition.VersionedOwnership
- 
Copy constructor.
- VersionedPartitions - Interface in com.tangosol.net.partition
- 
VersionedPartitions implementations provide a mapping from partition to version.
- VersionedPartitions.Iterator<T> - Interface in com.tangosol.net.partition
- 
An Iterator for partitions being tracked by aVersionedPartitionsimplementation that allows retrieval of the next partition as aprimitive.
- VersionedPartitions.VersionedIterator - Interface in com.tangosol.net.partition
- 
An Iterator for partitions being tracked by aVersionedPartitionsimplementation that allows retrieval of partition and version.
- versionedPut(V) - Static method in class com.tangosol.util.Processors
- 
Construct a versioned put processor that updates an entry with a new value if and only if the version of the new value matches to the version of the current entry's value (which must exist).
- versionedPut(V, boolean, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct a versioned put processor that updates an entry with a new value if and only if the version of the new value matches to the version of the current entry's value.
- VersionedPut<K,V extends Versionable> - Class in com.tangosol.util.processor
- 
VersionedPut is an EntryProcessor that assumes that entry values implementVersionableinterface and performs anEntry.setValueoperation if and only if the version of the specified value matches to the version of the current value.
- VersionedPut() - Constructor for class com.tangosol.util.processor.VersionedPut
- 
Default constructor (necessary for the ExternalizableLite interface).
- VersionedPut(V) - Constructor for class com.tangosol.util.processor.VersionedPut
- 
Construct a VersionedPut that updates an entry with a new value if and only if the version of the new value matches to the version of the current entry's value (which must exist).
- VersionedPut(V, boolean, boolean) - Constructor for class com.tangosol.util.processor.VersionedPut
- 
Construct a VersionedPut that updates an entry with a new value if and only if the version of the new value matches to the version of the current entry's value.
- versionedPutAll(Map<? extends K, ? extends V>) - Static method in class com.tangosol.util.Processors
- 
Construct a versioned putAll processor that updates an entry with a new value if and only if the version of the new value matches to the version of the current entry's value (which must exist).
- versionedPutAll(Map<? extends K, ? extends V>, boolean, boolean) - Static method in class com.tangosol.util.Processors
- 
Construct a versioned putAll processor that updates an entry with a new value if and only if the version of the new value matches to the version of the current entry's value (which must exist).
- VersionedPutAll<K,V extends Versionable> - Class in com.tangosol.util.processor
- 
VersionedPutAll is an EntryProcessor that assumes that entry values implementVersionableinterface and performs anEntry.setValueoperation only for entries whose versions match to versions of the corresponding current values.
- VersionedPutAll() - Constructor for class com.tangosol.util.processor.VersionedPutAll
- 
Default constructor (necessary for the ExternalizableLite interface).
- VersionedPutAll(Map<? extends K, ? extends V>) - Constructor for class com.tangosol.util.processor.VersionedPutAll
- 
Construct a VersionedPutAll processor that updates an entry with a new value if and only if the version of the new value matches to the version of the current entry's value (which must exist).
- VersionedPutAll(Map<? extends K, ? extends V>, boolean, boolean) - Constructor for class com.tangosol.util.processor.VersionedPutAll
- 
Construct a VersionedPutAll processor that updates an entry with a new value if and only if the version of the new value matches to the version of the current entry's value (which must exist).
- view() - Method in interface com.tangosol.net.NamedCache
- 
Construct aviewof thisNamedCache.
- view() - Method in interface com.tangosol.net.NamedMap
- 
Construct aviewof thisNamedMap.
- View - Annotation Type in com.oracle.coherence.cdi
- 
A qualifier annotation used when injecting a cache view.
- VIEW_TYPE - Static variable in interface com.tangosol.net.management.Registry
- 
String representing the "type" part of ObjectName for the ViewMBean.
- View.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theViewannotation.
- ViewBag(E, E) - Constructor for class com.tangosol.util.SortedBag.ViewBag
- 
Construct a view of the SortedBag, constrained to the range [from, to).
- ViewBuilder<K,V> - Class in com.tangosol.net
- 
TheViewBuilderprovides a means toViewBuilder.build()aview(ContinuousQueryCache) using a fluent pattern / style.
- ViewBuilder(NamedCache<K, V>) - Constructor for class com.tangosol.net.ViewBuilder
- 
Construct a newViewBuilderfor the providedNamedCache.
- ViewBuilder(Supplier<NamedCache<K, V>>) - Constructor for class com.tangosol.net.ViewBuilder
- 
Construct a newViewBuilderfor the providedNamedCache.
- ViewMBean - Interface in com.tangosol.net.management
- ViewMBeanImpl - Class in com.tangosol.net.management
- ViewMBeanImpl(ContinuousQueryCache) - Constructor for class com.tangosol.net.management.ViewMBeanImpl
- 
Constructs aViewMBeanImpl
- ViewScheme - Class in com.tangosol.coherence.config.scheme
- 
A Scheme that realizes both services and caches for Coherence 12.2.1.4 feature named 'views'.
- ViewScheme() - Constructor for class com.tangosol.coherence.config.scheme.ViewScheme
- 
Construct a ViewScheme.
- ViewSchemePreprocessor - Class in com.tangosol.coherence.config.xml.preprocessor
- 
DocumentElementPreprocessor.ElementPreprocessorfor the "view-scheme" element.
- virtuallyEqual(byte[], byte[]) - Static method in class com.tangosol.net.InetAddressHelper
- 
Compare specified raw IP addresses taking into account IPv4-compatible IPv6 addresses.
- visitCacheEntry(long, Binary, Binary) - Method in class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
- visitCacheEntry(long, Binary, Binary) - Method in interface com.tangosol.persistence.CachePersistenceHelper.Visitor
- 
Apply the visitor to the specified cache entry (key-value pair).
- visitIndex(long, Binary, Binary) - Method in class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
- visitIndex(long, Binary, Binary) - Method in interface com.tangosol.persistence.CachePersistenceHelper.Visitor
- 
Apply the visitor to the specified cache index.
- visitListener(long, Binary, long, boolean) - Method in class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
- visitListener(long, Binary, long, boolean) - Method in interface com.tangosol.persistence.CachePersistenceHelper.Visitor
- 
Apply the visitor to the specified cache entry listener.
- visitLock(long, Binary, long, long) - Method in class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
- visitLock(long, Binary, long, long) - Method in interface com.tangosol.persistence.CachePersistenceHelper.Visitor
- 
Apply the visitor to the specified cache entry lock.
- visitTrigger(long, Binary) - Method in class com.tangosol.persistence.AbstractPersistenceTools.StatsVisitor
- visitTrigger(long, Binary) - Method in interface com.tangosol.persistence.CachePersistenceHelper.Visitor
- 
Apply the visitor to the specified trigger.
- VOID - Static variable in class com.oracle.coherence.common.base.Classes
- 
Useful constant for methods with no arguments.
- VOID - Static variable in class com.oracle.coherence.grpc.proxy.BaseGrpcServiceImpl
- 
AVoidvalue to make it obvious the return value in Void methods.
- VOID - Static variable in class com.oracle.coherence.grpc.proxy.ResponseHandlers
- 
AVoidvalue to make it obvious the return value in Void methods.
- VOID - Static variable in class com.tangosol.util.ClassHelper
- 
Useful constant for methods with no arguments.
- VOID_PARAMS - Static variable in class com.oracle.coherence.common.base.Classes
- 
Useful constant for methods with no parameters.
- VOID_PARAMS - Static variable in class com.tangosol.util.ClassHelper
- 
Useful constant for methods with no parameters.
- VolatileHolder<V> - Class in com.oracle.coherence.common.base
- 
VolatileHolder is a basic implementation of the Holder interface where the held object is referenced from a volatile reference.
- VolatileHolder() - Constructor for class com.oracle.coherence.common.base.VolatileHolder
- 
Construct a VolatileHolder with no value.
- VolatileHolder(V) - Constructor for class com.oracle.coherence.common.base.VolatileHolder
- 
Construct a VolatileHolder with an initial value.
W
- wait(Object) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Wait on the the specified monitor while still respecting the calling thread'stimeout.
- wait(Object, long) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Wait on the specified monitor while still respecting the calling thread'stimeout.
- wait(Object, long) - Static method in class com.tangosol.util.Base
- 
Convenience method forObject.wait(long).
- wait(Object, long, int) - Static method in class com.oracle.coherence.common.base.Blocking
- 
Wait on the specified monitor while still respecting the calling thread'stimeout.
- WAIT_FOREVER - Static variable in class com.tangosol.io.AsyncBinaryStore
- 
Special wait time to indicate that a lock should be blocked on until it becomes available.
- waitFor(Object, long) - Method in class com.tangosol.net.cache.ReadWriteBackingMap
- 
Wait for notification on the specified object for no longer than the specified wait time.
- waitForAvailable() - Method in class com.tangosol.net.cache.OverflowMap.Status
- 
Wait for the Entry that this Status represents to become available.
- waitForAvailable() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Wait for the Entry that this Status represents to become available.
- waitForCompleted() - Method in class com.tangosol.net.cache.ReadWriteBackingMap.NonBlockingEntryStoreWrapper.LoadOperationObserver
- 
Synchronize loadInternal or loadAllInternal with responses.
- waitForNotify(long) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Wait for this LockableEntry to be notified that it has been freed by the previous lock-holder.
- waitForNotify(long) - Method in class com.tangosol.util.WrapperConcurrentMap.Lock
- 
Wait for a Lock release notification.
- waitForNotify(long, SegmentedConcurrentMap.ContentionObserver) - Method in class com.tangosol.util.SegmentedConcurrentMap.LockableEntry
- 
Wait for this LockableEntry to be notified that it has been freed by the previous lock-holder.
- waitForOpen(ThreadGateLite.Bar, long) - Method in class com.tangosol.util.ThreadGateLite
- 
Wait for notification that the bar has been lifted completely, i.e. all re-entrant barEntry calls were matched.
- waitForReservationDecision() - Method in class com.tangosol.net.cache.SimpleOverflowMap.Status
- 
Wait for the Entry that this Status represents to no longer be reserved.
- waitForResults(boolean) - Method in class com.tangosol.net.cache.AbstractBundler.Bundle
- 
Wait until results of bundled requests are retrieved.
- waitForServiceStart() - Method in class com.tangosol.net.DefaultCacheServer
- 
Block the calling thread until DefaultCacheServer has called start on all associated services.
- wakeNow() - Method in class com.tangosol.io.AsyncBinaryStore.QueueDaemon
- 
Force the daemon to wake up immediately.
- walk(Term) - Method in interface com.tangosol.coherence.dsltools.termtrees.TermWalker
- 
Return the result of the walking the specified TermTree.
- warn(String) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.WARNINGseverity.
- warn(String, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.WARNINGseverity.
- warn(Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified exception information (message and stack trace) withLogger.WARNINGseverity.
- warn(Supplier<String>) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message withLogger.WARNINGseverity.
- warn(Supplier<String>, Throwable) - Static method in class com.oracle.coherence.common.base.Logger
- 
Log the specified message and the exception stack trace withLogger.WARNINGseverity.
- warnEventSequence(MapEvent, MapEvent) - Static method in class com.tangosol.net.cache.OverflowMap
- 
Issue a one-time warning that events are being received in an order than cannot be explained by normal operation according to the contracts expected by this OverflowMap.
- warnEventSequence(MapEvent, MapEvent) - Static method in class com.tangosol.net.cache.SimpleOverflowMap
- 
Issue a one-time warning that events are being received in an order than cannot be explained by normal operation according to the contracts expected by this OverflowMap.
- warning(SAXParseException) - Method in class com.tangosol.run.xml.SaxParser.ValidationHandler
- 
Routine called when a warning occurs in parser.
- WARNING - Static variable in class com.oracle.coherence.common.base.Logger
- 
Severity 2 indicates a warning.
- warnMissingEvent(Object, int, boolean) - Method in class com.tangosol.net.cache.OverflowMap
- 
An expected event did not get raised.
- warnUnfathomable(MapEvent) - Method in class com.tangosol.net.cache.OverflowMap
- 
Something totally inexplicable has occurred.
- WEEKDAY_NAME - Static variable in class com.tangosol.coherence.dslquery.statement.persistence.AbstractSnapshotStatement
- 
Format weekday name.
- WeightedFilter(Filter, int) - Constructor for class com.tangosol.util.filter.ArrayFilter.WeightedFilter
- 
Construct the WeightedFilter.
- whenClosed() - Method in class com.tangosol.net.Coherence
- 
Obtain aCompletableFuturethat will be completed when thisCoherenceinstance has closed.
- whenDone() - Method in class com.oracle.coherence.grpc.SafeStreamObserver
- WheneverCommandOPToken() - Constructor for class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder.WheneverCommandOPToken
- 
Construct a WheneverCommandOPToken.
- WheneverQueryPlusStatement(boolean) - Constructor for class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder.WheneverQueryPlusStatement
- 
Construct a WheneverQueryPlusStatement to set the error action.
- WheneverStatementBuilder - Class in com.tangosol.coherence.dslquery.queryplus
- 
A class that builds the QueryPlus "WHENEVER" command.
- WheneverStatementBuilder() - Constructor for class com.tangosol.coherence.dslquery.queryplus.WheneverStatementBuilder
- WheneverStatementBuilder.WheneverCommandOPToken - Class in com.tangosol.coherence.dslquery.queryplus
- 
A CohQL OPToken representing the QueryPlus "whenever" command.
- WheneverStatementBuilder.WheneverQueryPlusStatement - Class in com.tangosol.coherence.dslquery.queryplus
- 
The command to set the QueryPlus error action.
- whenStarted() - Method in class com.oracle.coherence.grpc.proxy.GrpcServerController
- 
Obtain aCompletionStagethat will be completed when the gRPC server has started.
- whenStarted() - Method in class com.tangosol.net.Coherence
- 
Obtain aCompletableFuturethat will be completed when thisCoherenceinstance has started.
- WhereFilter - Annotation Type in com.oracle.coherence.cdi
- 
AFilterBindingannotation representing aFilterproduced from a CohQL where clause.
- WhereFilter.Literal - Class in com.oracle.coherence.cdi
- 
An annotation literal for theWhereFilterannotation.
- WhereFilterSupplier() - Constructor for class com.oracle.coherence.cdi.FilterProducer.WhereFilterSupplier
- WHITE_LIST - com.tangosol.coherence.config.builder.SSLSocketProviderDependenciesBuilder.NameListDependencies.USAGE
- WILD_CARD - Static variable in class com.oracle.coherence.cdi.events.AnnotatedMapListener
- 
The wild-card value for cache and service names;
- wipe(int, int) - Method in class com.tangosol.io.nio.BinaryMap
- 
Wipe a portion of the buffer.
- with(int, long) - Method in class com.tangosol.net.cache.CacheEvent
- with(int, long) - Method in class com.tangosol.util.MapEvent
- 
Return a MapEvent that is enriched with the provided partition and version.
- WITH_RAW_TYPES - Static variable in interface com.tangosol.net.cache.TypeAssertion
- 
When used warnings will be issued where types are configured but not used.
- WITH_RAW_TYPES - Static variable in interface com.tangosol.net.ValueTypeAssertion
- 
When used warnings will be issued where types are configured but not used.
- withApplicationContext(Context) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Set theapplication contextto associate to theCoherenceinstance.
- withBaseQuery(String) - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Set the base MBean query.
- withChild(Term) - Method in class com.tangosol.coherence.dsltools.termtrees.AtomicTerm
- 
Join the receiver with the given child Term.
- withChild(Term) - Method in class com.tangosol.coherence.dsltools.termtrees.NodeTerm
- 
Join the receiver with the given child Term.
- withChild(Term) - Method in class com.tangosol.coherence.dsltools.termtrees.Term
- 
Join the receiver with the given child Term.
- withClassLoader(ClassLoader) - Method in class com.tangosol.net.MapViewBuilder
- 
The optionalClassLoaderto use when performing serialization/de-serialization operations.
- withClassLoader(ClassLoader) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set theClassLoaderfor the session to be created.
- withClassLoader(ClassLoader) - Method in class com.tangosol.net.ViewBuilder
- 
The optionalClassLoaderto use when performing serialization/de-serialization operations.
- withCluster(String) - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Set the cluster name to be used in the query.
- withConfigUri(String) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set the cache configuration URI for the session to be created.
- withConverter(ValueExtractor<? super V, U>) - Static method in interface com.tangosol.net.topic.Subscriber
- 
Return a Convert option with the specified extractor.
- withDefaultSession(String) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- withEventInterceptor(EventInterceptor<?>) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Add anEventInterceptorthat will be added to allSessioninstances as they are created on start-up.
- withEventInterceptors(EventInterceptor<?>...) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Add theEventInterceptorinstances that will be added to allSessioninstances as they are created on start-up.
- withEventInterceptors(Iterable<? extends EventInterceptor<?>>) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Add theEventInterceptorinstances that will be added to allSessioninstances as they are created on start-up.
- withFilter(Filter<? super V>) - Static method in interface com.tangosol.net.topic.Subscriber
- 
Return a Filtered option with the specified filter.
- withFilter(String, Filter<String>) - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- withInterceptor(EventInterceptor<?>) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Add anEventInterceptorto add to the session
- withListener(Subscriber.ChannelOwnershipListener...) - Static method in class com.tangosol.net.topic.Subscriber.ChannelOwnershipListeners
- 
Create aSubscriber.ChannelOwnershipListenersoption with one or morelisteners.
- withListener(Subscriber.ChannelOwnershipListener...) - Static method in interface com.tangosol.net.topic.Subscriber
- 
Create aSubscriber.ChannelOwnershipListenersoption with one or morelisteners.
- withMBeanDomainName(String) - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Set the MBean domain name to be used on the query.
- withMember(String) - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Set the member key to be used in the query.
- withMode(Coherence.Mode) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set theCoherence.Modeto use, which will override any mode used by theCoherenceinstance.
- WITHOUT_TYPE_CHECKING - Static variable in interface com.tangosol.net.cache.TypeAssertion
- 
When used no type checking will occur and no warnings will be generated.
- WITHOUT_TYPE_CHECKING - Static variable in interface com.tangosol.net.ValueTypeAssertion
- 
When used no type checking will occur and no warnings will be generated.
- withoutTypeChecking() - Static method in interface com.tangosol.net.cache.TypeAssertion
- 
Obtains aTypeAssertionthat allows NamedCaches to be acquired without type-checking, warnings or log messages.
- withoutTypeChecking() - Static method in interface com.tangosol.net.ValueTypeAssertion
- 
Obtains aValueTypeAssertionthat allows topic to be acquired without type-checking, warnings or log messages.
- withParameter(Parameter) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Add a named parameter to use when resolving configuration parameters.
- withParameter(String, Expression<?>) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Add a named parameter to use when resolving configuration parameters.
- withParameter(String, Object) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Add a named parameter to use when resolving configuration parameters.
- withParameterResolver(ParameterResolver) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set the optionalParameterResolverto use to resolve configuration parameters.
- withPriority(int) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set the session creation priority.
- withRawTypes() - Static method in interface com.tangosol.net.cache.TypeAssertion
- 
Obtains aTypeAssertionthat allows NamedCaches to be acquired and assigned to a raw NamedCache reference.
- withRawTypes() - Static method in interface com.tangosol.net.ValueTypeAssertion
- 
Obtains aValueTypeAssertionthat allows topic to be acquired and assigned to a rawNamedTopicreference.
- withScopeName(String) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set the scope name for the session to be created.
- withService(String) - Method in class com.tangosol.net.management.MBeanAccessor.QueryBuilder
- 
Set the service name to be used in the query.
- withSession(SessionConfiguration) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Add aSessionConfigurationto theCoherenceinstance that will be used to create the correspondingSessionon start-up.
- withSessionProvider(SessionProvider) - Method in class com.tangosol.net.SessionConfiguration.Builder
- 
Set theSessionProviderto use.
- withSessions(SessionConfiguration...) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Add theSessionConfigurationinstances to theCoherenceinstance that will be used to create the correspondingSessioninstances on start-up.
- withSessions(Iterable<? extends SessionConfiguration>) - Method in class com.tangosol.net.CoherenceConfiguration.Builder
- 
Add theSessionConfigurationinstances to theCoherenceinstance that will be used to create the correspondingSessioninstances on start-up.
- withType(Class<V>) - Static method in interface com.tangosol.net.ValueTypeAssertion
- 
Obtains aValueTypeAssertionthat asserts the specified types are configured for a topic.
- withTypes(Class<K>, Class<V>) - Static method in interface com.tangosol.net.cache.TypeAssertion
- 
Obtains aTypeAssertionthat asserts the specified types are configured for a cache.
- WithTypesAssertion(Class<K>, Class<V>) - Constructor for class com.tangosol.net.cache.TypeAssertion.WithTypesAssertion
- 
ConstructsTypeAssertion.WithTypesAssertion
- WithValueTypeAssertion(Class<V>) - Constructor for class com.tangosol.net.ValueTypeAssertion.WithValueTypeAssertion
- 
ConstructsValueTypeAssertion.WithValueTypeAssertion
- wrap(PersistenceEnvironment<ReadBuffer>) - Method in class com.tangosol.coherence.config.builder.PersistenceEnvironmentParamBuilder
- 
Wrap aPersistenceEnvironmentwith a SafePersistenceEnvironment.
- wrap(PersistenceManager<R>) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceEnvironment
- 
Wrap the specified manager in a SafePersistenceManager implementation.
- wrap(PersistentStore<R>) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Wrap the specified store in a SafePersistentStore implementation.
- wrap(E) - Method in class com.tangosol.util.SortedBag
- 
Wrap the specified element to ensure uniqueness.
- wrapCacheLoader(CacheLoader<K, V>) - Static method in class com.tangosol.net.cache.CacheLoaderCacheStore
- 
Create a CacheStore wrapper for the passed CacheLoader.
- wrapEntry(Map.Entry) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Wrap an Entry from the Entry Set to make a Restricted Entry.
- wrapEntry(Map.Entry<FK, FV>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Wrap an Entry from the Entry Set to make a Converter Entry.
- wrapIterator(Iterator) - Method in class com.tangosol.util.RestrictedCollections.RestrictedEntrySet
- 
Wrap an Iterator from the Entry Set to make a Restricted Iterator.
- wrapIterator(Iterator<Map.Entry<FK, FV>>) - Method in class com.tangosol.util.ConverterCollections.ConverterEntrySet
- 
Wrap an Iterator from the Entry Set to make a Converter Iterator.
- WrapperBinaryStore(BinaryStore) - Constructor for class com.tangosol.net.cache.SerializationPagedCache.WrapperBinaryStore
- 
Construct a WrapperBinaryStore.
- WrapperBufferInput - Class in com.tangosol.io
- 
This is an imitation BufferInput implementation that provides the BufferInput interface by delegating to an object that implements the DataInput interface.
- WrapperBufferInput(DataInput) - Constructor for class com.tangosol.io.WrapperBufferInput
- 
Construct a WrapperBufferInput that will read from the specified object implementing the DataInput interface.
- WrapperBufferInput(DataInput, ClassLoader) - Constructor for class com.tangosol.io.WrapperBufferInput
- 
Construct a WrapperBufferInput that will read from the specified object implementing the DataInput interface.
- WrapperBufferInput.VersionAwareBufferInput - Class in com.tangosol.io
- 
A BufferInput implementation that in addition to delegating to the given DataInput provides an API to check whether the sender of the content of this BufferInput runs a version that supersedes (greater or equal to) the specified version.
- WrapperBufferOutput - Class in com.tangosol.io
- 
This is an imitation BufferOutput implementation that provides the BufferOutput interface by delegating to an object that implements the DataOutput interface.
- WrapperBufferOutput(DataOutput) - Constructor for class com.tangosol.io.WrapperBufferOutput
- 
Construct a WrapperBufferOutput that will write to the specified object implementing the DataOutput interface.
- WrapperBufferOutput.VersionAwareBufferOutput - Class in com.tangosol.io
- 
A BufferOutput implementation that in addition to delegating to the given DataOutput provides an API to check whether the recipients of the content of this BufferOutput run versions that supersede (greater or equal to) the specified version.
- WrapperCacheService - Class in com.tangosol.net
- 
CacheService implementation that delegates to a wrapped CacheService instance.
- WrapperCacheService(CacheService) - Constructor for class com.tangosol.net.WrapperCacheService
- 
Create a new WrapperCacheService that delegates to the given CacheService instance.
- WrapperCachingScheme - Class in com.tangosol.coherence.config.scheme
- 
A simple implementation of theCachingSchemeinterface built as a wrapper around another CachingScheme implementation.
- WrapperCachingScheme(CachingScheme) - Constructor for class com.tangosol.coherence.config.scheme.WrapperCachingScheme
- 
Create aWrapperCachingSchemethat wraps a specifiedCachingScheme.
- WrapperCollections - Class in com.tangosol.util
- 
A collection of abstract Collection implementation classes for wrapping Collection types.
- WrapperCollections() - Constructor for class com.tangosol.util.WrapperCollections
- WrapperCollections.AbstractWrapperCollection<E> - Class in com.tangosol.util
- 
Collection implementation which delegates all calls to another Collection.
- WrapperCollections.AbstractWrapperEntry<K,V> - Class in com.tangosol.util
- 
Map.Entry implementation which delegates all calls to another Map.Entry.
- WrapperCollections.AbstractWrapperIterator<E> - Class in com.tangosol.util
- 
Iterator implementation which delegates all calls to another Iterator.
- WrapperCollections.AbstractWrapperList<E> - Class in com.tangosol.util
- 
List implementation which delegates all calls to another List.
- WrapperCollections.AbstractWrapperListIterator<E> - Class in com.tangosol.util
- 
ListIterator implementation which delegates all calls to another ListIterator.
- WrapperCollections.AbstractWrapperLongArray<V> - Class in com.tangosol.util
- 
Abstract wrapper implementation for LongArrays.
- WrapperCollections.AbstractWrapperMap<K,V> - Class in com.tangosol.util
- 
Map implementation which delegates all calls to another Map.
- WrapperCollections.AbstractWrapperSet<E> - Class in com.tangosol.util
- 
Set implementation which delegates all calls to another Set.
- WrapperCollections.AbstractWrapperSortedMap<K,V> - Class in com.tangosol.util
- WrapperCollections.AbstractWrapperSortedSet<E> - Class in com.tangosol.util
- 
SortedSet implementation which delegates all calls to another SortedSet.
- WrapperCollections.ConcurrentWrapperCollection<E> - Class in com.tangosol.util
- 
Collection implementation which uses a ReadWriteLock to manage concurrent access to an underlying Collection.
- WrapperCollections.ConcurrentWrapperEntry<K,V> - Class in com.tangosol.util
- 
Map Entry implementation which uses a ReadWriteLock to manage concurrent access to an underlying Map Entry.
- WrapperCollections.ConcurrentWrapperEntrySet<K,V> - Class in com.tangosol.util
- 
Map Entry Set implementation which uses a ReadWriteLock to manage concurrent access to the underlying Entry objects.
- WrapperCollections.ConcurrentWrapperMap<K,V> - Class in com.tangosol.util
- 
Map implementation which uses a ReadWriteLock to manage concurrent access to an underlying Map.
- WrapperCollections.ConcurrentWrapperSet<E> - Class in com.tangosol.util
- 
Set implementation which uses a ReadWriteLock to manage concurrent access to an underlying Set.
- WrapperComparator(Comparator) - Constructor for class com.tangosol.util.SortedBag.WrapperComparator
- 
Construct a WrapperComparator around the specified comparator.
- WrapperConcurrentMap<K,V> - Class in com.tangosol.util
- 
A simple implementation of ConcurrentMap interface built as a wrapper around any Map implementation.
- WrapperConcurrentMap(Map<K, V>) - Constructor for class com.tangosol.util.WrapperConcurrentMap
- 
Construct a ConcurrentMap wrapper based on the specified map with locking enforced for put, remove and clear operations.
- WrapperConcurrentMap(Map<K, V>, boolean, long) - Constructor for class com.tangosol.util.WrapperConcurrentMap
- 
Construct a ConcurrentMap wrapper based on the specified map.
- WrapperConcurrentMap.Lock - Class in com.tangosol.util
- 
A lock object.
- WrapperDataInputStream - Class in com.tangosol.io
- 
This is an imitation DataInputStream class that provides the DataInput interface by delegating to an object that implements the DataInput interface.
- WrapperDataInputStream(DataInput) - Constructor for class com.tangosol.io.WrapperDataInputStream
- 
Construct a WrapperDataInputStream that will read from the specified object implementing the DataInput interface.
- WrapperDataInputStream(DataInput, ClassLoader) - Constructor for class com.tangosol.io.WrapperDataInputStream
- 
Construct a WrapperDataInputStream that will read from the specified object implementing the DataInput interface.
- WrapperDataOutputStream - Class in com.tangosol.io
- 
This is an imitation DataOutputStream class that provides the DataOutput interface by delegating to an object that implements the DataOutput interface.
- WrapperDataOutputStream(DataOutput) - Constructor for class com.tangosol.io.WrapperDataOutputStream
- 
Construct a WrapperDataOutputStream that will output to the specified object implementing the DataOutput interface.
- WrapperException - Exception in com.tangosol.util
- 
A WrapperException wraps a Throwable object as a RuntimeException.
- WrapperException(String) - Constructor for exception com.tangosol.util.WrapperException
- 
Construct a WrapperException with a specified detail message.
- WrapperException(Throwable) - Constructor for exception com.tangosol.util.WrapperException
- 
Construct a WrapperException from a Throwable object.
- WrapperException(Throwable, String) - Constructor for exception com.tangosol.util.WrapperException
- 
Construct a WrapperException from a Throwable object and an additional description.
- WrapperInputStream - Class in com.tangosol.io
- 
This is an InputStream class that delegates to another InputStream.
- WrapperInputStream() - Constructor for class com.tangosol.io.WrapperInputStream
- 
Construct an uninitialized WrapperInputStream.
- WrapperInputStream(InputStream) - Constructor for class com.tangosol.io.WrapperInputStream
- 
Construct a WrapperInputStream that will input from the specified InputStream object.
- WrapperInvocationService - Class in com.tangosol.net
- 
InvocationService implementation that delegates to a wrapped InvocationService instance.
- WrapperInvocationService(InvocationService) - Constructor for class com.tangosol.net.WrapperInvocationService
- 
Create a new WrapperInvocationService that delegates to the given InvocationService instance.
- WrapperListener(MapListener<K, V>) - Constructor for class com.tangosol.util.MapListenerSupport.WrapperListener
- 
Construct WrapperSynchronousListener.
- WrapperMBeanServerProxy - Class in com.tangosol.net.management
- 
AMBeanServerProxythat wraps aMBeanServer.
- WrapperMBeanServerProxy(Supplier<MBeanServer>) - Constructor for class com.tangosol.net.management.WrapperMBeanServerProxy
- 
Create aWrapperMBeanServerProxy.
- WrapperMBeanServerProxy(MBeanServer) - Constructor for class com.tangosol.net.management.WrapperMBeanServerProxy
- 
Create aWrapperMBeanServerProxy.
- WrapperNamedCache<K,V> - Class in com.tangosol.net.cache
- 
A simple implementation of NamedCache interface built as a wrapper around any Map implementation.
- WrapperNamedCache(String) - Constructor for class com.tangosol.net.cache.WrapperNamedCache
- 
Construct a NamedCache wrapper for an empty HashMap.
- WrapperNamedCache(Map<K, V>, String) - Constructor for class com.tangosol.net.cache.WrapperNamedCache
- 
Construct a NamedCache wrapper based on the specified map.
- WrapperNamedCache(Map<K, V>, String, CacheService) - Constructor for class com.tangosol.net.cache.WrapperNamedCache
- 
Construct a NamedCache wrapper based on the specified map.
- WrapperObjectInputStream - Class in com.tangosol.io
- 
This is an imitation ObjectInputStream class that provides the ObjectInput interface by delegating to an object that implements the ObjectInput interface.
- WrapperObjectInputStream(ObjectInput) - Constructor for class com.tangosol.io.WrapperObjectInputStream
- 
Construct a WrapperObjectInputStream that will read from the specified object implementing the ObjectInput interface.
- WrapperObjectOutputStream - Class in com.tangosol.io
- 
This is an imitation ObjectOutputStream class that provides the ObjectOutput interface by delegating to an object that implements the ObjectOutput interface.
- WrapperObjectOutputStream(ObjectOutput) - Constructor for class com.tangosol.io.WrapperObjectOutputStream
- 
Construct a WrapperObjectOutputStream that will output to the specified object implementing the ObjectOutput interface.
- WrapperObservableMap<K,V> - Class in com.tangosol.util
- 
A simple implementation of ObservableMap interface built as a wrapper around any Map implementation.
- WrapperObservableMap(Map<K, V>) - Constructor for class com.tangosol.util.WrapperObservableMap
- 
Construct an ObservableMap wrapper based on the specified map.
- WrapperObservableMap(Map<K, V>, boolean) - Constructor for class com.tangosol.util.WrapperObservableMap
- 
Construct an ObservableMap wrapper based on the specified map.
- WrapperObservableMap.InternalListener - Class in com.tangosol.util
- 
An internal MapListener that listens to the wrapped map.
- WrapperOutputStream - Class in com.tangosol.io
- 
This is an OutputStream class that delegates to another OutputStream.
- WrapperOutputStream() - Constructor for class com.tangosol.io.WrapperOutputStream
- 
Construct an uninitialized WrapperOutputStream.
- WrapperOutputStream(OutputStream) - Constructor for class com.tangosol.io.WrapperOutputStream
- 
Construct a WrapperOutputStream that will output to the specified OutputStream object.
- WrapperPrimingListener(MapListener) - Constructor for class com.tangosol.util.MapListenerSupport.WrapperPrimingListener
- WrapperPrimingListener(MapListener<Object, Object>) - Constructor for class com.oracle.coherence.grpc.proxy.MapListenerProxy.WrapperPrimingListener
- 
Constructs a newWrapperPrimingListenerthat will delegate map events to the providedMapListener.
- WrapperQueryRecorderFilter<T> - Class in com.tangosol.util.filter
- 
QueryRecorderFilter wrapper class.
- WrapperQueryRecorderFilter(Filter<T>) - Constructor for class com.tangosol.util.filter.WrapperQueryRecorderFilter
- 
Construct a WrapperQueryRecorderFilter.
- WrapperReentrantGate - Class in com.tangosol.util
- 
A Gate implementation that allows for 2^31 reentrant enter calls by a single thread.
- WrapperReentrantGate() - Constructor for class com.tangosol.util.WrapperReentrantGate
- 
Default constructor.
- WrapperReentrantGate(Gate<Void>) - Constructor for class com.tangosol.util.WrapperReentrantGate
- 
Construct a WrapperReentrantGate around the specified underlying gate.
- WrapperService - Class in com.tangosol.net
- 
Service implementation that delegates to a wrapped Service instance.
- WrapperService(Service) - Constructor for class com.tangosol.net.WrapperService
- 
Create a new WrapperService that delegates to the given Service instance.
- WrapperSessionConfiguration - Class in com.tangosol.net
- 
ASessionConfigurationthat delegates to anotherSessionConfiguration.
- WrapperSessionConfiguration(SessionConfiguration) - Constructor for class com.tangosol.net.WrapperSessionConfiguration
- 
Create aWrapperSessionConfiguration.
- WrapperSocketAddressProviderBuilder - Class in com.tangosol.coherence.config.builder
- 
The WrapperSocketAddressProviderBuilder wraps an AddressProviderBuilder so that it can produce a SocketAddressProvider.
- WrapperSocketAddressProviderBuilder(AddressProviderBuilder) - Constructor for class com.tangosol.coherence.config.builder.WrapperSocketAddressProviderBuilder
- 
Construct a WrapperSocketAddressProviderBuilder.
- WrapperStreamFactory - Interface in com.tangosol.io
- 
Deprecated.As of Coherence 3.7, deprecated with no replacement.
- WrapperStreamFactoryListProcessor - Class in com.tangosol.coherence.config.xml.processor
- 
Deprecated.
- WrapperStreamFactoryListProcessor() - Constructor for class com.tangosol.coherence.config.xml.processor.WrapperStreamFactoryListProcessor
- 
Deprecated.
- WrapperSynchronousListener(MapListener<K, V>) - Constructor for class com.tangosol.util.MapListenerSupport.WrapperSynchronousListener
- 
Construct WrapperSynchronousListener.
- write(byte[]) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes all the bytes in the arrayab.
- write(byte[]) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes all the bytes in the arrayab.
- write(byte[]) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writes all the bytes in the arrayab.
- write(byte[]) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes all the bytes in the arrayab.
- write(byte[]) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- write(byte[]) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes all the bytes in the arrayab.
- write(byte[]) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes all the bytes in the arrayab.
- write(byte[]) - Method in class com.tangosol.io.WrapperOutputStream
- 
Writes all the bytes in the arrayab.
- write(byte[]) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- 
Writes all the bytes in the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.Base64OutputStream
- 
Writeslenbytes from the specified byte array starting at offsetoffto this output stream.
- write(byte[], int, int) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Writeslenbytes from the specified byte array starting at offsetoffto this output stream.
- write(byte[], int, int) - Method in class com.tangosol.io.nio.ByteBufferOutputStream
- 
Writeslenbytes from the specified byte array starting at offsetoffto this output stream.
- write(byte[], int, int) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- write(byte[], int, int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.WrapperOutputStream
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(byte[], int, int) - Method in class com.tangosol.io.WriterPrintStream
- 
Writelenbytes from the specified byte array starting at offsetoffto this stream.
- write(byte[], int, int) - Method in class com.tangosol.net.DatagramPacketOutputStream
- 
Writes len bytes from the specified byte array starting at offset off to this output stream.
- write(byte[], int, int) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- 
Writescbbytes starting at offsetoffrom the arrayab.
- write(char[]) - Method in class com.tangosol.io.Utf8Writer
- 
Write an array of characters.
- write(char[]) - Method in class com.tangosol.util.NullImplementation.NullWriter
- write(char[], int, int) - Method in class com.tangosol.io.IndentingWriter
- 
Write a portion of an array of characters.
- write(char[], int, int) - Method in class com.tangosol.io.Utf8Writer
- 
Write a portion of an array of characters.
- write(char[], int, int) - Method in class com.tangosol.util.NullImplementation.NullWriter
- write(int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.io.Base64OutputStream
- 
Writes the specified byte to this output stream.
- write(int) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.io.IndentingWriter
- 
Write a single character.
- write(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.io.MultiByteArrayOutputStream
- 
Writes the specified byte to this output stream.
- write(int) - Method in class com.tangosol.io.nio.ByteBufferOutputStream
- 
Writes the specified byte to this output stream.
- write(int) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- write(int) - Method in class com.tangosol.io.Utf8Writer
- 
Write a single character.
- write(int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.io.WrapperOutputStream
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.io.WriterPrintStream
- 
Write the specified byte to this stream.
- write(int) - Method in class com.tangosol.net.CompressionFilter.DeflaterOutputShell
- 
Deprecated.Overrides the underlyingDeflaterOutputStream.write(int)implementation making it more memory efficient.
- write(int) - Method in class com.tangosol.net.DatagramPacketOutputStream
- 
Writes the specified byte to this output stream.
- write(int) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- 
Writes the eight low-order bits of the argumentb.
- write(int) - Method in class com.tangosol.util.NullImplementation.NullWriter
- write(int, byte) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Store the specified byte at the specified offset within the buffer.
- write(int, byte) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Store the specified byte at the specified offset within the buffer.
- write(int, byte) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Store the specified byte at the specified offset within the buffer.
- write(int, byte) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Store the specified byte at the specified offset within the buffer.
- write(int, byte) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Store the specified byte at the specified offset within the buffer.
- write(int, byte) - Method in interface com.tangosol.io.WriteBuffer
- 
Store the specified byte at the specified offset within the buffer.
- write(int, byte[]) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Store the specified bytes at the specified offset within the buffer.
- write(int, byte[]) - Method in interface com.tangosol.io.WriteBuffer
- 
Store the specified bytes at the specified offset within the buffer.
- write(int, byte[], int, int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Store the specified number of bytes from the specified location within the passed byte array at the specified offset within this buffer.
- write(int, byte[], int, int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Store the specified number of bytes from the specified location within the passed byte array at the specified offset within this buffer.
- write(int, byte[], int, int) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Store the specified number of bytes from the specified location within the passed byte array at the specified offset within this buffer.
- write(int, byte[], int, int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Store the specified number of bytes from the specified location within the passed byte array at the specified offset within this buffer.
- write(int, byte[], int, int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Store the specified number of bytes from the specified location within the passed byte array at the specified offset within this buffer.
- write(int, byte[], int, int) - Method in interface com.tangosol.io.WriteBuffer
- 
Store the specified number of bytes from the specified location within the passed byte array at the specified offset within this buffer.
- write(int, InputStreaming) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Store the remaining contents of the specified InputStreaming object at the specified offset within this buffer.
- write(int, InputStreaming) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Store the remaining contents of the specified InputStreaming object at the specified offset within this buffer.
- write(int, InputStreaming) - Method in interface com.tangosol.io.WriteBuffer
- 
Store the remaining contents of the specified InputStreaming object at the specified offset within this buffer.
- write(int, InputStreaming, int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Store the specified number of bytes from the specified InputStreaming object at the specified offset within this buffer.
- write(int, InputStreaming, int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Store the specified number of bytes from the specified InputStreaming object at the specified offset within this buffer.
- write(int, InputStreaming, int) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Store the specified number of bytes from the specified InputStreaming object at the specified offset within this buffer.
- write(int, InputStreaming, int) - Method in interface com.tangosol.io.WriteBuffer
- 
Store the specified number of bytes from the specified InputStreaming object at the specified offset within this buffer.
- write(int, ReadBuffer) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Store the contents of the specified ReadBuffer at the specified offset within this buffer.
- write(int, ReadBuffer) - Method in interface com.tangosol.io.WriteBuffer
- 
Store the contents of the specified ReadBuffer at the specified offset within this buffer.
- write(int, ReadBuffer, int, int) - Method in class com.tangosol.io.AbstractWriteBuffer
- 
Store the specified portion of the contents of the specified ReadBuffer at the specified offset within this buffer.
- write(int, ReadBuffer, int, int) - Method in class com.tangosol.io.ByteArrayWriteBuffer
- 
Store the specified portion of the contents of the specified ReadBuffer at the specified offset within this buffer.
- write(int, ReadBuffer, int, int) - Method in class com.tangosol.io.DelegatingWriteBuffer
- 
Store the specified portion of the contents of the specified ReadBuffer at the specified offset within this buffer.
- write(int, ReadBuffer, int, int) - Method in class com.tangosol.io.MultiBufferWriteBuffer
- 
Store the specified portion of the contents of the specified ReadBuffer at the specified offset within this buffer.
- write(int, ReadBuffer, int, int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer
- 
Store the specified portion of the contents of the specified ReadBuffer at the specified offset within this buffer.
- write(int, ReadBuffer, int, int) - Method in interface com.tangosol.io.WriteBuffer
- 
Store the specified portion of the contents of the specified ReadBuffer at the specified offset within this buffer.
- write(String) - Method in class com.tangosol.io.IndentingWriter
- 
Write a string.
- write(String) - Method in class com.tangosol.io.Utf8Writer
- 
Write a string.
- write(String) - Method in class com.tangosol.util.NullImplementation.NullWriter
- write(String, int, int) - Method in class com.tangosol.io.IndentingWriter
- 
Write a portion of a string.
- write(String, int, int) - Method in class com.tangosol.io.Utf8Writer
- 
Write a portion of a string.
- write(String, int, int) - Method in class com.tangosol.util.NullImplementation.NullWriter
- write(String, WriteBuffer.BufferOutput) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Write the PersistentStore associated with the specified identifier to the given output buffer.
- write(String, WriteBuffer.BufferOutput) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Write the PersistentStore associated with the specified identifier to the given output buffer.
- write(String, WriteBuffer.BufferOutput) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Write the PersistentStore associated with the specified identifier to the given output buffer.
- write(String, OutputStream) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Write the PersistentStore associated with the specified identifier to the given output stream.
- write(String, OutputStream) - Method in class com.tangosol.util.NullImplementation.NullPersistenceManager
- 
Write the PersistentStore associated with the specified identifier to the given output stream.
- write(Map<String, Object>, OutputStream) - Method in interface com.tangosol.net.management.MapJsonBodyHandler
- WRITE - com.tangosol.net.ConfigurableQuorumPolicy.PartitionedCacheQuorumPolicy.ActionRule
- WRITE - Static variable in interface com.tangosol.net.CacheService.CacheAction
- 
Singleton action for cache writes.
- WriteableEntrySetMap(Map.Entry) - Constructor for class com.tangosol.io.pof.PofHelper.WriteableEntrySetMap
- 
Construct a new WriteableEntrySetMap that is backed by a single Map.Entry object.
- WriteableEntrySetMap(Set) - Constructor for class com.tangosol.io.pof.PofHelper.WriteableEntrySetMap
- 
Construct a new WriteableEntrySetMap that is backed by the given Set of Map.Entry objects.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Write a sparse array of primitive values.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Write a sparse array of primitive values.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Write a sparse array of primitive values.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Write a sparse array of primitive values.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Write a sparse array of primitive values.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Write a sparse array of primitive values.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Write a sparse array of primitive values.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Write a sparse array of primitive values.
- writeArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Write a sparse array of primitive values.
- writeAttributes(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Write the attributes as part of a start tag.
- writeBigDecimal(int, BigDecimal) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a BigDecimal property to the POF stream.
- writeBigDecimal(int, BigDecimal) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a BigDecimal property to the POF stream.
- writeBigDecimal(WriteBuffer.BufferOutput, BigDecimal, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Write a BigDecimal to the passed DataOutput stream as a decimal value.
- writeBigDecimal(DataOutput, BigDecimal) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a BigDecimal to a DataOutput stream.
- writeBigInteger(int, BigInteger) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a BigInteger property to the POF stream.
- writeBigInteger(int, BigInteger) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a BigInteger property to the POF stream.
- writeBigInteger(WriteBuffer.BufferOutput, BigInteger) - Static method in class com.tangosol.io.pof.PofHelper
- 
Write a BigInteger as a packed int.
- writeBigInteger(DataOutput, BigInteger) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a BigInteger to a DataOutput stream.
- writeBinary(int, Binary) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write aBinaryproperty to the POF stream.
- writeBinary(int, Binary) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write aBinaryproperty to the POF stream.
- writeBoolean(boolean) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes the boolean value f.
- writeBoolean(boolean) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes the boolean valuef.
- writeBoolean(boolean) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes the boolean value f.
- writeBoolean(boolean) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes the boolean valuef.
- writeBoolean(boolean) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes the boolean valuef.
- writeBoolean(boolean) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeBoolean(boolean) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes the boolean value f.
- writeBoolean(boolean) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes the boolean valuef.
- writeBoolean(boolean) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes the boolean value f.
- writeBoolean(boolean) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeBoolean(int, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a boolean property to the POF stream.
- writeBoolean(int, boolean) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a boolean property to the POF stream.
- writeBoolean(int, boolean, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a boolean property to the POF stream.
- writeBooleanArray(int, boolean[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a boolean[] property to the POF stream.
- writeBooleanArray(int, boolean[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a boolean[] property to the POF stream.
- writeBooleanArray(DataOutput, boolean[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a packed boolean array.
- writeBuffer(ReadBuffer) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Write all the bytes from the passed ReadBuffer object.
- writeBuffer(ReadBuffer) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Write all the bytes from the passed ReadBuffer object.
- writeBuffer(ReadBuffer) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Write all the bytes from the passed ReadBuffer object.
- writeBuffer(ReadBuffer) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeBuffer(ReadBuffer) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Write all the bytes from the passed ReadBuffer object.
- writeBuffer(ReadBuffer) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Write all the bytes from the passed ReadBuffer object.
- writeBuffer(ReadBuffer, int, int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writecbbytes from the passed ReadBuffer object starting at offsetofwithin the passed ReadBuffer.
- writeBuffer(ReadBuffer, int, int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writecbbytes from the passed ReadBuffer object starting at offsetofwithin the passed ReadBuffer.
- writeBuffer(ReadBuffer, int, int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writecbbytes from the passed ReadBuffer object starting at offsetofwithin the passed ReadBuffer.
- writeBuffer(ReadBuffer, int, int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeBuffer(ReadBuffer, int, int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writecbbytes from the passed ReadBuffer object starting at offsetofwithin the passed ReadBuffer.
- writeBuffer(ReadBuffer, int, int) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writecbbytes from the passed ReadBuffer object starting at offsetofwithin the passed ReadBuffer.
- WriteBuffer - Interface in com.tangosol.io
- 
The WriteBuffer interface represents an in-memory block of binary data that is being accumulated (written to).
- WriteBuffer.BufferOutput - Interface in com.tangosol.io
- 
The BufferOutput interface represents a DataOutputStream on top of a WriteBuffer.
- writeByte(int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes the eight low-order bits of the argument b.
- writeByte(int) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes the eight low-order bits of the argumentb.
- writeByte(int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes the eight low-order bits of the argument b.
- writeByte(int) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes the eight low-order bits of the argumentb.
- writeByte(int) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes the eight low-order bits of the argumentb.
- writeByte(int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeByte(int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes the eight low-order bits of the argument b.
- writeByte(int) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes the eight low-order bits of the argumentb.
- writeByte(int) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes the eight low-order bits of the argument b.
- writeByte(int) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeByte(int, byte) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a byte property to the POF stream.
- writeByte(int, byte) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a byte property to the POF stream.
- writeByte(int, byte, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a byte property to the POF stream.
- writeByteArray(int, byte[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a byte[] property to the POF stream.
- writeByteArray(int, byte[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a byte[] property to the POF stream.
- writeByteArray(DataOutput, byte[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a variable-length encoded byte array.
- writeBytes(String) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes the String s, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Writes the String s, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes the Strings, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes the String s, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes the Strings, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes the Strings, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeBytes(String) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes the String s, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes the Strings, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes the String s, but only the low-order byte from each character of the String is written.
- writeBytes(String) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeChar(int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes a char value, comprised of the 16 low-order bits of the argument ch; the 16 high-order bits of ch are ignored.
- writeChar(int) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes a char value, comprised of the 16 low-order bits of the argumentch; the 16 high-order bits ofchare ignored.
- writeChar(int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes a char value, comprised of the 16 low-order bits of the argument ch; the 16 high-order bits of ch are ignored.
- writeChar(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writes a char value, comprised of the 16 low-order bits of the argument ch; the 16 high-order bits of ch are ignored.
- writeChar(int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer.ByteBufferOutput
- 
Writes a char value, comprised of the 16 low-order bits of the argument ch; the 16 high-order bits of ch are ignored.
- writeChar(int) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes a char value, comprised of the 16 low-order bits of the argumentch; the 16 high-order bits ofchare ignored.
- writeChar(int) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes a char value, comprised of the 16 low-order bits of the argumentch; the 16 high-order bits ofchare ignored.
- writeChar(int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeChar(int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes a char value, comprised of the 16 low-order bits of the argument ch; the 16 high-order bits of ch are ignored.
- writeChar(int) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes a char value, comprised of the 16 low-order bits of the argumentch; the 16 high-order bits ofchare ignored.
- writeChar(int) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes a char value, comprised of the 16 low-order bits of the argument ch; the 16 high-order bits of ch are ignored.
- writeChar(int) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeChar(int, char) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a char property to the POF stream.
- writeChar(int, char) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a char property to the POF stream.
- writeChar(int, char, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a char property to the POF stream.
- writeCharArray(int, char[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a char[] property to the POF stream.
- writeCharArray(int, char[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a char[] property to the POF stream.
- writeChars(String) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes the String s as a sequence of characters.
- writeChars(String) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Writes the String s as a sequence of characters.
- writeChars(String) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes the Stringsas a sequence of characters.
- writeChars(String) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes the String s as a sequence of characters.
- writeChars(String) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes the Stringsas a sequence of characters.
- writeChars(String) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes the Stringsas a sequence of characters.
- writeChars(String) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeChars(String) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes the String s as a sequence of characters.
- writeChars(String) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes the Stringsas a sequence of characters.
- writeChars(String) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes the String s as a sequence of characters.
- writeChars(String) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeChildren(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Write the element as it will appear in XML.
- writeCollection(int, Collection<? extends T>) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Collection property to the POF stream.
- writeCollection(int, Collection<? extends T>) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Collection property to the POF stream.
- writeCollection(int, Collection<? extends T>, Class<? extends T>) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a uniform Collection property to the POF stream.
- writeCollection(int, Collection<? extends T>, Class<? extends T>) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a uniform Collection property to the POF stream.
- writeCollection(DataOutput, Collection) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write collection content to a DataOutput stream.
- writeComment(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Write the element as it will appear in XML.
- writeDate(int, LocalDate) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeDate(int, LocalDate) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a LocalDate property to the POF stream in ISO8601 format.
- writeDate(int, Date) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeDate(int, Date) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeDate(WriteBuffer.BufferOutput, int, int, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Write a date value to a BufferOutput object.
- writeDate(DataOutput, Date) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a Date to a DataOutput stream.
- writeDateTime(int, Timestamp) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Timestamp property to the POF stream in ISO8601 format.
- writeDateTime(int, Timestamp) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Timestamp property to the POF stream in ISO8601 format.
- writeDateTime(int, LocalDateTime) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeDateTime(int, LocalDateTime) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a LocalDateTime property to the POF stream in ISO8601 format.
- writeDateTime(int, Date) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeDateTime(int, Date) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeDateTimeWithZone(int, Timestamp) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Timestamp property to the POF stream in ISO8601 format.
- writeDateTimeWithZone(int, Timestamp) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Timestamp property to the POF stream in ISO8601 format.
- writeDateTimeWithZone(int, OffsetDateTime) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeDateTimeWithZone(int, OffsetDateTime) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a OffsetDateTime property to the POF stream in ISO8601 format.
- writeDateTimeWithZone(int, ZonedDateTime) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a ZonedDateTime property to the POF stream in ISO8601 format.
- writeDateTimeWithZone(int, Date) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeDateTimeWithZone(int, Date) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeDouble(double) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer.ByteBufferOutput
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeDouble(double) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes a double value.
- writeDouble(double) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes a double value.
- writeDouble(double) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeDouble(int, double) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a double property to the POF stream.
- writeDouble(int, double) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a double property to the POF stream.
- writeDouble(int, double, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a double property to the POF stream.
- writeDoubleArray(int, double[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a double[] property to the POF stream.
- writeDoubleArray(int, double[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a double[] property to the POF stream.
- writeDoubleArray(DataOutput, double[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an array of double numbers to a DataOutput stream.
- writeElements(XmlElement, Object) - Method in class com.tangosol.run.xml.ArrayAdapter
- writeElements(XmlElement, Object) - Method in class com.tangosol.run.xml.CollectionAdapter
- writeElements(XmlElement, Object) - Method in class com.tangosol.run.xml.IterableAdapter
- writeElements(XmlElement, Object) - Method in class com.tangosol.run.xml.MapAdapter
- writeElements(XmlElement, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- writeEmptyTag(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Write the element as a combined start/end tag.
- writeEndTag(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Write the element's end tag.
- writeEvent(String, MapEvent<? extends K, ? extends V>) - Method in class com.tangosol.coherence.rest.events.MapEventOutput
- 
Write single event to this EventOutput.
- writeExternal(PofWriter) - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- writeExternal(PofWriter) - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.config.ParameterMacroExpression
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.config.ResolvableParameterList
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.config.SimpleParameterList
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.rest.util.PropertySpec
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.rest.util.StaticContent
- writeExternal(PofWriter) - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.config.expression.ChainedParameterResolver
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.config.expression.LiteralExpression
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.config.expression.NullParameterResolver
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.config.expression.Parameter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.config.expression.ScopedParameterResolver
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.config.expression.ValueMacroExpression
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in exception com.tangosol.io.pof.PortableException
- writeExternal(PofWriter) - Method in interface com.tangosol.io.pof.PortableObject
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.io.pof.reflect.SimplePofPath
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.net.AbstractPriorityTask
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- writeExternal(PofWriter) - Method in class com.tangosol.net.partition.Ownership
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.net.partition.PartitionSet
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.net.partition.SimplePartitionKey
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.net.partition.VersionedOwnership
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in exception com.tangosol.net.RequestIncompleteException
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in exception com.tangosol.net.RequestPolicyException
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.net.security.PermissionInfo
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Publisher.FailOnFull
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Publisher.OrderById
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Publisher.OrderByNone
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Publisher.OrderByThread
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Publisher.OrderByValue
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Subscriber.Convert
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Subscriber.Filtered
- writeExternal(PofWriter) - Method in class com.tangosol.net.topic.Subscriber.Name
- writeExternal(PofWriter) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.run.xml.SimpleElement
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.run.xml.SimpleValue
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.AbstractScript
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.Count
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.GroupAggregator
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.PriorityAggregator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.QueryRecorder
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.ScriptAggregator
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- writeExternal(PofWriter) - Method in class com.tangosol.util.aggregator.TopNAggregator
- writeExternal(PofWriter) - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.comparator.EntryComparator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.comparator.ExtractorComparator
- writeExternal(PofWriter) - Method in class com.tangosol.util.comparator.SafeComparator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.CompositeKey
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.ChainedFragmentExtractor
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.CompositeUpdater
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.EntryExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.FragmentExtractor
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.IdentityExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.KeyExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.PofExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.PofUpdater
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.ScriptValueExtractor
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.CacheEventFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.ExtractorFilter
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.FilterTrigger
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.InFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.LikeFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.LimitFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.MapEventFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.NeverFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.NotFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.PredicateFilter
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.PresentFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.PriorityFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- writeExternal(PofWriter) - Method in class com.tangosol.util.Fragment
- writeExternal(PofWriter) - Method in class com.tangosol.util.MapEvent
- writeExternal(PofWriter) - Method in class com.tangosol.util.NullFilter
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.NullImplementation.NullEntryProcessor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.NullImplementation.NullMap
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.CompositeProcessor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.ConditionalPut
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.ExtractorProcessor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.NumberIncrementor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.NumberMultiplier
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.PreloadRequest
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.PriorityProcessor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.TouchProcessor
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.UpdaterProcessor
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.VersionedPut
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.SimpleHolder
- writeExternal(PofWriter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.SimpleQueryRecord
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.transformer.SamplingEventTransformer
- writeExternal(PofWriter) - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
- writeExternal(PofWriter) - Method in class com.tangosol.util.UID
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(PofWriter) - Method in class com.tangosol.util.UUID
- 
Save the contents of a POF user type instance by writing its state using the specified PofWriter object.
- writeExternal(DataOutput) - Method in class com.oracle.coherence.concurrent.atomic.Atomics.SerializableAtomicMarkableReference
- writeExternal(DataOutput) - Method in class com.oracle.coherence.concurrent.atomic.Atomics.SerializableAtomicStampedReference
- writeExternal(DataOutput) - Method in class com.oracle.coherence.concurrent.locks.LockOwner
- writeExternal(DataOutput) - Method in class com.oracle.coherence.concurrent.PermitAcquirer
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.config.builder.InstanceBuilder
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.config.builder.StaticFactoryInstanceBuilder
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.config.ParameterMacroExpression
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.config.ResolvableParameterList
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.config.SimpleParameterList
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.AbstractCoherenceBasedCompleteConfiguration
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.common.CoherenceEntryProcessorResult
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.common.ContextJCacheStatistics
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.common.JCacheEntryMetaInf
- 
write to
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.common.JCacheIdentifier
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.common.NonSyntheticEntryFilter
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.CacheStatisticsExtractor
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.partitionedcache.PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.jcache.passthroughcache.PassThroughFilterAdapter
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.rest.util.extractor.MvelExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.rest.util.MvelManipulator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.rest.util.PropertySet
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.rest.util.StaticContent
- writeExternal(DataOutput) - Method in class com.tangosol.coherence.rest.util.updater.MvelUpdater
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.config.expression.ChainedParameterResolver
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.config.expression.LiteralExpression
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.config.expression.NullParameterResolver
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.config.expression.Parameter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.config.expression.ScopedParameterResolver
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.config.expression.ValueMacroExpression
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in interface com.tangosol.io.ExternalizableLite
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.io.pof.EvolvableHolder
- writeExternal(DataOutput) - Method in class com.tangosol.io.pof.reflect.SimplePofPath
- writeExternal(DataOutput) - Method in class com.tangosol.net.AbstractPriorityTask
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.net.partition.DefaultVersionedPartitions
- writeExternal(DataOutput) - Method in class com.tangosol.net.partition.Ownership
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.net.partition.PartitionSet
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.net.partition.PartitionStatistics
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.net.partition.SimplePartitionKey
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.net.partition.VersionedOwnership
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Publisher.FailOnFull
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Publisher.OrderById
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Publisher.OrderByNone
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Publisher.OrderByThread
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Publisher.OrderByValue
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Subscriber.CommitResult
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Subscriber.CompleteOnEmpty
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Subscriber.Convert
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Subscriber.Filtered
- writeExternal(DataOutput) - Method in class com.tangosol.net.topic.Subscriber.Name
- writeExternal(DataOutput) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.run.xml.SimpleElement.AttributeMap
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.run.xml.SimpleElement.ElementList
- writeExternal(DataOutput) - Method in class com.tangosol.run.xml.SimpleElement
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.run.xml.SimpleValue
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.run.xml.XmlBean
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.AbstractScript
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.AbstractAggregator
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.AbstractComparableAggregator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.CompositeAggregator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.Count
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.GroupAggregator
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.PriorityAggregator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.QueryRecorder
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.ScriptAggregator
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.TopNAggregator.PartialResult
- writeExternal(DataOutput) - Method in class com.tangosol.util.aggregator.TopNAggregator
- writeExternal(DataOutput) - Method in class com.tangosol.util.Binary
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.comparator.ChainedComparator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.comparator.EntryComparator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.comparator.ExtractorComparator
- writeExternal(DataOutput) - Method in class com.tangosol.util.comparator.SafeComparator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.CompositeKey
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.AbstractCompositeExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.ChainedFragmentExtractor
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.ComparisonValueExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.CompositeUpdater
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.ConditionalExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.DeserializationAccelerator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.EntryExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.FragmentExtractor
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.IdentityExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.KeyExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.ReflectionExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.ReflectionUpdater
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.ScriptValueExtractor
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.UniversalExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.extractor.UniversalUpdater
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.AlwaysFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.ArrayFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.CacheEventFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.ComparisonFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.ExtractorFilter
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.FilterTrigger
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.InKeySetFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.KeyAssociatedFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.LikeFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.LimitFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.MapEventFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.MapEventTransformerFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.NeverFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.NotFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.PartitionedFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.PredicateFilter
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.PresentFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.PriorityFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.filter.ValueChangeEventFilter
- writeExternal(DataOutput) - Method in class com.tangosol.util.Fragment
- writeExternal(DataOutput) - Method in class com.tangosol.util.ImmutableArrayList
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.LiteMap
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.LiteSet
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.MapSet
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.NullFilter
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.NullImplementation.NullEntryProcessor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.NullImplementation.NullMap
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.NullImplementation.NullSet
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.NullImplementation.NullValueExtractor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.CompositeProcessor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.ConditionalProcessor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.ConditionalPut
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.ConditionalPutAll
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.ConditionalRemove
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.ExtractorProcessor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.MethodInvocationProcessor
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.NumberIncrementor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.NumberMultiplier
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.PreloadRequest
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.PriorityProcessor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.PropertyManipulator
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.PropertyProcessor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.TouchProcessor
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.UpdaterProcessor
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.VersionedPut
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.processor.VersionedPutAll
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.SimpleHolder
- writeExternal(DataOutput) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.IndexLookupRecord
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult.Step
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.SimpleQueryRecord.PartialResult
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.SimpleQueryRecord
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.transformer.ExtractorEventTransformer
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.transformer.SamplingEventTransformer
- writeExternal(DataOutput) - Method in class com.tangosol.util.transformer.SemiLiteEventTransformer
- writeExternal(DataOutput) - Method in class com.tangosol.util.UID
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput) - Method in class com.tangosol.util.UUID
- 
Save the contents of this object by storing the object's state into the passed DataOutput object.
- writeExternal(DataOutput, ReadBuffer) - Static method in class com.tangosol.util.Binary
- 
Write the contents of the specified ReadBuffer to the specified DataOutput stream in a format that can be restored as a Binary viaBinary.readExternal(java.io.ObjectInput)
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.ArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.CollectionAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.DateTimeAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.MapAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.RestrictedStringAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SerializableAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.BigDecimalAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.BigIntegerAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.BooleanAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.ByteAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.CharAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.DateAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.DoubleAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.FloatAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.IntAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.LongAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.OldDateAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.ShortAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.StringAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.TimeAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.SimpleAdapter.TimestampAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.XmlElementAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(DataOutput, Object) - Method in class com.tangosol.run.xml.XmlSerializableAdapter
- 
Write the specified data to the passed DataOutput object.
- writeExternal(ObjectOutput) - Method in class com.tangosol.net.security.PermissionInfo
- writeExternal(ObjectOutput) - Method in class com.tangosol.run.xml.SimpleDocument
- 
The object implements the writeExternal method to save its contents by calling the methods of DataOutput for its primitive values or calling the writeObject method of ObjectOutput for objects, strings, and arrays.
- writeExternal(ObjectOutput) - Method in class com.tangosol.run.xml.XmlBean
- 
The object implements the writeExternal method to save its contents by calling the methods of DataOutput for its primitive values or calling the writeObject method of ObjectOutput for objects, strings, and arrays.
- writeExternal(ObjectOutput) - Method in class com.tangosol.util.Binary
- 
The object implements the writeExternal method to save its contents by calling the methods of DataOutput for its primitive values or calling the writeObject method of ObjectOutput for objects, strings, and arrays.
- writeExternal(ObjectOutput) - Method in class com.tangosol.util.LiteSet
- 
Write this object's data to the passed ObjectOutput stream.
- writeExternal(ObjectOutput) - Method in class com.tangosol.util.MapSet
- 
Write the contents of this object into the passed object stream.
- writeExternal(ObjectOutput) - Method in class com.tangosol.util.UUID
- 
Write this object to an ObjectOutputStream.
- writeExternalizableLite(DataOutput, ExternalizableLite) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an ExternalizableLite object to a DataOutput stream.
- writeFloat(float) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer.ByteBufferOutput
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeFloat(float) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes a float value.
- writeFloat(float) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes a float value.
- writeFloat(float) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeFloat(int, float) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a float property to the POF stream.
- writeFloat(int, float) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a float property to the POF stream.
- writeFloat(int, float, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a float property to the POF stream.
- writeFloatArray(int, float[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a float[] property to the POF stream.
- writeFloatArray(int, float[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a float[] property to the POF stream.
- writeFloatArray(DataOutput, float[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an array of float numbers to a DataOutput stream.
- writeHeader() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Write the block's data to the Buffer.
- writeInt(int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer.ByteBufferOutput
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeInt(int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes an int value.
- writeInt(int) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes an int value.
- writeInt(int) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeInt(int, int) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a int property to the POF stream.
- writeInt(int, int) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a int property to the POF stream.
- writeInt(int, int, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a int property to the POF stream.
- writeInt(WriteBuffer.BufferOutput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an int to a buffer using a variable length of storage.
- writeInt(DataOutput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an int to a stream using a variable length of storage.
- writeIntArray(int, int[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a int[] property to the POF stream.
- writeIntArray(int, int[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a int[] property to the POF stream.
- writeIntArray2d(DataOutput, int[][]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a 2-dimensional int-array to the stream
- writeKey() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Write the "key" portion of an Entry block, including the key hash.
- writeLock() - Method in class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock
- 
Returns the lock used for writing.
- WriteLock(RemoteReadWriteLock) - Constructor for class com.oracle.coherence.concurrent.locks.RemoteReadWriteLock.WriteLock
- 
Constructor for use by subclasses.
- writeLong(int, long) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a long property to the POF stream.
- writeLong(int, long) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a long property to the POF stream.
- writeLong(int, long, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a long property to the POF stream.
- writeLong(long) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer.ByteBufferOutput
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeLong(long) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes a long value.
- writeLong(long) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes a long value.
- writeLong(long) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeLong(WriteBuffer.BufferOutput, long) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a long to a buffer using a variable length of storage.
- writeLong(DataOutput, long) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a long to a stream using a variable length of storage.
- writeLongArray(int, long[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a long[] property to the POF stream.
- writeLongArray(int, long[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a long[] property to the POF stream.
- writeLongArray(int, LongArray) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeLongArray(int, LongArray<? extends T>) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a LongArray property to the POF stream.
- writeLongArray(int, LongArray<T>, Class<T>) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a uniform LongArray property to the POF stream.
- writeLongArray(int, LongArray, Class) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a uniform LongArray property to the POF stream.
- writeMap(int, Map<? extends K, ? extends V>) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Map property to the POF stream.
- writeMap(int, Map<? extends K, ? extends V>) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Map property to the POF stream.
- writeMap(int, Map<K, ? extends V>, Class<? extends K>) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a uniform key Map property to the POF stream.
- writeMap(int, Map<K, ? extends V>, Class<? extends K>) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a uniform key Map property to the POF stream.
- writeMap(int, Map<K, V>, Class<? extends K>, Class<? extends V>) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a uniform Map property to the POF stream.
- writeMap(int, Map<K, V>, Class<? extends K>, Class<? extends V>) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a uniform Map property to the POF stream.
- writeMap(DataOutput, Map) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write map content to a DataOutput stream.
- writeMetadata(File) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Write persistence metadata for this manager to the specified directory.
- writeMetadata(File, PersistenceManager<ReadBuffer>, String) - Method in class com.tangosol.persistence.AbstractSnapshotArchiver
- 
Write the metadata using given manager for a particular store to a destination directory.
- writeMetadata(File, Properties) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Write persistence metadata to the specified directory.
- writeObject(int, Object) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write an Object property to the POF stream.
- writeObject(int, Object) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write an Object property to the POF stream.
- writeObject(DataOutput, Object) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write the specified data to the passed DataOutput object.
- writeObject(Object) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes the Objectoso that the correspondingObjectInput.readObject()method can reconstitute an Object from the written data.
- writeObject(Object) - Method in class com.tangosol.io.WrapperObjectOutputStream
- 
Writes the Objectoso that the correspondingObjectInput.readObject()method can reconstitute an Object from the written data.
- writeObjectArray(int, T[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write an Object[] property to the POF stream.
- writeObjectArray(int, T[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write an Object[] property to the POF stream.
- writeObjectArray(int, T[], Class<? extends T>) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a uniform Object[] property to the POF stream.
- writeObjectArray(int, T[], Class<? extends T>) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a uniform Object[] property to the POF stream.
- writeOptional(int, Optional<T>) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeOptionalDouble(int, OptionalDouble) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeOptionalInt(int, OptionalInt) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeOptionalLong(int, OptionalLong) - Method in class com.tangosol.io.pof.PofBufferWriter
- writePackedInt(int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Write an int value using a variable-length storage-format.
- writePackedInt(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Write an int value using a variable-length storage-format.
- writePackedInt(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Write an int value using a variable-length storage-format.
- writePackedInt(int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writePackedInt(int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Write an int value using a variable-length storage-format.
- writePackedInt(int) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Write an int value using a variable-length storage-format.
- writePackedLong(long) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Write a long value using a variable-length storage-format.
- writePackedLong(long) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Write a long value using a variable-length storage-format.
- writePackedLong(long) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Write a long value using a variable-length storage-format.
- writePackedLong(long) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writePackedLong(long) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Write a long value using a variable-length storage-format.
- writePackedLong(long) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Write a long value using a variable-length storage-format.
- WriteQueue() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.WriteQueue
- 
Construct a WriteQueue that holds write-behind entries.
- writeQuorum(PersistentStore<ReadBuffer>, PartitionedService) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Write the current membership information to the "META" extent.
- writeQuorumRaw(PersistentStore<ReadBuffer>, Binary) - Static method in class com.tangosol.persistence.CachePersistenceHelper
- 
Write the current membership information in raw format to the "META" extent.
- writeRawDate(int, RawDate) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a RawDate property to the POF stream.
- writeRawDate(int, RawDate) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a RawDate property to the POF stream.
- writeRawDateTime(int, RawDateTime) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a RawDateTime property to the POF stream.
- writeRawDateTime(int, RawDateTime) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a RawDateTime property to the POF stream.
- writeRawDayTimeInterval(int, RawDayTimeInterval) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a RawDayTimeInterval property to the POF stream.
- writeRawDayTimeInterval(int, RawDayTimeInterval) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a RawDayTimeInterval property to the POF stream.
- writeRawQuad(int, RawQuad) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a RawQuad property to the POF stream.
- writeRawQuad(int, RawQuad) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a RawQuad property to the POF stream.
- writeRawTime(int, RawTime) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a RawTime property to the POF stream.
- writeRawTime(int, RawTime) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a RawTime property to the POF stream.
- writeRawTimeInterval(int, RawTimeInterval) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a RawTimeInterval property to the POF stream.
- writeRawTimeInterval(int, RawTimeInterval) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a RawTimeInterval property to the POF stream.
- writeRawYearMonthInterval(int, RawYearMonthInterval) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a RawYearMonthInterval property to the POF stream.
- writeRawYearMonthInterval(int, RawYearMonthInterval) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a RawYearMonthInterval property to the POF stream.
- writeRemainder(Binary) - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Write the remaining properties to the POF stream, terminating the writing of the current user type.
- writeRemainder(Binary) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write the remaining properties to the POF stream, terminating the writing of the current user type.
- writeRemainder(Binary) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write the remaining properties to the POF stream, terminating the writing of the current user type.
- writeReplace() - Method in interface com.tangosol.io.SerializationSupport
- 
Designate an alternative object to be used when writing an object to the buffer.
- WriterPrintStream - Class in com.tangosol.io
- 
Overrides PrintStream to delegate to a PrintWriter.
- WriterPrintStream(PrintWriter) - Constructor for class com.tangosol.io.WriterPrintStream
- writeSafe(String) - Method in class com.tangosol.persistence.AbstractPersistenceManager
- 
Copy the PersistentStore associated with the specified identifier to the configured safe area.
- writeSafe(String) - Method in class com.tangosol.persistence.SafePersistenceWrappers.SafePersistenceManager
- 
Copy the PersistentStore associated with the specified identifier to the configured safe area.
- writeSafeUTF(WriteBuffer.BufferOutput, String) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a variable-length encoded UTF packed String to the buffer.
- writeSafeUTF(DataOutput, String) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a variable-length encoded UTF packed String.
- writeSafeUTF(String) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Write a variable-length encoded UTF packed String.
- writeSafeUTF(String) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Write a variable-length encoded UTF packed String.
- writeSafeUTF(String) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeSafeUTF(String) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Write a variable-length encoded UTF packed String.
- writeSafeUTF(String) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Write a variable-length encoded UTF packed String.
- writeSerializable(DataOutput, Object) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an object to a DataOutput stream.
- writeSerializationHeader(WriteBuffer.BufferOutput, String) - Method in class com.tangosol.io.MultiplexingSerializer
- 
Write the multiplex serialization header.
- writeShort(int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes a short value, comprised of the 16 low-order bits of the argument n; the 16 high-order bits of n are ignored.
- writeShort(int) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Writes a short value, comprised of the 16 low-order bits of the argument n; the 16 high-order bits of n are ignored.
- writeShort(int) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes a short value, comprised of the 16 low-order bits of the argumentn; the 16 high-order bits ofnare ignored.
- writeShort(int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes a short value, comprised of the 16 low-order bits of the argument n; the 16 high-order bits of n are ignored.
- writeShort(int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Writes a short value, comprised of the 16 low-order bits of the argument n; the 16 high-order bits of n are ignored.
- writeShort(int) - Method in class com.tangosol.io.nio.ByteBufferWriteBuffer.ByteBufferOutput
- 
Writes a short value, comprised of the 16 low-order bits of the argument n; the 16 high-order bits of n are ignored.
- writeShort(int) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes a short value, comprised of the 16 low-order bits of the argumentn; the 16 high-order bits ofnare ignored.
- writeShort(int) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes a short value, comprised of the 16 low-order bits of the argumentn; the 16 high-order bits ofnare ignored.
- writeShort(int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeShort(int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes a short value, comprised of the 16 low-order bits of the argument n; the 16 high-order bits of n are ignored.
- writeShort(int) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes a short value, comprised of the 16 low-order bits of the argumentn; the 16 high-order bits ofnare ignored.
- writeShort(int) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes a short value, comprised of the 16 low-order bits of the argument n; the 16 high-order bits of n are ignored.
- writeShort(int) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeShort(int, short) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a short property to the POF stream.
- writeShort(int, short) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a short property to the POF stream.
- writeShort(int, short, boolean) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a short property to the POF stream.
- writeShortArray(int, short[]) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a short[] property to the POF stream.
- writeShortArray(int, short[]) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a short[] property to the POF stream.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.BooleanArrayAdapter
- 
Write a sparse array of primitive values.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ByteArrayAdapter
- 
Write a sparse array of primitive values.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.CharArrayAdapter
- 
Write a sparse array of primitive values.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.DoubleArrayAdapter
- 
Write a sparse array of primitive values.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.FloatArrayAdapter
- 
Write a sparse array of primitive values.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.IntArrayAdapter
- 
Write a sparse array of primitive values.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.LongArrayAdapter
- 
Write a sparse array of primitive values.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter.ShortArrayAdapter
- 
Write a sparse array of primitive values.
- writeSparseArray(XmlElement, Object, String) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Write a sparse array of primitive values.
- writeStartTag(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Write the element's start tag.
- writeStream(InputStreaming) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Write the remaining contents of the specified InputStreaming object.
- writeStream(InputStreaming) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Write the remaining contents of the specified InputStreaming object.
- writeStream(InputStreaming) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Write the remaining contents of the specified InputStreaming object.
- writeStream(InputStreaming) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeStream(InputStreaming) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Write the remaining contents of the specified InputStreaming object.
- writeStream(InputStreaming) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Write the remaining contents of the specified InputStreaming object.
- writeStream(InputStreaming, int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Write the specified number of bytes of the specified InputStreaming object.
- writeStream(InputStreaming, int) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Write the specified number of bytes of the specified InputStreaming object.
- writeStream(InputStreaming, int) - Method in class com.tangosol.io.MultiBufferWriteBuffer.MultiBufferOutput
- 
Write the specified number of bytes of the specified InputStreaming object.
- writeStream(InputStreaming, int) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeStream(InputStreaming, int) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Write the specified number of bytes of the specified InputStreaming object.
- writeStream(InputStreaming, int) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Write the specified number of bytes of the specified InputStreaming object.
- writeString(int, String) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a String property to the POF stream.
- writeString(int, String) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a String property to the POF stream.
- writeStringArray(DataOutput, String[]) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a String array.
- WriteThread() - Constructor for class com.tangosol.net.cache.ReadWriteBackingMap.WriteThread
- 
Default constructor.
- writeTime(int, Timestamp) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Timestamp property to the POF stream in ISO8601 format.
- writeTime(int, Timestamp) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Timestamp property to the POF stream in ISO8601 format.
- writeTime(int, LocalTime) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeTime(int, LocalTime) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a LocalTime property to the POF stream in ISO8601 format.
- writeTime(int, Date) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeTime(int, Date) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeTime(WriteBuffer.BufferOutput, int, int, int, int, int, int, int) - Static method in class com.tangosol.io.pof.PofHelper
- 
Write a time value to a BufferOutput object.
- writeTime(DataOutput, Time) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a Time to a DataOutput stream.
- writeTimestamp(DataOutput, Timestamp) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a Timestamp to a DataOutput stream.
- writeTimeWithZone(int, Timestamp) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Timestamp property to the POF stream in ISO8601 format.
- writeTimeWithZone(int, Timestamp) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Timestamp property to the POF stream in ISO8601 format.
- writeTimeWithZone(int, OffsetTime) - Method in class com.tangosol.io.pof.PofBufferWriter
- writeTimeWithZone(int, OffsetTime) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a OffsetTime property to the POF stream in ISO8601 format.
- writeTimeWithZone(int, Date) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeTimeWithZone(int, Date) - Method in interface com.tangosol.io.pof.PofWriter
- 
Write a Date property to the POF stream in ISO8601 format.
- writeTo(DataOutput) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Write the contents of this ReadBuffer to a DataOutput.
- writeTo(DataOutput) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Write the contents of this ReadBuffer to a DataOutput.
- writeTo(DataOutput) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Write the contents of this ReadBuffer to a DataOutput.
- writeTo(DataOutput) - Method in interface com.tangosol.io.ReadBuffer
- 
Write the contents of this ReadBuffer to a DataOutput.
- writeTo(DataOutput, int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Write the contents of this ReadBuffer to a DataOutput.
- writeTo(DataOutput, int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Write the contents of this ReadBuffer to a DataOutput.
- writeTo(DataOutput, int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Write the contents of this ReadBuffer to a DataOutput.
- writeTo(DataOutput, int, int) - Method in interface com.tangosol.io.ReadBuffer
- 
Write the contents of this ReadBuffer to a DataOutput.
- writeTo(OutputStream) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Write the contents of this ReadBuffer to an OutputStream.
- writeTo(OutputStream) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Write the contents of this ReadBuffer to an OutputStream.
- writeTo(OutputStream) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Write the contents of this ReadBuffer to an OutputStream.
- writeTo(OutputStream) - Method in interface com.tangosol.io.ReadBuffer
- 
Write the contents of this ReadBuffer to an OutputStream.
- writeTo(OutputStream, int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Write the contents of the ReadBuffer to an OutputStream.
- writeTo(OutputStream, int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Write the contents of the ReadBuffer to an OutputStream.
- writeTo(OutputStream, int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Write the contents of the ReadBuffer to an OutputStream.
- writeTo(OutputStream, int, int) - Method in interface com.tangosol.io.ReadBuffer
- 
Write the contents of the ReadBuffer to an OutputStream.
- writeTo(Object, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.tangosol.coherence.rest.providers.EntryWriter
- writeTo(Object, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.tangosol.coherence.rest.providers.JsonCollectionWriter
- writeTo(Object, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.tangosol.coherence.rest.providers.ObjectWriter
- writeTo(Object, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.tangosol.coherence.rest.providers.XmlCollectionWriter
- writeTo(ByteBuffer) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Write the contents of the Binary object to a ByteBuffer.
- writeTo(ByteBuffer) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Write the contents of the Binary object to a ByteBuffer.
- writeTo(ByteBuffer) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Write the contents of the Binary object to a ByteBuffer.
- writeTo(ByteBuffer) - Method in interface com.tangosol.io.ReadBuffer
- 
Write the contents of the Binary object to a ByteBuffer.
- writeTo(ByteBuffer, int, int) - Method in class com.tangosol.io.AbstractByteArrayReadBuffer
- 
Write the contents of the Binary object to a ByteBuffer.
- writeTo(ByteBuffer, int, int) - Method in class com.tangosol.io.MultiBufferReadBuffer
- 
Write the contents of the Binary object to a ByteBuffer.
- writeTo(ByteBuffer, int, int) - Method in class com.tangosol.io.nio.ByteBufferReadBuffer
- 
Write the contents of the Binary object to a ByteBuffer.
- writeTo(ByteBuffer, int, int) - Method in interface com.tangosol.io.ReadBuffer
- 
Write the contents of the Binary object to a ByteBuffer.
- writeTo(Map, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.tangosol.coherence.rest.providers.XmlMapWriter
- writeTo(Set, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.tangosol.coherence.rest.providers.XmlKeysWriter
- writeTrint(DataOutput, int) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a three-byte integer value to a stream.
- writeTrint(DataOutput, long) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a three-byte integer value to a stream.
- writeUserType(int, Object) - Method in class com.tangosol.io.pof.PofBufferWriter
- 
Write a user-type to the POF stream.
- writeUserTypeInfo() - Method in class com.tangosol.io.pof.PofBufferWriter.UserTypeWriter
- 
Write out the type and version identifiers of the user type to the POF stream, if they haven't already been written.
- writeUTF(DataOutput, String) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write a variable-length encoded UTF packed String.
- writeUTF(String) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Writes the String s as a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in class com.tangosol.io.ByteArrayWriteBuffer.ByteArrayBufferOutput
- 
Writes the String s as a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in class com.tangosol.io.DebugDataOutputStream
- 
Writes the Stringsas a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in class com.tangosol.io.DelegatingWriteBuffer.DelegatingBufferOutput
- 
Writes the String s as a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in class com.tangosol.io.PackedDataOutputStream
- 
Writes the Stringsas a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in class com.tangosol.io.pof.PofOutputStream
- 
Writes the Stringsas a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in class com.tangosol.io.SizeEstimatingBufferOutput
- writeUTF(String) - Method in class com.tangosol.io.WrapperBufferOutput
- 
Writes the String s as a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in class com.tangosol.io.WrapperDataOutputStream
- 
Writes the Stringsas a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in interface com.tangosol.io.WriteBuffer.BufferOutput
- 
Writes the String s as a sequence of characters, but using UTF-8 encoding for the characters, and including the String length data so that the correspondingDataInput.readUTF()method can reconstitute a String from the written data.
- writeUTF(String) - Method in class com.tangosol.util.NullImplementation.NullOutputStream
- writeUTF(String, int, int) - Method in class com.tangosol.io.AbstractWriteBuffer.AbstractBufferOutput
- 
Write out the characters of the passed String as UTF-8 data.
- writeValue() - Method in class com.tangosol.io.nio.BinaryMap.Block
- 
Write the "value" portion of an Entry block.
- writeValue(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Write the value as it will appear in XML.
- writeValue(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleValue
- 
Write the value as it will appear in XML.
- writeValue(PrintWriter, boolean) - Method in interface com.tangosol.run.xml.XmlValue
- 
Write the value as it will appear in XML.
- writeXml(XmlElement, Object) - Method in class com.tangosol.run.xml.PrimitiveArrayAdapter
- 
Serialize an object into an XML element.
- writeXml(XmlElement, Object) - Method in class com.tangosol.run.xml.PropertyAdapter
- 
Serialize an object into an XML element.
- writeXml(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleDocument
- 
Write the XML document, including an XML header and DOCTYPE if one exists.
- writeXml(PrintWriter, boolean) - Method in class com.tangosol.run.xml.SimpleElement
- 
Write the element as it will appear in XML.
- writeXml(PrintWriter, boolean) - Method in interface com.tangosol.run.xml.XmlDocument
- 
Write the XML document, including an XML header and DOCTYPE if one exists.
- writeXml(PrintWriter, boolean) - Method in interface com.tangosol.run.xml.XmlElement
- 
Write the element as it will appear in XML.
- writeXmlBean(DataOutput, XmlBean) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an XmlBean object to a DataOutput stream.
- writeXmlSerializable(DataOutput, XmlSerializable) - Static method in class com.tangosol.util.ExternalizableHelper
- 
Write an XmlSerializable object to a DataOutput stream.
- WritingPofHandler - Class in com.tangosol.io.pof
- 
An implementation of PofHandler that writes a POF stream to a WriteBuffer using a BufferOutput object.
- WritingPofHandler(WriteBuffer.BufferOutput) - Constructor for class com.tangosol.io.pof.WritingPofHandler
- 
Construct a Writing POF Handler that will write a POF stream to the passed BufferOutput object.
- WritingPofHandler.Complex - Class in com.tangosol.io.pof
- 
A Complex object represents the current complex data structure in the POF stream.
- WritingPofHandler.ComplexMap - Class in com.tangosol.io.pof
- 
A ComplexMap object represents a map data structure (with uniform keys or with uniform keys and values) in the POF stream.
X
- XML_ATTR_SCHEMA_LOCATION - Static variable in class com.tangosol.run.xml.XmlHelper
- 
The XML attribute used to specify schema locations.
- XML_ATTR_XMLNS - Static variable in class com.tangosol.run.xml.XmlHelper
- 
The XML attribute name used to specify xml schema.
- XmlAttribute - Interface in com.tangosol.run.xml
- 
AnXmlAttributerepresents an Xml Attribute, defined within anXmlElement.
- XmlBean - Class in com.tangosol.run.xml
- 
This is a base class for building XmlSerializable value objects.
- XmlBean() - Constructor for class com.tangosol.run.xml.XmlBean
- 
Construct a value object.
- XMLBEAN_CLASS_CACHE - Static variable in class com.tangosol.util.ExternalizableHelper
- 
Option: XmlBean class cache implementation.
- XmlBean.BeanInfo - Class in com.tangosol.run.xml
- 
A BeanInfo contains information about the XML bean and its properties.
- XmlCollectionWriter - Class in com.tangosol.coherence.rest.providers
- 
Provider responsible for converting Java collections to a XML formatted stream.
- XmlCollectionWriter() - Constructor for class com.tangosol.coherence.rest.providers.XmlCollectionWriter
- 
Default constructor.
- XmlCollectionWriter(MarshallerRegistry) - Constructor for class com.tangosol.coherence.rest.providers.XmlCollectionWriter
- 
Construct an XmlCollectionWriter instance.
- XmlConfigurable - Interface in com.tangosol.run.xml
- 
Deprecated.
- XmlDocument - Interface in com.tangosol.run.xml
- 
An interface for XML document access.
- XmlDocumentReference - Class in com.tangosol.run.xml
- 
AnXmlDocumentReferenceprovides an mechanism to reference anXmlDocument.
- XmlDocumentReference(String) - Constructor for class com.tangosol.run.xml.XmlDocumentReference
- 
Standard Constructor.
- XmlDocumentReference(URI) - Constructor for class com.tangosol.run.xml.XmlDocumentReference
- 
Standard Constructor.
- XmlElement - Interface in com.tangosol.run.xml
- 
An interface for XML element access.
- XmlElementAdapter - Class in com.tangosol.run.xml
- 
An XmlElementAdapter supports properties of type XmlElement.
- XmlElementAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.XmlElementAdapter
- 
Construct an XmlElementAdapter.
- XMLHealthCheckDependencies() - Constructor for class com.tangosol.coherence.config.xml.processor.HealthProcessor.XMLHealthCheckDependencies
- XmlHelper - Class in com.tangosol.run.xml
- 
This abstract class contains XML manipulation methods.
- XmlHelper() - Constructor for class com.tangosol.run.xml.XmlHelper
- XmlHelper.ParameterResolver - Interface in com.tangosol.run.xml
- 
An interface that describes a callback to resolve a substitutable parameter value.
- XmlJaxbMarshaller<T> - Class in com.tangosol.coherence.rest.io
- 
Deprecated.As of 12.2.1.0.0, replaced byJaxbXmlMarshaller
- XmlJaxbMarshaller(Class<T>) - Constructor for class com.tangosol.coherence.rest.io.XmlJaxbMarshaller
- 
Deprecated.Construct an XmlJaxbMarshaller instance.
- XmlKeysWriter - Class in com.tangosol.coherence.rest.providers
- 
Provider responsible for converting set of keys to a XML formatted stream.
- XmlKeysWriter() - Constructor for class com.tangosol.coherence.rest.providers.XmlKeysWriter
- 
Default constructor.
- XmlKeysWriter(MarshallerRegistry) - Constructor for class com.tangosol.coherence.rest.providers.XmlKeysWriter
- 
Construct an XmlKeysWriter instance.
- XmlMapWriter - Class in com.tangosol.coherence.rest.providers
- 
Provider responsible for converting Java maps to an XML formatted stream.
- XmlMapWriter() - Constructor for class com.tangosol.coherence.rest.providers.XmlMapWriter
- XmlSerializable - Interface in com.tangosol.run.xml
- 
An interface for XML serialization.
- XmlSerializableAdapter - Class in com.tangosol.run.xml
- 
An XmlSerializableAdapter supports Java objects that implement the XmlSerializable interface.
- XmlSerializableAdapter(XmlBean.BeanInfo, Class, String, String, XmlElement) - Constructor for class com.tangosol.run.xml.XmlSerializableAdapter
- 
Construct an XmlSerializableAdapter.
- XmlSerializablePofSerializer - Class in com.tangosol.io.pof
- 
PofSerializerimplementation that supports the serialization and deserialization of any class that implementsXmlSerializableto and from a POF stream.
- XmlSerializablePofSerializer(int) - Constructor for class com.tangosol.io.pof.XmlSerializablePofSerializer
- 
Create a new XmlSerializablePofSerializer for the user type with the given type identifier.
- XmlSimpleName - Annotation Type in com.tangosol.config.xml
- 
Denotes that a class is associated with the processing of a specifically named Xml element or attribute.
- XmlValue - Interface in com.tangosol.run.xml
- 
An interface for XML element content and element attribute values.
- xor(Filter) - Method in interface com.tangosol.util.Filter
- 
Return a composed predicate that represents a logical XOR of this predicate and another.
- XorFilter - Class in com.tangosol.util.filter
- 
Filter which returns the logical exclusive or ("xor") of two other filters.
- XorFilter() - Constructor for class com.tangosol.util.filter.XorFilter
- 
Default constructor (necessary for the ExternalizableLite interface).
- XorFilter(Filter, Filter) - Constructor for class com.tangosol.util.filter.XorFilter
- 
Construct a "xor" filter.
- XorOperator - Class in com.tangosol.coherence.dslquery.operator
- 
A class representing the logical XOR operator.
- XorOperator() - Constructor for class com.tangosol.coherence.dslquery.operator.XorOperator
- 
Constructs an XorOperator.
Z
A B C D E F G H I J K L M N O P Q R S T U V W X ZAll Classes All Packages