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.messaging Contains exception classes related to connection error.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.EntryAggregatorimplementations.com.tangosol.util.comparator Contains concreteComparatorimplementations and related interfaces.com.tangosol.util.extractor ContainsValueExtractorandValueUpdaterrelated classes.com.tangosol.util.filter Contains concreteFilterimplementations and related interfaces.com.tangosol.util.processor Contains concreteInvocableMap.EntryProcessorimplementations.com.tangosol.util.transformer Contains concreteMapEventTransformerimplementations.
- 
- 
Uses of PortableObject in com.oracle.coherence.concurrentClasses in com.oracle.coherence.concurrent that implement PortableObject Modifier and Type Class Description classPermitAcquirerThe 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.locksClasses in com.oracle.coherence.concurrent.locks that implement PortableObject Modifier and Type Class Description classLockOwnerThe 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.configClasses in com.tangosol.coherence.config that implement PortableObject Modifier and Type Class Description classParameterMacroExpression<T>AParameterMacroExpressionis anExpressionrepresenting the use of a Coherence Parameter Macro, typically occurring with in a Coherence Cache Configuration file.classResolvableParameterListAResolvableParameterListis aParameterListimplementation that additionally supports name-basedParameterresolution as defined by theParameterResolverinterface.classSimpleParameterListASimpleParameterListis a simple implementation ofParameterList.
- 
Uses of PortableObject in com.tangosol.coherence.config.builderClasses in com.tangosol.coherence.config.builder that implement PortableObject Modifier and Type Class Description classInstanceBuilder<T>AnInstanceBuilderis aParameterizedBuilderimplementation that additionally supports injection based on Coherence <instance%gt; or <class-scheme> configurations.classStaticFactoryInstanceBuilder<T>AStaticFactoryInstanceBuilderis aParameterizedBuilderthat 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.jcacheClasses in com.tangosol.coherence.jcache that implement PortableObject Modifier and Type Class Description classAbstractCoherenceBasedCompleteConfiguration<K,V>A base implementation of aCoherenceBasedCompleteConfiguration.
- 
Uses of PortableObject in com.tangosol.coherence.jcache.commonClasses in com.tangosol.coherence.jcache.common that implement PortableObject Modifier and Type Class Description classCoherenceEntryProcessorResult<T>A Coherence-basedEntryProcessorResult.classContextJCacheStatisticsJCache Statistics implementation.classJCacheEntryMetaInfRepresents the JCache metadata for a key and value pair stored in aCache.classJCacheIdentifierAn internal class to represent the unique identity of a JCache cache.classNonSyntheticEntryFilter<T>Server side filter to filter out both coherence and jcache synthetic events.
- 
Uses of PortableObject in com.tangosol.coherence.jcache.localcacheClasses in com.tangosol.coherence.jcache.localcache that implement PortableObject Modifier and Type Class Description static classLocalCacheAsynchronousMapListener.NonSyntheticEntryFilterServer side filter to filter out both coherence and jcache synthetic events.classLocalCacheConfiguration<K,V>AConfigurationfor aCachebased on a Coherence <local-scheme>, or more specifically an in-processNamedCache.
- 
Uses of PortableObject in com.tangosol.coherence.jcache.partitionedcacheClasses in com.tangosol.coherence.jcache.partitionedcache that implement PortableObject Modifier and Type Class Description static classPartitionedCacheAsynchronousMapListener.NonSyntheticEntryFilterNonSyntheticEntryFilterclassPartitionedCacheConfiguration<K,V>AConfigurationfor aCachebased on a Coherence <distributed-scheme> or more specifically a partitioned (aka: distributed)NamedCache.static classPartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter<T>Server side filter for JCache ExpiryCacheEvents.static classPartitionedJCacheStatistics.CacheStatisticsExtractorGet CacheStatistics from binEntry's context for JCache id.static classPartitionedJCacheStatistics.PartitionedCacheStatisticsAggregatorCollect JCache CacheStatistics from all storage-enabled members.static classPartitionedJCacheStatistics.PartitionedCacheStatisticsClearClear JCache CacheStatistics from all storage-enabled members.
- 
Uses of PortableObject in com.tangosol.coherence.jcache.passthroughcacheClasses in com.tangosol.coherence.jcache.passthroughcache that implement PortableObject Modifier and Type Class Description classPassThroughFilterAdapter<K,V>
- 
Uses of PortableObject in com.tangosol.coherence.jcache.remotecacheClasses in com.tangosol.coherence.jcache.remotecache that implement PortableObject Modifier and Type Class Description classRemoteCacheConfiguration<K,V>AConfigurationfor aCachebased on a Coherence <remote-scheme>, or more specifically aNamedCache.
- 
Uses of PortableObject in com.tangosol.coherence.rest.utilClasses in com.tangosol.coherence.rest.util that implement PortableObject Modifier and Type Class Description classMvelManipulatorMVEL-based ValueManipulator implementation.classPropertySet<T>Represents a set of named properties and allows the extraction of those properties from a target object.classPropertySpecSpecification for a single property.classStaticContentA 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.extractorClasses in com.tangosol.coherence.rest.util.extractor that implement PortableObject Modifier and Type Class Description classMvelExtractorMVEL-based ValueExtractor implementation.
- 
Uses of PortableObject in com.tangosol.coherence.rest.util.updaterClasses in com.tangosol.coherence.rest.util.updater that implement PortableObject Modifier and Type Class Description classMvelUpdaterMVEL-based ValueUpdater implementation.
- 
Uses of PortableObject in com.tangosol.config.expressionClasses in com.tangosol.config.expression that implement PortableObject Modifier and Type Class Description classChainedParameterResolverAChainedParameterResolveris aParameterResolverthat consults zero or more providedParameterResolvers in the order in which they were defined or added to resolve aParameter.classLiteralExpression<T>ALiteralExpressionis a literal (aka: constant)Expression.classNullParameterResolverclassParameterAParameterrepresents an optionally named and optionally explicitly typedExpression.classScopedParameterResolverAScopedParameterResolveris aParameterResolverimplementation that provides the ability to "scope"Parameterdefinitions to either an inner (wrapped) or outerParameterResolver, such that those being defined in the outerParameterResolverhide those (of the same name) in the inner (wrapped)ParameterResolver.classValueMacroExpressionAValueMacroExpressionis a string value potentially containing expandable macros.
- 
Uses of PortableObject in com.tangosol.io.pofSubinterfaces of PortableObject in com.tangosol.io.pof Modifier and Type Interface Description interfaceEvolvablePortableObjectExtension of thePortableObjectinterface that supports forwards- and backwards-compatibility of POF data streams.Classes in com.tangosol.io.pof that implement PortableObject Modifier and Type Class Description classPortableExceptionAPortableExceptionis an exception that allows information about a remote exception or error to be serialized and deserialized to/from aPOFstream.Methods in com.tangosol.io.pof with parameters of type PortableObject Modifier and Type Method Description voidPortableObjectSerializer. initialize(PortableObject portable, PofReader in)Initialize the specified (newly instantiated) PortableObject instance using the specified reader.
- 
Uses of PortableObject in com.tangosol.io.pof.reflectClasses in com.tangosol.io.pof.reflect that implement PortableObject Modifier and Type Class Description classAbstractPofPathAbstract base class for static, path-based implementations ofPofNavigatorinterface.classSimplePofPathA staticPofNavigatorimplementation which uses an array of integer indices to navigate the PofValue hierarchy.
- 
Uses of PortableObject in com.tangosol.netClasses in com.tangosol.net that implement PortableObject Modifier and Type Class Description classAbstractPriorityTaskAn abstract base for PriorityTask implementations.classRequestIncompleteExceptionSignals that a request execution in a distributed environment failed to complete successfully.classRequestPolicyExceptionSignals that a request was not allowed to complete due to the related service action being disallowed by the corresponding ActionPolicy.classRequestTimeoutExceptionSignals 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.cacheClasses in com.tangosol.net.cache that implement PortableObject Modifier and Type Class Description classCacheEvent<K,V>An extension of the MapEvent which allows to differentiate between client driven (natural) events and cache internal (synthetic) events.protected static classOverflowMap.HistoricCacheEventA CacheEvent that carries a recent value (to avoid it being lost during eviction).
- 
Uses of PortableObject in com.tangosol.net.messagingClasses in com.tangosol.net.messaging that implement PortableObject Modifier and Type Class Description classConnectionExceptionSignals that an underlying communication channel used by a Connection may have been closed, severed, or become unusable.classSuspectConnectionExceptionSignals that an underlying communication channel used by a Connection may have been closed, severed, or become unusable because the suspect protocol has disconnected the client.
- 
Uses of PortableObject in com.tangosol.net.partitionClasses in com.tangosol.net.partition that implement PortableObject Modifier and Type Class Description classDefaultVersionedPartitionsDefault implementation ofVersionedPartitions,classOwnershipOwnership is a light-weight data structure that contains a partition ownership information.classPartitionSetPartitionSet is a light-weight data structure that represents a set of partitions that are used in parallel processing.classSimplePartitionKeySimplePartitionKey is a trivialPartitionAwareKeyimplementation.classVersionedOwnershipAn extension of the partition Ownership object which also carries a change version.
- 
Uses of PortableObject in com.tangosol.net.securityClasses in com.tangosol.net.security that implement PortableObject Modifier and Type Class Description classPermissionInfoPermissionInfo holds the information needed to validate and respond to a security related request.
- 
Uses of PortableObject in com.tangosol.net.topicClasses in com.tangosol.net.topic that implement PortableObject Modifier and Type Class Description static classPublisher.FailOnFullThe FailOnFull option indicates that theCompletableFuturereturned from thePublisher.publish(V)operation should complete exceptionally upon identifying that the topic is or has become full.static classPublisher.OrderBy<V>The OrderBy option specifies the ordering of async operations with respect to one another.static classPublisher.OrderById<V>Publisher.OrderByoption ensures ordering ofsent valuesacross all threads which share the sameorderId.static classPublisher.OrderByNone<V>Publisher.OrderByoption enforces no specific ordering betweensent valuesallowing for the greatest level of parallelism.static classPublisher.OrderByRoundRobin<V>Publisher.OrderByoption which computes the unit-of-order such that each message is sent to the next channel in a round-robin order.static classPublisher.OrderByThread<V>Publisher.OrderByoption which ensures that a sequence ofsent valuesissued by a single thread will complete in order.static classPublisher.OrderByValue<V>Publisher.OrderByoption which computes the unit-of-order based on applyingconstructor'sorderIdFunction parameteronsent value.static classSubscriber.CommitResultThe result of a commit request.static classSubscriber.CompleteOnEmpty<V>The CompleteOnEmpty option indicates that theCompletableFuturereturned from theSubscriber.receive()operation should complete with a nullSubscriber.Elementupon identifying that the topic is or has become empty.static classSubscriber.Convert<V,U>The Convert option specifies aValueExtractorthat will convert topic values that a subscriber is interested in receiving prior to sending them to the subscriber.static classSubscriber.Filtered<V>The Filtered option specifies a filter that will determine which topic values a subscriber is interested in receiving.static classSubscriber.Name<V>The Name option is used to specify a subscriber group name.
- 
Uses of PortableObject in com.tangosol.run.xmlClasses in com.tangosol.run.xml that implement PortableObject Modifier and Type Class Description classSimpleDocumentA simple implementation of the XmlElement interface.classSimpleElementA simple implementation of the XmlElement interface.classSimpleValueA simple implementation of the XmlValue interface.
- 
Uses of PortableObject in com.tangosol.utilClasses in com.tangosol.util that implement PortableObject Modifier and Type Class Description protected static classAbstractKeyBasedMap.DeferredCacheEvent<K,V>A DeferredCacheEvent is aCacheEventobject that defers the loading of theold value.classAbstractScriptAbstractScriptBase is the base class for script based processing.classCompositeKey<P,S>Key class that consists of a primary and secondary component.static classConverterCollections.ConverterCacheEvent<K,V>A Converter CacheEvent views an underlying CacheEvent through a set of key and value Converters.static classConverterCollections.ConverterMapEvent<K,V>A ConverterMapEvent views an underlying MapEvent through a set of key and value Converters.classFragment<T>An object that represents a fragment of another object.classMapEvent<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 classMapListenerSupport.FilterEventAn 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.classNullFilterFilter which discards null references.static classNullImplementation.NullEntryProcessorAn implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.static classNullImplementation.NullMapA Map that contains nothing and does nothing.static classNullImplementation.NullObservableMapAn immutable ObservableMap which contains nothing.static classNullImplementation.NullSetAn immutable set which contains nothing.static classNullImplementation.NullValueExtractorA ValueExtractor that always results in the passed-in value.classSimpleHolder<V>General purpose container that can be used as an accumulator for any reference type.classSimpleQueryRecordSimple QueryRecord implementation.static classSimpleQueryRecord.PartialResultSimple QueryRecord.PartialResult implementation.classSimpleQueryRecord.PartialResult.AbstractRecordableStepSimple abstract RecordableStep implementation.classSimpleQueryRecord.PartialResult.ExplainStepSimple QueryRecord.PartialResult.ExplainStep implementation.static classSimpleQueryRecord.PartialResult.IndexLookupRecordSimple QueryRecord.PartialResult.IndexLookupRecord implementation.static classSimpleQueryRecord.PartialResult.StepSimple QueryRecord.PartialResult.Step implementation.classSimpleQueryRecord.PartialResult.TraceStepSimple QueryRecord.PartialResult.TraceStep implementation.classUIDA UID is a 128-bit identifier that is almost guaranteed to be unique.classUUIDA UUID is a 256-bit identifier that, if it is generated, is statistically guaranteed to be unique.
- 
Uses of PortableObject in com.tangosol.util.aggregatorClasses in com.tangosol.util.aggregator that implement PortableObject Modifier and Type Class Description classAbstractAggregator<K,V,T,E,R>Abstract base class implementation ofInvocableMap.EntryAggregatorthat supports streaming aggregation.classAbstractBigDecimalAggregator<T>Abstract aggregator that processesNumbervalues extracted from a set of entries in a Map and returns a result in a form of aBigDecimalvalue.classAbstractComparableAggregator<T,R>Abstract aggregator that processes values extracted from a set of entries in a Map, with knowledge of how to compare those values.classAbstractDoubleAggregator<T>Abstract aggregator that processes numeric values extracted from a set of entries in a Map.classAbstractLongAggregator<T>Abstract aggregator that processes numeric values extracted from a set of entries in a Map.classBigDecimalAverage<T>Calculates an average for values of any numeric type extracted from a set of entries in a Map in a form of aBigDecimalvalue.classBigDecimalMax<T>Calculates a maximum of numeric values extracted from a set of entries in a Map in a form of aBigDecimalvalue.classBigDecimalMin<T>Calculates a minimum of numeric values extracted from a set of entries in a Map in a form of aBigDecimalvalue.classBigDecimalSum<T>Calculates an sum for values of any numberic type extracted from a set of entries in a Map in a form of aBigDecimalvalue.classComparableMax<T,R>Calculates a maximum among values extracted from a set of entries in a Map.classComparableMin<T,R>Calculates a minimum among values extracted from a set of entries in a Map.classCompositeAggregator<K,V>CompositeAggregator provides an ability to execute a collection of aggregators against the same subset of the entries in an InvocableMap, resulting in a list of corresponding aggregation results.static classCompositeAggregator.ParallelDeprecated.As of Coherence 12.2.1.classCount<K,V>Calculates a number of values in an entry set.classDistinctValues<K,V,T,E>Return the set of unique values extracted from a set of entries in a Map.classDoubleAverage<T>Calculates an average for values of any numeric type extracted from a set of entries in a Map.classDoubleMax<T>Calculates a maximum of numeric values extracted from a set of entries in a Map.classDoubleMin<T>Calculates a minimum of numeric values extracted from a set of entries in a Map.classDoubleSum<T>Sums up numeric values extracted from a set of entries in a Map.classGroupAggregator<K,V,T,E,R>The GroupAggregator provides an ability to split a subset of entries in an InvocableMap into a collection of non-intersecting subsets and then aggregate them separately and independently.static classGroupAggregator.Parallel<K,V,T,E,R>Deprecated.As of Coherence 12.2.1.classLongMax<T>Calculates a maximum of numeric values extracted from a set of entries in a Map.classLongMin<T>Calculates a minimum of numeric values extracted from a set of entries in a Map.classLongSum<T>Sums up numeric values extracted from a set of entries in a Map.classPriorityAggregator<K,V,P,R>PriorityAggregator is used to explicitly control the scheduling priority and timeouts for execution of EntryAggregator-based methods.classQueryRecorder<K,V>This aggregator is used to produce aQueryRecordobject that contains an estimated or actual cost of the query execution for a given filter.classReducerAggregator<K,V,T,E>The ReducerAggregator is used to implement functionality similar toCacheMap.getAll(Collection)API.classScriptAggregator<K,V,P,R>ScriptAggregator is aInvocableMap.StreamingAggregatorthat wraps a script written in one of the languages supported by Graal VM.classTopNAggregator<K,V,T,E>TopNAggregator is a ParallelAwareAggregator that aggregates the top N extracted values into an array.static classTopNAggregator.PartialResult<E>The sorted partial result.
- 
Uses of PortableObject in com.tangosol.util.comparatorClasses in com.tangosol.util.comparator that implement PortableObject Modifier and Type Class Description classChainedComparator<T>Composite comparator implementation based on a collection of comparators.classEntryComparatorComparator implementation used to compare map entries.classExtractorComparator<T>Comparator implementation that uses specifiedValueExtractorto extract value(s) to be used for comparison.classInverseComparator<T>Comparator that reverses the result of another comparator.classSafeComparator<T>Null-safe delegating comparator.
- 
Uses of PortableObject in com.tangosol.util.extractorClasses in com.tangosol.util.extractor that implement PortableObject Modifier and Type Class Description classAbstractCompositeExtractor<T,E>Abstract super class for ValueExtractor implementations that are based on an underlying array of ValueExtractor objects.classChainedExtractor<T,E>Composite ValueExtractor implementation based on an array of extractors.classChainedFragmentExtractor<T,E>AValueExtractorthat extracts aFragmentfrom a nested property of the target object.classComparisonValueExtractor<T,E extends Number>A synthetic ValueExtractor that returns a result of comparison between two values extracted from the same target.classCompositeUpdaterA ValueUpdater implementation based on an extractor-updater pair that could also be used as a ValueManipulator.classConditionalExtractor<T,E>An IndexAwareExtractor implementation that is only used to create aConditionalIndex.classDeserializationAcceleratorDeserializationAccelerator is anIndexAwareExtractorimplementation that is used to create aForwardOnlyMapIndex, which in turn is used for deserialization optimization.classEntryExtractorThe EntryExtractor is a base abstract class for special purpose custom ValueExtractor implementations.classFragmentExtractor<T>AValueExtractorthat is used to extract aFragmentfrom an object.classIdentityExtractor<T>Trivial ValueExtractor implementation that does not actually extract anything from the passed value, but returns the value itself.classKeyExtractor<T,E>The KeyExtractor is a special purpose ValueExtractor implementation that serves as an indicator that a query should be run against the key objects rather than the values.classMultiExtractorComposite ValueExtractor implementation based on an array of extractors.classPofExtractor<T,E>POF-based ValueExtractor implementation.classPofUpdaterPOF-based ValueUpdater implementation.classReflectionExtractor<T,E>Reflection-based ValueExtractor implementation.classReflectionUpdaterReflection-based ValueUpdater implementation.classScriptValueExtractor<T,E>ScriptValueExtractor is anAbstractExtractorthat wraps a script written in one of the languages supported by Graal VM.classUniversalExtractor<T,E>Universal ValueExtractor implementation.classUniversalUpdaterUniversal ValueUpdater implementation.
- 
Uses of PortableObject in com.tangosol.util.filterClasses in com.tangosol.util.filter that implement PortableObject Modifier and Type Class Description classAllFilterFilter which returns the logical "and" of a filter array.classAlwaysFilter<T>Filter which always evaluates to true.classAndFilterFilter which returns the logical "and" of two other filters.classAnyFilterFilter which returns the logical "or" of a filter array.classArrayFilterFilter which is a logical operator of a filter array.classBetweenFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Between" condition.classCacheEventFilter<K,V>An extension of theMapEventFilterwhich allows selection of client driven (natural) events, cache internal (synthetic) events, or both.classComparisonFilter<T,E,C>Filter which compares the result of a method invocation with a value.classContainsAllFilter<T,E>Filter which tests aCollectionor Object array value returned from a method invocation for containment of all values in a Set.classContainsAnyFilter<T,E>Filter which tests aCollectionor Object array value returned from a method invocation for containment of any value in a Set.classContainsFilter<T,E>Filter which tests aCollectionor Object array value returned from a method invocation for containment of a given value.classEqualsFilter<T,E>Filter which compares the result of a method invocation with a value for equality.classExtractorFilter<T,E>Base Filter implementation for doing extractor-based processing.classFilterTriggerA generic Filter-based MapTrigger implementation.classGreaterEqualsFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Greater or Equal" condition.classGreaterFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Greater" condition.classInFilter<T,E>Filter which checks whether the result of a method invocation belongs to a predefined set of values.classInKeySetFilter<T>Filter that limits the underlying filter evaluation only to the specified set of keys.classIsNotNullFilter<T,E>Filter which tests the result of a method invocation for inequality to null.classIsNullFilter<T,E>Filter which compares the result of a method invocation with null.classKeyAssociatedFilter<T>Filter which limits the scope of another filter according to the key association information.classLessEqualsFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Less or Equals" condition.classLessFilter<T,E extends Comparable<? super E>>Filter which compares the result of a method invocation with a value for "Less" condition.classLikeFilter<T,E>Filter which compares the result of a method invocation with a value for pattern match.classLimitFilter<T>Filter which truncates the results of another filter.classMapEventFilter<K,V>Filter which evaluates the content of a MapEvent object according to the specified criteria.classMapEventTransformerFilter<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.classNeverFilter<T>Filter which always evaluates to false.classNotEqualsFilter<T,E>Filter which compares the result of a method invocation with a value for inequality.classNotFilter<T>Filter which negates the results of another filter.classOrFilterFilter which returns the logical "or" of two other filters.classPartitionedFilter<T>Filter which limits the scope of another filter to those entries that have keys that belong to the specified partition set.classPredicateFilter<T,E>Ajava.util.function.PredicatebasedExtractorFilter.classPresentFilter<T>Filter which returns true forInvocableMap.Entryobjects that currently exist in a Map.classPriorityFilter<T>PriorityFilter is used to explicitly control the scheduling priority and timeouts for execution of filter-based methods.classRegexFilter<T,E>Filter which uses the regular expression pattern match defined by thePattern.matches(String, CharSequence)contract.classScriptFilter<V>ScriptFilter is aFilterthat wraps a script written in one of the languages supported by Graal VM.classValueChangeEventFilter<V,E>Filter which evaluates the content of a MapEvent values based on the specified value extractor.classXorFilterFilter which returns the logical exclusive or ("xor") of two other filters.
- 
Uses of PortableObject in com.tangosol.util.processorClasses in com.tangosol.util.processor that implement PortableObject Modifier and Type Class Description classAbstractEvolvableProcessor<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.classCompositeProcessor<K,V>The CompositeProcessor represents a collection of entry processors that are invoked sequentially against the same Entry.classConditionalProcessor<K,V,T>Conditional entry processor represents a processor that is invoked conditionally based on the result of an entry evaluation.classConditionalPut<K,V>ConditionalPut is an EntryProcessor that performs anEntry.setValueoperation if the specified condition is satisfied.classConditionalPutAll<K,V>ConditionalPutAll is an EntryProcessor that performs aEntry.setValueoperation for multiple entries that satisfy the specified condition.classConditionalRemove<K,V>ConditionalRemove is an EntryProcessor that performs anEntry.removeoperation if the specified condition is satisfied.classExtractorProcessor<K,V,T,E>ExtractorProcessor is an EntryProcessor implementations that extracts a value from an object cached in an InvocableMap.classMethodInvocationProcessor<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.classNumberIncrementor<K,V,N extends Number>The NumberIncrementor entry processor is used to increment a property value of aNumbertype.classNumberMultiplier<K,V,N extends Number>The NumberMultiplier entry processor is used to multiply a property value of aNumbertype.classPreloadRequest<K,V>PreloadRequest is a simple EntryProcessor that performs aEntry.getValuecall.classPriorityProcessor<K,V,T>PriorityProcessor is used to explicitly control the scheduling priority and timeouts for execution of EntryProcessor-based methods.classPropertyManipulator<V,R>PropertyManipulator is a reflection based ValueManipulator implementation based on the JavaBean property name conventions.classPropertyProcessor<K,V,R>PropertyProcessor is a base class for EntryProcessor implementations that depend on a ValueManipulator.classScriptProcessor<K,V,R>ScriptProcessor is anInvocableMap.EntryProcessorthat wraps a script written in one of the languages supported by Graal VM.classTouchProcessorTouches an entry (if present) in order to trigger interceptor re-evaluation and possibly increment expiry time.classUpdaterProcessor<K,V,T>UpdaterProcessor is an EntryProcessor implementations that updates an attribute of an object cached in an InvocableMap.classVersionedPut<K,V extends Versionable>VersionedPut is an EntryProcessor that assumes that entry values implementVersionableinterface and performs anEntry.setValueoperation if and only if the version of the specified value matches to the version of the current value.classVersionedPutAll<K,V extends Versionable>VersionedPutAll is an EntryProcessor that assumes that entry values implementVersionableinterface and performs anEntry.setValueoperation only for entries whose versions match to versions of the corresponding current values.
- 
Uses of PortableObject in com.tangosol.util.transformerClasses in com.tangosol.util.transformer that implement PortableObject Modifier and Type Class Description classExtractorEventTransformer<K,V,E>ExtractorEventTransformer is a special purposeMapEventTransformerimplementation that transforms emitted events, extracting one or more properties from either the OldValue or the NewValue.classSamplingEventTransformer<K,V>AMapEventTransformerimplementation which will send at most one event per storage member per sampling interval, in order to throttle down the number of events received by the slow consumer.classSemiLiteEventTransformer<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.
 
-