Uses of Package
com.tangosol.util
-
Packages that use com.tangosol.util Package Description com.oracle.coherence.caffeine Contains interfaces and classes related to the Caffeine backing map implementation.com.oracle.coherence.cdi Coherence CDI provides support for CDI (Contexts and Dependency Injection) within Coherence cluster members.com.oracle.coherence.cdi.events Support for adapting Coherence interceptors to standard CDI events.com.oracle.coherence.common.base The base package provides a number of classes to complement those in the java.lang package.com.oracle.coherence.concurrent Coherence Concurrent utilities based on java.util.concurrent.com.oracle.coherence.concurrent.locks Interfaces and classes providing a framework for locking and waiting for conditions that is distinct from built-in synchronization and monitors.com.oracle.coherence.grpc Low-level utilities for Coherence gRPC server and client implementation.com.oracle.coherence.grpc.proxy The Coherence gRPC server implementation.com.oracle.coherence.repository Contains classes to enable Repository-like access to Coherence data.com.tangosol.coherence.config Defines the Coherence configuration object model for accessing, customizing and or modifying configuration.com.tangosol.coherence.config.builder Defines the typical runtime configuration builders for the Coherence configuration object model.com.tangosol.coherence.config.scheme Defines the Coherence configuration object model classes and interfaces for Caching and Service Schemes.com.tangosol.coherence.config.xml.processor Defines the Xml document Element and Attribute Processors for Coherence Cache Configuration files.com.tangosol.coherence.dslquery Contains packages and classes supporting the Coherence CohQL command line tool.com.tangosol.coherence.dslquery.function This package contains builders for the various CohQL functions.com.tangosol.coherence.dslquery.operator This package contains implementations of theBaseOperator
interface.com.tangosol.coherence.dslquery.statement This package containsStatementBuilder
implementations.com.tangosol.coherence.dslquery.statement.persistence This package contains classes for persistence related statement builders.com.tangosol.coherence.federation Contains Federation conflict resolution interfaces.com.tangosol.coherence.jcache.common Common utilities used by Coherence JCache.com.tangosol.coherence.jcache.localcache Contains classes related to local cache implementation of Coherence JCache.com.tangosol.coherence.jcache.partitionedcache Contains classes related to partitioned cache implementation of Coherence JCache.com.tangosol.coherence.jcache.passthroughcache Contains classes related to pass-through cache implementation of Coherence JCache.com.tangosol.coherence.rest Contains classes related to the Coherence REST API.com.tangosol.coherence.rest.events Contains classes related to the Coherence REST APIMapEvent
s.com.tangosol.coherence.rest.io Contains classes related to REST marshalling.com.tangosol.coherence.rest.query Contains classes related to the Coherence REST pluggable query engine.com.tangosol.coherence.rest.util Contains packages and classes related to the Coherence REST API utilities.com.tangosol.coherence.rest.util.aggregator Contains classes related to REST-based aggregation.com.tangosol.coherence.rest.util.extractor Contains classes related to REST-based extractor.com.tangosol.coherence.rest.util.processor Contains classes related to REST-based entry processing.com.tangosol.coherence.rest.util.updater Contains classes related to REST-based updater.com.tangosol.config.xml Defines classes and interfaces for processing Xml documents and building object models, like configuration, based on said documents though the use of injection.com.tangosol.io Contains classes providing cache persistence of serialized objects.com.tangosol.io.bdb Contains Sleepycat Berkeley DB BinaryStore implementation classes.com.tangosol.io.nio Contains classes related to J2SE 1.4 NIO functionality.com.tangosol.io.pof Contains classes related to POF serialization and deserialization.com.tangosol.io.pof.reflect Contains classes related to POF stream navigation and manipulation.com.tangosol.license com.tangosol.net Contains basic cluster interfaces and factories.com.tangosol.net.cache Contains classes providing various caching strategies.com.tangosol.net.events Contains classes related to the Coherence Live Event Model.com.tangosol.net.events.partition Contains classes related to PartitionedService events within the Coherence Live Event Model.com.tangosol.net.events.partition.cache Contains classes related to PartitionedCache events within the Coherence Live Event Model.com.tangosol.net.management Contains classes related to the Coherence Management Framework.com.tangosol.net.partition Contains interfaces and classes related to partitioned services.com.tangosol.net.proxy Contains interfaces and classes related to proxy services.com.tangosol.net.security Contains classes related to the Coherence Security Framework.com.tangosol.net.topic Contains classes that providing topic entities for publish/subscribe messaging.com.tangosol.persistence Contains classes and helpers for implementing various types of persistence.com.tangosol.run.jca Contains classes providing Java 2 Connector Architecture functionality.com.tangosol.run.xml Contains classes providing basic XML related functionality.com.tangosol.util Contains various generic utilities.com.tangosol.util.aggregator Contains concreteInvocableMap.EntryAggregator
implementations.com.tangosol.util.comparator Contains concreteComparator
implementations and related interfaces.com.tangosol.util.extractor ContainsValueExtractor
andValueUpdater
related classes.com.tangosol.util.filter Contains concreteFilter
implementations and related interfaces.com.tangosol.util.function Contains Functional interfaces allowing remote execution of lambda expressions and method references.com.tangosol.util.processor Contains concreteInvocableMap.EntryProcessor
implementations.com.tangosol.util.stream Contains classes to support functional-style operations on remote streams of elements, such as map-reduce transformations on collections.com.tangosol.util.transformer Contains concreteMapEventTransformer
implementations. -
Classes in com.tangosol.util used by com.oracle.coherence.caffeine Class Description Filter Provide for "pluggable" conditional behavior.MapListener The listener interface for receiving MapEvents.ObservableMap ObservableMap interface represents an object with a model being a Map that allows for pluggable notifications for occurring changes. -
Classes in com.tangosol.util used by com.oracle.coherence.cdi Class Description Filter Provide for "pluggable" conditional behavior.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapEventTransformer MapEventTransformer interface is used to allow an event consumer to change the content of aMapEvent
destined for the correspondingMapListener
.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.oracle.coherence.cdi.events Class Description Filter Provide for "pluggable" conditional behavior.InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapEventTransformer MapEventTransformer interface is used to allow an event consumer to change the content of aMapEvent
destined for the correspondingMapListener
.MapListener The listener interface for receiving MapEvents. -
Classes in com.tangosol.util used by com.oracle.coherence.common.base Class Description Binary A thread-safe immutable binary object.ByteSequence Represents a sequence of bytes. -
Classes in com.tangosol.util used by com.oracle.coherence.concurrent Class Description UUID A UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique. -
Classes in com.tangosol.util used by com.oracle.coherence.concurrent.locks Class Description UUID A UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique. -
Classes in com.tangosol.util used by com.oracle.coherence.grpc Class Description Binary A thread-safe immutable binary object.Controllable The Controllable interface represents a configurable daemon-like object, quite often referred to as a service, that usually operates on its own thread and has a controllable life cycle.Converter Provide for "pluggable" object conversions. -
Classes in com.tangosol.util used by com.oracle.coherence.grpc.proxy Class Description AbstractMapListener A base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.ConcurrentMap Map with additional concurrency features.Controllable The Controllable interface represents a configurable daemon-like object, quite often referred to as a service, that usually operates on its own thread and has a controllable life cycle.Converter Provide for "pluggable" object conversions.Filter Provide for "pluggable" conditional behavior.InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapListener The listener interface for receiving MapEvents.MapListenerSupport.PrimingListener A tag interface indicating that this listener is registered as a synchronous listener for lite events (carrying only a key) and generates a "priming" event when registered.MapListenerSupport.SynchronousListener A tag interface indicating that tagged MapListener implementation has to receive the MapEvent notifications in a synchronous manner.MapTrigger MapTrigger represents a functional agent that allows to validate, reject or modify mutating operations against an underlying map.SynchronousListener A tag interface indicating that a listener implementation has to receive the event notifications synchronously on the corresponding service's thread.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.oracle.coherence.repository Class Description Filter Provide for "pluggable" conditional behavior.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapListener The listener interface for receiving MapEvents.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.ValueUpdater ValueUpdater is used to update an object's state. -
Classes in com.tangosol.util used by com.tangosol.coherence.config Class Description ResourceRegistry AResourceRegistry
is a registry and owner of strongly typed and explicitly named resources. -
Classes in com.tangosol.util used by com.tangosol.coherence.config.builder Class Description Filter Provide for "pluggable" conditional behavior.MapListener The listener interface for receiving MapEvents.RegistrationBehavior A RegistrationBehavior is used by numerous registries for the purpose of specifying the required behavior when registering an artifact. -
Classes in com.tangosol.util used by com.tangosol.coherence.config.scheme Class Description Filter Provide for "pluggable" conditional behavior.MapListener The listener interface for receiving MapEvents.ObservableMap ObservableMap interface represents an object with a model being a Map that allows for pluggable notifications for occurring changes.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.config.xml.processor Class Description Filter Provide for "pluggable" conditional behavior.MapListener The listener interface for receiving MapEvents. -
Classes in com.tangosol.util used by com.tangosol.coherence.dslquery Class Description Filter Provide for "pluggable" conditional behavior.ResourceRegistry AResourceRegistry
is a registry and owner of strongly typed and explicitly named resources.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.dslquery.function Class Description ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.dslquery.operator Class Description Filter Provide for "pluggable" conditional behavior.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.dslquery.statement Class Description Base Base class for providing standard functionality.Filter Provide for "pluggable" conditional behavior.InvocableMap.EntryAggregator An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.dslquery.statement.persistence Class Description Base Base class for providing standard functionality. -
Classes in com.tangosol.util used by com.tangosol.coherence.federation Class Description Binary A thread-safe immutable binary object.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.ValueUpdater ValueUpdater is used to update an object's state. -
Classes in com.tangosol.util used by com.tangosol.coherence.jcache.common Class Description Converter Provide for "pluggable" object conversions.Filter Provide for "pluggable" conditional behavior.ResourceRegistry AResourceRegistry
is a registry and owner of strongly typed and explicitly named resources. -
Classes in com.tangosol.util used by com.tangosol.coherence.jcache.localcache Class Description AbstractMapListener A base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.Base Base class for providing standard functionality.Filter Provide for "pluggable" conditional behavior.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapListener The listener interface for receiving MapEvents.MapListenerSupport.SynchronousListener A tag interface indicating that tagged MapListener implementation has to receive the MapEvent notifications in a synchronous manner.SynchronousListener A tag interface indicating that a listener implementation has to receive the event notifications synchronously on the corresponding service's thread.WrapperCollections.AbstractWrapperIterator Iterator implementation which delegates all calls to another Iterator. -
Classes in com.tangosol.util used by com.tangosol.coherence.jcache.partitionedcache Class Description AbstractMapListener A base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.Base Base class for providing standard functionality.BinaryEntry Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.Filter Provide for "pluggable" conditional behavior.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.InvocableMap.EntryAggregator An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.InvocableMap.StreamingAggregator A StreamingAggregator is an extension ofInvocableMap.EntryAggregator
that processes entries in a streaming fashion and provides better control overexecution characteristics
.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapListener The listener interface for receiving MapEvents.MapListenerSupport.SynchronousListener A tag interface indicating that tagged MapListener implementation has to receive the MapEvent notifications in a synchronous manner.ResourceRegistry AResourceRegistry
is a registry and owner of strongly typed and explicitly named resources.SynchronousListener A tag interface indicating that a listener implementation has to receive the event notifications synchronously on the corresponding service's thread.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.WrapperCollections.AbstractWrapperIterator Iterator implementation which delegates all calls to another Iterator. -
Classes in com.tangosol.util used by com.tangosol.coherence.jcache.passthroughcache Class Description Filter Provide for "pluggable" conditional behavior.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapListener The listener interface for receiving MapEvents. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest Class Description ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest.events Class Description Filter Provide for "pluggable" conditional behavior.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapListener The listener interface for receiving MapEvents. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest.io Class Description Binary A thread-safe immutable binary object. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest.query Class Description ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest.util Class Description Binary A thread-safe immutable binary object.LiteMap An implementation of java.util.Map that is optimal (in terms of both size and speed) for very small sets of data but still works excellently with large sets of data.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.ValueManipulator ValueManipulator represents a composition ofValueExtractor
andValueUpdater
implementations.ValueUpdater ValueUpdater is used to update an object's state.Versionable An interface for versionable data. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest.util.aggregator Class Description InvocableMap.EntryAggregator An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest.util.extractor Class Description Base Base class for providing standard functionality.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest.util.processor Class Description InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map. -
Classes in com.tangosol.util used by com.tangosol.coherence.rest.util.updater Class Description Base Base class for providing standard functionality.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.ValueUpdater ValueUpdater is used to update an object's state. -
Classes in com.tangosol.util used by com.tangosol.config.xml Class Description ResourceRegistry AResourceRegistry
is a registry and owner of strongly typed and explicitly named resources.ResourceResolver AResourceResolver
provides a mechanism to lookup and resolve optionally named, strongly typed resources. -
Classes in com.tangosol.util used by com.tangosol.io Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.BitHelper A collection of methods for bit-based operations.ByteSequence Represents a sequence of bytes.ConcurrentMap Map with additional concurrency features.Daemon A abstract Daemon thread handler.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.HashEncoded HashEncoded interface represents an ability to retrieve an encoded hash value; most commonly used to calculate a partition id. -
Classes in com.tangosol.util used by com.tangosol.io.bdb Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object. -
Classes in com.tangosol.util used by com.tangosol.io.nio Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.ByteSequence Represents a sequence of bytes.Converter Provide for "pluggable" object conversions.HashEncoded HashEncoded interface represents an ability to retrieve an encoded hash value; most commonly used to calculate a partition id.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.MapTrigger.Entry A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.QueryMap.Entry A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.SimpleMapEntry A map entry (key-value pair). -
Classes in com.tangosol.util used by com.tangosol.io.pof Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.LongArray An interface, similar in its methods to List, and similar in its purpose to a Java array, designed for sparse storage and indexed by long values. -
Classes in com.tangosol.util used by com.tangosol.io.pof.reflect Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.LongArray An interface, similar in its methods to List, and similar in its purpose to a Java array, designed for sparse storage and indexed by long values. -
Classes in com.tangosol.util used by com.tangosol.license Class Description Base Base class for providing standard functionality. -
Classes in com.tangosol.util used by com.tangosol.net Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.BitHelper A collection of methods for bit-based operations.ConcurrentMap Map with additional concurrency features.Controllable The Controllable interface represents a configurable daemon-like object, quite often referred to as a service, that usually operates on its own thread and has a controllable life cycle.Converter Provide for "pluggable" object conversions.Daemon A abstract Daemon thread handler.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.Filter Provide for "pluggable" conditional behavior.InvocableMap An InvocableMap is a Map against which both entry-targeted processing and aggregating operations can be invoked.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.InvocableMap.EntryAggregator An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map.Listeners Provide a simple, efficient, and thread-safe implementation of a list of event listeners.MapIndex MapIndex is used to correlate values stored in an indexed Map (or attributes of those values) to the corresponding keys in the indexed Map.MapListener The listener interface for receiving MapEvents.ObservableMap ObservableMap interface represents an object with a model being a Map that allows for pluggable notifications for occurring changes.QueryMap Map with additional query features.ResourceRegistry AResourceRegistry
is a registry and owner of strongly typed and explicitly named resources.Service A Service is a Controllable that emits service lifecycle events.ServiceListener The listener interface for receiving ServiceEvents.SynchronousListener A tag interface indicating that a listener implementation has to receive the event notifications synchronously on the corresponding service's thread.TransactionMap ConcurrentMap with additional transaction support.UID A UID is a 128-bit identifier that is almost guaranteed to be unique.UUID A UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.net.cache Class Description AbstractKeyBasedMap AbstractKeyBasedMap is a base class for Map implementations.AbstractKeyBasedMap.EntrySet A set of entries backed by this map.AbstractKeyBasedMap.EntrySet.Entry 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.AbstractKeySetBasedMap AbstractKeySetBasedMap is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.AbstractKeySetBasedMap.EntrySet A set of entries backed by this map.AbstractMapListener A base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.AsynchronousAgent Base class for asynchronous operations that provides a simple implementation of theFuture
interface.Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.BinaryEntry Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view.ConcurrentMap Map with additional concurrency features.Converter Provide for "pluggable" object conversions.ConverterCollections.ConverterMap A Converter Map views an underlying Map through a set of key and value Converters.Daemon A abstract Daemon thread handler.Filter Provide for "pluggable" conditional behavior.Gate A thin extension ofGate
.InvocableMap An InvocableMap is a Map against which both entry-targeted processing and aggregating operations can be invoked.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.InvocableMap.EntryAggregator An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map.LongArray An interface, similar in its methods to List, and similar in its purpose to a Java array, designed for sparse storage and indexed by long values.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapListener The listener interface for receiving MapEvents.MapListenerSupport This class provides support for advanced MapListener functionality.MapListenerSupport.PrimingListener A tag interface indicating that this listener is registered as a synchronous listener for lite events (carrying only a key) and generates a "priming" event when registered.MapListenerSupport.SynchronousListener A tag interface indicating that tagged MapListener implementation has to receive the MapEvent notifications in a synchronous manner.MapTrigger.Entry A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.MultiplexingMapListener A base class that simplifies the implementation of a MapListener by multiplexing all events into a single listener method.ObservableMap ObservableMap interface represents an object with a model being a Map that allows for pluggable notifications for occurring changes.QueryMap Map with additional query features.QueryMap.Entry A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.SafeHashMap An implementation of java.util.Map that is synchronized, but minimally so.SafeHashMap.Entry A map entry (key-value pair).SafeHashMap.EntrySet A set of entries backed by this map.SafeHashMap.KeySet A set of entries backed by this map.SafeHashMap.ValuesCollection A collection of values backed by this map.SimpleMapEntry A map entry (key-value pair).SynchronousListener A tag interface indicating that a listener implementation has to receive the event notifications synchronously on the corresponding service's thread.TaskDaemon A Daemon thread handler that asynchronously executes Runnable tasks, either at a scheduled time or "as soon as possible".ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.ValueUpdater ValueUpdater is used to update an object's state.WrapperConcurrentMap A simple implementation of ConcurrentMap interface built as a wrapper around any Map implementation.WrapperObservableMap A simple implementation of ObservableMap interface built as a wrapper around any Map implementation. -
Classes in com.tangosol.util used by com.tangosol.net.events Class Description BinaryEntry Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view.RegistrationBehavior A RegistrationBehavior is used by numerous registries for the purpose of specifying the required behavior when registering an artifact. -
Classes in com.tangosol.util used by com.tangosol.net.events.partition Class Description BinaryEntry Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view. -
Classes in com.tangosol.util used by com.tangosol.net.events.partition.cache Class Description BinaryEntry Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view.InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map. -
Classes in com.tangosol.util used by com.tangosol.net.management Class Description Base Base class for providing standard functionality.Filter Provide for "pluggable" conditional behavior.HealthCheck A class that can return its health status -
Classes in com.tangosol.util used by com.tangosol.net.partition Class Description AbstractKeyBasedMap AbstractKeyBasedMap is a base class for Map implementations.AbstractKeyBasedMap.EntrySet A set of entries backed by this map.AbstractKeyBasedMap.EntrySet.Entry A Map Entry implementation that defers its value acquisition from the containing map (viaMap.get(Object)
) if the Entry is constructed with a null value.AbstractKeyBasedMap.KeySet A set of keys backed by this map.AbstractKeySetBasedMap AbstractKeySetBasedMap is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.AbstractKeySetBasedMap.EntrySet A set of entries backed by this map.Base Base class for providing standard functionality.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.Filter Provide for "pluggable" conditional behavior.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.MapListener The listener interface for receiving MapEvents.MapTrigger.Entry A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.ObservableMap ObservableMap interface represents an object with a model being a Map that allows for pluggable notifications for occurring changes.PrimitiveSparseArray A data structure resembling a long array indexed by long values.QueryMap.Entry A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.SimpleMapEntry A map entry (key-value pair).WrapperObservableMap A simple implementation of ObservableMap interface built as a wrapper around any Map implementation. -
Classes in com.tangosol.util used by com.tangosol.net.proxy Class Description Base Base class for providing standard functionality.UID A UID is a 128-bit identifier that is almost guaranteed to be unique. -
Classes in com.tangosol.util used by com.tangosol.net.security Class Description Base Base class for providing standard functionality.BinaryEntry Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface. -
Classes in com.tangosol.util used by com.tangosol.net.topic Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.Filter Provide for "pluggable" conditional behavior.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.persistence Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.Converter Provide for "pluggable" object conversions.Filter Provide for "pluggable" conditional behavior.LongArray An interface, similar in its methods to List, and similar in its purpose to a Java array, designed for sparse storage and indexed by long values.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.NullImplementation.NullPersistenceEnvironment APersistenceEnvironment
that does nothing.NullImplementation.NullPersistenceManager APersistenceManager
that does nothing.NullImplementation.NullPersistentStore APersistentStore
that does as little as possible. -
Classes in com.tangosol.util used by com.tangosol.run.jca Class Description Base Base class for providing standard functionality.TransactionMap ConcurrentMap with additional transaction support.TransactionMap.Validator A callback interface used by TransactionMap implementations. -
Classes in com.tangosol.util used by com.tangosol.run.xml Class Description Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.MapTrigger.Entry A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.QueryMap.Entry A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.SimpleMapEntry A map entry (key-value pair). -
Classes in com.tangosol.util used by com.tangosol.util Class Description AbstractByteSequence A simple base class for ByteSequence implementations.AbstractKeyBasedMap AbstractKeyBasedMap is a base class for Map implementations.AbstractKeyBasedMap.EntrySet A set of entries backed by this map.AbstractKeyBasedMap.EntrySet.Entry A Map Entry implementation that defers its value acquisition from the containing map (viaMap.get(Object)
) if the Entry is constructed with a null value.AbstractKeyBasedMap.EntrySet.EntrySetIterator An Iterator over the EntrySet that is backed by the Map.AbstractKeyBasedMap.KeySet A set of keys backed by this map.AbstractKeyBasedMap.ValuesCollection A Collection of values backed by this map.AbstractKeySetBasedMap AbstractKeySetBasedMap is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.AbstractLongArray An implementation of portions of the LongArray interface.AbstractSafeLongArray An abstract base class for thread-safeLongArray
s which are protected by lock(s).AbstractSafeLongArray.SafeIterator A lock based LongArray Iterator.AbstractSparseArray A data structure resembling an array indexed by long values, stored as an AVL tree.AbstractSparseArray.Crawler A tree node iterator.AbstractSparseArray.Node An AVL tree node.AnyEvent An AnyEvent is an event used when no specific event implementation fits and it is not worth making one.Base Base class for providing standard functionality.Binary A thread-safe immutable binary object.BinaryEntry Map.Entry that internally stores both key and value in a Binary format and uses an underlying Serializer to convert it to and from an Object view.BitHelper A collection of methods for bit-based operations.Builder ABuilder
provides a mechanism for realizing a specific class of object as required.ByteSequence Represents a sequence of bytes.ChainedCollection An unmodifiable Collection that provides access to many collections in the given order.ChainedMap.EntrySet A set of entries backed by this map.ChainedSet An unmodifiable Set that provides access to many sets in the given order.ConcurrentMap Map with additional concurrency features.Controllable The Controllable interface represents a configurable daemon-like object, quite often referred to as a service, that usually operates on its own thread and has a controllable life cycle.Converter Provide for "pluggable" object conversions.ConverterCollections.AbstractConverterEntry An abstract Map Entry that lazily converts the key and value.ConverterCollections.ConverterCacheMap A Converter CacheMap views an underlying CacheMap through a set of key and value Converters.ConverterCollections.ConverterCollection A Converter Collection views an underlying Collection through a Converter.ConverterCollections.ConverterEntry A Map Entry that lazily converts the key and value.ConverterCollections.ConverterEntrySet A Converter Entry Set views an underlying Entry Set through a set of key and value Converters.ConverterCollections.ConverterEnumerator Provide an implementation of an enumerator which converts each of the items which it enumerates.ConverterCollections.ConverterHolder A Holder that converts the element before returning them.ConverterCollections.ConverterList A Converter List views an underlying List through a Converter.ConverterCollections.ConverterListIterator A Converter ListIterator views an underlying ListIterator through a Converter.ConverterCollections.ConverterMap A Converter Map views an underlying Map through a set of key and value Converters.ConverterCollections.ConverterMapEvent A ConverterMapEvent views an underlying MapEvent through a set of key and value Converters.ConverterCollections.ConverterMapEvent.ConverterMapEventEntry ConverterMapEventEntry provides the Map Entry interface to the information encapsulated inside the ConverterMapEvent.ConverterCollections.ConverterMapListener A converter MapListener that converts events of the underlying MapListener for the underlying map.ConverterCollections.ConverterObservableMap A Converter ObservableMap views an underlying ObservableMap through a set of key and value Converters.ConverterCollections.ConverterSet A Converter Set views an underlying Set through a Converter.ConverterCollections.ConverterSortedMap A Converter SortedMap views an underlying SortedMap through a set of key and value Converters.ConverterCollections.ConverterSortedSet A Converter SortedSet views an underlying SortedSet through a Converter.CopyOnWriteLongArray A thread-safe variant ofLongArray
in which all mutating operations (e.g.Daemon A abstract Daemon thread handler.Daemon.DaemonWorker The sub-class of Thread that this Daemon uses as the actual thread of execution.DaemonThreadFactory DaemonThreadFactory is a ThreadFactory which produces daemon threads.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.ExternalizableHelper.IntDecoratedObject Integer decorated object.ExternalizableHelper.Shielded Marker interface.ExternalizableHelper.XmlBeanClassCache An interface for caching class reference by integer ID values.Filter Provide for "pluggable" conditional behavior.Fragment An object that represents a fragment of another object.Gate A thin extension ofGate
.HashEncoded HashEncoded interface represents an ability to retrieve an encoded hash value; most commonly used to calculate a partition id.InflatableCollection A Collection implementation which optimizes memory consumption for collections that often contain just a single value.InflatableCollection.InflatedCollection A marker interface which is used to identify internally inflated Collections.InvocableMap An InvocableMap is a Map against which both entry-targeted processing and aggregating operations can be invoked.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.InvocableMap.EntryAggregator An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map.InvocableMap.StreamingAggregator A StreamingAggregator is an extension ofInvocableMap.EntryAggregator
that processes entries in a streaming fashion and provides better control overexecution characteristics
.InvocableMapHelper.RoutingMapTriggerEntry MapTrigger.Entry wrapper that routes the getValue() call onto getOriginalValue().InvocableMapHelper.SimpleEntry Simple implementation of the InvocableMap.Entry interface.Listeners Provide a simple, efficient, and thread-safe implementation of a list of event listeners.LongArray An interface, similar in its methods to List, and similar in its purpose to a Java array, designed for sparse storage and indexed by long values.LongArray.Iterator An Iterator that adds a "current element" concept, similar to theMap.Entry
interface.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapEventTransformer MapEventTransformer interface is used to allow an event consumer to change the content of aMapEvent
destined for the correspondingMapListener
.MapIndex MapIndex is used to correlate values stored in an indexed Map (or attributes of those values) to the corresponding keys in the indexed Map.MapListener The listener interface for receiving MapEvents.MapListenerSupport This class provides support for advanced MapListener functionality.MapListenerSupport.PrimingListener A tag interface indicating that this listener is registered as a synchronous listener for lite events (carrying only a key) and generates a "priming" event when registered.MapListenerSupport.SynchronousListener A tag interface indicating that tagged MapListener implementation has to receive the MapEvent notifications in a synchronous manner.MapListenerSupport.WrapperListener A base class for various wrapper listener classes.MapListenerSupport.WrapperSynchronousListener A wrapper class that turns the specified MapListener into a synchronous listener.MapSet An ExternalizableLite implementation of java.util.Set that uses an underlying Map object to store its data in, just as the Java HashSet implementation uses an underlying HashMap for its element storage.MapTrigger MapTrigger represents a functional agent that allows to validate, reject or modify mutating operations against an underlying map.MapTrigger.Entry A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.MultiplexingMapListener A base class that simplifies the implementation of a MapListener by multiplexing all events into a single listener method.NullFilter Filter which discards null references.NullImplementation.NullAddressProvider Null implementation ofAddressProvider
.NullImplementation.NullBackingMapManagerContext An implementation of BackingMapManagerContext that does nothing.NullImplementation.NullCacheStore An implementation of an CacheStore that does nothing.NullImplementation.NullCollector ACollector
implementation that does nothing.NullImplementation.NullContinuation A Continuation that does nothing.NullImplementation.NullConverter A Converter that does nothing.NullImplementation.NullEntryProcessor An implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.NullImplementation.NullEnumerator An empty enumerator.NullImplementation.NullMap A Map that contains nothing and does nothing.NullImplementation.NullMemberIdentityProvider An implementation of aMemberIdentityProvider
that returnsnull
for all its methods.NullImplementation.NullPartitionAssignmentStrategy An implementation ofPartitionAssignmentStrategy
that does nothing.NullImplementation.NullPersistenceEnvironment APersistenceEnvironment
that does nothing.NullImplementation.NullPersistenceManager APersistenceManager
that does nothing.NullImplementation.NullPersistentStore APersistentStore
that does as little as possible.NullImplementation.NullPofContext An implementation of PofContext that does nothing.NullImplementation.NullPofHandler An implementation of PofHandler that does nothing.NullImplementation.NullResourceRegistry AResourceRegistry
implementation that does nothing.NullImplementation.NullValueExtractor A ValueExtractor that always results in the passed-in value.ObservableMap ObservableMap interface represents an object with a model being a Map that allows for pluggable notifications for occurring changes.PagedIterator.Advancer Advancer is a pluggable component that knows how to load a new page (Collection) of objects to be used by the enclosing PagedIterator.PrimitiveSparseArray A data structure resembling a long array indexed by long values.PrimitiveSparseArray.Iterator Iterator over long values stored in the tree.QueryContext The QueryContext provides an execution context to server-side agents during query execution.QueryMap Map with additional query features.QueryMap.Entry A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.QueryRecord The QueryRecord object carries information regarding the estimated or actual execution cost for a query operation.QueryRecord.PartialResult A QueryRecord.PartialResult is a partial query record that contains recorded costs for a query operation.QueryRecord.PartialResult.ExplainStep A QueryRecord.ExplainStep is aQueryRecord.PartialResult.RecordableStep
that provides the ability to record the estimated cost of evaluating a filter as part of a query operation.QueryRecord.PartialResult.IndexLookupRecord An IndexLookupRecord holds the recorded information about an index lookup performed during filter evaluation as part of a query record.QueryRecord.PartialResult.RecordableStep A QueryRecord.RecordableStep is astep
that provides the ability to record the cost of evaluating a filter as part of a query operation.QueryRecord.PartialResult.Step A QueryRecord.Step carries the recorded cost of evaluating a filter as part of a query operation.QueryRecord.PartialResult.TraceStep A QueryRecord.TraceStep is aQueryRecord.PartialResult.RecordableStep
that provides the ability to record the information associated with the actual cost of evaluating a filter as part of a query operation.ReadHeavyLongArray A thread-safe LongArray implementation for read heavy workloads but which is also efficient with frequent and/or bursty writes.RecyclingLinkedList.Node A Node in the List.RegistrationBehavior A RegistrationBehavior is used by numerous registries for the purpose of specifying the required behavior when registering an artifact.ResourceRegistry AResourceRegistry
is a registry and owner of strongly typed and explicitly named resources.ResourceRegistry.ResourceLifecycleObserver TheResourceRegistry.ResourceLifecycleObserver
interface defines lifecycle handlers for resources registered with aResourceRegistry
.ResourceResolver AResourceResolver
provides a mechanism to lookup and resolve optionally named, strongly typed resources.Resources Implement simple basis for package (and other) resources.RestrictedCollections.RestrictedCollection A restricted Collection that requires its contents to be of a specified class.RestrictedCollections.RestrictedMap A restricted Map that requires its keys and values to be of specified classes.RestrictedCollections.RestrictedSet A restricted Set that requires its contents to be of a specified class.SafeHashMap An implementation of java.util.Map that is synchronized, but minimally so.SafeHashMap.Entry A map entry (key-value pair).SafeHashMap.EntrySet A set of entries backed by this map.SafeHashMap.KeySet A set of entries backed by this map.SafeHashMap.ValuesCollection A collection of values backed by this map.SafeLinkedList Implementation of the Collection Framework interface "List" using a linked list algorithm.SafeLinkedList.Node A Node in the List.SafeLongArray A thread-safe variant ofLongArray
in which is protected by a ReentrantLock.SafeSortedMap Implementation of aSortedMap
extendingConcurrentSkipListMap
to support null keys and null values.SafeSortedMap.SubMap SubMap delegation to manageSafeSortedMap.NULL
in entry key and/or value.SegmentedConcurrentMap An implementation of SegmentedHashMap that also implements the ConcurrentMap interface.SegmentedConcurrentMap.ConditionalRemoveAction Action support for a conditional remove().SegmentedConcurrentMap.ContentionObserver ContentionObserver is used to observe the contention lock-related actions performed on the concurrent map.SegmentedConcurrentMap.LockableEntry LockableEntry is an Entry that supports locking.SegmentedConcurrentMap.LockAction Action support for lock().SegmentedConcurrentMap.SizeAction Action support for size().SegmentedConcurrentMap.UnlockAction Action support for unlock().SegmentedHashMap An implementation of java.util.Map that is optimized for heavy concurrent use.SegmentedHashMap.ContainsValueAction Action support for containsValue().SegmentedHashMap.Entry A map entry (key-value pair).SegmentedHashMap.EntryAction An EntryAction encapsulates a logical action to be executed in the context of a key (that may or may not exist in the map).SegmentedHashMap.EntryActionAdapter EntryActionAdapter is a convenience class that provides default implementations for the EntryAction and IterableEntryAction interface methods.SegmentedHashMap.EntrySet A set of entries backed by this map.SegmentedHashMap.GetEntryAction Action support for getEntryInternal.SegmentedHashMap.InsertAction Action support for insert.SegmentedHashMap.IterableEntryAction IterableEntryAction is an EntryAction that is suitable for applying to all keys in a map.SegmentedHashMap.KeySet A set of entries backed by this map.SegmentedHashMap.RemoveAction Action support for remove().SegmentedHashMap.Segment Segment metadata.SegmentedHashMap.ValuesCollection A collection of values backed by this map.Service A Service is a Controllable that emits service lifecycle events.ServiceEvent An event which indicates that a Service state has changed: a service is starting a service has started a service is stopping a service has stopped A ServiceEvent object is sent as an argument to the ServiceListener interface methods.ServiceListener The listener interface for receiving ServiceEvents.SimpleEnumerator Provide a generic implementation of an array enumerator.SimpleLongArray An implementation of LongArray that stores values in an array, thus is actually an "IntArray".SimpleMapEntry A map entry (key-value pair).SimpleMapIndex SimpleMapIndex is a MapIndex implementation used to correlate property values extracted from resource map entries with corresponding keys using what is commonly known as an Inverted Index algorithm.SimpleMapIndex.IndexCalculator.CalculatorState The CalculatorState identifies the method used by the calculator to calculate the cost of a key or a value type.SimpleQueryRecord.PartialResult.AbstractRecordableStep Simple abstract RecordableStep implementation.SimpleQueryRecord.PartialResult.IndexLookupRecord Simple QueryRecord.PartialResult.IndexLookupRecord implementation.SimpleQueryRecord.PartialResult.Step Simple QueryRecord.PartialResult.Step implementation.SimpleResourceRegistry ASimpleResourceRegistry
is a basic implementation of aResourceRegistry
.SortedBag SortedBag is a multiset or bag implementation that supports sorted traversal of the contained elements and is optimized for insertions and removals.SortedBag.UniqueElement UniqueElement represents a unique instance of a logical element in the bag.SparseArray A data structure resembling an Object array indexed by long values.Streamer Enables traversal of elements in the underlying data set using eitherIterator
,Spliterator
or aStream
, while allowing implementors to provide additional metadata, such as the size and other characteristics of the underlying data set.StringTable Like a hash table, but built specifically for strings.SynchronousListener A tag interface indicating that a listener implementation has to receive the event notifications synchronously on the corresponding service's thread.ThreadFactory Factory interface for Thread creation.ThreadGateLite.Bar Bar represents the state of thebars
placed on this gate.TransactionMap ConcurrentMap with additional transaction support.TransactionMap.Validator A callback interface used by TransactionMap implementations.Tree A thread-safe balanced binary search tree.Unsafe A collection of "back-door" utilities and helpers used internally.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.ValueUpdater ValueUpdater is used to update an object's state.Versionable An interface for versionable data.WrapperCollections.AbstractWrapperCollection Collection implementation which delegates all calls to another Collection.WrapperCollections.AbstractWrapperIterator Iterator implementation which delegates all calls to another Iterator.WrapperCollections.AbstractWrapperList List implementation which delegates all calls to another List.WrapperCollections.AbstractWrapperLongArray Abstract wrapper implementation for LongArrays.WrapperCollections.AbstractWrapperMap Map implementation which delegates all calls to another Map.WrapperCollections.AbstractWrapperSet Set implementation which delegates all calls to another Set.WrapperCollections.AbstractWrapperSortedSet SortedSet implementation which delegates all calls to another SortedSet.WrapperCollections.ConcurrentWrapperCollection Collection implementation which uses a ReadWriteLock to manage concurrent access to an underlying Collection.WrapperCollections.ConcurrentWrapperSet Set implementation which uses a ReadWriteLock to manage concurrent access to an underlying Set.WrapperConcurrentMap.Lock A lock object.WrapperException A WrapperException wraps a Throwable object as a RuntimeException.WrapperObservableMap A simple implementation of ObservableMap interface built as a wrapper around any Map implementation. -
Classes in com.tangosol.util used by com.tangosol.util.aggregator Class Description AbstractScript AbstractScriptBase is the base class for script based processing.AsynchronousAgent Base class for asynchronous operations that provides a simple implementation of theFuture
interface.Base Base class for providing standard functionality.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.Filter Provide for "pluggable" conditional behavior.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.InvocableMap.EntryAggregator An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.InvocableMap.ParallelAwareAggregator Deprecated.This interface was deprecated in Coherence 12.2.1 and might be removed in a future release.InvocableMap.StreamingAggregator A StreamingAggregator is an extension ofInvocableMap.EntryAggregator
that processes entries in a streaming fashion and provides better control overexecution characteristics
.QueryRecord The QueryRecord object carries information regarding the estimated or actual execution cost for a query operation.QueryRecord.PartialResult A QueryRecord.PartialResult is a partial query record that contains recorded costs for a query operation.SortedBag SortedBag is a multiset or bag implementation that supports sorted traversal of the contained elements and is optimized for insertions and removals.Streamer Enables traversal of elements in the underlying data set using eitherIterator
,Spliterator
or aStream
, while allowing implementors to provide additional metadata, such as the size and other characteristics of the underlying data set.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.util.comparator Class Description Base Base class for providing standard functionality.QueryMap.Entry A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.util.extractor Class Description Base Base class for providing standard functionality.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.Filter Provide for "pluggable" conditional behavior.Fragment An object that represents a fragment of another object.MapIndex MapIndex is used to correlate values stored in an indexed Map (or attributes of those values) to the corresponding keys in the indexed Map.MapTrigger.Entry A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.QueryMap.Entry A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.ValueManipulator ValueManipulator represents a composition ofValueExtractor
andValueUpdater
implementations.ValueUpdater ValueUpdater is used to update an object's state. -
Classes in com.tangosol.util used by com.tangosol.util.filter Class Description AbstractScript AbstractScriptBase is the base class for script based processing.Base Base class for providing standard functionality.BitHelper A collection of methods for bit-based operations.Converter Provide for "pluggable" object conversions.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.Filter Provide for "pluggable" conditional behavior.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapEventTransformer MapEventTransformer interface is used to allow an event consumer to change the content of aMapEvent
destined for the correspondingMapListener
.MapIndex MapIndex is used to correlate values stored in an indexed Map (or attributes of those values) to the corresponding keys in the indexed Map.MapTrigger MapTrigger represents a functional agent that allows to validate, reject or modify mutating operations against an underlying map.MapTrigger.Entry A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.QueryContext The QueryContext provides an execution context to server-side agents during query execution.QueryRecord.PartialResult.ExplainStep A QueryRecord.ExplainStep is aQueryRecord.PartialResult.RecordableStep
that provides the ability to record the estimated cost of evaluating a filter as part of a query operation.QueryRecord.PartialResult.TraceStep A QueryRecord.TraceStep is aQueryRecord.PartialResult.RecordableStep
that provides the ability to record the information associated with the actual cost of evaluating a filter as part of a query operation.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.util.function Class Description ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.util.processor Class Description AbstractScript AbstractScriptBase is the base class for script based processing.AsynchronousAgent Base class for asynchronous operations that provides a simple implementation of theFuture
interface.Base Base class for providing standard functionality.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.Filter Provide for "pluggable" conditional behavior.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.InvocableMap.EntryProcessor An invocable agent that operates against the Entry objects within a Map.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.ValueManipulator ValueManipulator represents a composition ofValueExtractor
andValueUpdater
implementations.ValueUpdater ValueUpdater is used to update an object's state.Versionable An interface for versionable data. -
Classes in com.tangosol.util used by com.tangosol.util.stream Class Description InvocableMap An InvocableMap is a Map against which both entry-targeted processing and aggregating operations can be invoked.InvocableMap.Entry An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.SimpleHolder General purpose container that can be used as an accumulator for any reference type.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction. -
Classes in com.tangosol.util used by com.tangosol.util.transformer Class Description Base Base class for providing standard functionality.BitHelper A collection of methods for bit-based operations.ExternalizableHelper Helpers for the Serializable, Externalizable and the ExternalizableLite interface.MapEvent An event which indicates that the content of a map has changed: an entry has been added an entry has been removed an entry has been changed A MapEvent object is sent as an argument to the MapListener interface methods.MapEventTransformer MapEventTransformer interface is used to allow an event consumer to change the content of aMapEvent
destined for the correspondingMapListener
.ValueExtractor ValueExtractor is used to both extract values (for example, for sorting or filtering) from an object, and to provide an identity for that extraction.