Uses of Class
com.tangosol.util.Base
-
Packages that use Base Package Description com.oracle.coherence.grpc.proxy The Coherence gRPC server implementation.com.tangosol.coherence.dslquery.statement This package containsStatementBuilderimplementations.com.tangosol.coherence.dslquery.statement.persistence This package contains classes for persistence related statement builders.com.tangosol.coherence.jcache.localcache Contains classes related to local cache implementation of Coherence JCache.com.tangosol.coherence.jcache.partitionedcache Contains classes related to partitioned cache implementation of Coherence JCache.com.tangosol.coherence.rest.util.extractor Contains classes related to REST-based extractor.com.tangosol.coherence.rest.util.updater Contains classes related to REST-based updater.com.tangosol.io Contains classes providing cache persistence of serialized objects.com.tangosol.io.bdb Contains Sleepycat Berkeley DB BinaryStore implementation classes.com.tangosol.io.nio Contains classes related to J2SE 1.4 NIO functionality.com.tangosol.io.pof Contains classes related to POF serialization and deserialization.com.tangosol.io.pof.reflect Contains classes related to POF stream navigation and manipulation.com.tangosol.license com.tangosol.net Contains basic cluster interfaces and factories.com.tangosol.net.cache Contains classes providing various caching strategies.com.tangosol.net.management Contains classes related to the Coherence Management Framework.com.tangosol.net.partition Contains interfaces and classes related to partitioned services.com.tangosol.net.proxy Contains interfaces and classes related to proxy services.com.tangosol.net.security Contains classes related to the Coherence Security Framework.com.tangosol.net.topic Contains classes that providing topic entities for publish/subscribe messaging.com.tangosol.persistence Contains classes and helpers for implementing various types of persistence.com.tangosol.run.jca Contains classes providing Java 2 Connector Architecture functionality.com.tangosol.run.xml Contains classes providing basic XML related functionality.com.tangosol.util Contains various generic utilities.com.tangosol.util.aggregator Contains concreteInvocableMap.EntryAggregatorimplementations.com.tangosol.util.comparator Contains concreteComparatorimplementations and related interfaces.com.tangosol.util.extractor ContainsValueExtractorandValueUpdaterrelated classes.com.tangosol.util.filter Contains concreteFilterimplementations and related interfaces.com.tangosol.util.processor Contains concreteInvocableMap.EntryProcessorimplementations.com.tangosol.util.transformer Contains concreteMapEventTransformerimplementations. -
-
Uses of Base in com.oracle.coherence.grpc.proxy
Subclasses of Base in com.oracle.coherence.grpc.proxy Modifier and Type Class Description protected static classMapListenerProxy.DeactivationListenerNamedCacheDeactivationListenerthat will communicate cache truncation and destruction events over the proxy. -
Uses of Base in com.tangosol.coherence.dslquery.statement
Subclasses of Base in com.tangosol.coherence.dslquery.statement Modifier and Type Class Description classAbstractStatementA base class forStatementimplementations.static classBackupStatementBuilder.BackupStatementImplementation of the CohQL "BACKUP" command.static classCreateCacheStatementBuilder.CreateCacheStatementImplementation of the CohQL "CREATE CACHE" command.static classCreateIndexStatementBuilder.CreateIndexStatementImplementation of the CohQL "CREATE INDEX" command.static classDeleteStatementBuilder.DeleteStatementImplementation of the CohQL "DELETE" query.static classDropCacheStatementBuilder.DropCacheStatementImplementation of the CohQL "DROP CACHE" command.static classDropIndexStatementBuilder.DropIndexStatementImplementation of the CohQL "create index" command.static classInsertStatementBuilder.InsertStatementImplementation of the CohQL "INSERT" command.static classQueryRecorderStatementBuilder.QueryRecorderStatementImplementation of the CohQL "QueryRecorder" command.static classRestoreStatementBuilder.RestoreStatementImplementation of the CohQL "RESTORE" command.static classSelectStatementBuilder.SelectStatementImplementation of the CohQL "SELECT" command.static classSourceStatementBuilder.SourceStatementImplementation of the CohQL "source" command.static classTruncateCacheStatementBuilder.TruncateCacheStatementImplementation of the CohQL "TRUNCATE CACHE" command.static classUpdateStatementBuilder.UpdateStatementImplementation of the CohQL "UPDATE" command. -
Uses of Base in com.tangosol.coherence.dslquery.statement.persistence
Subclasses of Base in com.tangosol.coherence.dslquery.statement.persistence Modifier and Type Class Description classAbstractSnapshotStatementAbstract implementation of anAbstractStatementproviding functionality useful for generic snapshot statements.static classArchiveSnapshotStatementBuilder.ArchiveSnapshotStatementImplementation of the CohQL "ARCHIVE SNAPSHOT" command.static classCreateSnapshotStatementBuilder.CreateSnapshotStatementImplementation of the CohQL "CREATE SNAPSHOT" command.static classForceRecoveryStatementBuilder.ForceRecoveryStatementImplementation of the CohQL "FORCE RECOVERY" command.static classListArchiverStatementBuilder.ListArchiverStatementImplementation of the CohQL "LIST ARCHIVER" command.static classListServicesStatementBuilder.ListServicesStatementImplementation of the CohQL "LIST SERVICES" command.static classListSnapshotsStatementBuilder.ListSnapshotsStatementImplementation of the CohQL "LIST SNAPSHOTS" command.static classRecoverSnapshotStatementBuilder.RecoverSnapshotStatementImplementation of the CohQL "RECOVER SNAPSHOT" command.static classRemoveSnapshotStatementBuilder.RemoveSnapshotStatementImplementation of the CohQL "REMOVE [ARCHIVED] SNAPSHOT" command.static classResumeServiceStatementBuilder.ResumeServiceStatementImplementation of the CohQL "RESUME SERVICE" command.static classRetrieveSnapshotStatementBuilder.RetrieveSnapshotStatementImplementation of the CohQL "RETRIEVE SNAPSHOT" command.static classSuspendServiceStatementBuilder.SuspendServiceStatementImplementation of the CohQL "SUSPEND SERVICE" command.static classValidateSnapshotStatementBuilder.ValidateSnapshotStatementImplementation of the CohQL "VALIDATE [ARCHIVED] SNAPSHOT" command. -
Uses of Base in com.tangosol.coherence.jcache.localcache
Subclasses of Base in com.tangosol.coherence.jcache.localcache Modifier and Type Class Description classLocalCacheAsynchronousMapListener<K,V>MapListener for Coherence-based JCache adapter implementation to generate JCacheCoherenceCacheEntryEvent.classLocalCacheSynchronousMapListener<K,V>Synchronous version of LocalCacheAsynchronousMapListener. -
Uses of Base in com.tangosol.coherence.jcache.partitionedcache
Subclasses of Base in com.tangosol.coherence.jcache.partitionedcache Modifier and Type Class Description classPartitionedCacheAsynchronousMapListener<K,V>MapListener for coherence cache to implement jcache map events.classPartitionedCacheConfigurationMapListenerMapListener for meta-information about JCachePartitionedCacheinstances.classPartitionedCacheSynchronousMapListener<K,V>Synchronous version of PartitionedCacheAsynchronousMapListener.classPartitionedCacheSyntheticDeleteMapListener<K,V>MapListener for coherence cache to generate JCache ExpiryEvents.static classPartitionedJCacheStatistics.CacheStatisticsExtractorGet CacheStatistics from binEntry's context for JCache id. -
Uses of Base in com.tangosol.coherence.rest.util.extractor
Subclasses of Base in com.tangosol.coherence.rest.util.extractor Modifier and Type Class Description classMvelExtractorMVEL-based ValueExtractor implementation. -
Uses of Base in com.tangosol.coherence.rest.util.updater
Subclasses of Base in com.tangosol.coherence.rest.util.updater Modifier and Type Class Description classMvelUpdaterMVEL-based ValueUpdater implementation. -
Uses of Base in com.tangosol.io
Subclasses of Base in com.tangosol.io Modifier and Type Class Description classAbstractBinaryStoreAbstract implementation of the BinaryStore interface.classAbstractByteArrayReadBufferThe 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 NIOclassAbstractReadBufferAbstract base implementation of the ReadBuffer interface.classAsyncBinaryStoreAn AsyncBinaryStore is a BinaryStore wrapper that performs the "O" (output) portion of its I/O asynchronously on a daemon thread.protected classAsyncBinaryStore.QueueDaemonA daemon that processes queued writes.classByteArrayReadBufferA ReadBuffer on top of a byte array.classDecoratedBinaryDeltaCompressorA DeltaCompressor implementation that works with decorated binary values.classDecorationOnlyDeltaCompressorDecorationOnlyDeltaCompressor is a DeltaCompressor which optimizes for "decoration-only" updates.classMultiBufferReadBufferThe 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.classWrapperBufferOutputThis is an imitation BufferOutput implementation that provides the BufferOutput interface by delegating to an object that implements the DataOutput interface.static classWrapperBufferOutput.VersionAwareBufferOutputA 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. -
Uses of Base in com.tangosol.io.bdb
Subclasses of Base in com.tangosol.io.bdb Modifier and Type Class Description classBerkeleyDBBinaryStoreAn implementation of the BinaryStore interface using Sleepycat Berkeley DB Java Edition.classBerkeleyDBBinaryStoreManagerAn implementation of the BinaryStoreManager interface using Sleepycat Berkeley DB Java Edition.classDatabaseFactoryFactory for Berkeley DB Environments and Databases.classDatabaseFactoryManagerA manager for Berkeley DB Database factories. -
Uses of Base in com.tangosol.io.nio
Subclasses of Base in com.tangosol.io.nio Modifier and Type Class Description classAbstractBufferManagerProvides a basic implementation of ByteBufferManager.classAbstractStoreManagerA base implementation of BinaryStoreManager interface that usesBinaryMapobjects built on aByteBufferManagerto provideBinaryStoreobjects.classBinaryMap.BlockA Block is the unit of storage within a Buffer.static classBinaryMap.EntryA map entry (key-value pair).classByteBufferReadBufferA ReadBuffer implementation on top of a Java NIO ByteBuffer.classMappedBufferManagerManages a ByteBuffer on a file.classMappedStoreManagerAn implementation of BinaryStoreManager interface that usesBinaryMapobjects built on theMappedBufferManagerto provideBinaryStoreobjects. -
Uses of Base in com.tangosol.io.pof
Subclasses of Base in com.tangosol.io.pof Modifier and Type Class Description classAbstractPofHandlerAn abstract implementation of PofHandler that delegates to a PofHandler.classDuplexingPofHandlerAn implementation of PofHandler that passes each call onto two different PofHandler objects.classExternalizableLitePofSerializerPofSerializerimplementation that supports the serialization and deserialization of any class that implementsExternalizableLiteto and from a POF stream.classExternalizablePofSerializerPofSerializerimplementation that supports the serialization and deserialization of any class that implementsExternalizableto and from a POF stream.classLoggingPofHandlerAn implementation of PofHandler that logs all of the stream contents for debugging / testing purposes.classPofBufferReaderPofReaderimplementation that reads POF-encoded data from aBufferInput.static classPofBufferReader.UserTypeReaderThe UserTypeReader implementation is a contextually-aware PofReader whose purpose is to advance through the properties of a value of a specified user type.classPofBufferWriterPofWriterimplementation that writes POF-encoded data to aBufferOutput.static classPofBufferWriter.UserTypeWriterThe UserTypeWriter implementation is a contextually-aware PofWriter whose purpose is to write the properties of a value of a specified user type.classPofHelperCollection of helper methods for POF streams.classPofParserA "push" parser (event-based parser) for ripping through a POF stream and delivering the contents as events to a PofHandler object.classPofPrincipalGeneric Principal implementation that can be used to represent the identity of any remote entity.classPortableObjectSerializerPofSerializerimplementation that supports the serialization and deserialization of any class that implementsPortableObjectto and from a POF stream.classRawDateAn immutable POF date value.classRawDateTimeAn immutable POF date-time value.classRawDayTimeIntervalAn immutable POF day-time interval value.classRawTimeAn immutable POF time value.classRawTimeIntervalAn immutable POF time interval value.classRawYearMonthIntervalAn immutable POF year-month interval value.classSafeConfigurablePofContext.ExternalSerializerSerializer used for Serializable and ExternalizableLite objects.classSafeConfigurablePofContext.JavaPofSerializerDefault Java serializer.classSafeConfigurablePofContext.SafePofSerializerSerializer used for objects implementing the PortableObject interface.classValidatingPofHandlerAn implementation of PofHandler that validates a POF stream.classValidatingPofHandler.ComplexA Complex object represents the current complex data structure in the POF stream.classValidatingPofHandler.ComplexMapA ComplexMap object represents a map data structure (potentially with uniform keys or with uniform keys and values) in the POF stream.classWritingPofHandlerAn implementation of PofHandler that writes a POF stream to a WriteBuffer using a BufferOutput object.static classWritingPofHandler.ComplexA Complex object represents the current complex data structure in the POF stream.static classWritingPofHandler.ComplexMapA ComplexMap object represents a map data structure (with uniform keys or with uniform keys and values) in the POF stream.classXmlSerializablePofSerializerPofSerializerimplementation that supports the serialization and deserialization of any class that implementsXmlSerializableto and from a POF stream. -
Uses of Base in com.tangosol.io.pof.reflect
Subclasses of Base in com.tangosol.io.pof.reflect Modifier and Type Class Description classAbstractPofPathAbstract base class for static, path-based implementations ofPofNavigatorinterface.classAbstractPofValueAn abstract base class that implements common functionality for all PofValue types.classComplexPofValueAn abstract base class for complex POF types, such as collections, arrays, maps, and user types.classPofArrayPofArray is aPofValueimplementation for arrays.classPofCollectionPofCollection isPofValueimplementation for collections.classPofSparseArrayPofSparseArray isPofValueimplementation for sparse arrays.protected static classPofSparseArray.NilPofValueNilPofValue represents a value that does not exist in the original POF stream.classPofUniformArrayPofUniformArray isPofValueimplementation for uniform arrays.classPofUniformCollectionPofUniformCollection isPofValueimplementation for uniform collections.classPofUniformSparseArrayPofUniformSparseArray isPofValueimplementation for uniform sparse arrays.classPofUserTypePofUserType isPofValueimplementation for user types.classPofValueParserParses POF-encoded binary and returns an instance of aPofValuewrapper for it.classSimplePofPathA staticPofNavigatorimplementation which uses an array of integer indices to navigate the PofValue hierarchy.classSimplePofValueSimplePofValue represents POF values which do not contain children (e.g. -
Uses of Base in com.tangosol.license
Subclasses of Base in com.tangosol.license with annotations of type with type parameters of type that implement declared as with annotations of type with type parameters of type with annotations of type with annotations of type with type parameters of type that return that return types with arguments of type with parameters of type with type arguments of type that throw with annotations of type with annotations of type with parameters of type with type arguments of type that throw Modifier and Type Class Description classcom.tangosol.license.CoherenceApplicationEditionThis class is a license class.classcom.tangosol.license.CoherenceCommunityEditionThis class is a license class.classcom.tangosol.license.CoherenceDataGridEditionThis class is a license class.classcom.tangosol.license.LicensedObjectThis class is a base class for classes that may be license-limited. -
Uses of Base in com.tangosol.net
Subclasses of Base in com.tangosol.net Modifier and Type Class Description classAbstractBackingMapManagerAbstract base of the BackingMapManager implementations.classAbstractInvocableAn abstract base for Invocable and PriorityTask implementations.classAbstractPriorityTaskAn abstract base for PriorityTask implementations.classAbstractServiceLoadBalancer<S extends Service,T extends ServiceLoad>An abstract base for ServiceLoadBalancer implementations.classCacheFactoryFactory for the Coherence™ cache product.classCompressionFilterDeprecated.As of Coherence 3.7classConfigurableQuorumPolicyConfigurableQuorumPolicy provides a Quorum-basedActionPolicyfor services based on the cluster-configuration.static classConfigurableQuorumPolicy.ClusterQuorumPolicyClusterQuorumPolicy defines an action policy that is applicable to the cluster.static classConfigurableQuorumPolicy.MembershipQuorumPolicyMembershipQuorumPolicy is a quorum policy that is stateless and based solely on service membership sizes.static classConfigurableQuorumPolicy.PartitionedCacheQuorumPolicyPartitionedCacheQuorumPolicy defines a configurable quorum policy that is applicable to a DistributedCacheService.static classConfigurableQuorumPolicy.ProxyQuorumPolicyProxyQuorumPolicy defines a configurable quorum policy that is applicable to a proxy service.classDefaultCacheServerDefaultCacheServer 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.classDefaultConfigurableCacheFactoryDeprecated.classDefaultConfigurableCacheFactory.ManagerDeprecated.BackingMapManager implementation that uses the configuration XML to create the required backing maps and provides client access to those maps.protected classDefaultConfigurableCacheFactory.PartitionedBackingMapManagerDeprecated.BackingMapManager implementation used by PartitionAwareBackingMap(s) to lazily configure the enclosing PABM based on the configuration settings of the enclosed maps.classExtensibleConfigurableCacheFactoryExtensibleConfigurableCacheFactory provides a facility to access caches declared in a "coherence-cache-config.xsd" compliant configuration file.static classExtensibleConfigurableCacheFactory.ManagerThe Manager class uses builders to create the required backing maps and provides client access to those maps.static classExtensibleConfigurableCacheFactory.PartitionedBackingMapManagerThe PartitionedBackingMapManager is used by PartitionAwareBackingMap(s) to lazily configure the enclosing PABM based on the configuration settings of the enclosed maps.classGuardSupportA concrete implementation of Guardian/Guardable interactions.classLoadBalancerA non-sticky HTTP load-balancer.static classLoadBalancer.AddressPortAn AddressPort is an immutable combination of an IP address and a port number.static classLoadBalancer.QueueA Queue is used to effeciently queue up items for daemon threads to work on.classLoadBalancer.RequestHandlerA RequestHandler is a daemon thread that processes a request from a queue.classLoadBalancer.ResponseHandlerA ResponseHandler is a daemon thread that processes an outgoing response from a destination server.static classLoadBalancer.SocketHandlerA SocketHandler is an abstract daemon thread.classRefreshableAddressProviderA RefreshableAddressProvider is an AddressProvider implementation that wraps another AddressProvider and refresh the address list of the provider asynchronously.protected classRefreshableAddressProvider.RefreshThreadclassSimpleServiceLoadBalancer<S extends Service,T extends ServiceLoad>A simple ServiceLoadBalancer implementation. -
Uses of Base in com.tangosol.net.cache
Subclasses of Base in com.tangosol.net.cache Modifier and Type Class Description classAbstractBinaryEntryBundlerAn abstract BinaryEntry-based bundler that serves as a base for BinaryEntryStore operation bundling.protected classAbstractBinaryEntryBundler.BundleclassAbstractBundlerAn abstract base for processors that implement bundling strategy.protected classAbstractBundler.BundleBundle represents a unit of optimized execution.classAbstractCacheLoader<K,V>An abstract base class for the JCache CacheLoader.classAbstractCacheStore<K,V>An abstract base class for the JCache CacheLoader.classAbstractEntryBundlerAn abstract entry-based bundler serves as a base for NamedCache.put() and CacheStore.store() operation bundling.protected classAbstractEntryBundler.BundleclassAbstractEvictionPolicyAn abstract base class for custom cache eviction policies.classAbstractKeyBundlerAn 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.protected classAbstractKeyBundler.BundleBundle represents a unit of optimized execution.classAbstractSerializationCacheAn abstract base class for serialization-based caches.classBackingMapBinaryEntryAn implementation of the BinaryEntry interface that is based on specified binary key, binary value and BackingMapManagerContext.classBinaryMemoryCalculatorA UnitCalculator implementation that weighs a cache entry based upon the amount of physical memory (in bytes) required to store the entry.classBinaryStoreCacheStore<K,V>A CacheStore that sits directly on top of a BinaryStore.classBundlingNamedCacheBundling NamedCache implementation.protected classBundlingNamedCache.GetBundlerprotected classBundlingNamedCache.PutBundlerprotected classBundlingNamedCache.RemoveBundlerclassCacheLoaderCacheStore<K,V>A read-only CacheStore that wraps a CacheLoader.static classCacheLoaderCacheStore.Iterable<K,V>An extension to the CacheLoaderCacheStore that implements the IterableCacheLoader interface.static classCacheStoreMap.ReadWriteMapA Map implementation that delegates straight through to a CacheStore.protected classCachingMap.DeactivationListenerDeactivationListener for the back NamedCache.protected classCachingMap.FrontMapListenerMapListener for front map responsible for deregistering back map listeners upon front map eviction.protected classCachingMap.PrimingListenerMapListener for back map responsible for keeping the front map coherent with the back map.protected classCachingMap.SimpleListenerMapListener for back map responsible for keeping the front map coherent with the back map.classContinuousQueryCache<K,V_BACK,V_FRONT>Create a materialized view of aNamedCacheusing theCoherenceContinuous Query capability.classContinuousQueryCache.AddListenerAMapListenerfor adding items to theContinuousQueryCache.protected classContinuousQueryCache.DeactivationListenerDeactivationListener for the underlying NamedCache.protected classContinuousQueryCache.EventRouter<K,V>An EventRouter routes events from the internal cache of theContinuousQueryCacheto the client listeners, and it can do so asynchronously when appropriate.protected classContinuousQueryCache.InternalMapListenerThis listener allows interception of all events triggered by the the internalObservableMapof theContinuousQueryCache.classContinuousQueryCache.RemoveListenerAMapListenerfor evicting items from theContinuousQueryCache.classLocalCache.EntryA holder for a cached value.protected classLocalCache.InternalListenerAn internal MapListener that listens to this cache and reports changes to the CacheStore.protected classLocalCache.KeyMaskA class that masks certain changes so that they are not reported back to the CacheStore.classMapCacheStore<K,V>A CacheStore that sits directly on top of a Map.classOldCache.EntryDeprecated.A holder for a cached value.classOverflowMapAn 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).protected classOverflowMap.BackMapListenerA listener for the back map.protected classOverflowMap.FrontMapListenerA listener for the front map that moves evictions to the back map.classReadonlyNamedCache<K,V>A simple extension of the WrapperNamedCache implementation that shields all content mutating operations such as put(), remove(), lock() etc.classReadWriteBackingMap.BinaryEntryStoreWrapperA wrapper around the original BinaryEntryStore to allow operations to be overridden and extended.static classReadWriteBackingMap.CacheLoaderCacheStoreA CacheStore wrapped around a CacheLoader.classReadWriteBackingMap.CacheStoreWrapperA wrapper around the original CacheStore to allow operations to be overridden and extended.classReadWriteBackingMap.EntryA queue entry that is scheduled to come out of the front of the queue no earlier than some specific point in time.static classReadWriteBackingMap.EvictingBackupMapA Map implementation used for a backup map that evicts all data that has been successfully written.protected classReadWriteBackingMap.InternalMapListenerA MapListener implementation that listens to the internal cache and routes those events to anyone listening to this ReadWriteBackingMap.classReadWriteBackingMap.NonBlockingEntryStoreWrapperA wrapper around the original NonBlockingEntryStore to allow operations to be overridden and extended.classReadWriteBackingMap.ReadQueueA queue of keys that should be read from the underlying CacheStore.classReadWriteBackingMap.ReadThreadA 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.classReadWriteBackingMap.StoreWrapperAbstract wrapper around a cache store to allow operations to be overridden and extended.classReadWriteBackingMap.WriteQueueA queue that only releases entries after a configurable period of time.classReadWriteBackingMap.WriteThreadThis is the write-behind thread that pulls things from the write-behind queue and writes them to the CacheStore that the backing map uses.classSeppukuMapListenerA map listener that follows the "seppuku" pattern, invalidating the Map entries when MapEvents for another related ObservableMap are delivered.classSerializationCacheA version of SerializationMap that implements an LRU policy.protected classSerializationCache.EntryAttributesA class that holds on to the expiry time and touch order for an entry.classSerializationCache.EntrySet.EntryA Cache Entry implementation.classSerializationMapMap implementation that stores its contents in a BinaryStore.classSerializationPagedCacheA version of SerializationMap that implements an LRU policy using time-based paging of the cache.classSerializationPagedCache.PagedBinaryStoreA virtual BinaryStore implementation that aggregates a sequence (newest to oldest) of periodic BinaryStore objects.classSimpleCacheStatisticsImplementation of the CacheStatistics interface intended for use by a cache to maintain its statistics.classSimpleMemoryCalculatorA UnitCalculator implementation that weighs a cache entry based upon the amount of physical memory (in bytes) required to store the entry.classSimpleOverflowMapA 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).protected classSimpleOverflowMap.FrontMapListenerA listener for the front map that moves evictions to the back map.classSimpleSerializationMapMap implementation that stores and accesses its contents through an underlying BinaryStore.classVersionedBackingMap.CacheStoreWrapperDeprecated.A wrapper around the original CacheStore to allow operations to be overridden and extended.protected classVersionedBackingMap.InternalMapListenerDeprecated.A MapListener implementation that listens to the internal cache and routes those events to anyone listening to this VersionedBackingMap.classVersionedNearCache.VersionCacheListenerDeprecated.A map listener that listens to the VersionCache and invalidates local entries accordingly.classWrapperNamedCache<K,V>A simple implementation of NamedCache interface built as a wrapper around any Map implementation. -
Uses of Base in com.tangosol.net.management
Subclasses of Base in com.tangosol.net.management Modifier and Type Class Description classMBeanConnectorUtility class to expose Coherence JMX MBeans via the Sun JMX reference implementation HtmlAdaptorServer or a JMX RemoteJMXConnectorServer.classMBeanHelperHelper class providing various functionality related to aggregation of attributes and methods exposed by Coherence JMX framework MBeans.classObjectNameExcludeFilterFilter used to prevent registering MBeans that match the specified pattern. -
Uses of Base in com.tangosol.net.partition
Subclasses of Base in com.tangosol.net.partition Modifier and Type Class Description classBroadKeyPartitioningStrategyThe 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.classDefaultKeyPartitioningStrategyDefaultKeyPartitioningStrategy provides a simple strategy for assigning keys to partitions which is based on the hash code of keys in internal (serialized to Binary) form.classObservableSplittingBackingCacheThe ObservableSplittingBackingCache is an implementation of the ConfigurableCacheMap interface that works as an observable backing map in a partitioned system.protected static classObservableSplittingBackingCache.CapacityAwareMapA subclass of PartitionSplittingBackingMap which allows an injected instance ofObservableSplittingBackingMapto be called immediately before inserting a value(s) in a partition map.classObservableSplittingBackingCache.EntrySet.EntryA Cache Entry implementation.classObservableSplittingBackingMapAn observable, cache-aware PartitionAwareBackingMap implementation.classOwnershipOwnership is a light-weight data structure that contains a partition ownership information.classPartitionSetPartitionSet is a light-weight data structure that represents a set of partitions that are used in parallel processing.classPartitionSplittingBackingMapIn 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.classPartitionSplittingBackingMap.MaskedPartitionMapA read-only view into a subset of backing maps managed by the underlying PartitionSplittingBackingMap.classVersionedOwnershipAn extension of the partition Ownership object which also carries a change version. -
Uses of Base in com.tangosol.net.proxy
Subclasses of Base in com.tangosol.net.proxy Modifier and Type Class Description classDefaultProxyServiceLoadBalancerDefault ProxyServiceLoadBalancer implementation. -
Uses of Base in com.tangosol.net.security
Subclasses of Base in com.tangosol.net.security Modifier and Type Class Description classDefaultControllerThe default implementation of the AccessController interface.classDefaultIdentityAsserterThe default implementation of the IdentityAsserter interface.classPermissionInfoPermissionInfo holds the information needed to validate and respond to a security related request.classSecurityThe Security class is used to associate client's identity with an action that requires access to protected clustered resources.classSimpleHandlerThe SimpleHandler class is a CallbackHandler implementation based on a specified user name and password. -
Uses of Base in com.tangosol.net.topic
Subclasses of Base in com.tangosol.net.topic Modifier and Type Class Description classTopicBackingMapManager<D extends TopicDependencies,S extends NamedTopicScheme>A base class for topic backing map managers. -
Uses of Base in com.tangosol.persistence
Subclasses of Base in com.tangosol.persistence Modifier and Type Class Description classAbstractPersistenceEnvironmentAbstract implementation of a ReadBuffer-based PersistentEnvironment.classAbstractPersistenceManager<PS extends AbstractPersistenceManager.AbstractPersistentStore>Abstract implementation of a ReadBuffer-based PersistentManager.classAbstractPersistenceManager.AbstractPersistentStoreAbstract implementation of a ReadBuffer-based PersistentStore.protected classAbstractPersistenceManager.AbstractPersistentStore.BatchTaskRunnable implementation that is used to perform and commit a sequence of mutating persistent store operations asynchronously.protected classAbstractPersistenceManager.AbstractPersistentStore.BatchTask.EraseOperationAn erase() Operation.protected classAbstractPersistenceManager.AbstractPersistentStore.BatchTask.OperationBase class for Runnable implementations that encapsulate a persistent store operation.protected classAbstractPersistenceManager.AbstractPersistentStore.BatchTask.StoreOperationA store() Operation.protected classAbstractPersistenceManager.AbstractPersistentStore.DeleteExtentTaskA Task implementation that deletes an extent from the associated store.protected classAbstractPersistenceManager.AbstractPersistentStore.OpenTaskAn OpenTask opens the store (parent of this inner class) with the provided store and notifies the Collector when complete.classAbstractPersistenceManager.TaskRunnable extension that adds the ability to notify the task that it has been canceled.static classGUIDHelper.GUIDResolverResolver used during a recovery to discover the newest available GUID for a given partition. -
Uses of Base in com.tangosol.run.jca
Subclasses of Base in com.tangosol.run.jca Modifier and Type Class Description classSimpleValidatorSimple generic Validator implementation that uses hashCode values for the enlisted resources to resolve optimistic transaction conflicts. -
Uses of Base in com.tangosol.run.xml
Subclasses of Base in com.tangosol.run.xml Modifier and Type Class Description classArrayAdapterAn ArrayAdapter supports properties of Java array types (not including arrays of primitive types).classCollectionAdapterA CollectionAdapter supports properties whose types implement the java.util.Collection interface.classDateFormatAdapterA property adapter for formatting formatting and parsing dates in a locale-sensitive manner.classDateTimeAdapterA property adapter for the <xs:dateTime> format conforming to ISO 8601classIterableAdapterAn IterableAdapter is the base class for any data type that must be iterated over to serialize/deserialize, such as arrays, collections and maps.classMapAdapterA MapAdapter supports properties whose types implement the java.util.Map interface.classPrimitiveArrayAdapterA PrimitiveArrayAdapter supports arrays of primitive types, such as "int", "char", etc.static classPrimitiveArrayAdapter.BooleanArrayAdapterA PropertyAdapter supporting boolean[].static classPrimitiveArrayAdapter.ByteArrayAdapterA PropertyAdapter supporting byte[].static classPrimitiveArrayAdapter.CharArrayAdapterA PropertyAdapter supporting char[].static classPrimitiveArrayAdapter.DoubleArrayAdapterA PropertyAdapter supporting double[].static classPrimitiveArrayAdapter.FloatArrayAdapterA PropertyAdapter supporting float[].static classPrimitiveArrayAdapter.IntArrayAdapterA PropertyAdapter supporting int[].static classPrimitiveArrayAdapter.LongArrayAdapterA PropertyAdapter supporting long[].static classPrimitiveArrayAdapter.ShortArrayAdapterA PropertyAdapter supporting short[].classPropertyAdapterThe PropertyAdapter is the base class for handling the operations that can occur on any property.classQNameAdapterA property adapter for QName primitive datatype.classRestrictedStringAdapterA 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).classSaxParserA simple XML parser.classSerializableAdapterA SerializableAdapter supports Java objects that implement the Serializable interface.classSimpleAdapterA 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.Datestatic classSimpleAdapter.BigDecimalAdapterA simple property adapter for BigDecimal.static classSimpleAdapter.BigIntegerAdapterA simple property adapter for BigInteger.static classSimpleAdapter.BooleanAdapterA simple property adapter for boolean.static classSimpleAdapter.ByteAdapterA simple property adapter for byte.static classSimpleAdapter.CharAdapterA simple property adapter for char.static classSimpleAdapter.DateAdapterA simple property adapter for Date.static classSimpleAdapter.DoubleAdapterA simple property adapter for double.static classSimpleAdapter.FloatAdapterA simple property adapter for float.static classSimpleAdapter.IntAdapterA simple property adapter for int.static classSimpleAdapter.LongAdapterA simple property adapter for long.static classSimpleAdapter.OldDateAdapterA simple property adapter for the Date class from the java/util package.static classSimpleAdapter.ShortAdapterA simple property adapter for short.static classSimpleAdapter.StringAdapterA simple property adapter for String.static classSimpleAdapter.SystemTimeAdapterA 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.static classSimpleAdapter.TimeAdapterA simple property adapter for Time.static classSimpleAdapter.TimestampAdapterA simple property adapter for Timestamp.classSimpleDocumentA simple implementation of the XmlElement interface.classSimpleElementA simple implementation of the XmlElement interface.classSimpleElement.AttributeMap.EntryAn implementation of Entry that supports keeping them in a list.classSimpleParserThis class uses the XmlTokenizer to produce an XmlDocument from XML text.classSimpleValueA simple implementation of the XmlValue interface.classXmlBeanThis is a base class for building XmlSerializable value objects.classXmlElementAdapterAn XmlElementAdapter supports properties of type XmlElement.classXmlHelperThis abstract class contains XML manipulation methods.classXmlSerializableAdapterAn XmlSerializableAdapter supports Java objects that implement the XmlSerializable interface. -
Uses of Base in com.tangosol.util
Subclasses of Base in com.tangosol.util Modifier and Type Class Description classAbstractKeyBasedMap<K,V>AbstractKeyBasedMap is a base class for Map implementations.protected classAbstractKeyBasedMap.EntrySet.EntryA Map Entry implementation that defers its value acquisition from the containing map (viaMap.get(Object)) if the Entry is constructed with a null value.classAbstractKeySetBasedMap<K,V>AbstractKeySetBasedMap is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.classAbstractMapListenerA base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.classBinaryA thread-safe immutable binary object.classBitHelperA collection of methods for bit-based operations.classChainedEnumeratorProvide an enumerator which enumerates the contents of multiple enumerators.classClassFilterFilter which discards all objects that are not of a certain class.classCompositeKey<P,S>Key class that consists of a primary and secondary component.classConditionalIndexConditionalIndex is aMapIndeximplementation that uses an associated filter to evaluate whether or not an entry should be indexed.static classConverterCollections.ConverterCacheListener<K,V>A converter MapListener that converts events of the underlying MapListener for the underlying NamedCache.static classConverterCollections.ConverterMapListener<K,V>A converter MapListener that converts events of the underlying MapListener for the underlying map.classDaemonA abstract Daemon thread handler.classDequeueRepresents a double-ended queue (dequeue) of objects.classEnumerationIterator<E>Provide a implementation of an Iterator based on data from an Enumeration.classExternalizableHelperHelpers for the Serializable, Externalizable and the ExternalizableLite interface.static classExternalizableHelper.DecoratedMultiBufferReadBufferDecoratedMultiBufferReadBuffer is a MultiBufferWriteBuffer that represents a binary "decorated" value, and allows a more optimizedExternalizableHelper.getUndecorated(ReadBuffer)operation.protected static classExternalizableHelper.IntDecoratedObjectInteger decorated object.static classExternalizableHelper.SimpleXmlBeanClassCacheAn implementation XmlBeanClassCache that uses a pre-defined list of XmlBean implementations.classFilterEnumeratorProvide a generic implementation of an enumerator which can enumerate items based on an inclusion test.classInvocableMapHelperHelper methods for InvocableMap implementations and Filter related evaluation.static classInvocableMapHelper.SimpleEntry<K,V>Simple implementation of the InvocableMap.Entry interface.classIteratorEnumeratorProvide a implementation of an enumerator based on data from an Iterator.classKeyValueArrayMapKeyValueArrayMap is a Map implementation backed by an array of keys, and an array of the associated values.classListenersProvide a simple, efficient, and thread-safe implementation of a list of event listeners.classMapListenerSupportThis class provides support for advanced MapListener functionality.static classMapListenerSupport.WrapperListener<K,V>A base class for various wrapper listener classes.static classMapListenerSupport.WrapperPrimingListenerA wrapper class that turns the specified MapListener into a priming listener.static classMapListenerSupport.WrapperSynchronousListener<K,V>A wrapper class that turns the specified MapListener into a synchronous listener.classMapTriggerListenerMapTriggerListener is a special purpose MapListener implementation that is used to register aMapTriggeron a corresponding ObservableMap.classMultiplexingMapListener<K,V>A base class that simplifies the implementation of a MapListener by multiplexing all events into a single listener method.classNullFilterFilter which discards null references.static classNullImplementation.NullEntryProcessorAn implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.protected classObservableHashMap.Entry<K,V>A holder for a cached value.classOpenHashMap<K,V>An implementation ofMapthat is optimized for memory footprint.protected classOpenHashMap.EntrySet.EntryAn 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.classPagedIteratorPagedIterator 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.protected classRecyclingLinkedList.NodeA Node in the List.classRestrictedCollectionsA collection of Collection implementation classes that limit the data type.static classRestrictedCollections.RestrictedCollectionA restricted Collection that requires its contents to be of a specified class.static classRestrictedCollections.RestrictedEntrySetA restricted Collection that requires its contents to be of a specified class.protected classRestrictedCollections.RestrictedEntrySet.RestrictedEntryA Map Entry that restricts the key and value types.protected classRestrictedCollections.RestrictedEntrySet.RestrictedIteratorA Map Entry Iterator that restricts the key and value types.static classRestrictedCollections.RestrictedListA restricted List that requires its contents to be of a specified class.static classRestrictedCollections.RestrictedListIteratorA restricted ListIterator that requires its contents to be of a specified class.static classRestrictedCollections.RestrictedMapA restricted Map that requires its keys and values to be of specified classes.static classRestrictedCollections.RestrictedSetA restricted Set that requires its contents to be of a specified class.static classRestrictedCollections.RestrictedSortedMapA restricted SortedMap that requires its keys and values to be of specified classes.static classRestrictedCollections.RestrictedSortedSetA restricted Set that requires its contents to be of a specified class.protected static classSafeHashMap.Entry<K,V>A map entry (key-value pair).protected static classSafeLinkedList.NodeA Node in the List.classSegmentedConcurrentMapAn implementation of SegmentedHashMap that also implements the ConcurrentMap interface.classSegmentedConcurrentMap.LockableEntryLockableEntry is an Entry that supports locking.classSegmentedHashMapAn implementation of java.util.Map that is optimized for heavy concurrent use.protected static classSegmentedHashMap.EntryA map entry (key-value pair).classSimpleEnumerator<E>Provide a generic implementation of an array enumerator.classSimpleMapEntry<K,V>A map entry (key-value pair).classSimpleMapIndexSimpleMapIndex 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.static classSimpleMapIndex.IndexCalculatorA statefulcalculatorused to calculate the cost of a homogeneous index (holding all values of a single type).classSortedEnumeratorSorts the contents of the passed enumerator then enumerates those contents.classStringTableLike a hash table, but built specifically for strings.classTaskDaemonA Daemon thread handler that asynchronously executes Runnable tasks, either at a scheduled time or "as soon as possible".classTaskDaemon.PeriodicTaskA PeriodicTask is a task that automatically reschedules itself so that it executes on a periodic basis.classThreadLocalObjectThis class provides an implementation of thread local storage.classTreeA thread-safe balanced binary search tree.classUIDA UID is a 128-bit identifier that is almost guaranteed to be unique.classUUIDA UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique.classWrapperConcurrentMap<K,V>A simple implementation of ConcurrentMap interface built as a wrapper around any Map implementation.protected static classWrapperConcurrentMap.LockA lock object.classWrapperObservableMap<K,V>A simple implementation of ObservableMap interface built as a wrapper around any Map implementation.protected classWrapperObservableMap.InternalListenerAn internal MapListener that listens to the wrapped map. -
Uses of Base in com.tangosol.util.aggregator
Subclasses of Base in com.tangosol.util.aggregator Modifier and Type Class Description classAbstractAggregator<K,V,T,E,R>Abstract base class implementation ofInvocableMap.EntryAggregatorthat supports streaming aggregation.classAbstractBigDecimalAggregator<T>Abstract aggregator that processesNumbervalues extracted from a set of entries in a Map and returns a result in a form of aBigDecimalvalue.classAbstractComparableAggregator<T,R>Abstract aggregator that processes values extracted from a set of entries in a Map, with knowledge of how to compare those values.classAbstractDoubleAggregator<T>Abstract aggregator that processes numeric values extracted from a set of entries in a Map.classAbstractLongAggregator<T>Abstract aggregator that processes numeric values extracted from a set of entries in a Map.classBigDecimalAverage<T>Calculates an average for values of any numeric type extracted from a set of entries in a Map in a form of aBigDecimalvalue.classBigDecimalMax<T>Calculates a maximum of numeric values extracted from a set of entries in a Map in a form of aBigDecimalvalue.classBigDecimalMin<T>Calculates a minimum of numeric values extracted from a set of entries in a Map in a form of aBigDecimalvalue.classBigDecimalSum<T>Calculates an sum for values of any numberic type extracted from a set of entries in a Map in a form of aBigDecimalvalue.classComparableMax<T,R>Calculates a maximum among values extracted from a set of entries in a Map.classComparableMin<T,R>Calculates a minimum among values extracted from a set of entries in a Map.classCompositeAggregator<K,V>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.static classCompositeAggregator.ParallelDeprecated.As of Coherence 12.2.1.classCount<K,V>Calculates a number of values in an entry set.classDistinctValues<K,V,T,E>Return the set of unique values extracted from a set of entries in a Map.classDoubleAverage<T>Calculates an average for values of any numeric type extracted from a set of entries in a Map.classDoubleMax<T>Calculates a maximum of numeric values extracted from a set of entries in a Map.classDoubleMin<T>Calculates a minimum of numeric values extracted from a set of entries in a Map.classDoubleSum<T>Sums up numeric values extracted from a set of entries in a Map.classGroupAggregator<K,V,T,E,R>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.static classGroupAggregator.Parallel<K,V,T,E,R>Deprecated.As of Coherence 12.2.1.classLongMax<T>Calculates a maximum of numeric values extracted from a set of entries in a Map.classLongMin<T>Calculates a minimum of numeric values extracted from a set of entries in a Map.classLongSum<T>Sums up numeric values extracted from a set of entries in a Map.classPriorityAggregator<K,V,P,R>PriorityAggregator is used to explicitly control the scheduling priority and timeouts for execution of EntryAggregator-based methods.classReducerAggregator<K,V,T,E>The ReducerAggregator is used to implement functionality similar toCacheMap.getAll(Collection)API. -
Uses of Base in com.tangosol.util.comparator
Subclasses of Base in com.tangosol.util.comparator Modifier and Type Class Description classChainedComparator<T>Composite comparator implementation based on a collection of comparators.classEntryComparatorComparator implementation used to compare map entries.classInverseComparator<T>Comparator that reverses the result of another comparator.classSafeComparator<T>Null-safe delegating comparator. -
Uses of Base in com.tangosol.util.extractor
Subclasses of Base in com.tangosol.util.extractor Modifier and Type Class Description classAbstractCompositeExtractor<T,E>Abstract super class for ValueExtractor implementations that are based on an underlying array of ValueExtractor objects.classAbstractExtractor<T,E>Abstract base for ValueExtractor implementations.classAbstractUpdater<K,V,U>Abstract base for ValueUpdater implementations.classChainedExtractor<T,E>Composite ValueExtractor implementation based on an array of extractors.classChainedFragmentExtractor<T,E>AValueExtractorthat extracts aFragmentfrom a nested property of the target object.classComparisonValueExtractor<T,E extends Number>A synthetic ValueExtractor that returns a result of comparison between two values extracted from the same target.classCompositeUpdaterA ValueUpdater implementation based on an extractor-updater pair that could also be used as a ValueManipulator.classConditionalExtractor<T,E>An IndexAwareExtractor implementation that is only used to create aConditionalIndex.classDeserializationAcceleratorDeserializationAccelerator is anIndexAwareExtractorimplementation that is used to create aForwardOnlyMapIndex, which in turn is used for deserialization optimization.classEntryExtractorThe EntryExtractor is a base abstract class for special purpose custom ValueExtractor implementations.classFragmentExtractor<T>AValueExtractorthat is used to extract aFragmentfrom an object.classIdentityExtractor<T>Trivial ValueExtractor implementation that does not actually extract anything from the passed value, but returns the value itself.classKeyExtractor<T,E>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.classMultiExtractorComposite ValueExtractor implementation based on an array of extractors.classPofExtractor<T,E>POF-based ValueExtractor implementation.classPofUpdaterPOF-based ValueUpdater implementation.classReflectionExtractor<T,E>Reflection-based ValueExtractor implementation.classReflectionUpdaterReflection-based ValueUpdater implementation.classScriptValueExtractor<T,E>ScriptValueExtractor is anAbstractExtractorthat wraps a script written in one of the languages supported by Graal VM.classUniversalExtractor<T,E>Universal ValueExtractor implementation.classUniversalUpdaterUniversal ValueUpdater implementation. -
Uses of Base in com.tangosol.util.filter
Subclasses of Base in com.tangosol.util.filter Modifier and Type Class Description classAbstractQueryRecorderFilter<T>Abstract base class implementation ofQueryRecorderFilter.classAllFilterFilter which returns the logical "and" of a filter array.classAlwaysFilter<T>Filter which always evaluates to true.classAndFilterFilter which returns the logical "and" of two other filters.classAnyFilterFilter which returns the logical "or" of a filter array.classArrayFilterFilter which is a logical operator of a filter array.classBetweenFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Between" condition.classCacheEventFilter<K,V>An extension of theMapEventFilterwhich allows selection of client driven (natural) events, cache internal (synthetic) events, or both.classComparisonFilter<T,E,C>Filter which compares the result of a method invocation with a value.classContainsAllFilter<T,E>Filter which tests aCollectionor Object array value returned from a method invocation for containment of all values in a Set.classContainsAnyFilter<T,E>Filter which tests aCollectionor Object array value returned from a method invocation for containment of any value in a Set.classContainsFilter<T,E>Filter which tests aCollectionor Object array value returned from a method invocation for containment of a given value.classEqualsFilter<T,E>Filter which compares the result of a method invocation with a value for equality.classExtractorFilter<T,E>Base Filter implementation for doing extractor-based processing.classFilterTriggerA generic Filter-based MapTrigger implementation.classGreaterEqualsFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Greater or Equal" condition.classGreaterFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Greater" condition.classInFilter<T,E>Filter which checks whether the result of a method invocation belongs to a predefined set of values.classInKeySetFilter<T>Filter that limits the underlying filter evaluation only to the specified set of keys.classIsNotNullFilter<T,E>Filter which tests the result of a method invocation for inequality to null.classIsNullFilter<T,E>Filter which compares the result of a method invocation with null.classKeyAssociatedFilter<T>Filter which limits the scope of another filter according to the key association information.classKeyFilter<T>EntryFilter which checks whether an entry key belongs to a set.classLessEqualsFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Less or Equals" condition.classLessFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Less" condition.classLikeFilter<T,E>Filter which compares the result of a method invocation with a value for pattern match.classLimitFilter<T>Filter which truncates the results of another filter.classMapEventFilter<K,V>Filter which evaluates the content of a MapEvent object according to the specified criteria.classMapEventTransformerFilter<T>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.classNeverFilter<T>Filter which always evaluates to false.classNotEqualsFilter<T,E>Filter which compares the result of a method invocation with a value for inequality.classNotFilter<T>Filter which negates the results of another filter.classOrFilterFilter which returns the logical "or" of two other filters.classPartitionedFilter<T>Filter which limits the scope of another filter to those entries that have keys that belong to the specified partition set.classPredicateFilter<T,E>Ajava.util.function.PredicatebasedExtractorFilter.classPresentFilter<T>Filter which returns true forInvocableMap.Entryobjects that currently exist in a Map.classPriorityFilter<T>PriorityFilter is used to explicitly control the scheduling priority and timeouts for execution of filter-based methods.classRegexFilter<T,E>Filter which uses the regular expression pattern match defined by thePattern.matches(String, CharSequence)contract.classWrapperQueryRecorderFilter<T>QueryRecorderFilter wrapper class.classXorFilterFilter which returns the logical exclusive or ("xor") of two other filters. -
Uses of Base in com.tangosol.util.processor
Subclasses of Base in com.tangosol.util.processor Modifier and Type Class Description classAbstractProcessor<K,V,R>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.classCompositeProcessor<K,V>The CompositeProcessor represents a collection of entry processors that are invoked sequentially against the same Entry.classConditionalProcessor<K,V,T>Conditional entry processor represents a processor that is invoked conditionally based on the result of an entry evaluation.classConditionalPut<K,V>ConditionalPut is an EntryProcessor that performs anEntry.setValueoperation if the specified condition is satisfied.classConditionalPutAll<K,V>ConditionalPutAll is an EntryProcessor that performs aEntry.setValueoperation for multiple entries that satisfy the specified condition.classConditionalRemove<K,V>ConditionalRemove is an EntryProcessor that performs anEntry.removeoperation if the specified condition is satisfied.classExtractorProcessor<K,V,T,E>ExtractorProcessor is an EntryProcessor implementations that extracts a value from an object cached in an InvocableMap.classNumberIncrementor<K,V,N extends Number>The NumberIncrementor entry processor is used to increment a property value of aNumbertype.classNumberMultiplier<K,V,N extends Number>The NumberMultiplier entry processor is used to multiply a property value of aNumbertype.classPreloadRequest<K,V>PreloadRequest is a simple EntryProcessor that performs aEntry.getValuecall.classPriorityProcessor<K,V,T>PriorityProcessor is used to explicitly control the scheduling priority and timeouts for execution of EntryProcessor-based methods.classPropertyManipulator<V,R>PropertyManipulator is a reflection based ValueManipulator implementation based on the JavaBean property name conventions.classPropertyProcessor<K,V,R>PropertyProcessor is a base class for EntryProcessor implementations that depend on a ValueManipulator.classUpdaterProcessor<K,V,T>UpdaterProcessor is an EntryProcessor implementations that updates an attribute of an object cached in an InvocableMap.classVersionedPut<K,V extends Versionable>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.classVersionedPutAll<K,V extends Versionable>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. -
Uses of Base in com.tangosol.util.transformer
Subclasses of Base in com.tangosol.util.transformer Modifier and Type Class Description classExtractorEventTransformer<K,V,E>ExtractorEventTransformer is a special purposeMapEventTransformerimplementation that transforms emitted events, extracting one or more properties from either the OldValue or the NewValue.classSamplingEventTransformer<K,V>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.classSemiLiteEventTransformer<K,V>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.
-