Package com.tangosol.util
package com.tangosol.util
Contains various generic utilities.
-
ClassDescriptionA simple base class for ByteSequence implementations.A naive ByteSequence that glues two ByteSequence instances together.A naive ByteSequence that represents a portion of another ByteSequence.AbstractKeyBasedMap<K,
V> AbstractKeyBasedMap is a base class for Map implementations.A DeferredCacheEvent is aCacheEvent
object that defers the loading of theold value
.AbstractKeySetBasedMap is an extension to the AbstractKeyBasedMap that has a full awareness of the set of keys upon which the Map is based.An implementation of portions of the LongArray interface.A base class that simplifies the implementation of a MapListener, particularly inner classes that only implement one or two of the three event methods.An abstract base class for thread-safeLongArray
s which are protected by lock(s).AbstractScriptBase is the base class for script based processing.A data structure resembling an array indexed by long values, stored as an AVL tree.An AVL tree node.Deprecated.Simple Aggregator DSL.An AnyEvent is an event used when no specific event implementation fits and it is not worth making one.An AnyEvent is an event used when no specific event implementation fits and it is not worth making one.An AssertionException is thrown when an assertion fails.Base class for asynchronous operations that provides a simple implementation of theFuture
interface.Base class for providing standard functionality.Inner class for over-riding the destination of log(), out() and err() calls.A thread-safe immutable binary object.BinaryEntry<K,V> 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.a WriteBuffer implementation whose primary purpose is to be used to create Binary objects.A collection of methods for bit-based operations.Builder<T>ABuilder
provides a mechanism for realizing a specific class of object as required.Provides a collection of helper methods for working withBuilder
s.Represents a sequence of bytes.Implements a collator which caches its keys.An unmodifiable Collection that provides access to many collections in the given order.Provide an enumerator which enumerates the contents of multiple enumerators.Chains two maps into one virtual map.AChainedResourceResolver
is aResourceResolver
that chains together one or more otherResourceResolver
s, those of which will be queried (in the order in which they are added to theChainedResourceResolver
) when attempting to resolve a resource.ChainedSet<E>An unmodifiable Set that provides access to many sets in the given order.Resizable-array implementation of the List interface.Filter which discards all objects that are not of a certain class.This abstract class contains dynamic (reflect-based) class, method, and field manipulation methods.Deprecated.As of Coherence 12.1.2CompositeKey<P,S> Key class that consists of a primary and secondary component.ConcurrentMap<K,V> Map with additional concurrency features.ConditionalIndex is aMapIndex
implementation that uses an associated filter to evaluate whether or not an entry should be indexed.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<F,T> Provide for "pluggable" object conversions.A collection of Collection implementation classes that use the Converter interface to convert the items stored in underlying collection objects.ConverterCollections.AbstractConverterEntry<FK,TK, FV, TV> An abstract Map Entry that lazily converts the key and value.A ConfigurableCacheMap.Entry that lazily converts the key and value.A Converter CacheEvent views an underlying CacheEvent through a set of key and value Converters.A converter MapListener that converts events of the underlying MapListener for the underlying NamedCache.ConverterCollections.ConverterCacheMap<FK,TK, FV, TV> A Converter CacheMap views an underlying CacheMap through a set of key and value Converters.A Converter Collection views an underlying Collection through a Converter.A Comparator that Converts the elements before comparing them.ConverterCollections.ConverterConcurrentMap<FK,TK, FV, TV> A Converter ConcurrentMap views an underlying ConcurrentMap through a set of key and value Converters.ConverterCollections.ConverterEntry<FK,TK, FV, TV> A Map Entry that lazily converts the key and value.ConverterCollections.ConverterEntrySet<FK,TK, FV, TV> A Converter Entry Set views an underlying Entry Set through a set of key and value Converters.Provide an implementation of an enumerator which converts each of the items which it enumerates.A Holder that converts the element before returning them.ConverterCollections.ConverterInvocableMap<FK,TK, FV, TV> A Converter InvocableMap views an underlying InvocableMap through a set of key and value Converters.A Converter List views an underlying List through a Converter.A Converter ListIterator views an underlying ListIterator through a Converter.ConverterLongArray converts the value of the LongArray from its raw form (typeF
) to the desired from (typeT
).ConverterCollections.ConverterMap<FK,TK, FV, TV> A Converter Map views an underlying Map through a set of key and value Converters.A ConverterMapEvent views an underlying MapEvent through a set of key and value Converters.A converter MapListener that converts events of the underlying MapListener for the underlying map.ConverterCollections.ConverterNamedCache<FK,TK, FV, TV> A Converter NamedCache views an underlying NamedCache through a set of key and value Converters.ConverterCollections.ConverterObservableMap<FK,TK, FV, TV> A Converter ObservableMap views an underlying ObservableMap through a set of key and value Converters.ConverterCollections.ConverterQueryMap<FK,TK, FV, TV> A Converter QueryMap views an underlying QueryMap through a set of key and value Converters.A Converter Set views an underlying Set through a Converter.ConverterCollections.ConverterSortedMap<FK,TK, FV, TV> A Converter SortedMap views an underlying SortedMap through a set of key and value Converters.A Converter SortedSet views an underlying SortedSet through a Converter.Deprecated.As of Coherence 12.1.2, replaced byConverterCollections.ConverterEnumerator
A thread-safe variant ofLongArray
in which all mutating operations (e.g.Unmodifiable view of a LongArray.Iterator.CopyOnWriteMap<K,V> A thread-safe variant ofMap
in which all mutating operations (e.g.A abstract Daemon thread handler.DaemonThreadFactory is a ThreadFactory which produces daemon threads.Implements a set which is based on another set, which is assumed to be immutable.Represents a double-ended queue (dequeue) of objects.Deprecated.useDisposable
insteadA trivial Map implementation that is based on a specified set of entries.Provide a implementation of an Iterator based on data from an Enumeration.Helpers for the Serializable, Externalizable and the ExternalizableLite interface.DecoratedMultiBufferReadBuffer is a MultiBufferWriteBuffer that represents a binary "decorated" value, and allows a more optimizedExternalizableHelper.getUndecorated(ReadBuffer)
operation.Default ObjectStreamFactory implementation.A DeltaCompressor wrapper implementation that removes/replaces the serialization format byte (FMT_EXT) before/after delegating to the underlying compressor.Integer decorated object.Marker interface.An OutputStream that implements DataOutput that delegates all operations other than flush and close to an underlying object that implements DataOutput.An InputStream that delegates all operations other than close to an underlying InputStream.An OutputStream that implements ObjectOutput that delegates all operations other than flush and close to an underlying object that implements ObjectOutput.An OutputStream that delegates all operations other than flush and close to an underlying OutputStream.An implementation XmlBeanClassCache that uses a pre-defined list of XmlBean implementations.Serialization statistics for a given user type.An interface for caching class reference by integer ID values.Simple Extractor DSL.Filter<T>Provide for "pluggable" conditional behavior.FilterBuildingException is the RuntimeException thrown by theQueryHelper
when building aFilter
.Provide a generic implementation of an enumerator which can enumerate items based on an inclusion test.Simple Filter DSL.ForwardOnlyMapIndex is aMapIndex
implementation that unlike theSimpleMapIndex
maintains only a forward index and not the inverse index.Fragment<T>An object that represents a fragment of another object.Gate<R>A thin extension ofGate
.HashEncoded interface represents an ability to retrieve an encoded hash value; most commonly used to calculate a partition id.This abstract class contains helper functions for calculating hash code values for any group of java intrinsics.A class that can return its health statusA simple executable class that will perform a health check query against a specific URL.Implementation of the Collection Framework interface "List" in a read- only fashion on top of an array data structure.Implementation of the List interface in a read-only fashion based on a collection of arrays.A Collection implementation which optimizes memory consumption for collections that often contain just a single value.A marker interface which is used to identify internally inflated Collections.A List specialization of InflatableCollection.A Set specialization of InflatableCollection.InvocableMap<K,V> An InvocableMap is a Map against which both entry-targeted processing and aggregating operations can be invoked.InvocableMap.Entry<K,V> An InvocableMap.Entry contains additional information and exposes additional operations that the basic Map.Entry does not.InvocableMap.EntryAggregator<K,V, R> An EntryAggregator represents processing that can be directed to occur against some subset of the entries in an InvocableMap, resulting in a aggregated result.InvocableMap.EntryProcessor<K,V, R> An invocable agent that operates against the Entry objects within a Map.InvocableMap.ParallelAwareAggregator<K,V, P, R> Deprecated.This interface was deprecated in Coherence 12.2.1 and might be removed in a future release.Deprecated.This interface was deprecated in Coherence 12.2.1 and might be removed in a future release.InvocableMap.StreamingAggregator<K,V, P, R> A StreamingAggregator is an extension ofInvocableMap.EntryAggregator
that processes entries in a streaming fashion and provides better control overexecution characteristics
.Helper methods for InvocableMap implementations and Filter related evaluation.MapListener implementation that routes the map events into the corresponding MapIndex calls.BinaryEntry wrapper that routes the getValue()/getBinaryValue() calls onto getOriginalValue()/getOriginalBinaryValue().MapTrigger.Entry wrapper that routes the getValue() call onto getOriginalValue().Simple implementation of the InvocableMap.Entry interface.Provide a implementation of an enumerator based on data from an Iterator.KeyValueArrayMap is a Map implementation backed by an array of keys, and an array of the associated values.Provide a simple, efficient, and thread-safe implementation of a list of event listeners.ListMap<K,V> As of Coherence 3.2, the ListMap simply extends Java's own LinkedHashMap, which became available in JDK 1.4.LiteMap<K,V> 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.LiteSet<E>An implementation of java.util.Set that is optimal (in terms of both size and speed) for very small sets of data but still works excellently with large sets of data.LongArray<V>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.An Iterator that adds a "current element" concept, similar to theMap.Entry
interface.MapEvent<K,V> 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<K,V, U> MapEventTransformer interface is used to allow an event consumer to change the content of aMapEvent
destined for the correspondingMapListener
.MapIndex<K,V, E> 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<K,V> The listener interface for receiving MapEvents.This class provides support for advanced MapListener functionality.An extension of the CacheEvent which may carry no values (old or new), but instead holds on an array of Filter objects being the "cause" of the event.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.A tag interface indicating that tagged MapListener implementation has to receive the MapEvent notifications in a synchronous manner.A base class for various wrapper listener classes.A wrapper class that turns the specified MapListener into a priming listener.A wrapper class that turns the specified MapListener into a synchronous listener.An exception to indicate that a required map does not exist.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<K,V> MapTrigger represents a functional agent that allows to validate, reject or modify mutating operations against an underlying map.MapTrigger.Entry<K,V> A MapTrigger Entry represents a pending change to an Entry that is about to committed to the underlying Map.MapTriggerListener is a special purpose MapListener implementation that is used to register aMapTrigger
on a corresponding ObservableMap.A base class that simplifies the implementation of a MapListener by multiplexing all events into a single listener method.Filter which discards null references.A collection of classes that do nothing.An implementation of an ActionPolicy that allows all actions.Null implementation ofAddressProvider
.An implementation of BackingMapManagerContext that does nothing.An implementation of an CacheStore that does nothing.ACollector
implementation that does nothing.A Continuation that does nothing.A Converter that does nothing.An implementation of a DeltaCompressor that does nothing and always returns the new stream.An implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.An empty enumerator.An immutable emptyLongArray
A Map that contains nothing and does nothing.An implementation of aMemberIdentityProvider
that returnsnull
for all its methods.An immutable ObservableMap which contains nothing.An OutputStream that does basically nothing.An implementation ofPartitionAssignmentStrategy
that does nothing.APersistenceEnvironment
that does nothing.APersistenceManager
that does nothing.APersistentStore
that does as little as possible.An implementation of PofContext that does nothing.An implementation of PofHandler that does nothing.A reader that does basically nothing.AResourceRegistry
implementation that does nothing.An immutable set which contains nothing.A ValueExtractor that always results in the passed-in value.A writer that does basically nothing.ObservableHashMap<K,V> An ObservableMap implementation that extends the SafeHashMap.ObservableMap<K,V> ObservableMap interface represents an object with a model being a Map that allows for pluggable notifications for occurring changes.OpenHashMap<K,V> An implementation ofMap
that is optimized for memory footprint.OpenHashSet<E>An implementation ofSet
that is optimized for memory footprint.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.Advancer is a pluggable component that knows how to load a new page (Collection) of objects to be used by the enclosing PagedIterator.A data structure resembling a long array indexed by long values.Node mapping long key to Object value.SimpleInvocableMap.EntryProcessor
DSL.Proxyable<T>An interface that should be implemented by the classes that are able to create a client-side proxy for itself.The QueryContext provides an execution context to server-side agents during query execution.QueryHelper is a utility class that provides a set of factory methods used for building instances ofFilter
orValueExtractor
.QueryMap<K,V> Map with additional query features.QueryMap.Entry<K,V> A QueryMap Entry exposes additional index-related operation that the basic Map Entry does not.The QueryRecord object carries information regarding the estimated or actual execution cost for a query operation.A QueryRecord.PartialResult is a partial query record that contains recorded costs for a query operation.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.An IndexLookupRecord holds the recorded information about an index lookup performed during filter evaluation as part of a query record.A QueryRecord.RecordableStep is astep
that provides the ability to record the cost of evaluating a filter as part of a query operation.A QueryRecord.Step carries the recorded cost of evaluating a filter as part of a query operation.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.A thread-safe LongArray implementation for read heavy workloads but which is also efficient with frequent and/or bursty writes.Extends SafeLinkedList and adds recycling of Node objects.A RegistrationBehavior is used by numerous registries for the purpose of specifying the required behavior when registering an artifact.AResourceRegistry
is a registry and owner of strongly typed and explicitly named resources.TheResourceRegistry.ResourceLifecycleObserver
interface defines lifecycle handlers for resources registered with aResourceRegistry
.AResourceResolver
provides a mechanism to lookup and resolve optionally named, strongly typed resources.Provides helpful methods for working withResourceResolver
s.A collection of Collection implementation classes that limit the data type.A restricted Collection that requires its contents to be of a specified class.A restricted Collection that requires its contents to be of a specified class.A restricted List that requires its contents to be of a specified class.A restricted ListIterator that requires its contents to be of a specified class.A restricted Map that requires its keys and values to be of specified classes.A restricted Set that requires its contents to be of a specified class.A restricted SortedMap that requires its keys and values to be of specified classes.A restricted Set that requires its contents to be of a specified class.SafeClock maintains a "safe" time in milliseconds.SafeHashMap<K,V> An implementation of java.util.Map that is synchronized, but minimally so.SafeHashMap.Entry<K,V> A map entry (key-value pair).An implementation of java.util.Set that is synchronized, but minimally so.Implementation of the Collection Framework interface "List" using a linked list algorithm.A Node in the List.A thread-safe variant ofLongArray
in which is protected by a ReentrantLock.Implementation of aSortedMap
extendingConcurrentSkipListMap
to support null keys and null values.Entry set delegation of the super map implementation.Key set delegation of the super map implementation.Map.Entry implementation that supports null key/value placeholders.SubMap delegation to manageSafeSortedMap.NULL
in entry key and/or value.Values delegation of the super map implementation.Represents an exception of some sort has occurred while loading or executing scripts.An implementation of SegmentedHashMap that also implements the ConcurrentMap interface.ContentionObserver is used to observe the contention lock-related actions performed on the concurrent map.Action support for size().An implementation of java.util.Map that is optimized for heavy concurrent use.Action support for containsValue().A map entry (key-value pair).An EntryAction encapsulates a logical action to be executed in the context of a key (that may or may not exist in the map).EntryActionAdapter is a convenience class that provides default implementations for the EntryAction and IterableEntryAction interface methods.IterableEntryAction is an EntryAction that is suitable for applying to all keys in a map.Segment metadata.An implementation of java.util.Set that is optimized for heavy concurrent use.A Service is a Controllable that emits service lifecycle events.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.The listener interface for receiving ServiceEvents.SetMap<K,V> Provide a generic implementation of an array enumerator.SimpleHolder<V>General purpose container that can be used as an accumulator for any reference type.An implementation of LongArray that stores values in an array, thus is actually an "IntArray".SimpleMapEntry<K,V> A map entry (key-value pair).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.A statefulcalculator
used to calculate the cost of a homogeneous index (holding all values of a single type).The CalculatorState identifies the method used by the calculator to calculate the cost of a key or a value type.Simple QueryRecord implementation.Simple QueryRecord.PartialResult implementation.Simple QueryRecord.PartialResult.IndexLookupRecord implementation.Simple QueryRecord.PartialResult.Step implementation.Simple query record reporter used to obtain a string representation ofQueryRecord
object.ASimpleResourceRegistry
is a basic implementation of aResourceRegistry
.A simple implementation of aResourceResolver
.A LIFO (last in, first out) unbounded stack of objects.Simple implementation of aStreamer
.The Sizable interface is implemented by types that are capable of calculating the memory footprint of an instance.SortedBag<E>SortedBag is a multiset or bag implementation that supports sorted traversal of the contained elements and is optimized for insertions and removals.Sorts the contents of the passed enumerator then enumerates those contents.SparseArray<V>A data structure resembling an Object array indexed by long values.Node mapping long key to Object value.Streamer<T>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.Like a hash table, but built specifically for strings.SubList<T>Implements a list which is based on another list, represents a sub-list of the underlying list.SubSet<E>Implements a set which is based on another set, which is assumed to be immutable.SynchronousListener<K,V> A tag interface indicating that a listener implementation has to receive the event notifications synchronously on the corresponding service's thread.A Daemon thread handler that asynchronously executes Runnable tasks, either at a scheduled time or "as soon as possible".Factory interface for Thread creation.ThreadGate<R>A thin extension ofThreadGate
.ThreadGateLite is a Gate implementation built around theReentrantReadWriteLock
.Bar represents the state of thebars
placed on this gate.This class provides an implementation of thread local storage.ConcurrentMap with additional transaction support.A callback interface used by TransactionMap implementations.A thread-safe balanced binary search tree.A UID is a 128-bit identifier that is almost guaranteed to be unique.UniversalManipulator implementation.A collection of "back-door" utilities and helpers used internally.A UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique.ValueExtractor<T,E> 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<T,V> ValueManipulator represents a composition ofValueExtractor
andValueUpdater
implementations.ValueUpdater<T,U> ValueUpdater is used to update an object's state.Versionable<T extends Comparable<? super T>>An interface for versionable data.A collection of abstract Collection implementation classes for wrapping Collection types.Collection implementation which delegates all calls to another Collection.Map.Entry implementation which delegates all calls to another Map.Entry.Iterator implementation which delegates all calls to another Iterator.List implementation which delegates all calls to another List.Abstract wrapper implementation for LongArrays.Map implementation which delegates all calls to another Map.Set implementation which delegates all calls to another Set.SortedSet implementation which delegates all calls to another SortedSet.Collection implementation which uses a ReadWriteLock to manage concurrent access to an underlying Collection.Map Entry implementation which uses a ReadWriteLock to manage concurrent access to an underlying Map Entry.Map Entry Set implementation which uses a ReadWriteLock to manage concurrent access to the underlying Entry objects.Map implementation which uses a ReadWriteLock to manage concurrent access to an underlying Map.Set implementation which uses a ReadWriteLock to manage concurrent access to an underlying Set.WrapperConcurrentMap<K,V> A simple implementation of ConcurrentMap interface built as a wrapper around any Map implementation.A lock object.A WrapperException wraps a Throwable object as a RuntimeException.WrapperObservableMap<K,V> A simple implementation of ObservableMap interface built as a wrapper around any Map implementation.A Gate implementation that allows for 2^31 reentrant enter calls by a single thread.
AbstractStableIterator