Uses of Class
com.tangosol.util.Base
Package
Description
The Coherence gRPC server implementation.
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 providing cache persistence of serialized objects.
Contains Sleepycat Berkeley DB BinaryStore implementation classes.
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.oracle.coherence.grpc.proxy
Modifier and TypeClassDescriptionprotected static class
NamedCacheDeactivationListener
that will communicate cache truncation and destruction events over the proxy. -
Uses of Base in com.tangosol.coherence.dslquery.statement
Modifier and TypeClassDescriptionclass
A base class forStatement
implementations.static class
Implementation of the CohQL "BACKUP" command.static class
Implementation of the CohQL "CREATE CACHE" command.static class
Implementation of the CohQL "CREATE INDEX" command.static class
Implementation of the CohQL "DELETE" query.static class
Implementation of the CohQL "DROP CACHE" command.static class
Implementation of the CohQL "create index" command.static class
Implementation of the CohQL "INSERT" command.static class
Implementation of the CohQL "QueryRecorder" command.static class
Implementation of the CohQL "RESTORE" command.static class
Implementation of the CohQL "SELECT" command.static class
Implementation of the CohQL "source" command.static class
Implementation of the CohQL "TRUNCATE CACHE" command.static class
Implementation of the CohQL "UPDATE" command. -
Uses of Base in com.tangosol.coherence.dslquery.statement.persistence
Modifier and TypeClassDescriptionclass
Abstract implementation of anAbstractStatement
providing functionality useful for generic snapshot statements.static class
Implementation of the CohQL "ARCHIVE SNAPSHOT" command.static class
Implementation of the CohQL "CREATE SNAPSHOT" command.static class
Implementation of the CohQL "FORCE RECOVERY" command.static class
Implementation of the CohQL "LIST ARCHIVER" command.static class
Implementation of the CohQL "LIST SERVICES" command.static class
Implementation of the CohQL "LIST SNAPSHOTS" command.static class
Implementation of the CohQL "RECOVER SNAPSHOT" command.static class
Implementation of the CohQL "REMOVE [ARCHIVED] SNAPSHOT" command.static class
Implementation of the CohQL "RESUME SERVICE" command.static class
Implementation of the CohQL "RETRIEVE SNAPSHOT" command.static class
Implementation of the CohQL "SUSPEND SERVICE" command.static class
Implementation of the CohQL "VALIDATE [ARCHIVED] SNAPSHOT" command. -
Uses of Base in com.tangosol.coherence.jcache.localcache
Modifier and TypeClassDescriptionclass
MapListener for Coherence-based JCache adapter implementation to generate JCacheCoherenceCacheEntryEvent
.class
Synchronous version of LocalCacheAsynchronousMapListener. -
Uses of Base in com.tangosol.coherence.jcache.partitionedcache
Modifier and TypeClassDescriptionclass
MapListener for coherence cache to implement jcache map events.class
MapListener for meta-information about JCachePartitionedCache
instances.class
Synchronous version of PartitionedCacheAsynchronousMapListener.class
MapListener for coherence cache to generate JCache ExpiryEvents.static class
Get CacheStatistics from binEntry's context for JCache id. -
Uses of Base in com.tangosol.io
Modifier and TypeClassDescriptionclass
Abstract implementation of the BinaryStore interface.class
The AbstractByteArrayReadBuffer abstract class is intended to serve as a base class for the following: the pre-existing Binary class a new byte[] based class that does not attempt to add the immutability aspect provided by the Binary class a new ByteBuffer based class that will work with Java NIOclass
Abstract base implementation of the ReadBuffer interface.class
An AsyncBinaryStore is a BinaryStore wrapper that performs the "O" (output) portion of its I/O asynchronously on a daemon thread.protected class
A daemon that processes queued writes.class
A ReadBuffer on top of a byte array.class
A DeltaCompressor implementation that works with decorated binary values.class
DecorationOnlyDeltaCompressor is a DeltaCompressor which optimizes for "decoration-only" updates.class
The MultiBufferReadBuffer is a ReadBuffer implementation that presents a view across any number of underlying ReadBuffer objects, as if they were appended end-to-end into a single ReadBuffer.class
This is an imitation BufferOutput implementation that provides the BufferOutput interface by delegating to an object that implements the DataOutput interface.static class
A BufferOutput implementation that in addition to delegating to the given DataOutput provides an API to check whether the recipients of the content of this BufferOutput run versions that supersede (greater or equal to) the specified version. -
Uses of Base in com.tangosol.io.bdb
Modifier and TypeClassDescriptionclass
An implementation of the BinaryStore interface using Sleepycat Berkeley DB Java Edition.class
An implementation of the BinaryStoreManager interface using Sleepycat Berkeley DB Java Edition.class
Factory for Berkeley DB Environments and Databases.class
A manager for Berkeley DB Database factories. -
Uses of Base in com.tangosol.io.nio
Modifier and TypeClassDescriptionclass
Provides a basic implementation of ByteBufferManager.class
A base implementation of BinaryStoreManager interface that usesBinaryMap
objects built on aByteBufferManager
to provideBinaryStore
objects.class
A Block is the unit of storage within a Buffer.static class
A map entry (key-value pair).class
A ReadBuffer implementation on top of a Java NIO ByteBuffer.class
Manages a ByteBuffer on a file.class
An implementation of BinaryStoreManager interface that usesBinaryMap
objects built on theMappedBufferManager
to provideBinaryStore
objects. -
Uses of Base in com.tangosol.io.pof
Modifier and TypeClassDescriptionclass
An abstract implementation of PofHandler that delegates to a PofHandler.class
An implementation of PofHandler that passes each call onto two different PofHandler objects.class
PofSerializer
implementation that supports the serialization and deserialization of any class that implementsExternalizableLite
to and from a POF stream.class
PofSerializer
implementation that supports the serialization and deserialization of any class that implementsExternalizable
to and from a POF stream.class
An implementation of PofHandler that logs all of the stream contents for debugging / testing purposes.class
PofReader
implementation that reads POF-encoded data from aBufferInput
.static class
The UserTypeReader implementation is a contextually-aware PofReader whose purpose is to advance through the properties of a value of a specified user type.class
PofWriter
implementation that writes POF-encoded data to aBufferOutput
.static class
The UserTypeWriter implementation is a contextually-aware PofWriter whose purpose is to write the properties of a value of a specified user type.class
Collection of helper methods for POF streams.class
A "push" parser (event-based parser) for ripping through a POF stream and delivering the contents as events to a PofHandler object.class
Generic Principal implementation that can be used to represent the identity of any remote entity.class
PofSerializer
implementation that supports the serialization and deserialization of any class that implementsPortableObject
to and from a POF stream.class
An immutable POF date value.class
An immutable POF date-time value.class
An immutable POF day-time interval value.class
An immutable POF time value.class
An immutable POF time interval value.class
An immutable POF year-month interval value.class
Serializer used for Serializable and ExternalizableLite objects.class
Default Java serializer.class
Serializer used for objects implementing the PortableObject interface.class
An implementation of PofHandler that validates a POF stream.class
A Complex object represents the current complex data structure in the POF stream.class
A ComplexMap object represents a map data structure (potentially with uniform keys or with uniform keys and values) in the POF stream.class
An implementation of PofHandler that writes a POF stream to a WriteBuffer using a BufferOutput object.static class
A Complex object represents the current complex data structure in the POF stream.static class
A ComplexMap object represents a map data structure (with uniform keys or with uniform keys and values) in the POF stream.class
PofSerializer
implementation that supports the serialization and deserialization of any class that implementsXmlSerializable
to and from a POF stream. -
Uses of Base in com.tangosol.io.pof.reflect
Modifier and TypeClassDescriptionclass
Abstract base class for static, path-based implementations ofPofNavigator
interface.class
An abstract base class that implements common functionality for all PofValue types.class
An abstract base class for complex POF types, such as collections, arrays, maps, and user types.class
PofArray is aPofValue
implementation for arrays.class
PofCollection isPofValue
implementation for collections.class
PofSparseArray isPofValue
implementation for sparse arrays.protected static class
NilPofValue represents a value that does not exist in the original POF stream.class
PofUniformArray isPofValue
implementation for uniform arrays.class
PofUniformCollection isPofValue
implementation for uniform collections.class
PofUniformSparseArray isPofValue
implementation for uniform sparse arrays.class
PofUserType isPofValue
implementation for user types.class
Parses POF-encoded binary and returns an instance of aPofValue
wrapper for it.class
A staticPofNavigator
implementation which uses an array of integer indices to navigate the PofValue hierarchy.class
SimplePofValue represents POF values which do not contain children (e.g. -
Uses of Base in com.tangosol.license
Modifier and TypeClassDescriptionclass
com.tangosol.license.CoherenceApplicationEdition
This class is a license class.class
com.tangosol.license.CoherenceCommunityEdition
This class is a license class.class
com.tangosol.license.CoherenceDataGridEdition
This class is a license class.class
com.tangosol.license.LicensedObject
This class is a base class for classes that may be license-limited. -
Uses of Base in com.tangosol.net
Modifier and TypeClassDescriptionclass
Abstract base of the BackingMapManager implementations.class
An abstract base for Invocable and PriorityTask implementations.class
An abstract base for PriorityTask implementations.class
AbstractServiceLoadBalancer<S extends Service,
T extends ServiceLoad> An abstract base for ServiceLoadBalancer implementations.class
Factory for the Coherence™ cache product.class
Deprecated.As of Coherence 3.7class
ConfigurableQuorumPolicy provides a Quorum-basedActionPolicy
for services based on the cluster-configuration.static class
ClusterQuorumPolicy defines an action policy that is applicable to the cluster.static class
MembershipQuorumPolicy is a quorum policy that is stateless and based solely on service membership sizes.static class
PartitionedCacheQuorumPolicy defines a configurable quorum policy that is applicable to a DistributedCacheService.static class
ProxyQuorumPolicy defines a configurable quorum policy that is applicable to a proxy service.class
DefaultCacheServer is a simple command line facility and convenience API that starts all services that are declared as requiring an "autostart" in the configurable factory XML descriptor.class
Deprecated.class
Deprecated.BackingMapManager implementation that uses the configuration XML to create the required backing maps and provides client access to those maps.protected class
Deprecated.BackingMapManager implementation used by PartitionAwareBackingMap(s) to lazily configure the enclosing PABM based on the configuration settings of the enclosed maps.class
ExtensibleConfigurableCacheFactory provides a facility to access caches declared in a "coherence-cache-config.xsd" compliant configuration file.static class
The Manager class uses builders to create the required backing maps and provides client access to those maps.static class
The PartitionedBackingMapManager is used by PartitionAwareBackingMap(s) to lazily configure the enclosing PABM based on the configuration settings of the enclosed maps.class
A concrete implementation of Guardian/Guardable interactions.class
A non-sticky HTTP load-balancer.static class
An AddressPort is an immutable combination of an IP address and a port number.static class
A Queue is used to effeciently queue up items for daemon threads to work on.class
A RequestHandler is a daemon thread that processes a request from a queue.class
A ResponseHandler is a daemon thread that processes an outgoing response from a destination server.static class
A SocketHandler is an abstract daemon thread.class
A RefreshableAddressProvider is an AddressProvider implementation that wraps another AddressProvider and refresh the address list of the provider asynchronously.protected class
class
SimpleServiceLoadBalancer<S extends Service,
T extends ServiceLoad> A simple ServiceLoadBalancer implementation. -
Uses of Base in com.tangosol.net.cache
Modifier and TypeClassDescriptionclass
An abstract BinaryEntry-based bundler that serves as a base for BinaryEntryStore operation bundling.protected class
class
An abstract base for processors that implement bundling strategy.protected class
Bundle represents a unit of optimized execution.class
AbstractCacheLoader<K,
V> An abstract base class for the JCache CacheLoader.class
AbstractCacheStore<K,
V> An abstract base class for the JCache CacheLoader.class
An abstract entry-based bundler serves as a base for NamedCache.put() and CacheStore.store() operation bundling.protected class
class
An abstract base class for custom cache eviction policies.class
An abstract key-based bundler serves as a base for NamedCache get() and remove() operation bundling as well as the CacheStore load() and erase() operation bundling.protected class
Bundle represents a unit of optimized execution.class
An abstract base class for serialization-based caches.class
An implementation of the BinaryEntry interface that is based on specified binary key, binary value and BackingMapManagerContext.class
A UnitCalculator implementation that weighs a cache entry based upon the amount of physical memory (in bytes) required to store the entry.class
A CacheStore that sits directly on top of a BinaryStore.class
Bundling NamedCache implementation.protected class
protected class
protected class
class
A read-only CacheStore that wraps a CacheLoader.static class
An extension to the CacheLoaderCacheStore that implements the IterableCacheLoader interface.static class
A Map implementation that delegates straight through to a CacheStore.protected class
DeactivationListener for the back NamedCache.protected class
MapListener for front map responsible for deregistering back map listeners upon front map eviction.protected class
MapListener for back map responsible for keeping the front map coherent with the back map.protected class
MapListener for back map responsible for keeping the front map coherent with the back map.class
ContinuousQueryCache<K,
V_BACK, V_FRONT> Create a materialized view of aNamedCache
using theCoherence
Continuous Query capability.class
AMapListener
for adding items to theContinuousQueryCache
.protected class
DeactivationListener for the underlying NamedCache.protected class
An EventRouter routes events from the internal cache of theContinuousQueryCache
to the client listeners, and it can do so asynchronously when appropriate.protected class
This listener allows interception of all events triggered by the the internalObservableMap
of theContinuousQueryCache
.class
AMapListener
for evicting items from theContinuousQueryCache
.class
A holder for a cached value.protected class
An internal MapListener that listens to this cache and reports changes to the CacheStore.protected class
A class that masks certain changes so that they are not reported back to the CacheStore.class
MapCacheStore<K,
V> A CacheStore that sits directly on top of a Map.class
An Observable Map implementation that wraps two maps - a front map (assumed to be fast but limited in its maximum size) and a back map (assumed to be slower but much less limited in its maximum size).protected class
A listener for the back map.protected class
A listener for the front map that moves evictions to the back map.class
ReadonlyNamedCache<K,
V> A simple extension of the WrapperNamedCache implementation that shields all content mutating operations such as put(), remove(), lock() etc.class
A wrapper around the original BinaryEntryStore to allow operations to be overridden and extended.static class
A CacheStore wrapped around a CacheLoader.class
A wrapper around the original CacheStore to allow operations to be overridden and extended.class
A queue entry that is scheduled to come out of the front of the queue no earlier than some specific point in time.static class
A Map implementation used for a backup map that evicts all data that has been successfully written.protected class
A MapListener implementation that listens to the internal cache and routes those events to anyone listening to this ReadWriteBackingMap.class
A wrapper around the original NonBlockingEntryStore to allow operations to be overridden and extended.class
A queue of keys that should be read from the underlying CacheStore.class
A thread that removes keys from aReadWriteBackingMap.ReadQueue
, reads the value for the key from the underlying CacheStore, and caches the value in the internal ReadWriteBackingMap cache.class
Abstract wrapper around a cache store to allow operations to be overridden and extended.class
A queue that only releases entries after a configurable period of time.class
This is the write-behind thread that pulls things from the write-behind queue and writes them to the CacheStore that the backing map uses.class
A map listener that follows the "seppuku" pattern, invalidating the Map entries when MapEvents for another related ObservableMap are delivered.class
A version of SerializationMap that implements an LRU policy.protected class
A class that holds on to the expiry time and touch order for an entry.class
A Cache Entry implementation.class
Map implementation that stores its contents in a BinaryStore.class
A version of SerializationMap that implements an LRU policy using time-based paging of the cache.class
A virtual BinaryStore implementation that aggregates a sequence (newest to oldest) of periodic BinaryStore objects.class
Implementation of the CacheStatistics interface intended for use by a cache to maintain its statistics.class
A UnitCalculator implementation that weighs a cache entry based upon the amount of physical memory (in bytes) required to store the entry.class
A non-observable Map implementation that wraps two maps - a front map (assumed to be fast but limited in its maximum size) and a back map (assumed to be slower but much less limited in its maximum size).protected class
A listener for the front map that moves evictions to the back map.class
Map implementation that stores and accesses its contents through an underlying BinaryStore.class
Deprecated.A wrapper around the original CacheStore to allow operations to be overridden and extended.protected class
Deprecated.A MapListener implementation that listens to the internal cache and routes those events to anyone listening to this VersionedBackingMap.class
Deprecated.A map listener that listens to the VersionCache and invalidates local entries accordingly.class
WrapperNamedCache<K,
V> A simple implementation of NamedCache interface built as a wrapper around any Map implementation. -
Uses of Base in com.tangosol.net.management
Modifier and TypeClassDescriptionclass
Utility class to expose Coherence JMX MBeans via the Sun JMX reference implementation HtmlAdaptorServer or a JMX RemoteJMXConnectorServer
.class
Helper class providing various functionality related to aggregation of attributes and methods exposed by Coherence JMX framework MBeans.class
Filter used to prevent registering MBeans that match the specified pattern. -
Uses of Base in com.tangosol.net.partition
Modifier and TypeClassDescriptionclass
The BroadKeyPartitioningStrategy is a strategy that could be used in cases when the standard key association-based strategy produces very uneven partition distribution - some partitions having significantly larger amount of data than others.class
DefaultKeyPartitioningStrategy provides a simple strategy for assigning keys to partitions which is based on the hash code of keys in internal (serialized to Binary) form.class
The ObservableSplittingBackingCache is an implementation of the ConfigurableCacheMap interface that works as an observable backing map in a partitioned system.protected static class
A subclass of PartitionSplittingBackingMap which allows an injected instance ofObservableSplittingBackingMap
to be called immediately before inserting a value(s) in a partition map.class
A Cache Entry implementation.class
An observable, cache-aware PartitionAwareBackingMap implementation.class
Ownership is a light-weight data structure that contains a partition ownership information.class
PartitionSet is a light-weight data structure that represents a set of partitions that are used in parallel processing.class
In a partitioned configuration, the PartitionSplittingBackingMap is a "map multi-plexer" that enables multiple backing maps to be used in place of a single backing map.class
A read-only view into a subset of backing maps managed by the underlying PartitionSplittingBackingMap.class
An extension of the partition Ownership object which also carries a change version. -
Uses of Base in com.tangosol.net.proxy
Modifier and TypeClassDescriptionclass
Default ProxyServiceLoadBalancer implementation. -
Uses of Base in com.tangosol.net.security
Modifier and TypeClassDescriptionfinal class
The default implementation of the AccessController interface.class
The default implementation of the IdentityAsserter interface.class
PermissionInfo holds the information needed to validate and respond to a security related request.class
The Security class is used to associate client's identity with an action that requires access to protected clustered resources.class
The SimpleHandler class is a CallbackHandler implementation based on a specified user name and password. -
Uses of Base in com.tangosol.net.topic
Modifier and TypeClassDescriptionclass
TopicBackingMapManager<D extends TopicDependencies,
S extends NamedTopicScheme> A base class for topic backing map managers. -
Uses of Base in com.tangosol.persistence
Modifier and TypeClassDescriptionclass
Abstract implementation of a ReadBuffer-based PersistentEnvironment.class
Abstract implementation of a ReadBuffer-based PersistentManager.class
Abstract implementation of a ReadBuffer-based PersistentStore.protected class
Runnable implementation that is used to perform and commit a sequence of mutating persistent store operations asynchronously.protected class
An erase() Operation.protected class
Base class for Runnable implementations that encapsulate a persistent store operation.protected class
A store() Operation.protected class
A Task implementation that deletes an extent from the associated store.protected class
An OpenTask opens the store (parent of this inner class) with the provided store and notifies the Collector when complete.class
Runnable extension that adds the ability to notify the task that it has been canceled.static class
Resolver used during a recovery to discover the newest available GUID for a given partition. -
Uses of Base in com.tangosol.run.jca
Modifier and TypeClassDescriptionclass
Simple generic Validator implementation that uses hashCode values for the enlisted resources to resolve optimistic transaction conflicts. -
Uses of Base in com.tangosol.run.xml
Modifier and TypeClassDescriptionclass
An ArrayAdapter supports properties of Java array types (not including arrays of primitive types).class
A CollectionAdapter supports properties whose types implement the java.util.Collection interface.class
A property adapter for formatting formatting and parsing dates in a locale-sensitive manner.class
A property adapter for the <xs:dateTime> format conforming to ISO 8601class
An IterableAdapter is the base class for any data type that must be iterated over to serialize/deserialize, such as arrays, collections and maps.class
A MapAdapter supports properties whose types implement the java.util.Map interface.class
A PrimitiveArrayAdapter supports arrays of primitive types, such as "int", "char", etc.static class
A PropertyAdapter supporting boolean[].static class
A PropertyAdapter supporting byte[].static class
A PropertyAdapter supporting char[].static class
A PropertyAdapter supporting double[].static class
A PropertyAdapter supporting float[].static class
A PropertyAdapter supporting int[].static class
A PropertyAdapter supporting long[].static class
A PropertyAdapter supporting short[].class
The PropertyAdapter is the base class for handling the operations that can occur on any property.class
A property adapter for QName primitive datatype.class
A property adapter for a String based type that is known to have a converting factory method with the following signature:public static <type> valueOf(String s)
.class
A simple XML parser.class
A SerializableAdapter supports Java objects that implement the Serializable interface.class
A SimpleAdapter supports Java intrinsic types and a common set of Java classes: java.lang.Boolean java.lang.Byte java.lang.Character java.lang.Short java.lang.Integer java.lang.Long java.lang.Float java.lang.Double java.lang.String java.math.BigDecimal java.math.BigInteger java.sql.Date java.sql.Time java.sql.Timestamp java.util.Datestatic class
A simple property adapter for BigDecimal.static class
A simple property adapter for BigInteger.static class
A simple property adapter for boolean.static class
A simple property adapter for byte.static class
A simple property adapter for char.static class
A simple property adapter for Date.static class
A simple property adapter for double.static class
A simple property adapter for float.static class
A simple property adapter for int.static class
A simple property adapter for long.static class
A simple property adapter for the Date class from the java/util package.static class
A simple property adapter for short.static class
A simple property adapter for String.static class
A simple property adapter for Java long and java.lang.Long values that is string-formatted as a date/time, assuming that the long value is actualy a system time.static class
A simple property adapter for Time.static class
A simple property adapter for Timestamp.class
A simple implementation of the XmlElement interface.class
A simple implementation of the XmlElement interface.class
An implementation of Entry that supports keeping them in a list.class
This class uses the XmlTokenizer to produce an XmlDocument from XML text.class
A simple implementation of the XmlValue interface.class
This is a base class for building XmlSerializable value objects.class
An XmlElementAdapter supports properties of type XmlElement.class
This abstract class contains XML manipulation methods.class
An XmlSerializableAdapter supports Java objects that implement the XmlSerializable interface. -
Uses of Base in com.tangosol.util
Modifier and TypeClassDescriptionclass
AbstractKeyBasedMap<K,
V> AbstractKeyBasedMap is a base class for Map implementations.protected class
A Map Entry implementation that defers its value acquisition from the containing map (viaMap.get(Object)
) if the Entry is constructed with a null value.class
AbstractKeySetBasedMap is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.class
A base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.final class
A thread-safe immutable binary object.class
A collection of methods for bit-based operations.class
Provide an enumerator which enumerates the contents of multiple enumerators.class
Filter which discards all objects that are not of a certain class.class
CompositeKey<P,
S> Key class that consists of a primary and secondary component.class
ConditionalIndex is aMapIndex
implementation that uses an associated filter to evaluate whether or not an entry should be indexed.static class
A converter MapListener that converts events of the underlying MapListener for the underlying NamedCache.static class
A converter MapListener that converts events of the underlying MapListener for the underlying map.class
A abstract Daemon thread handler.class
Represents a double-ended queue (dequeue) of objects.class
Provide a implementation of an Iterator based on data from an Enumeration.class
Helpers for the Serializable, Externalizable and the ExternalizableLite interface.static class
DecoratedMultiBufferReadBuffer is a MultiBufferWriteBuffer that represents a binary "decorated" value, and allows a more optimizedExternalizableHelper.getUndecorated(ReadBuffer)
operation.protected static final class
Integer decorated object.static class
An implementation XmlBeanClassCache that uses a pre-defined list of XmlBean implementations.class
Provide a generic implementation of an enumerator which can enumerate items based on an inclusion test.class
Helper methods for InvocableMap implementations and Filter related evaluation.static class
Simple implementation of the InvocableMap.Entry interface.class
Provide a implementation of an enumerator based on data from an Iterator.class
KeyValueArrayMap is a Map implementation backed by an array of keys, and an array of the associated values.class
Provide a simple, efficient, and thread-safe implementation of a list of event listeners.class
This class provides support for advanced MapListener functionality.static class
A base class for various wrapper listener classes.static class
A wrapper class that turns the specified MapListener into a priming listener.static class
A wrapper class that turns the specified MapListener into a synchronous listener.class
MapTriggerListener is a special purpose MapListener implementation that is used to register aMapTrigger
on a corresponding ObservableMap.class
A base class that simplifies the implementation of a MapListener by multiplexing all events into a single listener method.class
Filter which discards null references.static class
An implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.protected class
A holder for a cached value.class
OpenHashMap<K,
V> An implementation ofMap
that is optimized for memory footprint.protected class
An Entry implementation that is augmented to allow an Entry instance to be re-used, which means that the same Entry instance can represent different map entries over time.class
PagedIterator is an Iterator implementation based on a concept of a page Advancer - a pluggable component that knows how to supply a next page of objects to iterate through.protected class
A Node in the List.class
A collection of Collection implementation classes that limit the data type.static class
A restricted Collection that requires its contents to be of a specified class.static class
A restricted Collection that requires its contents to be of a specified class.protected class
A Map Entry that restricts the key and value types.protected class
A Map Entry Iterator that restricts the key and value types.static class
A restricted List that requires its contents to be of a specified class.static class
A restricted ListIterator that requires its contents to be of a specified class.static class
A restricted Map that requires its keys and values to be of specified classes.static class
A restricted Set that requires its contents to be of a specified class.static class
A restricted SortedMap that requires its keys and values to be of specified classes.static class
A restricted Set that requires its contents to be of a specified class.protected static class
SafeHashMap.Entry<K,
V> A map entry (key-value pair).protected static class
A Node in the List.class
An implementation of SegmentedHashMap that also implements the ConcurrentMap interface.class
LockableEntry is an Entry that supports locking.class
An implementation of java.util.Map that is optimized for heavy concurrent use.protected static class
A map entry (key-value pair).class
Provide a generic implementation of an array enumerator.class
SimpleMapEntry<K,
V> A map entry (key-value pair).class
SimpleMapIndex is a MapIndex implementation used to correlate property values extracted from resource map entries with corresponding keys using what is commonly known as an Inverted Index algorithm.static class
A statefulcalculator
used to calculate the cost of a homogeneous index (holding all values of a single type).class
Sorts the contents of the passed enumerator then enumerates those contents.final class
Like a hash table, but built specifically for strings.class
A Daemon thread handler that asynchronously executes Runnable tasks, either at a scheduled time or "as soon as possible".class
A PeriodicTask is a task that automatically reschedules itself so that it executes on a periodic basis.class
This class provides an implementation of thread local storage.class
A thread-safe balanced binary search tree.class
A UID is a 128-bit identifier that is almost guaranteed to be unique.final class
A UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique.class
WrapperConcurrentMap<K,
V> A simple implementation of ConcurrentMap interface built as a wrapper around any Map implementation.protected static class
A lock object.class
WrapperObservableMap<K,
V> A simple implementation of ObservableMap interface built as a wrapper around any Map implementation.protected class
An internal MapListener that listens to the wrapped map. -
Uses of Base in com.tangosol.util.aggregator
Modifier and TypeClassDescriptionclass
AbstractAggregator<K,
V, T, E, R> Abstract base class implementation ofInvocableMap.EntryAggregator
that supports streaming aggregation.class
Abstract aggregator that processesNumber
values extracted from a set of entries in a Map and returns a result in a form of aBigDecimal
value.class
Abstract aggregator that processes values extracted from a set of entries in a Map, with knowledge of how to compare those values.class
Abstract aggregator that processes numeric values extracted from a set of entries in a Map.class
Abstract aggregator that processes numeric values extracted from a set of entries in a Map.class
Calculates an average for values of any numeric type extracted from a set of entries in a Map in a form of aBigDecimal
value.class
Calculates a maximum of numeric values extracted from a set of entries in a Map in a form of aBigDecimal
value.class
Calculates a minimum of numeric values extracted from a set of entries in a Map in a form of aBigDecimal
value.class
Calculates an sum for values of any numberic type extracted from a set of entries in a Map in a form of aBigDecimal
value.class
ComparableMax<T,
R> Calculates a maximum among values extracted from a set of entries in a Map.class
ComparableMin<T,
R> Calculates a minimum among values extracted from a set of entries in a Map.class
CompositeAggregator<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 class
Deprecated.As of Coherence 12.2.1.class
Count<K,
V> Calculates a number of values in an entry set.class
DistinctValues<K,
V, T, E> Return the set of unique values extracted from a set of entries in a Map.class
Calculates an average for values of any numeric type extracted from a set of entries in a Map.class
DoubleMax<T>
Calculates a maximum of numeric values extracted from a set of entries in a Map.class
DoubleMin<T>
Calculates a minimum of numeric values extracted from a set of entries in a Map.class
DoubleSum<T>
Sums up numeric values extracted from a set of entries in a Map.class
GroupAggregator<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 class
GroupAggregator.Parallel<K,
V, T, E, R> Deprecated.As of Coherence 12.2.1.class
LongMax<T>
Calculates a maximum of numeric values extracted from a set of entries in a Map.class
LongMin<T>
Calculates a minimum of numeric values extracted from a set of entries in a Map.class
LongSum<T>
Sums up numeric values extracted from a set of entries in a Map.class
PriorityAggregator<K,
V, P, R> PriorityAggregator is used to explicitly control the scheduling priority and timeouts for execution of EntryAggregator-based methods.class
ReducerAggregator<K,
V, T, E> The ReducerAggregator is used to implement functionality similar toCacheMap.getAll(Collection)
API. -
Uses of Base in com.tangosol.util.comparator
Modifier and TypeClassDescriptionclass
Composite comparator implementation based on a collection of comparators.class
Comparator implementation used to compare map entries.class
Comparator that reverses the result of another comparator.class
Null-safe delegating comparator. -
Uses of Base in com.tangosol.util.extractor
Modifier and TypeClassDescriptionclass
Abstract super class for ValueExtractor implementations that are based on an underlying array of ValueExtractor objects.class
AbstractExtractor<T,
E> Abstract base for ValueExtractor implementations.class
AbstractUpdater<K,
V, U> Abstract base for ValueUpdater implementations.class
ChainedExtractor<T,
E> Composite ValueExtractor implementation based on an array of extractors.class
AValueExtractor
that extracts aFragment
from a nested property of the target object.class
ComparisonValueExtractor<T,
E extends Number> A synthetic ValueExtractor that returns a result of comparison between two values extracted from the same target.class
A ValueUpdater implementation based on an extractor-updater pair that could also be used as a ValueManipulator.class
ConditionalExtractor<T,
E> An IndexAwareExtractor implementation that is only used to create aConditionalIndex
.class
DeserializationAccelerator is anIndexAwareExtractor
implementation that is used to create aForwardOnlyMapIndex
, which in turn is used for deserialization optimization.class
The EntryExtractor is a base abstract class for special purpose custom ValueExtractor implementations.class
AValueExtractor
that is used to extract aFragment
from an object.class
Trivial ValueExtractor implementation that does not actually extract anything from the passed value, but returns the value itself.class
KeyExtractor<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.class
Composite ValueExtractor implementation based on an array of extractors.class
PofExtractor<T,
E> POF-based ValueExtractor implementation.class
POF-based ValueUpdater implementation.class
ReflectionExtractor<T,
E> Reflection-based ValueExtractor implementation.class
Reflection-based ValueUpdater implementation.class
ScriptValueExtractor<T,
E> ScriptValueExtractor is anAbstractExtractor
that wraps a script written in one of the languages supported by Graal VM.class
UniversalExtractor<T,
E> Universal ValueExtractor implementation.class
Universal ValueUpdater implementation. -
Uses of Base in com.tangosol.util.filter
Modifier and TypeClassDescriptionclass
Abstract base class implementation ofQueryRecorderFilter
.class
Filter which returns the logical "and" of a filter array.class
AlwaysFilter<T>
Filter which always evaluates to true.class
Filter which returns the logical "and" of two other filters.class
Filter which returns the logical "or" of a filter array.class
Filter which is a logical operator of a filter array.class
BetweenFilter<T,
E extends Comparable<? super E>> Filter which compares the result of a method invocation with a value for "Between" condition.class
CacheEventFilter<K,
V> An extension of theMapEventFilter
which allows selection of client driven (natural) events, cache internal (synthetic) events, or both.class
ComparisonFilter<T,
E, C> Filter which compares the result of a method invocation with a value.class
ContainsAllFilter<T,
E> Filter which tests aCollection
or Object array value returned from a method invocation for containment of all values in a Set.class
ContainsAnyFilter<T,
E> Filter which tests aCollection
or Object array value returned from a method invocation for containment of any value in a Set.class
ContainsFilter<T,
E> Filter which tests aCollection
or Object array value returned from a method invocation for containment of a given value.class
EqualsFilter<T,
E> Filter which compares the result of a method invocation with a value for equality.class
ExtractorFilter<T,
E> Base Filter implementation for doing extractor-based processing.class
A generic Filter-based MapTrigger implementation.class
GreaterEqualsFilter<T,
E extends Comparable<? super E>> Filter which compares the result of a method invocation with a value for "Greater or Equal" condition.class
GreaterFilter<T,
E extends Comparable<? super E>> Filter which compares the result of a method invocation with a value for "Greater" condition.class
InFilter<T,
E> Filter which checks whether the result of a method invocation belongs to a predefined set of values.class
Filter that limits the underlying filter evaluation only to the specified set of keys.class
IsNotNullFilter<T,
E> Filter which tests the result of a method invocation for inequality to null.class
IsNullFilter<T,
E> Filter which compares the result of a method invocation with null.class
Filter which limits the scope of another filter according to the key association information.class
KeyFilter<T>
EntryFilter which checks whether an entry key belongs to a set.class
LessEqualsFilter<T,
E extends Comparable<? super E>> Filter which compares the result of a method invocation with a value for "Less or Equals" condition.class
LessFilter<T,
E extends Comparable<? super E>> Filter which compares the result of a method invocation with a value for "Less" condition.class
LikeFilter<T,
E> Filter which compares the result of a method invocation with a value for pattern match.class
LimitFilter<T>
Filter which truncates the results of another filter.class
MapEventFilter<K,
V> Filter which evaluates the content of a MapEvent object according to the specified criteria.class
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.class
NeverFilter<T>
Filter which always evaluates to false.class
NotEqualsFilter<T,
E> Filter which compares the result of a method invocation with a value for inequality.class
NotFilter<T>
Filter which negates the results of another filter.class
Filter which returns the logical "or" of two other filters.class
Filter which limits the scope of another filter to those entries that have keys that belong to the specified partition set.class
PredicateFilter<T,
E> Ajava.util.function.Predicate
basedExtractorFilter
.class
Filter which returns true forInvocableMap.Entry
objects that currently exist in a Map.class
PriorityFilter is used to explicitly control the scheduling priority and timeouts for execution of filter-based methods.class
RegexFilter<T,
E> Filter which uses the regular expression pattern match defined by theString.matches(String)
contract.class
QueryRecorderFilter wrapper class.class
Filter which returns the logical exclusive or ("xor") of two other filters. -
Uses of Base in com.tangosol.util.processor
Modifier and TypeClassDescriptionclass
AbstractProcessor<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.class
CompositeProcessor<K,
V> The CompositeProcessor represents a collection of entry processors that are invoked sequentially against the same Entry.class
ConditionalProcessor<K,
V, T> Conditional entry processor represents a processor that is invoked conditionally based on the result of an entry evaluation.class
ConditionalPut<K,
V> ConditionalPut is an EntryProcessor that performs anEntry.setValue
operation if the specified condition is satisfied.class
ConditionalPutAll<K,
V> ConditionalPutAll is an EntryProcessor that performs aEntry.setValue
operation for multiple entries that satisfy the specified condition.class
ConditionalRemove<K,
V> ConditionalRemove is an EntryProcessor that performs anEntry.remove
operation if the specified condition is satisfied.class
ExtractorProcessor<K,
V, T, E> ExtractorProcessor is an EntryProcessor implementations that extracts a value from an object cached in an InvocableMap.class
NumberIncrementor<K,
V, N extends Number> The NumberIncrementor entry processor is used to increment a property value of aNumber
type.class
NumberMultiplier<K,
V, N extends Number> The NumberMultiplier entry processor is used to multiply a property value of aNumber
type.class
PreloadRequest<K,
V> PreloadRequest is a simple EntryProcessor that performs aEntry.getValue
call.class
PriorityProcessor<K,
V, T> PriorityProcessor is used to explicitly control the scheduling priority and timeouts for execution of EntryProcessor-based methods.class
PropertyManipulator<V,
R> PropertyManipulator is a reflection based ValueManipulator implementation based on the JavaBean property name conventions.class
PropertyProcessor<K,
V, R> PropertyProcessor is a base class for EntryProcessor implementations that depend on a ValueManipulator.class
UpdaterProcessor<K,
V, T> UpdaterProcessor is an EntryProcessor implementations that updates an attribute of an object cached in an InvocableMap.class
VersionedPut<K,
V extends Versionable> VersionedPut is an EntryProcessor that assumes that entry values implementVersionable
interface and performs anEntry.setValue
operation if and only if the version of the specified value matches to the version of the current value.class
VersionedPutAll<K,
V extends Versionable> VersionedPutAll is an EntryProcessor that assumes that entry values implementVersionable
interface and performs anEntry.setValue
operation only for entries whose versions match to versions of the corresponding current values. -
Uses of Base in com.tangosol.util.transformer
Modifier and TypeClassDescriptionclass
ExtractorEventTransformer<K,
V, E> ExtractorEventTransformer is a special purposeMapEventTransformer
implementation that transforms emitted events, extracting one or more properties from either the OldValue or the NewValue.class
AMapEventTransformer
implementation 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.class
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.