Uses of Class
com.tangosol.util.Base
Packages that use Base
Package
Description
Contains classes supporting the Coherence Container.
Contains Coherence-based WorkManager implementation classes.
Defines the Coherence configuration object model classes and interfaces for
Caching and Service Schemes.
This package contains
StatementBuilder implementations.This package contains classes for persistence related statement builders.
Contains classes related to local cache implementation of Coherence JCache.
Contains classes related to partitioned cache implementation of Coherence JCache.
Contains classes related to the HTTP Session Replication Module.
Contains classes related to the HTTP Session Replication Module
that are specific to the Servlet 2.3 specification and higher.
Contains Coherence*Web MBean classes.
Contains classes providing cache persistence of serialized objects.
Contains Sleepycat Berkeley DB BinaryStore implementation classes.
Contains classes related to the journaling services.
Contains classes related to J2SE 1.4 NIO functionality.
Contains classes related to POF serialization and deserialization.
Contains classes related to POF stream navigation and manipulation.
Contains basic cluster interfaces and factories.
Contains classes providing various caching strategies.
Contains classes related to the Coherence Management Framework.
Contains interfaces and classes related to partitioned services.
Contains interfaces and classes related to proxy services.
Contains classes related to the Coherence Security Framework.
Contains classes that providing topic entities for publish/subscribe messaging.
Contains classes and helpers for implementing various types of persistence.
Contains classes providing Java 2 Connector Architecture functionality.
Contains classes providing basic XML related functionality.
Contains various generic utilities.
Contains concrete
InvocableMap.EntryAggregator
implementations.Contains concrete
Comparator implementations and related interfaces.Contains
ValueExtractor and
ValueUpdater related classes.Contains concrete
Filter implementations and related interfaces.Contains concrete
InvocableMap.EntryProcessor
implementations.Contains concrete
MapEventTransformer
implementations.-
Uses of Base in com.tangosol.application
Subclasses of Base in com.tangosol.applicationModifier and TypeClassDescriptionprotected static classContext aware delegating listener.protected static classContext aware delegating synchronous priming listener.protected static classContext aware delegating synchronous listener. -
Uses of Base in com.tangosol.coherence.commonj
Subclasses of Base in com.tangosol.coherence.commonjModifier and TypeClassDescriptionclassAn implementation of commonj.work.WorkManager based on a joint BEA-IBM specification: "The Timer and Work Manager for Application Servers", which is a foundation of JSR 237: Work Manager for Application Servers.protected static classBase class for Invocable tasks related to the WorkManager.protected static classInvocable task used during handshake, which has to be scheduledimmediately.protected static classInvocable task that forces a release for a wrapped Work object.protected classRemoteWorkManager is a delegating WorkManager wrapper.protected static classInvocable task that requests a status for a given Work.protected static classInvocable task that posts a wrapped Work object to a WorkManager queue.protected static classInvocable task that delivers a WorkEvent to a WorkListener.protected classThe member listener for the InvocationService used by the WorkManager.protected classA holder for a Work object that serves as a communication intermediary between a client and a [remote] service.protected classA WorkEvent implementation.protected classThe InvocationObserver for all posted work.protected static classA WorkStatus object is used to communicate a work execution status back to the caller. -
Uses of Base in com.tangosol.coherence.config.scheme
Subclasses of Base in com.tangosol.coherence.config.schemeModifier and TypeClassDescriptionstatic classThe Manager class uses builders to create the required backing maps and provides client access to those maps. -
Uses of Base in com.tangosol.coherence.dslquery.statement
Subclasses of Base in com.tangosol.coherence.dslquery.statementModifier and TypeClassDescriptionclassA base class forStatementimplementations.static classImplementation of the CohQL "BACKUP" command.static classImplementation of the CohQL "CREATE CACHE" command.static classImplementation of the CohQL "CREATE INDEX" command.static classImplementation of the CohQL "DELETE" query.static classImplementation of the CohQL "DROP CACHE" command.static classImplementation of the CohQL "create index" command.static classImplementation of the CohQL "INSERT" command.static classImplementation of the CohQL "QueryRecorder" command.static classImplementation of the CohQL "RESTORE" command.static classImplementation of the CohQL "SELECT" command.static classImplementation of the CohQL "source" command.static classImplementation of the CohQL "TRUNCATE CACHE" command.static classImplementation of the CohQL "UPDATE" command. -
Uses of Base in com.tangosol.coherence.dslquery.statement.persistence
Subclasses of Base in com.tangosol.coherence.dslquery.statement.persistenceModifier and TypeClassDescriptionclassAbstract implementation of anAbstractStatementproviding functionality useful for generic snapshot statements.static classImplementation of the CohQL "ARCHIVE SNAPSHOT" command.static classImplementation of the CohQL "CREATE SNAPSHOT" command.static classImplementation of the CohQL "FORCE RECOVERY" command.static classImplementation of the CohQL "LIST ARCHIVER" command.static classImplementation of the CohQL "LIST SERVICES" command.static classImplementation of the CohQL "LIST SNAPSHOTS" command.static classImplementation of the CohQL "RECOVER SNAPSHOT" command.static classImplementation of the CohQL "REMOVE [ARCHIVED] SNAPSHOT" command.static classImplementation of the CohQL "RESUME SERVICE" command.static classImplementation of the CohQL "RETRIEVE SNAPSHOT" command.static classImplementation of the CohQL "SUSPEND SERVICE" command.static classImplementation of the CohQL "VALIDATE [ARCHIVED] SNAPSHOT" command. -
Uses of Base in com.tangosol.coherence.jcache.localcache
Subclasses of Base in com.tangosol.coherence.jcache.localcacheModifier and TypeClassDescriptionclassMapListener for Coherence-based JCache adapter implementation to generate JCacheCoherenceCacheEntryEvent.classSynchronous version of LocalCacheAsynchronousMapListener. -
Uses of Base in com.tangosol.coherence.jcache.partitionedcache
Subclasses of Base in com.tangosol.coherence.jcache.partitionedcacheModifier and TypeClassDescriptionclassMapListener for coherence cache to implement jcache map events.classMapListener for meta-information about JCachePartitionedCacheinstances.classSynchronous version of PartitionedCacheAsynchronousMapListener.classMapListener for coherence cache to generate JCache ExpiryEvents.static classGet CacheStatistics from binEntry's context for JCache id. -
Uses of Base in com.tangosol.coherence.servlet
Subclasses of Base in com.tangosol.coherence.servletModifier and TypeClassDescriptionclassAn abstract base class from which implementations of HttpSessionCollection can be more easily built.classAn abstract base class from which implementations of HttpSessionModel can be more easily built.classAn immutable object to hold attribute values and related information.classThis agent is used to request the other servers in the cluster to unlock the specified session ID.classRequest context information for an HTTP Servlet request.classAn invocation service that logs the stacktraces of all threads holding a lock for a session.classAn implementation of HttpSessionCollection that manages 'monolithic' session objects.classThis is an implementation of HttpSessionModel that manages its attribute state in a single ('monolithic') serializable unit, allowing session attributes to safely form graphs while avoiding duplication of objects, yet not being able to optimize attribute serialization and deserialization as a result.classAn immutable object to hold attribute values and related information.classRequest context information for a standard Servlet request.classA collection of methods that support the implementation of Coherence web container components used to replace the corresponding implementations provided by the application server vendor.classA daemon thread class that will clean up expired sessions.classAn implementation of HttpSessionCollection that manages session objects as multiple units, splitting out larger session attributes into separately managed entries.classThis is an implementation of HttpSessionModel that manages most of its state in a single serializable unit, but splits out its large attributes -- if any -- into separately managed units.static classSplitHttpSessionModel.ElasticKey<P,Integer> ElasticKey, used by to store segments of a large value that exceeds the flash journal size limit.classAn immutable object to hold attribute values and related information.classAn implementation of HttpSessionCollection that manages session objects as individual units that contain all of their own attributes, as if the session were a single serializable object, however with some optimizations for attribute serialization and deserialization.classAn implementation of HttpSessionModel that is managed as a single unit, but optimizes the management of individual attributes within a session for purposes of serialization and deserialization.classThis command line utility installs container-specific Coherence*Web classes into a web container installation so that Coherence*Web can tightly integrate with the target web container.static classAbstract base class for all command line utilities that modify web container libraries to support extension. -
Uses of Base in com.tangosol.coherence.servlet.api23
Subclasses of Base in com.tangosol.coherence.servlet.api23Modifier and TypeClassDescriptionclassThe Coherence session management Factory for the Servlet 2.3 specification.classAn implementation of the FilterConfig interface that provides for a clustered ServletContext.classAn implementation of the Filter interface that provides for clustered ServletContext and HttpSession objects.classDeprecated.As of Java(tm) Servlet API 2.1 for security reasons, with no replacement.classThis is the HttpSession implementation that supports clustering.classAn implementation of the ServletConfig interface that provides for a clustered ServletContext.classAn implementation of the ServletContextAttributeListener interface that will listen to the application server events and translate them (wrapping the ServletContext) and routing them to the application listeners.classAn implementation of the ServletContextListener interface that will listen to application server events when the application is deployed with its own ServletContextListener(s) declared, so that the events can be forwarded to the application's listener(s).classInner class: A listener to listen to the clustered servlet context attributes and make those same changes to the local ServletContext.classAn implementation of the Servlet interface that provides a clustered ServletContext.classAn extension to the clustered servlet wrapper for servlets that implement SingleThreadModel. -
Uses of Base in com.tangosol.coherence.servlet.management
Subclasses of Base in com.tangosol.coherence.servlet.managementModifier and TypeClassDescriptionclassHttpSessionManagerMBean implementation class. -
Uses of Base in com.tangosol.io
Subclasses of Base in com.tangosol.ioModifier and TypeClassDescriptionclassAbstract implementation of the BinaryStore interface.classAn AsyncBinaryStore is a BinaryStore wrapper that performs the "O" (output) portion of its I/O asynchronously on a daemon thread.protected classA daemon that processes queued writes.classA DeltaCompressor implementation that works with decorated binary values.classDecorationOnlyDeltaCompressor is a DeltaCompressor which optimizes for "decoration-only" updates.classThis is an imitation BufferOutput implementation that provides the BufferOutput interface by delegating to an object that implements the DataOutput interface.static classA 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.bdbModifier and TypeClassDescriptionclassAn implementation of the BinaryStore interface using Sleepycat Berkeley DB Java Edition.classAn implementation of the BinaryStoreManager interface using Sleepycat Berkeley DB Java Edition.classFactory for Berkeley DB Environments and Databases.classA manager for Berkeley DB Database factories. -
Uses of Base in com.tangosol.io.journal
Subclasses of Base in com.tangosol.io.journalModifier and TypeClassDescriptionprotected classThe CollectorDaemon evaluates the JournalFile objects to see which ones should be evacuated, it evacuates those that should be, and it deletes those that have been successfully evacuated.protected classThe PreparerDaemon takes the enqueued Binary values for the JournalFile objects, and lays them out in Buffer objects from the BufferPool, enqueuing them for the WriterDaemon to write.protected classThe WriterDaemon takes the enqueued Buffer objects from the PreparerDaemon, and appends them to a JournalFile. -
Uses of Base in com.tangosol.io.nio
Subclasses of Base in com.tangosol.io.nioModifier and TypeClassDescriptionclassProvides a basic implementation of ByteBufferManager.classA base implementation of BinaryStoreManager interface that usesBinaryMapobjects built on aByteBufferManagerto provideBinaryStoreobjects.classA Block is the unit of storage within a Buffer.static classA map entry (key-value pair).classDeprecated.useJournalBinaryStoreinsteadclassDeprecated.useJournalBinaryStoreinsteadclassManages a ByteBuffer on a file.classAn 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.pofModifier and TypeClassDescriptionclassAn abstract implementation of PofHandler that delegates to a PofHandler.classAn implementation of PofHandler that passes each call onto two different PofHandler objects.classPofSerializerimplementation that supports the serialization and deserialization of any class that implementsExternalizableLiteto and from a POF stream.classPofSerializerimplementation that supports the serialization and deserialization of any class that implementsExternalizableto and from a POF stream.classAn implementation of PofHandler that logs all of the stream contents for debugging / testing purposes.classPofReaderimplementation that reads POF-encoded data from aBufferInput.static classThe UserTypeReader implementation is a contextually-aware PofReader whose purpose is to advance through the properties of a value of a specified user type.classPofWriterimplementation that writes POF-encoded data to aBufferOutput.static classThe UserTypeWriter implementation is a contextually-aware PofWriter whose purpose is to write the properties of a value of a specified user type.classCollection of helper methods for POF streams.classA "push" parser (event-based parser) for ripping through a POF stream and delivering the contents as events to a PofHandler object.classGeneric Principal implementation that can be used to represent the identity of any remote entity.classPofSerializerimplementation that supports the serialization and deserialization of any class that implementsPortableObjectto and from a POF stream.classAn immutable POF date value.classAn immutable POF date-time value.classAn immutable POF day-time interval value.classAn immutable POF time value.classAn immutable POF time interval value.classAn immutable POF year-month interval value.classSerializer used for Serializable and ExternalizableLite objects.classDefault Java serializer.classSerializer used for objects implementing the PortableObject interface.classAn implementation of PofHandler that validates a POF stream.classA Complex object represents the current complex data structure in the POF stream.classA ComplexMap object represents a map data structure (potentially with uniform keys or with uniform keys and values) in the POF stream.classAn implementation of PofHandler that writes a POF stream to a WriteBuffer using a BufferOutput object.static classA Complex object represents the current complex data structure in the POF stream.static classA ComplexMap object represents a map data structure (with uniform keys or with uniform keys and values) in the POF stream.classPofSerializerimplementation 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.reflectModifier and TypeClassDescriptionclassAbstract base class for static, path-based implementations ofPofNavigatorinterface.classAn abstract base class that implements common functionality for all PofValue types.classAn abstract base class for complex POF types, such as collections, arrays, maps, and user types.classPofArray is aPofValueimplementation for arrays.classPofCollection isPofValueimplementation for collections.classPofSparseArray isPofValueimplementation for sparse arrays.protected static classNilPofValue represents a value that does not exist in the original POF stream.classPofUniformArray isPofValueimplementation for uniform arrays.classPofUniformCollection isPofValueimplementation for uniform collections.classPofUniformSparseArray isPofValueimplementation for uniform sparse arrays.classPofUserType isPofValueimplementation for user types.classParses POF-encoded binary and returns an instance of aPofValuewrapper for it.classA staticPofNavigatorimplementation which uses an array of integer indices to navigate the PofValue hierarchy.classSimplePofValue represents POF values which do not contain children (e.g. -
Uses of Base in com.tangosol.license
Subclasses of Base in com.tangosol.licenseModifier and TypeClassDescriptionclasscom.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.netModifier and TypeClassDescriptionclassAbstract base of the BackingMapManager implementations.classAn abstract base for Invocable and PriorityTask implementations.classAn abstract base for PriorityTask implementations.classAbstractServiceLoadBalancer<S extends Service,T extends ServiceLoad> An abstract base for ServiceLoadBalancer implementations.classFactory for the Coherence™ cache product.classDeprecated.As of Coherence 3.7classConfigurableQuorumPolicy provides a Quorum-basedActionPolicyfor services based on the cluster-configuration.static classClusterQuorumPolicy defines an action policy that is applicable to the cluster.static classMembershipQuorumPolicy is a quorum policy that is stateless and based solely on service membership sizes.static classPartitionedCacheQuorumPolicy defines a configurable quorum policy that is applicable to a DistributedCacheService.static classProxyQuorumPolicy defines a configurable quorum policy that is applicable to a proxy service.classDefaultCacheServer 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.static classGarServer provides the functionality of DefaultCacheServer under the context of a GAR file.classDeprecated.classDeprecated.BackingMapManager implementation that uses the configuration XML to create the required backing maps and provides client access to those maps.protected classDeprecated.BackingMapManager implementation used by PartitionAwareBackingMap(s) to lazily configure the enclosing PABM based on the configuration settings of the enclosed maps.classExtensibleConfigurableCacheFactory provides a facility to access caches declared in a "coherence-cache-config.xsd" compliant configuration file.static classThe Manager class uses builders to create the required backing maps and provides client access to those maps.static classThe PartitionedBackingMapManager is used by PartitionAwareBackingMap(s) to lazily configure the enclosing PABM based on the configuration settings of the enclosed maps.classA concrete implementation of Guardian/Guardable interactions.classA non-sticky HTTP load-balancer.static classAn AddressPort is an immutable combination of an IP address and a port number.static classA Queue is used to effeciently queue up items for daemon threads to work on.classA RequestHandler is a daemon thread that processes a request from a queue.classA ResponseHandler is a daemon thread that processes an outgoing response from a destination server.static classA SocketHandler is an abstract daemon thread.classA RefreshableAddressProvider is an AddressProvider implementation that wraps another AddressProvider and refresh the address list of the provider asynchronously.protected classclassSimpleServiceLoadBalancer<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.cacheModifier and TypeClassDescriptionclassAn abstract BinaryEntry-based bundler that serves as a base for BinaryEntryStore operation bundling.protected classclassAn abstract base for processors that implement bundling strategy.protected classBundle 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.classAn abstract entry-based bundler serves as a base for NamedCache.put() and CacheStore.store() operation bundling.protected classclassAn abstract base class for custom cache eviction policies.classAn 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 classBundle represents a unit of optimized execution.classAn abstract base class for serialization-based caches.classAn implementation of the BinaryEntry interface that is based on specified binary key, binary value and BackingMapManagerContext.classA UnitCalculator implementation that weighs a cache entry based upon the amount of physical memory (in bytes) required to store the entry.classA CacheStore that sits directly on top of a BinaryStore.classBlindCompactSerializationCache is aCompactSerializationCacheextension enforcing CompactSerializationCache to operate under a blind mode.classBundling NamedCache implementation.protected classprotected classprotected classclassA read-only CacheStore that wraps a CacheLoader.static classAn extension to the CacheLoaderCacheStore that implements the IterableCacheLoader interface.static classA Map implementation that delegates straight through to a CacheStore.protected classDeactivationListener for the back NamedCache.protected classMapListener for front map responsible for deregistering back map listeners upon front map eviction.protected classMapListener for back map responsible for keeping the front map coherent with the back map.protected classMapListener for back map responsible for keeping the front map coherent with the back map.classCompactSerializationCache is an implementation ofConfigurableCacheMapwhich is optimized for compact on-heap footprint.classContinuousQueryCache<K,V_BACK, V_FRONT> Create a materialized view of aNamedCacheusing theCoherenceContinuous Query capability.classAMapListenerfor adding items to theContinuousQueryCache.protected classDeactivationListener for the underlying NamedCache.protected classAn EventRouter routes events from the internal cache of theContinuousQueryCacheto the client listeners, and it can do so asynchronously when appropriate.protected classThis listener allows interception of all events triggered by the internalObservableMapof theContinuousQueryCache.classAMapListenerfor evicting items from theContinuousQueryCache.classA holder for a cached value.protected classAn internal MapListener that listens to this cache and reports changes to the CacheStore.protected classA 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.classDeprecated.A holder for a cached value.classAn 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 classA listener for the back map.protected classA 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.classA wrapper around the original BinaryEntryStore to allow operations to be overridden and extended.static classA CacheStore wrapped around a CacheLoader.classA wrapper around the original CacheStore to allow operations to be overridden and extended.classA queue entry that is scheduled to come out of the front of the queue no earlier than some specific point in time.static classA Map implementation used for a backup map that evicts all data that has been successfully written.protected classA MapListener implementation that listens to the internal cache and routes those events to anyone listening to this ReadWriteBackingMap.classA wrapper around the original NonBlockingEntryStore to allow operations to be overridden and extended.classA queue of keys that should be read from the underlying CacheStore.classA 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.classAbstract wrapper around a cache store to allow operations to be overridden and extended.classA queue that only releases entries after a configurable period of time.classThis is the write-behind thread that pulls things from the write-behind queue and writes them to the CacheStore that the backing map uses.classA map listener that follows the "seppuku" pattern, invalidating the Map entries when MapEvents for another related ObservableMap are delivered.classA version of SerializationMap that implements an LRU policy.protected classA class that holds on to the expiry time and touch order for an entry.classA Cache Entry implementation.classMap implementation that stores its contents in a BinaryStore.classA version of SerializationMap that implements an LRU policy using time-based paging of the cache.classA virtual BinaryStore implementation that aggregates a sequence (newest to oldest) of periodic BinaryStore objects.classImplementation of the CacheStatistics interface intended for use by a cache to maintain its statistics.classA UnitCalculator implementation that weighs a cache entry based upon the amount of physical memory (in bytes) required to store the entry.classA 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 classA listener for the front map that moves evictions to the back map.classMap implementation that stores and accesses its contents through an underlying BinaryStore.classDeprecated.A wrapper around the original CacheStore to allow operations to be overridden and extended.protected classDeprecated.A MapListener implementation that listens to the internal cache and routes those events to anyone listening to this VersionedBackingMap.classDeprecated.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.managementModifier and TypeClassDescriptionclassUtility class to expose Coherence JMX MBeans via the Sun JMX reference implementation HtmlAdaptorServer or a JMX RemoteJMXConnectorServer.classHelper class providing various functionality related to aggregation of attributes and methods exposed by Coherence JMX framework MBeans.classFilter 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.partitionModifier and TypeClassDescriptionclassThe 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.classDefaultKeyPartitioningStrategy provides a simple strategy for assigning keys to partitions which is based on the hash code of keys in internal (serialized to Binary) form.classThe ObservableSplittingBackingCache is an implementation of the ConfigurableCacheMap interface that works as an observable backing map in a partitioned system.protected static classA subclass of PartitionSplittingBackingMap which allows an injected instance ofObservableSplittingBackingMapto be called immediately before inserting a value(s) in a partition map.classA Cache Entry implementation.classAn observable, cache-aware PartitionAwareBackingMap implementation.classOwnership is a light-weight data structure that contains a partition ownership information.classIn 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.classA read-only view into a subset of backing maps managed by the underlying PartitionSplittingBackingMap.classAn 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.proxyModifier and TypeClassDescriptionclassDefault ProxyServiceLoadBalancer implementation. -
Uses of Base in com.tangosol.net.security
Subclasses of Base in com.tangosol.net.securityModifier and TypeClassDescriptionfinal classThe default implementation of the AccessController interface.classThe default implementation of the IdentityAsserter interface.classPermissionInfo holds the information needed to validate and respond to a security related request.classThe Security class is used to associate client's identity with an action that requires access to protected clustered resources.classThe 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.topicModifier and TypeClassDescriptionclassTopicBackingMapManager<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.persistenceModifier and TypeClassDescriptionclassAbstract implementation of a ReadBuffer-based PersistentEnvironment.classAbstract implementation of a ReadBuffer-based PersistentManager.classAbstract implementation of a ReadBuffer-based PersistentStore.protected classRunnable implementation that is used to perform and commit a sequence of mutating persistent store operations asynchronously.protected classAn erase() Operation.protected classBase class for Runnable implementations that encapsulate a persistent store operation.protected classA store() Operation.protected classA Task implementation that deletes an extent from the associated store.protected classAn OpenTask opens the store (parent of this inner class) with the provided store and notifies the Collector when complete.classRunnable extension that adds the ability to notify the task that it has been canceled.static classResolver 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.jcaModifier and TypeClassDescriptionclassCacheAdapter encapsulates the operations neccessary to communicate with Coherence™ resource adapter (coherence-tx.rar).classSimple 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.xmlModifier and TypeClassDescriptionclassAn ArrayAdapter supports properties of Java array types (not including arrays of primitive types).classA CollectionAdapter supports properties whose types implement the java.util.Collection interface.classA property adapter for formatting formatting and parsing dates in a locale-sensitive manner.classA property adapter for the <xs:dateTime> format conforming to ISO 8601classAn IterableAdapter is the base class for any data type that must be iterated over to serialize/deserialize, such as arrays, collections and maps.classA MapAdapter supports properties whose types implement the java.util.Map interface.classA PrimitiveArrayAdapter supports arrays of primitive types, such as "int", "char", etc.static classA PropertyAdapter supporting boolean[].static classA PropertyAdapter supporting byte[].static classA PropertyAdapter supporting char[].static classA PropertyAdapter supporting double[].static classA PropertyAdapter supporting float[].static classA PropertyAdapter supporting int[].static classA PropertyAdapter supporting long[].static classA PropertyAdapter supporting short[].classThe PropertyAdapter is the base class for handling the operations that can occur on any property.classA property adapter for QName primitive datatype.classA 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).classA simple XML parser.classA SerializableAdapter supports Java objects that implement the Serializable interface.classA 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 classA simple property adapter for BigDecimal.static classA simple property adapter for BigInteger.static classA simple property adapter for boolean.static classA simple property adapter for byte.static classA simple property adapter for char.static classA simple property adapter for Date.static classA simple property adapter for double.static classA simple property adapter for float.static classA simple property adapter for int.static classA simple property adapter for long.static classA simple property adapter for the Date class from the java/util package.static classA simple property adapter for short.static classA simple property adapter for String.static classA 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 classA simple property adapter for Time.static classA simple property adapter for Timestamp.classA simple implementation of the XmlElement interface.classA simple implementation of the XmlElement interface.classAn implementation of Entry that supports keeping them in a list.classThis class uses the XmlTokenizer to produce an XmlDocument from XML text.classA simple implementation of the XmlValue interface.classThis is a base class for building XmlSerializable value objects.classAn XmlElementAdapter supports properties of type XmlElement.classThis abstract class contains XML manipulation methods.classAn XmlSerializableAdapter supports Java objects that implement the XmlSerializable interface. -
Uses of Base in com.tangosol.util
Subclasses of Base in com.tangosol.utilModifier and TypeClassDescriptionclassAbstractKeyBasedMap<K,V> AbstractKeyBasedMap is a base class for Map implementations.protected classA 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 is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.classA base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.static classA java.util.Map<Binary, Long> implementation.classA collection of methods for bit-based operations.classProvide an enumerator which enumerates the contents of multiple enumerators.classFilter which discards all objects that are not of a certain class.classCompositeKey<P,S> Key class that consists of a primary and secondary component.classConditionalIndex is aMapIndeximplementation that uses an associated filter to evaluate whether or not an entry should be indexed.static classA converter MapListener that converts events of the underlying MapListener for the underlying NamedCache.static classA converter MapListener that converts events of the underlying MapListener for the underlying map.classA abstract Daemon thread handler.classRepresents a double-ended queue (dequeue) of objects.classProvide a implementation of an Iterator based on data from an Enumeration.classHelpers for the Serializable, Externalizable and the ExternalizableLite interface.protected static final classInteger decorated object.static classAn implementation XmlBeanClassCache that uses a pre-defined list of XmlBean implementations.classProvide a generic implementation of an enumerator which can enumerate items based on an inclusion test.classHelper methods for InvocableMap implementations and Filter related evaluation.static classSimple implementation of the InvocableMap.Entry interface.classProvide a implementation of an enumerator based on data from an Iterator.classKeyValueArrayMap is a Map implementation backed by an array of keys, and an array of the associated values.classProvide a simple, efficient, and thread-safe implementation of a list of event listeners.classThis class provides support for advanced MapListener functionality.static classA base class for various wrapper listener classes.static classA wrapper class that turns the specified MapListener into a priming listener.static classA wrapper class that turns the specified MapListener into a synchronous listener.classMapTriggerListener is a special purpose MapListener implementation that is used to register aMapTriggeron a corresponding ObservableMap.classA base class that simplifies the implementation of a MapListener by multiplexing all events into a single listener method.classFilter which discards null references.static classAn implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.protected classA holder for a cached value.classOpenHashMap<K,V> An implementation ofMapthat is optimized for memory footprint.protected classAn 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.classPagedIterator 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 classA Node in the List.classA collection of Collection implementation classes that limit the data type.static classA restricted Collection that requires its contents to be of a specified class.static classA restricted Collection that requires its contents to be of a specified class.protected classA Map Entry that restricts the key and value types.protected classA Map Entry Iterator that restricts the key and value types.static classA restricted List that requires its contents to be of a specified class.static classA restricted ListIterator that requires its contents to be of a specified class.static classA restricted Map that requires its keys and values to be of specified classes.static classA restricted Set that requires its contents to be of a specified class.static classA restricted SortedMap that requires its keys and values to be of specified classes.static classA 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 classA Node in the List.classAn implementation of SegmentedHashMap that also implements the ConcurrentMap interface.classLockableEntry is an Entry that supports locking.classAn implementation of java.util.Map that is optimized for heavy concurrent use.protected static classA map entry (key-value pair).classProvide a generic implementation of an array enumerator.classSimpleMapEntry<K,V> A map entry (key-value pair).classSimpleMapIndex 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 classA statefulcalculatorused to calculate the cost of a homogeneous index (holding all values of a single type).classSorts the contents of the passed enumerator then enumerates those contents.final classLike a hash table, but built specifically for strings.classA Daemon thread handler that asynchronously executes Runnable tasks, either at a scheduled time or "as soon as possible".classA PeriodicTask is a task that automatically reschedules itself so that it executes on a periodic basis.classThis class provides an implementation of thread local storage.classA thread-safe balanced binary search tree.classA UID is a 128-bit identifier that is almost guaranteed to be unique.final classA 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 classA lock object.classWrapperObservableMap<K,V> A simple implementation of ObservableMap interface built as a wrapper around any Map implementation.protected classAn internal MapListener that listens to the wrapped map. -
Uses of Base in com.tangosol.util.aggregator
Subclasses of Base in com.tangosol.util.aggregatorModifier and TypeClassDescriptionclassAbstractAggregator<K,V, T, E, R> Abstract base class implementation ofInvocableMap.EntryAggregatorthat supports streaming aggregation.classAbstract aggregator that processesNumbervalues extracted from a set of entries in a Map and returns a result in a form of aBigDecimalvalue.classAbstract aggregator that processes values extracted from a set of entries in a Map, with knowledge of how to compare those values.classAbstract aggregator that processes numeric values extracted from a set of entries in a Map.classAbstract aggregator that processes numeric values extracted from a set of entries in a Map.classCalculates an average for values of any numeric type extracted from a set of entries in a Map in a form of aBigDecimalvalue.classCalculates a maximum of numeric values extracted from a set of entries in a Map in a form of aBigDecimalvalue.classCalculates a minimum of numeric values extracted from a set of entries in a Map in a form of aBigDecimalvalue.classCalculates 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 classDeprecated.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.classCalculates 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.comparatorModifier and TypeClassDescriptionclassComposite comparator implementation based on a collection of comparators.classComparator implementation used to compare map entries.classComparator that reverses the result of another comparator.classNull-safe delegating comparator. -
Uses of Base in com.tangosol.util.extractor
Subclasses of Base in com.tangosol.util.extractorModifier and TypeClassDescriptionclassAbstract 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.classAValueExtractorthat 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.classA 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.classDeserializationAccelerator is anIndexAwareExtractorimplementation that is used to create aForwardOnlyMapIndex, which in turn is used for deserialization optimization.classThe EntryExtractor is a base abstract class for special purpose custom ValueExtractor implementations.classAValueExtractorthat is used to extract aFragmentfrom an object.classTrivial 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.classComposite ValueExtractor implementation based on an array of extractors.classPofExtractor<T,E> POF-based ValueExtractor implementation.classPOF-based ValueUpdater implementation.classReflectionExtractor<T,E> Reflection-based ValueExtractor implementation.classReflection-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.classUniversal ValueUpdater implementation. -
Uses of Base in com.tangosol.util.filter
Subclasses of Base in com.tangosol.util.filterModifier and TypeClassDescriptionclassAbstract base class implementation ofQueryRecorderFilter.classFilter which returns the logical "and" of a filter array.classAlwaysFilter<T>Filter which always evaluates to true.classFilter which returns the logical "and" of two other filters.classFilter which returns the logical "or" of a filter array.classFilter 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.classA 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.classFilter 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.classFilter 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 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.classFilter which returns the logical "or" of two other filters.classFilter 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.classFilter which returns true forInvocableMap.Entryobjects that currently exist in a Map.classPriorityFilter 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.classQueryRecorderFilter wrapper class.classFilter 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.processorModifier and TypeClassDescriptionclassAbstractProcessor<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.transformerModifier and TypeClassDescriptionclassExtractorEventTransformer<K,V, E> ExtractorEventTransformer is a special purposeMapEventTransformerimplementation that transforms emitted events, extracting one or more properties from either the OldValue or the NewValue.classAMapEventTransformerimplementation 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 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.