Uses of Interface
com.tangosol.io.pof.PortableObject
-
Packages that use PortableObject Package Description 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.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.jcache Contains classes related to Coherence JCache.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.jcache.remotecache Contains classes related to remote cache implementation of Coherence JCache.com.tangosol.coherence.rest.util Contains packages and classes related to the Coherence REST API utilities.com.tangosol.coherence.rest.util.extractor Contains classes related to REST-based extractor.com.tangosol.coherence.rest.util.updater Contains classes related to REST-based updater.com.tangosol.config.expression Defines classes and interfaces for representing and evaluating expressions.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.net Contains basic cluster interfaces and factories.com.tangosol.net.cache Contains classes providing various caching strategies.com.tangosol.net.partition Contains interfaces and classes related to partitioned 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.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.processor Contains concreteInvocableMap.EntryProcessor
implementations.com.tangosol.util.transformer Contains concreteMapEventTransformer
implementations. -
-
Uses of PortableObject in com.oracle.coherence.concurrent
Classes in com.oracle.coherence.concurrent that implement PortableObject Modifier and Type Class Description class
PermitAcquirer
The identity of a acquirer, represented by the UUID of the member, and the ID of a thread holding or attempting to acquire permit. -
Uses of PortableObject in com.oracle.coherence.concurrent.locks
Classes in com.oracle.coherence.concurrent.locks that implement PortableObject Modifier and Type Class Description class
LockOwner
The identity of a lock owner, represented by the UID of the member, and the ID of a thread holding or attempting to acquire the lock. -
Uses of PortableObject in com.tangosol.coherence.config
Classes in com.tangosol.coherence.config that implement PortableObject Modifier and Type Class Description class
ParameterMacroExpression<T>
AParameterMacroExpression
is anExpression
representing the use of a Coherence Parameter Macro, typically occurring with in a Coherence Cache Configuration file.class
ResolvableParameterList
AResolvableParameterList
is aParameterList
implementation that additionally supports name-basedParameter
resolution as defined by theParameterResolver
interface.class
SimpleParameterList
ASimpleParameterList
is a simple implementation ofParameterList
. -
Uses of PortableObject in com.tangosol.coherence.config.builder
Classes in com.tangosol.coherence.config.builder that implement PortableObject Modifier and Type Class Description class
InstanceBuilder<T>
AnInstanceBuilder
is aParameterizedBuilder
implementation that additionally supports injection based on Coherence <instance%gt; or <class-scheme> configurations.class
StaticFactoryInstanceBuilder<T>
AStaticFactoryInstanceBuilder
is aParameterizedBuilder
that has been configured to realize objects based on the properties defined by an <instance> configuration element that uses the static <class-factory-name> approach. -
Uses of PortableObject in com.tangosol.coherence.jcache
Classes in com.tangosol.coherence.jcache that implement PortableObject Modifier and Type Class Description class
AbstractCoherenceBasedCompleteConfiguration<K,V>
A base implementation of aCoherenceBasedCompleteConfiguration
. -
Uses of PortableObject in com.tangosol.coherence.jcache.common
Classes in com.tangosol.coherence.jcache.common that implement PortableObject Modifier and Type Class Description class
CoherenceEntryProcessorResult<T>
A Coherence-basedEntryProcessorResult
.class
ContextJCacheStatistics
JCache Statistics implementation.class
JCacheEntryMetaInf
Represents the JCache metadata for a key and value pair stored in aCache
.class
JCacheIdentifier
An internal class to represent the unique identity of a JCache cache.class
NonSyntheticEntryFilter<T>
Server side filter to filter out both coherence and jcache synthetic events. -
Uses of PortableObject in com.tangosol.coherence.jcache.localcache
Classes in com.tangosol.coherence.jcache.localcache that implement PortableObject Modifier and Type Class Description static class
LocalCacheAsynchronousMapListener.NonSyntheticEntryFilter
Server side filter to filter out both coherence and jcache synthetic events.class
LocalCacheConfiguration<K,V>
AConfiguration
for aCache
based on a Coherence <local-scheme>, or more specifically an in-processNamedCache
. -
Uses of PortableObject in com.tangosol.coherence.jcache.partitionedcache
Classes in com.tangosol.coherence.jcache.partitionedcache that implement PortableObject Modifier and Type Class Description static class
PartitionedCacheAsynchronousMapListener.NonSyntheticEntryFilter
NonSyntheticEntryFilterclass
PartitionedCacheConfiguration<K,V>
AConfiguration
for aCache
based on a Coherence <distributed-scheme> or more specifically a partitioned (aka: distributed)NamedCache
.static class
PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter<T>
Server side filter for JCache ExpiryCacheEvents.static class
PartitionedJCacheStatistics.CacheStatisticsExtractor
Get CacheStatistics from binEntry's context for JCache id.static class
PartitionedJCacheStatistics.PartitionedCacheStatisticsAggregator
Collect JCache CacheStatistics from all storage-enabled members.static class
PartitionedJCacheStatistics.PartitionedCacheStatisticsClear
Clear JCache CacheStatistics from all storage-enabled members. -
Uses of PortableObject in com.tangosol.coherence.jcache.passthroughcache
Classes in com.tangosol.coherence.jcache.passthroughcache that implement PortableObject Modifier and Type Class Description class
PassThroughFilterAdapter<K,V>
-
Uses of PortableObject in com.tangosol.coherence.jcache.remotecache
Classes in com.tangosol.coherence.jcache.remotecache that implement PortableObject Modifier and Type Class Description class
RemoteCacheConfiguration<K,V>
AConfiguration
for aCache
based on a Coherence <remote-scheme>, or more specifically aNamedCache
. -
Uses of PortableObject in com.tangosol.coherence.rest.util
Classes in com.tangosol.coherence.rest.util that implement PortableObject Modifier and Type Class Description class
MvelManipulator
MVEL-based ValueManipulator implementation.class
PropertySet<T>
Represents a set of named properties and allows the extraction of those properties from a target object.class
PropertySpec
Specification for a single property.class
StaticContent
A simple representation of static content, which is used as a pass-through storage format for content other than JSON. -
Uses of PortableObject in com.tangosol.coherence.rest.util.extractor
Classes in com.tangosol.coherence.rest.util.extractor that implement PortableObject Modifier and Type Class Description class
MvelExtractor
MVEL-based ValueExtractor implementation. -
Uses of PortableObject in com.tangosol.coherence.rest.util.updater
Classes in com.tangosol.coherence.rest.util.updater that implement PortableObject Modifier and Type Class Description class
MvelUpdater
MVEL-based ValueUpdater implementation. -
Uses of PortableObject in com.tangosol.config.expression
Classes in com.tangosol.config.expression that implement PortableObject Modifier and Type Class Description class
ChainedParameterResolver
AChainedParameterResolver
is aParameterResolver
that consults zero or more providedParameterResolver
s in the order in which they were defined or added to resolve aParameter
.class
LiteralExpression<T>
ALiteralExpression
is a literal (aka: constant)Expression
.class
NullParameterResolver
class
Parameter
AParameter
represents an optionally named and optionally explicitly typedExpression
.class
ScopedParameterResolver
AScopedParameterResolver
is aParameterResolver
implementation that provides the ability to "scope"Parameter
definitions to either an inner (wrapped) or outerParameterResolver
, such that those being defined in the outerParameterResolver
hide those (of the same name) in the inner (wrapped)ParameterResolver
.class
ValueMacroExpression
AValueMacroExpression
is a string value potentially containing expandable macros. -
Uses of PortableObject in com.tangosol.io.pof
Subinterfaces of PortableObject in com.tangosol.io.pof Modifier and Type Interface Description interface
EvolvablePortableObject
Extension of thePortableObject
interface that supports forwards- and backwards-compatibility of POF data streams.Classes in com.tangosol.io.pof that implement PortableObject Modifier and Type Class Description class
PortableException
APortableException
is an exception that allows information about a remote exception or error to be serialized and deserialized to/from aPOF
stream.Methods in com.tangosol.io.pof with parameters of type PortableObject Modifier and Type Method Description void
PortableObjectSerializer. initialize(PortableObject portable, PofReader in)
Initialize the specified (newly instantiated) PortableObject instance using the specified reader. -
Uses of PortableObject in com.tangosol.io.pof.reflect
Classes in com.tangosol.io.pof.reflect that implement PortableObject Modifier and Type Class Description class
AbstractPofPath
Abstract base class for static, path-based implementations ofPofNavigator
interface.class
SimplePofPath
A staticPofNavigator
implementation which uses an array of integer indices to navigate the PofValue hierarchy. -
Uses of PortableObject in com.tangosol.net
Classes in com.tangosol.net that implement PortableObject Modifier and Type Class Description class
AbstractPriorityTask
An abstract base for PriorityTask implementations.class
RequestIncompleteException
Signals that a request execution in a distributed environment failed to complete successfully.class
RequestPolicyException
Signals that a request was not allowed to complete due to the related service action being disallowed by the corresponding ActionPolicy.class
RequestTimeoutException
Signals that a request execution in a distributed environment did not complete in a pre-determined amount of time. -
Uses of PortableObject in com.tangosol.net.cache
Classes in com.tangosol.net.cache that implement PortableObject Modifier and Type Class Description class
CacheEvent<K,V>
An extension of the MapEvent which allows to differentiate between client driven (natural) events and cache internal (synthetic) events.protected static class
OverflowMap.HistoricCacheEvent
A CacheEvent that carries a recent value (to avoid it being lost during eviction). -
Uses of PortableObject in com.tangosol.net.partition
Classes in com.tangosol.net.partition that implement PortableObject Modifier and Type Class Description class
DefaultVersionedPartitions
Default implementation ofVersionedPartitions
,class
Ownership
Ownership is a light-weight data structure that contains a partition ownership information.class
PartitionSet
PartitionSet is a light-weight data structure that represents a set of partitions that are used in parallel processing.class
SimplePartitionKey
SimplePartitionKey is a trivialPartitionAwareKey
implementation.class
VersionedOwnership
An extension of the partition Ownership object which also carries a change version. -
Uses of PortableObject in com.tangosol.net.security
Classes in com.tangosol.net.security that implement PortableObject Modifier and Type Class Description class
PermissionInfo
PermissionInfo holds the information needed to validate and respond to a security related request. -
Uses of PortableObject in com.tangosol.net.topic
Classes in com.tangosol.net.topic that implement PortableObject Modifier and Type Class Description static class
Publisher.FailOnFull
The FailOnFull option indicates that theCompletableFuture
returned from thePublisher.publish(V)
operation should complete exceptionally upon identifying that the topic is or has become full.static class
Publisher.OrderBy<V>
The OrderBy option specifies the ordering of async operations with respect to one another.static class
Publisher.OrderById<V>
Publisher.OrderBy
option ensures ordering ofsent values
across all threads which share the sameorderId
.static class
Publisher.OrderByNone<V>
Publisher.OrderBy
option enforces no specific ordering betweensent values
allowing for the greatest level of parallelism.static class
Publisher.OrderByRoundRobin<V>
Publisher.OrderBy
option which computes the unit-of-order such that each message is sent to the next channel in a round-robin order.static class
Publisher.OrderByThread<V>
Publisher.OrderBy
option which ensures that a sequence ofsent values
issued by a single thread will complete in order.static class
Publisher.OrderByValue<V>
Publisher.OrderBy
option which computes the unit-of-order based on applyingconstructor's
orderIdFunction parameter
onsent value
.static class
Subscriber.CommitResult
The result of a commit request.static class
Subscriber.CompleteOnEmpty<V>
The CompleteOnEmpty option indicates that theCompletableFuture
returned from theSubscriber.receive()
operation should complete with a nullSubscriber.Element
upon identifying that the topic is or has become empty.static class
Subscriber.Convert<V,U>
The Convert option specifies aValueExtractor
that will convert topic values that a subscriber is interested in receiving prior to sending them to the subscriber.static class
Subscriber.Filtered<V>
The Filtered option specifies a filter that will determine which topic values a subscriber is interested in receiving.static class
Subscriber.Name<V>
The Name option is used to specify a subscriber group name. -
Uses of PortableObject in com.tangosol.run.xml
Classes in com.tangosol.run.xml that implement PortableObject Modifier and Type Class Description class
SimpleDocument
A simple implementation of the XmlElement interface.class
SimpleElement
A simple implementation of the XmlElement interface.class
SimpleValue
A simple implementation of the XmlValue interface. -
Uses of PortableObject in com.tangosol.util
Classes in com.tangosol.util that implement PortableObject Modifier and Type Class Description protected static class
AbstractKeyBasedMap.DeferredCacheEvent<K,V>
A DeferredCacheEvent is aCacheEvent
object that defers the loading of theold value
.class
AbstractScript
AbstractScriptBase is the base class for script based processing.class
CompositeKey<P,S>
Key class that consists of a primary and secondary component.static class
ConverterCollections.ConverterCacheEvent<K,V>
A Converter CacheEvent views an underlying CacheEvent through a set of key and value Converters.static class
ConverterCollections.ConverterMapEvent<K,V>
A ConverterMapEvent views an underlying MapEvent through a set of key and value Converters.class
Fragment<T>
An object that represents a fragment of another object.class
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.static class
MapListenerSupport.FilterEvent
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.class
NullFilter
Filter which discards null references.static class
NullImplementation.NullEntryProcessor
An implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.static class
NullImplementation.NullMap
A Map that contains nothing and does nothing.static class
NullImplementation.NullObservableMap
An immutable ObservableMap which contains nothing.static class
NullImplementation.NullSet
An immutable set which contains nothing.static class
NullImplementation.NullValueExtractor
A ValueExtractor that always results in the passed-in value.class
SimpleHolder<V>
General purpose container that can be used as an accumulator for any reference type.class
SimpleQueryRecord
Simple QueryRecord implementation.static class
SimpleQueryRecord.PartialResult
Simple QueryRecord.PartialResult implementation.class
SimpleQueryRecord.PartialResult.AbstractRecordableStep
Simple abstract RecordableStep implementation.class
SimpleQueryRecord.PartialResult.ExplainStep
Simple QueryRecord.PartialResult.ExplainStep implementation.static class
SimpleQueryRecord.PartialResult.IndexLookupRecord
Simple QueryRecord.PartialResult.IndexLookupRecord implementation.static class
SimpleQueryRecord.PartialResult.Step
Simple QueryRecord.PartialResult.Step implementation.class
SimpleQueryRecord.PartialResult.TraceStep
Simple QueryRecord.PartialResult.TraceStep implementation.class
UID
A UID is a 128-bit identifier that is almost guaranteed to be unique.class
UUID
A UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique. -
Uses of PortableObject in com.tangosol.util.aggregator
Classes in com.tangosol.util.aggregator that implement PortableObject Modifier and Type Class Description class
AbstractAggregator<K,V,T,E,R>
Abstract base class implementation ofInvocableMap.EntryAggregator
that supports streaming aggregation.class
AbstractBigDecimalAggregator<T>
Abstract aggregator that processesNumber
values extracted from a set of entries in a Map and returns a result in a form of aBigDecimal
value.class
AbstractComparableAggregator<T,R>
Abstract aggregator that processes values extracted from a set of entries in a Map, with knowledge of how to compare those values.class
AbstractDoubleAggregator<T>
Abstract aggregator that processes numeric values extracted from a set of entries in a Map.class
AbstractLongAggregator<T>
Abstract aggregator that processes numeric values extracted from a set of entries in a Map.class
BigDecimalAverage<T>
Calculates an average for values of any numeric type extracted from a set of entries in a Map in a form of aBigDecimal
value.class
BigDecimalMax<T>
Calculates a maximum of numeric values extracted from a set of entries in a Map in a form of aBigDecimal
value.class
BigDecimalMin<T>
Calculates a minimum of numeric values extracted from a set of entries in a Map in a form of aBigDecimal
value.class
BigDecimalSum<T>
Calculates an sum for values of any numberic type extracted from a set of entries in a Map in a form of aBigDecimal
value.class
ComparableMax<T,R>
Calculates a maximum among values extracted from a set of entries in a Map.class
ComparableMin<T,R>
Calculates a minimum among values extracted from a set of entries in a Map.class
CompositeAggregator<K,V>
CompositeAggregator provides an ability to execute a collection of aggregators against the same subset of the entries in an InvocableMap, resulting in a list of corresponding aggregation results.static class
CompositeAggregator.Parallel
Deprecated.As of Coherence 12.2.1.class
Count<K,V>
Calculates a number of values in an entry set.class
DistinctValues<K,V,T,E>
Return the set of unique values extracted from a set of entries in a Map.class
DoubleAverage<T>
Calculates an average for values of any numeric type extracted from a set of entries in a Map.class
DoubleMax<T>
Calculates a maximum of numeric values extracted from a set of entries in a Map.class
DoubleMin<T>
Calculates a minimum of numeric values extracted from a set of entries in a Map.class
DoubleSum<T>
Sums up numeric values extracted from a set of entries in a Map.class
GroupAggregator<K,V,T,E,R>
The GroupAggregator provides an ability to split a subset of entries in an InvocableMap into a collection of non-intersecting subsets and then aggregate them separately and independently.static class
GroupAggregator.Parallel<K,V,T,E,R>
Deprecated.As of Coherence 12.2.1.class
LongMax<T>
Calculates a maximum of numeric values extracted from a set of entries in a Map.class
LongMin<T>
Calculates a minimum of numeric values extracted from a set of entries in a Map.class
LongSum<T>
Sums up numeric values extracted from a set of entries in a Map.class
PriorityAggregator<K,V,P,R>
PriorityAggregator is used to explicitly control the scheduling priority and timeouts for execution of EntryAggregator-based methods.class
QueryRecorder<K,V>
This aggregator is used to produce aQueryRecord
object that contains an estimated or actual cost of the query execution for a given filter.class
ReducerAggregator<K,V,T,E>
The ReducerAggregator is used to implement functionality similar toCacheMap.getAll(Collection)
API.class
ScriptAggregator<K,V,P,R>
ScriptAggregator is aInvocableMap.StreamingAggregator
that wraps a script written in one of the languages supported by Graal VM.class
TopNAggregator<K,V,T,E>
TopNAggregator is a ParallelAwareAggregator that aggregates the top N extracted values into an array.static class
TopNAggregator.PartialResult<E>
The sorted partial result. -
Uses of PortableObject in com.tangosol.util.comparator
Classes in com.tangosol.util.comparator that implement PortableObject Modifier and Type Class Description class
ChainedComparator<T>
Composite comparator implementation based on a collection of comparators.class
EntryComparator
Comparator implementation used to compare map entries.class
ExtractorComparator<T>
Comparator implementation that uses specifiedValueExtractor
to extract value(s) to be used for comparison.class
InverseComparator<T>
Comparator that reverses the result of another comparator.class
SafeComparator<T>
Null-safe delegating comparator. -
Uses of PortableObject in com.tangosol.util.extractor
Classes in com.tangosol.util.extractor that implement PortableObject Modifier and Type Class Description class
AbstractCompositeExtractor<T,E>
Abstract super class for ValueExtractor implementations that are based on an underlying array of ValueExtractor objects.class
ChainedExtractor<T,E>
Composite ValueExtractor implementation based on an array of extractors.class
ChainedFragmentExtractor<T,E>
AValueExtractor
that extracts aFragment
from a nested property of the target object.class
ComparisonValueExtractor<T,E extends Number>
A synthetic ValueExtractor that returns a result of comparison between two values extracted from the same target.class
CompositeUpdater
A ValueUpdater implementation based on an extractor-updater pair that could also be used as a ValueManipulator.class
ConditionalExtractor<T,E>
An IndexAwareExtractor implementation that is only used to create aConditionalIndex
.class
DeserializationAccelerator
DeserializationAccelerator is anIndexAwareExtractor
implementation that is used to create aForwardOnlyMapIndex
, which in turn is used for deserialization optimization.class
EntryExtractor
The EntryExtractor is a base abstract class for special purpose custom ValueExtractor implementations.class
FragmentExtractor<T>
AValueExtractor
that is used to extract aFragment
from an object.class
IdentityExtractor<T>
Trivial ValueExtractor implementation that does not actually extract anything from the passed value, but returns the value itself.class
KeyExtractor<T,E>
The KeyExtractor is a special purpose ValueExtractor implementation that serves as an indicator that a query should be run against the key objects rather than the values.class
MultiExtractor
Composite ValueExtractor implementation based on an array of extractors.class
PofExtractor<T,E>
POF-based ValueExtractor implementation.class
PofUpdater
POF-based ValueUpdater implementation.class
ReflectionExtractor<T,E>
Reflection-based ValueExtractor implementation.class
ReflectionUpdater
Reflection-based ValueUpdater implementation.class
ScriptValueExtractor<T,E>
ScriptValueExtractor is anAbstractExtractor
that wraps a script written in one of the languages supported by Graal VM.class
UniversalExtractor<T,E>
Universal ValueExtractor implementation.class
UniversalUpdater
Universal ValueUpdater implementation. -
Uses of PortableObject in com.tangosol.util.filter
Classes in com.tangosol.util.filter that implement PortableObject Modifier and Type Class Description class
AllFilter
Filter which returns the logical "and" of a filter array.class
AlwaysFilter<T>
Filter which always evaluates to true.class
AndFilter
Filter which returns the logical "and" of two other filters.class
AnyFilter
Filter which returns the logical "or" of a filter array.class
ArrayFilter
Filter which is a logical operator of a filter array.class
BetweenFilter<T,E extends Comparable<? super E>>
Filter which compares the result of a method invocation with a value for "Between" condition.class
CacheEventFilter<K,V>
An extension of theMapEventFilter
which allows selection of client driven (natural) events, cache internal (synthetic) events, or both.class
ComparisonFilter<T,E,C>
Filter which compares the result of a method invocation with a value.class
ContainsAllFilter<T,E>
Filter which tests aCollection
or Object array value returned from a method invocation for containment of all values in a Set.class
ContainsAnyFilter<T,E>
Filter which tests aCollection
or Object array value returned from a method invocation for containment of any value in a Set.class
ContainsFilter<T,E>
Filter which tests aCollection
or Object array value returned from a method invocation for containment of a given value.class
EqualsFilter<T,E>
Filter which compares the result of a method invocation with a value for equality.class
ExtractorFilter<T,E>
Base Filter implementation for doing extractor-based processing.class
FilterTrigger
A generic Filter-based MapTrigger implementation.class
GreaterEqualsFilter<T,E extends Comparable<? super E>>
Filter which compares the result of a method invocation with a value for "Greater or Equal" condition.class
GreaterFilter<T,E extends Comparable<? super E>>
Filter which compares the result of a method invocation with a value for "Greater" condition.class
InFilter<T,E>
Filter which checks whether the result of a method invocation belongs to a predefined set of values.class
InKeySetFilter<T>
Filter that limits the underlying filter evaluation only to the specified set of keys.class
IsNotNullFilter<T,E>
Filter which tests the result of a method invocation for inequality to null.class
IsNullFilter<T,E>
Filter which compares the result of a method invocation with null.class
KeyAssociatedFilter<T>
Filter which limits the scope of another filter according to the key association information.class
LessEqualsFilter<T,E extends Comparable<? super E>>
Filter which compares the result of a method invocation with a value for "Less or Equals" condition.class
LessFilter<T,E extends Comparable<? super E>>
Filter which compares the result of a method invocation with a value for "Less" condition.class
LikeFilter<T,E>
Filter which compares the result of a method invocation with a value for pattern match.class
LimitFilter<T>
Filter which truncates the results of another filter.class
MapEventFilter<K,V>
Filter which evaluates the content of a MapEvent object according to the specified criteria.class
MapEventTransformerFilter<T>
MapEventTransformerFilter is a generic multiplexing wrapper that combines two implementations: a Filter (most commonly aMapEventFilter
) and a MapEventTransformer and is used to register event listeners that allow to change the content of a MapEvent.class
NeverFilter<T>
Filter which always evaluates to false.class
NotEqualsFilter<T,E>
Filter which compares the result of a method invocation with a value for inequality.class
NotFilter<T>
Filter which negates the results of another filter.class
OrFilter
Filter which returns the logical "or" of two other filters.class
PartitionedFilter<T>
Filter which limits the scope of another filter to those entries that have keys that belong to the specified partition set.class
PredicateFilter<T,E>
Ajava.util.function.Predicate
basedExtractorFilter
.class
PresentFilter<T>
Filter which returns true forInvocableMap.Entry
objects that currently exist in a Map.class
PriorityFilter<T>
PriorityFilter is used to explicitly control the scheduling priority and timeouts for execution of filter-based methods.class
RegexFilter<T,E>
Filter which uses the regular expression pattern match defined by thePattern.matches(String, CharSequence)
contract.class
ScriptFilter<V>
ScriptFilter is aFilter
that wraps a script written in one of the languages supported by Graal VM.class
ValueChangeEventFilter<V,E>
Filter which evaluates the content of a MapEvent values based on the specified value extractor.class
XorFilter
Filter which returns the logical exclusive or ("xor") of two other filters. -
Uses of PortableObject in com.tangosol.util.processor
Classes in com.tangosol.util.processor that implement PortableObject Modifier and Type Class Description class
AbstractEvolvableProcessor<K,V,R>
An Evolvable AbstractProcessor that is a partial EntryProcessor implementation that provides the default implementation of theAbstractEvolvableProcessor.processAll(java.util.Set<? extends com.tangosol.util.InvocableMap.Entry<K, V>>)
method.class
CompositeProcessor<K,V>
The CompositeProcessor represents a collection of entry processors that are invoked sequentially against the same Entry.class
ConditionalProcessor<K,V,T>
Conditional entry processor represents a processor that is invoked conditionally based on the result of an entry evaluation.class
ConditionalPut<K,V>
ConditionalPut is an EntryProcessor that performs anEntry.setValue
operation if the specified condition is satisfied.class
ConditionalPutAll<K,V>
ConditionalPutAll is an EntryProcessor that performs aEntry.setValue
operation for multiple entries that satisfy the specified condition.class
ConditionalRemove<K,V>
ConditionalRemove is an EntryProcessor that performs anEntry.remove
operation if the specified condition is satisfied.class
ExtractorProcessor<K,V,T,E>
ExtractorProcessor is an EntryProcessor implementations that extracts a value from an object cached in an InvocableMap.class
MethodInvocationProcessor<K,V,R>
An entry processor that invokes specified method on a value of a cache entry and optionally updates the entry with a modified value.class
NumberIncrementor<K,V,N extends Number>
The NumberIncrementor entry processor is used to increment a property value of aNumber
type.class
NumberMultiplier<K,V,N extends Number>
The NumberMultiplier entry processor is used to multiply a property value of aNumber
type.class
PreloadRequest<K,V>
PreloadRequest is a simple EntryProcessor that performs aEntry.getValue
call.class
PriorityProcessor<K,V,T>
PriorityProcessor is used to explicitly control the scheduling priority and timeouts for execution of EntryProcessor-based methods.class
PropertyManipulator<V,R>
PropertyManipulator is a reflection based ValueManipulator implementation based on the JavaBean property name conventions.class
PropertyProcessor<K,V,R>
PropertyProcessor is a base class for EntryProcessor implementations that depend on a ValueManipulator.class
ScriptProcessor<K,V,R>
ScriptProcessor is anInvocableMap.EntryProcessor
that wraps a script written in one of the languages supported by Graal VM.class
TouchProcessor
Touches an entry (if present) in order to trigger interceptor re-evaluation and possibly increment expiry time.class
UpdaterProcessor<K,V,T>
UpdaterProcessor is an EntryProcessor implementations that updates an attribute of an object cached in an InvocableMap.class
VersionedPut<K,V extends Versionable>
VersionedPut is an EntryProcessor that assumes that entry values implementVersionable
interface and performs anEntry.setValue
operation if and only if the version of the specified value matches to the version of the current value.class
VersionedPutAll<K,V extends Versionable>
VersionedPutAll is an EntryProcessor that assumes that entry values implementVersionable
interface and performs anEntry.setValue
operation only for entries whose versions match to versions of the corresponding current values. -
Uses of PortableObject in com.tangosol.util.transformer
Classes in com.tangosol.util.transformer that implement PortableObject Modifier and Type Class Description class
ExtractorEventTransformer<K,V,E>
ExtractorEventTransformer is a special purposeMapEventTransformer
implementation that transforms emitted events, extracting one or more properties from either the OldValue or the NewValue.class
SamplingEventTransformer<K,V>
AMapEventTransformer
implementation which will send at most one event per storage member per sampling interval, in order to throttle down the number of events received by the slow consumer.class
SemiLiteEventTransformer<K,V>
SemiLiteEventTransformer is a special purpose MapEventTransformer implementation that removes an OldValue from the MapEvent object for the purpose of reducing the amount of data that has to be sent over the network to event consumers.
-