Uses of Interface
com.tangosol.io.pof.PortableObject
Packages that use PortableObject
Package
Description
Coherence Concurrent utilities based on java.util.concurrent.
Classes to allow submission of tasks to the grid for execution.
Various predicates used by the Executor Service.
Options used as metadata for executors or during task
submission to the grid.
Task
implementations.Interfaces and classes providing a framework for locking and waiting for conditions that is distinct from built-in synchronization and monitors.
Contains Coherence-based WorkManager implementation classes.
Defines the Coherence configuration object model for accessing, customizing
and or modifying configuration.
Defines the typical runtime configuration builders for the Coherence
configuration object model.
Contains classes related to Coherence JCache.
Common utilities used by Coherence JCache.
Contains classes related to local cache implementation of Coherence JCache.
Contains classes related to partitioned cache implementation of Coherence JCache.
Contains classes related to pass-through cache implementation of Coherence JCache.
Contains classes related to remote cache implementation of Coherence JCache.
Contains packages and classes related to the Coherence REST API utilities.
Contains classes related to the HTTP Session Replication Module.
Defines classes and interfaces for representing and evaluating expressions.
Contains classes related to POF serialization and deserialization.
Contains classes related to POF stream navigation and manipulation.
Contains basic cluster interfaces and factories.
Contains classes providing various caching strategies.
Contains interfaces and classes related to partitioned services.
Contains classes related to the Coherence Security Framework.
Contains classes that providing topic entities for publish/subscribe messaging.
Contains classes providing basic XML related functionality.
Contains various generic utilities.
Contains concrete
InvocableMap.EntryAggregator
implementations.Contains concrete
Comparator implementations and related interfaces.Contains
ValueExtractor and
ValueUpdater related classes.Contains concrete
Filter implementations and related interfaces.Contains concrete
InvocableMap.EntryProcessor
implementations.Contains concrete
MapEventTransformer
implementations.-
Uses of PortableObject in com.oracle.coherence.concurrent
Classes in com.oracle.coherence.concurrent that implement PortableObjectModifier and TypeClassDescriptionclassThe identity of an 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.executor
Classes in com.oracle.coherence.concurrent.executor that implement PortableObjectModifier and TypeClassDescriptionclasscom.oracle.coherence.concurrent.executor.AbstractCollector<T,R> An abstractTask.Collector.classResult<T>static classATask.Collectorthat counts the number of results are present.static classATask.Collectorto collect any (the first provided) available result.static classATask.Collectorthat collects and returns the last contributed result.static classATask.Collectorthat collects and returns all contributed results that are values as aList.static classATask.Collectorthat collects and returns all contributed results that are values as aSet. -
Uses of PortableObject in com.oracle.coherence.concurrent.executor.function
Subinterfaces of PortableObject in com.oracle.coherence.concurrent.executor.functionModifier and TypeInterfaceDescriptioninterfaceRepresents a portableRemote.Predicate(boolean-valued function) with a single argument; a convenience interface for an implementation with no properties that require serialization.Classes in com.oracle.coherence.concurrent.executor.function that implement PortableObjectModifier and TypeClassDescriptionstatic classAnPredicates.AlwaysPredicatereturns true for any value provided to thePredicate.test(Object)method.static classARemote.Predicateto compare a value usingObject.equals(Object).static classAnPredicates.IsValuePredicatereturns true when a providedResult.isValue().static classARemote.Predicatethat negates the result of anotherRemote.Predicate.static classAnPredicates.NeverPredicatereturns false for any value provided to thePredicate.test(Object)method.static classAnPredicates.NullValuePredicatereturnstruefor any value provided to thePredicate.test(Object)method that isnull.static classARemote.Predicateto determine if anTaskExecutorService.ExecutorInfohas a specificTaskExecutorService.Registration.Option.static classARemote.Predicatefor matching the name of aRole.static classAnPredicates.ThrowablePredicatereturns true when a providedResult.isThrowable(). -
Uses of PortableObject in com.oracle.coherence.concurrent.executor.options
Classes in com.oracle.coherence.concurrent.executor.options that implement PortableObjectModifier and TypeClassDescriptionclassAnTaskExecutorService.Registration.Optionspecifying whether anExecutoris running on a Coherence cluster member.classclassAnTaskExecutorService.Registration.Optionto specify theDescriptionof a registeredExecutorService.classAnTaskExecutorService.Registration.Optiondefining a CoherenceMember.classclassclassAnTaskExecutorService.Registration.Optionto specify whether anExecutoris running on a storage enabled Coherence server. -
Uses of PortableObject in com.oracle.coherence.concurrent.executor.tasks
Classes in com.oracle.coherence.concurrent.executor.tasks that implement PortableObject -
Uses of PortableObject in com.oracle.coherence.concurrent.locks
Classes in com.oracle.coherence.concurrent.locks that implement PortableObjectModifier and TypeClassDescriptionclassThe 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.commonj
Classes in com.tangosol.coherence.commonj that implement PortableObjectModifier and TypeClassDescriptionprotected static classBase class for Invocable tasks related to the WorkManager.protected static classInvocable task used during handshake, which has to be scheduledimmediately.protected static classInvocable task that forces a release for a wrapped Work object.protected static classInvocable task that requests a status for a given Work.protected static classInvocable task that posts a wrapped Work object to a WorkManager queue.protected static classInvocable task that delivers a WorkEvent to a WorkListener.protected static classA WorkStatus object is used to communicate a work execution status back to the caller. -
Uses of PortableObject in com.tangosol.coherence.config
Classes in com.tangosol.coherence.config that implement PortableObjectModifier and TypeClassDescriptionclassAParameterMacroExpressionis anExpressionrepresenting the use of a Coherence Parameter Macro, typically occurring with in a Coherence Cache Configuration file.classAResolvableParameterListis aParameterListimplementation that additionally supports name-basedParameterresolution as defined by theParameterResolverinterface.classASimpleParameterListis a simple implementation ofParameterList. -
Uses of PortableObject in com.tangosol.coherence.config.builder
Classes in com.tangosol.coherence.config.builder that implement PortableObjectModifier and TypeClassDescriptionclassAnInstanceBuilderis aParameterizedBuilderimplementation that additionally supports injection based on Coherence <instance%gt; or <class-scheme> configurations.classAStaticFactoryInstanceBuilderis 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.jcache
Classes in com.tangosol.coherence.jcache that implement PortableObjectModifier and TypeClassDescriptionclassA base implementation of aCoherenceBasedCompleteConfiguration. -
Uses of PortableObject in com.tangosol.coherence.jcache.common
Classes in com.tangosol.coherence.jcache.common that implement PortableObjectModifier and TypeClassDescriptionclassA Coherence-basedEntryProcessorResult.classJCache Statistics implementation.classRepresents the JCache metadata for a key and value pair stored in aCache.classAn internal class to represent the unique identity of a JCache cache.classServer 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 PortableObjectModifier and TypeClassDescriptionstatic classServer side filter to filter out both coherence and jcache synthetic events.classAConfigurationfor aCachebased 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 PortableObjectModifier and TypeClassDescriptionstatic classNonSyntheticEntryFilterclassAConfigurationfor aCachebased on a Coherence <distributed-scheme> or more specifically a partitioned (aka: distributed)NamedCache.static classServer side filter for JCache ExpiryCacheEvents.static classGet CacheStatistics from binEntry's context for JCache id.static classCollect JCache CacheStatistics from all storage-enabled members.static classClear 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 PortableObjectModifier and TypeClassDescriptionclass -
Uses of PortableObject in com.tangosol.coherence.jcache.remotecache
Classes in com.tangosol.coherence.jcache.remotecache that implement PortableObjectModifier and TypeClassDescriptionclassAConfigurationfor aCachebased 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 PortableObjectModifier and TypeClassDescriptionclassPropertySet<T>Represents a set of named properties and allows the extraction of those properties from a target object.classSpecification for a single property.classA 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.servlet
Classes in com.tangosol.coherence.servlet that implement PortableObjectModifier and TypeClassDescriptionstatic classSplitHttpSessionModel.ElasticKey<P,Integer> ElasticKey, used by to store segments of a large value that exceeds the flash journal size limit. -
Uses of PortableObject in com.tangosol.config.expression
Classes in com.tangosol.config.expression that implement PortableObjectModifier and TypeClassDescriptionclassAChainedParameterResolveris aParameterResolverthat consults zero or more providedParameterResolvers in the order in which they were defined or added to resolve aParameter.classALiteralExpressionis a literal (aka: constant)Expression.classclassAParameterrepresents an optionally named and optionally explicitly typedExpression.classAScopedParameterResolveris 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.classAValueMacroExpressionis a string value potentially containing expandable macros. -
Uses of PortableObject in com.tangosol.io.pof
Subinterfaces of PortableObject in com.tangosol.io.pofModifier and TypeInterfaceDescriptioninterfaceDefines an interface that should be implemented by the classes that want to support evolution.interfaceExtension of thePortableObjectinterface that supports forwards- and backwards-compatibility of POF data streams.Classes in com.tangosol.io.pof that implement PortableObjectModifier and TypeClassDescriptionclassAPortableExceptionis 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 PortableObjectModifier and TypeMethodDescriptionvoidPortableObjectSerializer.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 PortableObjectModifier and TypeClassDescriptionclassAbstract base class for static, path-based implementations ofPofNavigatorinterface.classA staticPofNavigatorimplementation 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 PortableObjectModifier and TypeClassDescriptionclassAn abstract base for PriorityTask implementations.classSignals that a request execution in a distributed environment failed to complete successfully.classSignals that a request was not allowed to complete due to the related service action being disallowed by the corresponding ActionPolicy.classSignals 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 PortableObjectModifier and TypeClassDescriptionclassCacheEvent<K,V> An extension of the MapEvent which allows to differentiate between client driven (natural) events and cache internal (synthetic) events.protected static classA 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 PortableObjectModifier and TypeClassDescriptionclassDefault implementation ofVersionedPartitions,classOwnership is a light-weight data structure that contains a partition ownership information.classPartitionSet is a light-weight data structure that represents a set of partitions that are used in parallel processing.classSimplePartitionKey is a trivialPartitionAwareKeyimplementation.classAn 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 PortableObjectModifier and TypeClassDescriptionclassPermissionInfo 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 PortableObjectModifier and TypeClassDescriptionstatic classThe FailOnFull option indicates that theCompletableFuturereturned from thePublisher.publish(V)operation should complete exceptionally upon identifying that the topic is or has become full.static classThe OrderBy option specifies the ordering of async operations with respect to one another.static classPublisher.OrderByoption ensures ordering ofsent valuesacross all threads which share the sameorderId.static classPublisher.OrderByoption enforces no specific ordering betweensent valuesallowing for the greatest level of parallelism.static classPublisher.OrderByoption which computes the unit-of-order such that each message is sent to the next channel in a round-robin order.static classPublisher.OrderByoption which ensures that a sequence ofsent valuesissued by a single thread will complete in order.static classPublisher.OrderByoption which computes the unit-of-order based on applyingconstructor'sorderIdFunction parameteronsent value.static classThe result of a commit request.static classThe 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 classThe Filtered option specifies a filter that will determine which topic values a subscriber is interested in receiving.static classThe 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 PortableObjectModifier and TypeClassDescriptionclassA simple implementation of the XmlElement interface.classA simple implementation of the XmlElement interface.classA simple implementation of the XmlValue interface. -
Uses of PortableObject in com.tangosol.util
Classes in com.tangosol.util that implement PortableObjectModifier and TypeClassDescriptionprotected static classA DeferredCacheEvent is aCacheEventobject that defers the loading of theold value.classAbstractScriptBase is the base class for script based processing.classCompositeKey<P,S> Key class that consists of a primary and secondary component.static classA Converter CacheEvent views an underlying CacheEvent through a set of key and value Converters.static classA 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 classAn 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.classFilter which discards null references.static classAn implementation of an EntryProcessor that does nothing and returns Boolean.TRUE as a result of execution.static classA Map that contains nothing and does nothing.static classAn immutable ObservableMap which contains nothing.static classAn immutable set which contains nothing.static classA 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.classSimple QueryRecord implementation.static classSimple QueryRecord.PartialResult implementation.classSimple abstract RecordableStep implementation.classSimple QueryRecord.PartialResult.ExplainStep implementation.static classSimple QueryRecord.PartialResult.IndexLookupRecord implementation.static classSimple QueryRecord.PartialResult.Step implementation.classSimple QueryRecord.PartialResult.TraceStep implementation.classA UID is a 128-bit identifier that is almost guaranteed to be unique.classUniversalManipulator implementation.final classA 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 PortableObjectModifier and TypeClassDescriptionclassAbstractAggregator<K,V, T, E, R> Abstract base class implementation ofInvocableMap.EntryAggregatorthat supports streaming aggregation.classAbstract aggregator that processesNumbervalues extracted from a set of entries in a Map and returns a result in a form of aBigDecimalvalue.classAbstract aggregator that processes values extracted from a set of entries in a Map, with knowledge of how to compare those values.classAbstract aggregator that processes numeric values extracted from a set of entries in a Map.classAbstract aggregator that processes numeric values extracted from a set of entries in a Map.classCalculates an average for values of any numeric type extracted from a set of entries in a Map in a form of aBigDecimalvalue.classCalculates a maximum of numeric values extracted from a set of entries in a Map in a form of aBigDecimalvalue.classCalculates a minimum of numeric values extracted from a set of entries in a Map in a form of aBigDecimalvalue.classCalculates 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 classDeprecated.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.classCalculates 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 classThe sorted partial result. -
Uses of PortableObject in com.tangosol.util.comparator
Classes in com.tangosol.util.comparator that implement PortableObjectModifier and TypeClassDescriptionclassComposite comparator implementation based on a collection of comparators.classComparator implementation used to compare map entries.classComparator implementation that uses specifiedValueExtractorto extract value(s) to be used for comparison.classComparator that reverses the result of another comparator.classNull-safe delegating comparator. -
Uses of PortableObject in com.tangosol.util.extractor
Classes in com.tangosol.util.extractor that implement PortableObjectModifier and TypeClassDescriptionclassAbstract 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.classAValueExtractorthat 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.classA 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.classDeserializationAccelerator is anIndexAwareExtractorimplementation that is used to create aForwardOnlyMapIndex, which in turn is used for deserialization optimization.classThe EntryExtractor is a base abstract class for special purpose custom ValueExtractor implementations.classAValueExtractorthat is used to extract aFragmentfrom an object.classTrivial 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.classComposite ValueExtractor implementation based on an array of extractors.classPofExtractor<T,E> POF-based ValueExtractor implementation.classPOF-based ValueUpdater implementation.classReflectionExtractor<T,E> Reflection-based ValueExtractor implementation.classReflection-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.classUniversal ValueUpdater implementation. -
Uses of PortableObject in com.tangosol.util.filter
Classes in com.tangosol.util.filter that implement PortableObjectModifier and TypeClassDescriptionclassFilter which returns the logical "and" of a filter array.classAlwaysFilter<T>Filter which always evaluates to true.classFilter which returns the logical "and" of two other filters.classFilter which returns the logical "or" of a filter array.classFilter 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.classA 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.classFilter 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.classFilter 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 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.classFilter which returns the logical "or" of two other filters.classFilter 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.classFilter which returns true forInvocableMap.Entryobjects that currently exist in a Map.classPriorityFilter 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.classFilter which evaluates the content of a MapEvent values based on the specified value extractor.classFilter 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 PortableObjectModifier and TypeClassDescriptionclassAbstractEvolvableProcessor<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.classTouchProcessor<K,V, R> Touches 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.transformer
Classes in com.tangosol.util.transformer that implement PortableObjectModifier and TypeClassDescriptionclassExtractorEventTransformer<K,V, E> ExtractorEventTransformer is a special purposeMapEventTransformerimplementation that transforms emitted events, extracting one or more properties from either the OldValue or the NewValue.classAMapEventTransformerimplementation 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 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.