Uses of Interface
com.tangosol.util.Filter
Package
Description
Contains interfaces and classes related to the Caffeine backing map implementation.
Coherence CDI provides support for CDI (Contexts and Dependency Injection)
within Coherence cluster members.
Support for adapting Coherence interceptors to standard CDI events.
The Coherence gRPC server implementation.
Contains classes to enable Repository-like access to Coherence data.
Defines the typical runtime configuration builders for the Coherence
configuration object model.
Defines the Coherence configuration object model classes and interfaces for
Caching and Service Schemes.
Defines the Xml document Element and Attribute Processors for Coherence Cache
Configuration files.
Contains packages and classes supporting the Coherence CohQL command line tool.
This package contains implementations of the
BaseOperator
interface.This package contains
StatementBuilder
implementations.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 the Coherence REST API
MapEvent
s.Contains basic cluster interfaces and factories.
Contains classes providing various caching strategies.
Contains classes related to the Coherence Management Framework.
Contains interfaces and classes related to partitioned services.
Contains classes that providing topic entities for publish/subscribe messaging.
Contains classes and helpers for implementing various types of persistence.
Contains various generic utilities.
Contains concrete
InvocableMap.EntryAggregator
implementations.Contains
ValueExtractor
and
ValueUpdater
related classes.Contains concrete
Filter
implementations and related interfaces.Contains concrete
InvocableMap.EntryProcessor
implementations.-
Uses of Filter in com.oracle.coherence.caffeine
Modifier and TypeMethodDescriptionvoid
CaffeineCache.addMapListener
(MapListener listener, Filter filter, boolean fLite) void
CaffeineCache.removeMapListener
(MapListener listener, Filter filter) -
Uses of Filter in com.oracle.coherence.cdi
Modifier and TypeMethodDescriptionCreate aFilter
instance.FilterProducer.AlwaysFilterSupplier.create
(AlwaysFilter annotation) FilterProducer.WhereFilterSupplier.create
(WhereFilter annotation) <T> Filter
<T> FilterProducer.getFilter
(jakarta.enterprise.inject.spi.InjectionPoint injectionPoint) ProducesFilter
based on injection point metadata.<T> Filter
<T> FilterProducer.resolve
(Set<Annotation> annotations) -
Uses of Filter in com.oracle.coherence.cdi.events
-
Uses of Filter in com.oracle.coherence.grpc.proxy
Modifier and TypeFieldDescriptionprotected final ConcurrentMap
<Filter<?>, MapListenerProxy.FilterInfo> MapListenerProxy.f_mapFilter
The map ofFilters
that thisMapListenerProxy
was registered with.Modifier and TypeMethodDescription<T> Filter
<T> NamedCacheService.ensureFilter
(com.google.protobuf.ByteString bytes, Serializer serializer) Obtain aFilter
from the serialized data in aByteString
.<T> Filter
<T> NamedCacheServiceImpl.ensureFilter
(com.google.protobuf.ByteString bytes, Serializer serializer) Obtain aFilter
from the serialized data in aByteString
.<T> Filter
<T> NamedCacheService.getFilter
(com.google.protobuf.ByteString bytes, Serializer serializer) Obtain aFilter
from the serialized data in aByteString
.<T> Filter
<T> NamedCacheServiceImpl.getFilter
(com.google.protobuf.ByteString bytes, Serializer serializer) Obtain aFilter
from the serialized data in aByteString
.Modifier and TypeMethodDescriptionprotected void
MapListenerProxy.addListener
(Filter<?> filter, long filterId, boolean lite, boolean priming) Add this MapListenerProxy as a filter-based listener of the given NamedCache. -
Uses of Filter in com.oracle.coherence.repository
Modifier and TypeMethodDescriptionvoid
AbstractRepositoryBase.addListener
(Filter<?> filter, AbstractRepositoryBase.Listener<? super T> listener) Register a listener that will observe all events for entities that satisfy the specified criteria.AbstractAsyncRepository.average
(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor) Return the average of the specified function.AbstractAsyncRepository.average
(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor) Return the average of the specified function.AbstractAsyncRepository.average
(Filter<?> filter, Remote.ToIntFunction<? super T> extractor) Return the average of the specified function.AbstractAsyncRepository.average
(Filter<?> filter, Remote.ToLongFunction<? super T> extractor) Return the average of the specified function.AbstractRepository.average
(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor) Return the average of the specified function.double
AbstractRepository.average
(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor) Return the average of the specified function.double
AbstractRepository.average
(Filter<?> filter, Remote.ToIntFunction<? super T> extractor) Return the average of the specified function.double
AbstractRepository.average
(Filter<?> filter, Remote.ToLongFunction<? super T> extractor) Return the average of the specified function.Return the number of entities in this repository that satisfy specified filter.long
Return the number of entities in this repository that satisfy specified filter.<R> CompletableFuture
<Collection<? extends R>> AbstractAsyncRepository.distinct
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor) Return the set of distinct values for the specified extractor.<R> Collection
<? extends R> AbstractRepository.distinct
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor) Return the set of distinct values for the specified extractor.Return all entities that satisfy the specified criteria.<R> CompletableFuture
<Map<ID, R>> AbstractAsyncRepository.getAll
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor) Return a map of values extracted from a set of entities based on the specified criteria.<R> CompletableFuture
<Void> AbstractAsyncRepository.getAll
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor, BiConsumer<? super ID, ? super R> callback) Streams the id and the associated extracted value from a set of entities based on the specified criteria.Stream all entities that satisfy the specified criteria.Return all entities that satisfy the specified criteria.AbstractRepository.getAll
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor) Return a map of values extracted from a set of entities based on the specified criteria.AbstractAsyncRepository.getAllOrderedBy
(Filter<?> filter, Remote.Comparator<? super T> orderBy) Return all entities that satisfy the specified criteria, sorted using specifiedRemote.Comparator
.<R extends Comparable<? super R>>
CompletableFuture<Collection<T>> AbstractAsyncRepository.getAllOrderedBy
(Filter<?> filter, ValueExtractor<? super T, ? extends R> orderBy) Return all entities that satisfy the specified criteria, sorted using specifiedComparable
attribute.AbstractRepository.getAllOrderedBy
(Filter<?> filter, Remote.Comparator<? super T> orderBy) Return all entities that satisfy the specified criteria, sorted using specifiedRemote.Comparator
.<R extends Comparable<? super R>>
Collection<T> AbstractRepository.getAllOrderedBy
(Filter<?> filter, ValueExtractor<? super T, ? extends R> orderBy) Return all entities that satisfy the specified criteria, sorted using specifiedComparable
attribute.<K> CompletableFuture
<Map<K, Set<T>>> AbstractAsyncRepository.groupBy
(Filter<?> filter, ValueExtractor<? super T, ? extends K> extractor) Return the grouping of entities by the specified extractor.<K> CompletableFuture
<Map<K, SortedSet<T>>> AbstractAsyncRepository.groupBy
(Filter<?> filter, ValueExtractor<? super T, ? extends K> extractor, Remote.Comparator<? super T> orderBy) Return the grouping of entities by the specified extractor, ordered by the specified attribute within each group.<K,
A, R, M extends Map<K, R>>
CompletableFuture<M> AbstractAsyncRepository.groupBy
(Filter<?> filter, ValueExtractor<? super T, ? extends K> extractor, Remote.Supplier<M> mapFactory, RemoteCollector<? super T, A, R> collector) Return the grouping of entities by the specified extractor.<K,
A, R> CompletableFuture <Map<K, R>> AbstractAsyncRepository.groupBy
(Filter<?> filter, ValueExtractor<? super T, ? extends K> extractor, RemoteCollector<? super T, A, R> collector) Return the grouping of entities by the specified extractor.AbstractRepository.groupBy
(Filter<?> filter, ValueExtractor<? super T, ? extends K> extractor) Return the grouping of entities by the specified extractor.AbstractRepository.groupBy
(Filter<?> filter, ValueExtractor<? super T, ? extends K> extractor, Remote.Comparator<? super T> orderBy) Return the grouping of entities by the specified extractor, ordered by the specified attribute within each group.<K,
A, R, M extends Map<K, R>>
MAbstractRepository.groupBy
(Filter<?> filter, ValueExtractor<? super T, ? extends K> extractor, Remote.Supplier<M> mapFactory, RemoteCollector<? super T, A, R> collector) Return the grouping of entities by the specified extractor.<K,
A, R> Map <K, R> AbstractRepository.groupBy
(Filter<?> filter, ValueExtractor<? super T, ? extends K> extractor, RemoteCollector<? super T, A, R> collector) Return the grouping of entities by the specified extractor.AbstractAsyncRepository.max
(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor) Return the maximum value of the specified function.<R extends Comparable<? super R>>
CompletableFuture<R> AbstractAsyncRepository.max
(Filter<?> filter, Remote.ToComparableFunction<? super T, R> extractor) Return the maximum value of the specified function.AbstractAsyncRepository.max
(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor) Return the maximum value of the specified function.AbstractAsyncRepository.max
(Filter<?> filter, Remote.ToIntFunction<? super T> extractor) Return the maximum value of the specified function.AbstractAsyncRepository.max
(Filter<?> filter, Remote.ToLongFunction<? super T> extractor) Return the maximum value of the specified function.AbstractRepository.max
(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor) Return the maximum value of the specified function.<R extends Comparable<? super R>>
RAbstractRepository.max
(Filter<?> filter, Remote.ToComparableFunction<? super T, R> extractor) Return the maximum value of the specified function.double
AbstractRepository.max
(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor) Return the maximum value of the specified function.int
AbstractRepository.max
(Filter<?> filter, Remote.ToIntFunction<? super T> extractor) Return the maximum value of the specified function.long
AbstractRepository.max
(Filter<?> filter, Remote.ToLongFunction<? super T> extractor) Return the maximum value of the specified function.<R extends Comparable<? super R>>
CompletableFuture<Optional<T>> AbstractAsyncRepository.maxBy
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor) Return the entity with the maximum value of the specified function.<R extends Comparable<? super R>>
Optional<T> AbstractRepository.maxBy
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor) Return the entity with the maximum value of the specified function.AbstractAsyncRepository.min
(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor) Return the minimum value of the specified function.<R extends Comparable<? super R>>
CompletableFuture<R> AbstractAsyncRepository.min
(Filter<?> filter, Remote.ToComparableFunction<? super T, R> extractor) Return the minimum value of the specified function.AbstractAsyncRepository.min
(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor) Return the minimum value of the specified function.AbstractAsyncRepository.min
(Filter<?> filter, Remote.ToIntFunction<? super T> extractor) Return the minimum value of the specified function.AbstractAsyncRepository.min
(Filter<?> filter, Remote.ToLongFunction<? super T> extractor) Return the minimum value of the specified function.AbstractRepository.min
(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor) Return the minimum value of the specified function.<R extends Comparable<? super R>>
RAbstractRepository.min
(Filter<?> filter, Remote.ToComparableFunction<? super T, R> extractor) Return the minimum value of the specified function.double
AbstractRepository.min
(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor) Return the minimum value of the specified function.int
AbstractRepository.min
(Filter<?> filter, Remote.ToIntFunction<? super T> extractor) Return the minimum value of the specified function.long
AbstractRepository.min
(Filter<?> filter, Remote.ToLongFunction<? super T> extractor) Return the minimum value of the specified function.<R extends Comparable<? super R>>
CompletableFuture<Optional<T>> AbstractAsyncRepository.minBy
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor) Return the entity with the minimum value of the specified function.<R extends Comparable<? super R>>
Optional<T> AbstractRepository.minBy
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor) Return the entity with the minimum value of the specified function.Remove all entities based on the specified criteria.Remove all entities based on the specified criteria.boolean
Remove all entities based on the specified criteria.Remove all entities based on the specified criteria.void
AbstractRepositoryBase.removeListener
(Filter<?> filter, AbstractRepositoryBase.Listener<? super T> listener) Unregister a listener that observes all events for entities that satisfy the specified criteria.Return a stream of all entities in this repository that satisfy the specified criteria.AbstractAsyncRepository.sum
(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor) Return the sum of the specified function.AbstractAsyncRepository.sum
(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor) Return the sum of the specified function.AbstractAsyncRepository.sum
(Filter<?> filter, Remote.ToIntFunction<? super T> extractor) Return the sum of the specified function.AbstractAsyncRepository.sum
(Filter<?> filter, Remote.ToLongFunction<? super T> extractor) Return the sum of the specified function.AbstractRepository.sum
(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor) Return the sum of the specified function.double
AbstractRepository.sum
(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor) Return the sum of the specified function.long
AbstractRepository.sum
(Filter<?> filter, Remote.ToIntFunction<? super T> extractor) Return the sum of the specified function.long
AbstractRepository.sum
(Filter<?> filter, Remote.ToLongFunction<? super T> extractor) Return the sum of the specified function.<R extends Comparable<? super R>>
CompletableFuture<List<R>> AbstractAsyncRepository.top
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor, int cResults) Return the top N highest values for the specified extractor.<R> CompletableFuture
<List<R>> AbstractAsyncRepository.top
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor, Remote.Comparator<? super R> comparator, int cResults) Return the top N highest values for the specified extractor.<R extends Comparable<? super R>>
List<R> AbstractRepository.top
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor, int cResults) Return the top N highest values for the specified extractor.<R> List
<R> AbstractRepository.top
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor, Remote.Comparator<? super R> comparator, int cResults) Return the top N highest values for the specified extractor.AbstractAsyncRepository.topBy
(Filter<?> filter, Remote.Comparator<? super T> comparator, int cResults) Return the top N entities with the highest values for the specified extractor.<R extends Comparable<? super R>>
CompletableFuture<List<T>> AbstractAsyncRepository.topBy
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor, int cResults) Return the top N entities with the highest values for the specified extractor.AbstractRepository.topBy
(Filter<?> filter, Remote.Comparator<? super T> comparator, int cResults) Return the top N entities with the highest values for the specified extractor.<R extends Comparable<? super R>>
List<T> AbstractRepository.topBy
(Filter<?> filter, ValueExtractor<? super T, ? extends R> extractor, int cResults) Return the top N entities with the highest values for the specified extractor.<U,
R> CompletableFuture <Map<ID, R>> AbstractAsyncRepository.updateAll
(Filter<?> filter, Remote.BiFunction<? super T, ? super U, ? extends R> updater, U value) Update multiple entities using specified updater and the new value.<R> CompletableFuture
<Map<ID, R>> AbstractAsyncRepository.updateAll
(Filter<?> filter, Remote.Function<? super T, ? extends R> updater) Update multiple entities using specified updater function.<U> CompletableFuture
<Void> AbstractAsyncRepository.updateAll
(Filter<?> filter, ValueUpdater<? super T, ? super U> updater, U value) Update multiple entities using specified updater and the new value.AbstractRepository.updateAll
(Filter<?> filter, Remote.BiFunction<? super T, ? super U, ? extends R> updater, U value) Update multiple entities using specified updater and the new value.AbstractRepository.updateAll
(Filter<?> filter, Remote.Function<? super T, ? extends R> updater) Update multiple entities using specified updater function.<U> void
AbstractRepository.updateAll
(Filter<?> filter, ValueUpdater<? super T, ? super U> updater, U value) Update multiple entities using specified updater and the new value. -
Uses of Filter in com.tangosol.coherence.config.builder
Modifier and TypeMethodDescriptionInetAddressRangeFilterBuilder.realize
(ParameterResolver resolver, ClassLoader loader, ParameterList listParameters) Realizes (creates if necessary) an instance of a object of type T, using the providedParameterResolver
to resolve values any referencedParameter
s. -
Uses of Filter in com.tangosol.coherence.config.scheme
Modifier and TypeMethodDescriptionContinuousQueryCacheScheme.getFilterBuilder()
Return theParameterizedBuilder
used to construct theFilter
to be used by theContinuousQueryCache
.Modifier and TypeMethodDescriptionvoid
ContinuousQueryCacheScheme.setFilterBuilder
(ParameterizedBuilder<Filter> filterBuilder) -
Uses of Filter in com.tangosol.coherence.config.xml.processor
Modifier and TypeMethodDescriptionAuthorizedHostsProcessor.process
(ProcessingContext context, XmlElement xmlElement) Process anXmlElement
to return a specific type of value.TransformerProcessor.process
(ProcessingContext context, XmlElement xmlElement) -
Uses of Filter in com.tangosol.coherence.dslquery
Modifier and TypeMethodDescriptionFilterBuilder.makeFilter()
Make a new Filter from the set AST.FilterBuilder.makeFilter
(Term term) Make a new Filter from the given AST.FilterBuilder.makeFilter
(Term term, Object[] aoIndexedBindVars) Make a new Filter from the given AST using given array for Bind vars.FilterBuilder.makeFilter
(Term term, Object[] aoIndexedBindVars, Map mapNamedBindVars) Make a new Filter from the given AST using the given bind variables.FilterBuilder.makeFilter
(Term term, List listBindVars, ParameterResolver namedBindVars) Make a new Filter from the given AST using the given bind variables.FilterBuilder.makeFilterForCache
(String sCacheName, Term term, List indexedBindVars, ParameterResolver namedBindVars) Make a new Filter from the given AST using given array for Bind vars. -
Uses of Filter in com.tangosol.coherence.dslquery.operator
Modifier and TypeClassDescriptionclass
BaseOperator<F extends Filter>
A base class for CohQL Operator implementations.Modifier and TypeMethodDescriptionInOperator.makeFilter
(Object oLeft, Object oRight) XorOperator.makeFilter
(Object oLeft, Object oRight) Modifier and TypeMethodDescriptionprotected void
AndOperator.populateFilterArray
(Filter[] aFilterDest, Filter... aFilterSrc) Populate the specified targetFilter
array with the Filters in the source array.protected void
OrOperator.populateFilterArray
(Filter[] aFilterDest, Filter... aFilterSrc) Populate the specified targetFilter
array with the Filters in the source array. -
Uses of Filter in com.tangosol.coherence.dslquery.statement
Modifier and TypeFieldDescriptionprotected final Filter
DeleteStatementBuilder.DeleteStatement.f_filter
TheFilter
to be used in the CohQL "delete" command.protected final Filter
QueryRecorderStatementBuilder.QueryRecorderStatement.f_filter
TheFilter
to be explained or traced.protected final Filter
SelectStatementBuilder.AsyncSelectStatement.f_filter
TheFilter
to use in the query.protected final Filter
SelectStatementBuilder.SelectStatement.f_filter
TheFilter
to use in the query.protected final Filter
UpdateStatementBuilder.UpdateStatement.f_filter
TheFilter
that will be used to select entries to be updated.Modifier and TypeMethodDescriptionprotected static Filter
AbstractStatementBuilder.ensureFilter
(NodeTerm termWhere, String sCacheName, String sAlias, List listBindVars, ParameterResolver namedBindVars, ExecutionContext ctx) Build aFilter
for the given cache using the given where clause, alias and bind environments.SelectStatementBuilder.AsyncSelectStatement.getFilter()
Return theFilter
to use to execute this query.SelectStatementBuilder.SelectStatement.getFilter()
Return theFilter
to use to execute this query.ModifierConstructorDescriptionDeleteStatement
(String sCacheName, Filter filter) Create an instance ofDeleteStatementBuilder.DeleteStatement
that will delete all entries from the specified cache that match the givenFilter
.QueryRecorderStatement
(String sCacheName, Filter filter, QueryRecorder.RecordType type) Construct a QueryRecorderStatement that produces a plan or trace of the specified filter query against the specified cache.SelectStatement
(String sCache, Filter filter, InvocableMap.EntryAggregator aggregator, boolean fReduction) Construct a SelectStatement that will query the specified cache.UpdateStatement
(String sCache, Filter filter, InvocableMap.EntryProcessor processor) Construct a UpdateStatement that will update the specified cache. -
Uses of Filter in com.tangosol.coherence.jcache.common
Modifier and TypeClassDescriptionclass
Server side filter to filter out both coherence and jcache synthetic events. -
Uses of Filter in com.tangosol.coherence.jcache.localcache
Modifier and TypeClassDescriptionstatic class
Server side filter to filter out both coherence and jcache synthetic events. -
Uses of Filter in com.tangosol.coherence.jcache.partitionedcache
Modifier and TypeClassDescriptionstatic class
NonSyntheticEntryFilterstatic class
Server side filter for JCache ExpiryCacheEvents. -
Uses of Filter in com.tangosol.coherence.jcache.passthroughcache
Modifier and TypeClassDescriptionclass
-
Uses of Filter in com.tangosol.coherence.rest.events
Modifier and TypeMethodDescriptionSet the filter to listen on. -
Uses of Filter in com.tangosol.net
Modifier and TypeClassDescriptionstatic class
The RoutableFilter evaluates to true for any InetAddress which is externally routable.static class
SubnetMaskFilter evaluates to true for any address with matches the pattern for the masked bitsModifier and TypeFieldDescriptionprotected Filter
<?> MapViewBuilder.m_filter
TheFilter
that will be used to define the entries maintained in this view.Modifier and TypeMethodDescriptionClusterDependencies.getAuthorizedHostFilter()
Obtain the filter that is used by the cluster to determine whether to accept a new Cluster member.Modifier and TypeMethodDescription<R> CompletableFuture
<R> AsyncNamedMap.aggregate
(Filter<?> filter, InvocableMap.EntryAggregator<? super K, ? super V, R> aggregator) Perform an aggregating operation asynchronously against the set of entries that are selected by the given Filter.default long
PagedTopicService.ensureSubscriberGroup
(String sTopicName, String sGroupName, Filter<?> filter, ValueExtractor<?, ?> extractor) Ensure the specified subscriber group is created in a subscription.long
PagedTopicService.ensureSubscription
(String sTopicName, com.tangosol.internal.net.topic.impl.paged.model.SubscriberGroupId groupId, Subscriber.Id subscriberId, Filter<?> filter, ValueExtractor<?, ?> extractor) Ensure the specified subscriber is created in a subscription.default CompletableFuture
<Set<Map.Entry<K, V>>> Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.default CompletableFuture
<Set<Map.Entry<K, V>>> AsyncNamedMap.entrySet
(Filter<?> filter, Comparator<?> comparator) Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.default CompletableFuture
<Void> AsyncNamedMap.entrySet
(Filter<?> filter, BiConsumer<? super K, ? super V> callback) Stream the entries that satisfy the specified filter to the provided callback.default CompletableFuture
<Void> AsyncNamedMap.entrySet
(Filter<?> filter, Consumer<? super Map.Entry<? extends K, ? extends V>> callback) Stream the entries that satisfy the specified filter to the provided callback.TheFilter
that will be used to define the entries maintained in this view.TheFilter
that will be used to define the entries maintained in this view.default CompletableFuture
<Map<K, V>> Get all the entries that satisfy the specified filter.default CompletableFuture
<Void> AsyncNamedMap.getAll
(Filter<?> filter, BiConsumer<? super K, ? super V> callback) Get all the entries that satisfy the specified filter.default CompletableFuture
<Void> AsyncNamedMap.getAll
(Filter<?> filter, Consumer<? super Map.Entry<? extends K, ? extends V>> callback) Get all the entries that satisfy the specified filter.static InetAddress
InetAddressHelper.getLocalAddress
(Filter filter) Obtain the "best" local host address which matches the supplied filter.<R> CompletableFuture
<Map<K, R>> AsyncNamedMap.invokeAll
(Filter<?> filter, InvocableMap.EntryProcessor<K, V, R> processor) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter asynchronously, returning aCompletableFuture
that can be used to obtain the result of the invocation for each entry.default <R> CompletableFuture
<Void> AsyncNamedMap.invokeAll
(Filter<?> filter, InvocableMap.EntryProcessor<K, V, R> processor, BiConsumer<? super K, ? super R> callback) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter asynchronously, returning aCompletableFuture
that can be used to determine if the operation completed successfully.<R> CompletableFuture
<Void> AsyncNamedMap.invokeAll
(Filter<?> filter, InvocableMap.EntryProcessor<K, V, R> processor, Consumer<? super Map.Entry<? extends K, ? extends R>> callback) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter asynchronously, returning aCompletableFuture
that can be used to determine if the operation completed successfully.default CompletableFuture
<Set<K>> Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.default CompletableFuture
<Void> Stream the keys for the entries that satisfy the specified filter to the provided callback.default CompletableFuture
<Void> Removes all of the mappings that satisfy the specified filter from this map.default CompletableFuture
<Map<K, Void>> AsyncNamedMap.replaceAll
(Filter<?> filter, Remote.BiFunction<? super K, ? super V, ? extends V> function) Replace each entry's value with the result of invoking the given function on that entry until all entries selected by the specified filter have been processed or the function throws an exception.default CompletableFuture
<Collection<V>> Return a collection of the values contained in this map that satisfy the criteria expressed by the filter.default CompletableFuture
<Collection<V>> AsyncNamedMap.values
(Filter<?> filter, Comparator<? super V> comparator) Return a collection of the values contained in this map that satisfy the criteria expressed by the filter.default CompletableFuture
<Void> Stream the values for the entries that satisfy the specified filter to the provided callback. -
Uses of Filter in com.tangosol.net.cache
Modifier and TypeClassDescriptionprotected static class
A combination Filter and Converter used to iterate through the status map in order to iterate through the front keys.Modifier and TypeFieldDescriptionprotected Filter
CachingMap.FrontMapListener.m_filter
The filter associated with this listener.protected Filter
ContinuousQueryCache.m_filter
The filter that represents the subset of information from the underlyingNamedCache
that thisContinuousQueryCache
represents.Modifier and TypeMethodDescriptionprotected Filter
ContinuousQueryCache.createTransformerFilter
(MapEventFilter filterAdd) Wrap specifiedMapEventFilter
with aMapEventTransformerFilter
that will either transform cache value using transformer defined for thisContinuousQueryCache
, or remove the old value from the event usingSemiLiteEventTransformer
, if no transformer is defined for thisContinuousQueryCache
.ContinuousQueryCache.getFilter()
protected Filter
ContinuousQueryCache.mergeFilter
(Filter filter) Modifier and TypeMethodDescriptionvoid
AbstractSerializationCache.addMapListener
(MapListener listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.void
ContinuousQueryCache.addMapListener
(MapListener<? super K, ? super V_FRONT> listener, Filter filter, boolean fLite) void
LocalCache.addMapListener
(MapListener listener, Filter filter, boolean fLite) void
NearCache.addMapListener
(MapListener<? super K, ? super V> listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.void
OverflowMap.addMapListener
(MapListener listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.void
ReadWriteBackingMap.addMapListener
(MapListener listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.<R> R
ContinuousQueryCache.aggregate
(Filter filter, InvocableMap.EntryAggregator<? super K, ? super V_FRONT, R> aggregator) <R> R
NearCache.aggregate
(Filter filter, InvocableMap.EntryAggregator<? super K, ? super V, R> aggregator) Perform an aggregating operation against the set of entries that are selected by the given Filter.<R> R
WrapperNamedCache.aggregate
(Filter filter, InvocableMap.EntryAggregator<? super K, ? super V, R> agent) Perform an aggregating operation against the set of entries that are selected by the given Filter.ContinuousQueryCache.entrySet
(Filter filter, Comparator comparator) Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.NearCache.entrySet
(Filter filter, Comparator comparator) Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.WrapperNamedCache.entrySet
(Filter filter, Comparator comparator) Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.ContinuousQueryCache.entrySetInternal
(Filter filter) Return multiple values from the back cache based on a filter, transforming them in the process if necessary.ContinuousQueryCache.entrySetInternal
(Filter filter, Comparator comparator) Return multiple values from the back cache based on a filter, transforming them in the process if necessary.protected static String
ContinuousQueryCache.getDefaultName
(String sCacheName, Filter filter, ValueExtractor transformer) Return the default name used by the CQC.ContinuousQueryCache.invokeAll
(Filter filter, InvocableMap.EntryProcessor<K, V_FRONT, R> processor) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.NearCache.invokeAll
(Filter filter, InvocableMap.EntryProcessor<K, V, R> processor) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.ReadonlyNamedCache.invokeAll
(Filter filter, InvocableMap.EntryProcessor<K, V, R> agent) Should not be called.WrapperNamedCache.invokeAll
(Filter filter, InvocableMap.EntryProcessor<K, V, R> agent) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.protected Filter
ContinuousQueryCache.mergeFilter
(Filter filter) void
AbstractSerializationCache.removeMapListener
(MapListener listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.void
ContinuousQueryCache.removeMapListener
(MapListener<? super K, ? super V_FRONT> listener, Filter filter) void
LocalCache.removeMapListener
(MapListener listener, Filter filter) void
NearCache.removeMapListener
(MapListener<? super K, ? super V> listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.void
OverflowMap.removeMapListener
(MapListener listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.void
ReadWriteBackingMap.removeMapListener
(MapListener listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.ModifierConstructorDescriptionContinuousQueryCache
(NamedCache<K, V_BACK> cache, Filter filter) Create a locally materialized view of aNamedCache
using a Filter.ContinuousQueryCache
(NamedCache<K, V_BACK> cache, Filter filter, boolean fCacheValues) Create a materialized view of aNamedCache
using a Filter.ContinuousQueryCache
(NamedCache<K, V_BACK> cache, Filter filter, boolean fCacheValues, MapListener<? super K, ? super V_FRONT> listener, ValueExtractor<? super V_BACK, ? extends V_FRONT> transformer) Construct the ContinuousQueryCache.ContinuousQueryCache
(NamedCache<K, V_BACK> cache, Filter filter, MapListener<? super K, ? super V_FRONT> listener) Create a materialized view of aNamedCache
using a Filter.ContinuousQueryCache
(NamedCache<K, V_BACK> cache, Filter filter, MapListener<? super K, ? super V_FRONT> listener, ValueExtractor<? super V_BACK, ? extends V_FRONT> transformer) Create a materialized view of aNamedCache
using aFilter
.ContinuousQueryCache
(NamedCache<K, V_BACK> cache, Filter filter, ValueExtractor<? super V_BACK, ? extends V_FRONT> transformer) Create a locally materialized view of aNamedCache
using aFilter
and a transformer.ContinuousQueryCache
(Supplier<NamedCache<K, V_BACK>> supplierCache, Filter filter) Create a locally materialized view of aNamedCache
using aFilter
.ContinuousQueryCache
(Supplier<NamedCache<K, V_BACK>> supplierCache, Filter filter, boolean fCacheValues, MapListener<? super K, ? super V_FRONT> listener, ValueExtractor<? super V_BACK, ? extends V_FRONT> transformer, ClassLoader loader) Create a materialized view of aNamedCache
using aFilter
. -
Uses of Filter in com.tangosol.net.management
Modifier and TypeClassDescriptionclass
Filter used to prevent registering MBeans that match the specified pattern.Modifier and TypeFieldDescriptionprotected Filter
<MBeanAttributeInfo> MBeanAccessor.GetAttributes.m_filter
MBean Attribute filter.protected Filter
ObjectNameExcludeFilter.m_filter
The underlying filter.Modifier and TypeFieldDescriptionMBeanAccessor.QueryBuilder.m_mapFilters
A map of ObjectName key to Filter.MBeanAccessor.QueryBuilder.ParsedQuery.m_mapFilters
A map of ObjectName key to Filter.Modifier and TypeMethodDescriptionMBeanAccessor.QueryBuilder.ParsedQuery.getObjectNameFilter()
Return a Filter that can be applied against an ObjectName and ensures all the Filters within themap
of filters test successfully (logical AND).Modifier and TypeMethodDescriptionMBeanAccessor.QueryBuilder.ensureMapFilters()
Ensure a Map is created to storeFilter
s to apply against values of the key/value pairs within the ObjectName.MBeanAccessor.QueryBuilder.ParsedQuery.getMapFilters()
Return a map of key to Filter used to test against the corresponding key/value within the ObjectName.Modifier and TypeMethodDescriptionprotected void
MBeanAccessor.GetAttributes.addMBeanAttributes
(ObjectName oObjName, Map<String, Object> mapAttributes, MBeanServer mBeanServer, Filter<MBeanAttributeInfo> filter) Add attributes of an MBean to a Map.MBeanAccessor.getAttributes
(MBeanAccessor.QueryBuilder.ParsedQuery query, Filter<MBeanAttributeInfo> filter, boolean fAddStorageMBeanAttributes) Return all the attributes that match the query expressed by the providedMBeanAccessor.QueryBuilder
.MBeanServerProxy.getAttributes
(String sName, Filter<String> filter) Return a Map of attribute name to attribute value for a given MBean name.WrapperMBeanServerProxy.getAttributes
(String sName, Filter<String> filter) MBeanServerProxy.queryNames
(String sPattern, Filter<ObjectName> filter) Get the names of MBeans controlled by the MBean server that is collocated with thecluster registry
.MBeanServerProxy.queryNames
(ObjectName pattern, Filter<ObjectName> filter) Get the names of MBeans controlled by the MBean server that is collocated with thecluster registry
.WrapperMBeanServerProxy.queryNames
(String sPattern, Filter<ObjectName> filter) WrapperMBeanServerProxy.queryNames
(ObjectName pattern, Filter<ObjectName> filter) MBeanAccessor.QueryBuilder.withFilter
(String sKey, Filter<String> predicate) ModifierConstructorDescriptionGetAttributes
(MBeanAccessor.QueryBuilder.ParsedQuery query, Filter<MBeanAttributeInfo> filter, boolean fAddStorageMBeanAttributes) Create a GetAttributes object.QueryExpFilter
(Filter<ObjectName> filter) -
Uses of Filter in com.tangosol.net.partition
Modifier and TypeClassDescriptionclass
NotOwnedFilter is a Filter implementation used to evaluate Member objects, and selects members who are not represented in the reference ownership object.class
SafetyFilter is a Filter implementation used to evaluate Member objects, and selects members that are "strong" with respect to the reference ownership, as defined by the backup-strength.class
UnderloadedFilter is a Filter implementation that is used to evaluate Member objects, and selects those whose partition load is "underloaded" in comparison to the fair-share load.Modifier and TypeMethodDescriptionSimpleAssignmentStrategy.AnalysisContext.instantiateNotOwnedFilter
(Ownership owners) Instantiate and return a NotOwnedFilter with the specified ownership.SimpleAssignmentStrategy.AnalysisContext.instantiateOverloadedFilter
(boolean fPrimary) Instantiate a filter that matches members with an over-load.SimpleAssignmentStrategy.AnalysisContext.instantiateSafetyFilter
(Ownership owners, int iStore) Instantiate and return a SafetyFilter with the specified ownership.SimpleAssignmentStrategy.AnalysisContext.instantiateUnderloadedFilter
(boolean fPrimary) Instantiate a filter that matches members with an under-load.Modifier and TypeMethodDescriptionvoid
ObservableSplittingBackingMap.addMapListener
(MapListener listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.protected static int
SimpleAssignmentStrategy.filterArray
(Object[] ao, int cElems, Filter filter) Apply the specified filter to the specified array elements.protected static int
SimpleAssignmentStrategy.filterArray
(Object[] ao, Filter filter) Apply the specified filter to the elements of the specified array.protected static int
SimpleAssignmentStrategy.filterSort
(Object[] ao, int cElems, Comparator comparator, Filter filter) Filter the specified array elements and sort any matching elements using the specified comparator.protected static int
SimpleAssignmentStrategy.filterSort
(Object[] ao, Comparator comparator, Filter filter) Filter the elements in the specified array and sort any matching elements using the specified comparator.void
ObservableSplittingBackingMap.removeMapListener
(MapListener listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.ModifierConstructorDescriptionprotected
AbstractPartitionedIterator
(Filter filter, NamedCache cache, PartitionSet setPids) Create AbstractPartitionedIterator instance.protected
AbstractPartitionedIterator
(Filter filter, NamedCache cache, PartitionSet setPids, boolean fByMember, boolean fRandom) Create AbstractPartitionedIterator instance.PartitionedIterator
(NamedCache cache, Filter filter, PartitionSet setPids, int nOptions) Construct PartitionedIterator that will provide iteration of the keys of the specified cache using the specified filter, but will only query one partition or one member at a time. -
Uses of Filter in com.tangosol.net.topic
Modifier and TypeMethodDescriptionstatic <V> Subscriber.Filtered
<V> Return a Filtered option with the specified filter.void
NamedTopic.ensureSubscriberGroup
(String sGroup, Filter<?> filter, ValueExtractor<?, ?> extractor) Ensure that the specified subscriber group exists for this topic.static <V> Subscriber.Filtered
<V> Subscriber.withFilter
(Filter<? super V> filter) Return a Filtered option with the specified filter. -
Uses of Filter in com.tangosol.persistence
Modifier and TypeMethodDescriptionstatic com.oracle.coherence.persistence.PersistentStore.Visitor
<ReadBuffer> CachePersistenceHelper.instantiateEventsVisitor
(long lExtentId, Filter filter, long lVersion, Map<Long, MapEvent> mapEvents, Converter<Long, ReadBuffer> convKeyDown, Converter<ReadBuffer, Long> convKeyUp, Converter<Object, ReadBuffer> convDown, Converter<ReadBuffer, Object> convUp) Create aPersistentStore.Visitor
that can read a PersistentStore and populate the providedmapEvents
with events that are larger than the provided version (inclusive) and match the givenFilter
. -
Uses of Filter in com.tangosol.util
Modifier and TypeClassDescriptionclass
Filter which discards all objects that are not of a certain class.class
Filter which discards null references.Modifier and TypeFieldDescriptionprotected final Filter[]
MapListenerSupport.FilterEvent.f_aFilter
Filters that caused the event.protected Filter
FilterEnumerator.m_test
Test to perform on each item.Modifier and TypeFieldDescriptionprotected Map
<Filter, SimpleQueryRecord.PartialResult.Step> SimpleQueryRecord.PartialResult.AbstractRecordableStep.m_mapSteps
The Map of child steps.Modifier and TypeMethodDescriptionstatic <T> Filter
<T> Return a composite filter representing logical AND of all specified filters.static <T> Filter
<T> Filters.always()
Return a filter that always evaluates to true.default Filter
Return a composed filter that represents a short-circuiting logical AND of this filter and another.static <T> Filter
<T> Return a composite filter representing logical OR of all specified filters.static <T,
E> Filter <T> Filters.arrayContains
(ValueExtractor<T, E[]> extractor, E value) Return a filter that tests if the extracted array contains the specified value.static <T,
E> Filter <T> Filters.arrayContainsAll
(ValueExtractor<T, E[]> extractor, E... values) Return a filter that tests if the extracted array contains all of the specified values.static <T,
E> Filter <T> Filters.arrayContainsAll
(ValueExtractor<T, E[]> extractor, Set<? extends E> setValues) Return a filter that tests if the extracted array contains all of the specified values.static <T,
E> Filter <T> Filters.arrayContainsAny
(ValueExtractor<T, E[]> extractor, E... values) Return a filter that tests if the extracted array contains any of the specified values.static <T,
E> Filter <T> Filters.arrayContainsAny
(ValueExtractor<T, E[]> extractor, Set<? extends E> setValues) Return a filter that tests if the extracted array contains any of the specified values.static <T,
E extends Comparable<? super E>>
Filter<T> Filters.between
(ValueExtractor<T, ? extends E> extractor, E from, E to) Return a filter that tests if the extracted value is between the specified values (inclusive).static <T,
E, C extends Collection<? extends E>>
Filter<T> Filters.contains
(ValueExtractor<T, C> extractor, E value) Return a filter that tests if the extracted collection contains the specified value.static <T,
E, C extends Collection<? extends E>>
Filter<T> Filters.containsAll
(ValueExtractor<T, C> extractor, E... values) Return a filter that tests if the extracted collection contains all of the specified values.static <T,
E, C extends Collection<? extends E>>
Filter<T> Filters.containsAll
(ValueExtractor<T, C> extractor, Set<? extends E> setValues) Return a filter that tests if the extracted collection contains all of the specified values.static <T,
E, C extends Collection<? extends E>>
Filter<T> Filters.containsAny
(ValueExtractor<T, C> extractor, E... values) Return a filter that tests if the extracted collection contains any of the specified values.static <T,
E, C extends Collection<? extends E>>
Filter<T> Filters.containsAny
(ValueExtractor<T, C> extractor, Set<? extends E> setValues) Return a filter that tests if the extracted collection contains any of the specified values.static Filter
QueryHelper.createFilter
(String sWhereClause) Make a new Filter from the given String.static Filter
QueryHelper.createFilter
(String sWhereClause, Object[] aoBindings) Make a new Filter from the given String.static Filter
QueryHelper.createFilter
(String sWhereClause, Object[] aBindings, Map mapBindings) Make a new Filter from the given String.static Filter
QueryHelper.createFilter
(String sWhereClause, Object[] aBindings, Map mapBindings, CoherenceQueryLanguage language) Make a new Filter from the given String.static Filter
QueryHelper.createFilter
(String sWhereClause, Map mapBindings) Make a new Filter from the given String.static <T,
E> Filter <T> Filters.equal
(ValueExtractor<T, ? extends E> extractor, E value) Return a filter that tests for equality.static <T,
E> Filter <T> Return a filter that tests for equality using aUniversalExtractor
instance to extract the specified field.ConditionalIndex.getFilter()
Get the associated filter.Filter[]
MapListenerSupport.FilterEvent.getFilter()
Return an array of filters that are the cause of this event.Filter[]
Listeners.getFilters()
Return the array of filters associated with this Listeners object.static <T,
E extends Comparable<? super E>>
Filter<T> Filters.greater
(ValueExtractor<T, ? extends E> extractor, E value) Return a filter that tests if the extracted value is greater than the specified value.static <T,
E extends Comparable<? super E>>
Filter<T> Filters.greaterEqual
(ValueExtractor<T, ? extends E> extractor, E value) Return a filter that tests if the extracted value is greater than or equal to the specified value.static <T,
E> Filter <T> Filters.in
(ValueExtractor<T, ? extends E> extractor, E... values) Return a filter that tests if the extracted value is contained in the specified array.static <T,
E> Filter <T> Filters.in
(ValueExtractor<T, ? extends E> extractor, Set<? extends E> setValues) Return a filter that tests if the extracted value is contained in the specified set.static <T> Filter
<T> Filters.isFalse
(ValueExtractor<T, Boolean> extractor) Return a filter that evaluates to true if the extracted value isfalse
.static <T,
E> Filter <T> Filters.isNotNull
(ValueExtractor<T, E> extractor) Return a filter that evaluates to true for non-null values.static <T,
E> Filter <T> Filters.isNull
(ValueExtractor<T, E> extractor) Return a filter that evaluates to true for null values.static <T> Filter
<T> Filters.isTrue
(ValueExtractor<T, Boolean> extractor) Return a filter that evaluates to true if the extracted value istrue
.static <T,
E extends Comparable<? super E>>
Filter<T> Filters.less
(ValueExtractor<T, ? extends E> extractor, E value) Return a filter that tests if the extracted value is less than the specified value.static <T,
E extends Comparable<? super E>>
Filter<T> Filters.lessEqual
(ValueExtractor<T, ? extends E> extractor, E value) Return a filter that tests if the extracted value is less than or equal to the specified value.static <T,
E> Filter <T> Filters.like
(ValueExtractor<T, E> extractor, String sPattern) Return a LikeFilter for pattern match.static <T,
E> Filter <T> Filters.like
(ValueExtractor<T, E> extractor, String sPattern, boolean fIgnoreCase) Return a LikeFilter for pattern match.static <T,
E> Filter <T> Filters.like
(ValueExtractor<T, E> extractor, String sPattern, char chEscape) Return a LikeFilter for pattern match.static <T,
E> Filter <T> Filters.like
(ValueExtractor<T, E> extractor, String sPattern, char chEscape, boolean fIgnoreCase) Return a LikeFilter for pattern match.static <T> Filter
<T> Filters.never()
Return a filter that always evaluates to false.static <T> Filter
<T> Return a filter that represents the logical negation of the specified filter.static <T,
E> Filter <T> Filters.notEqual
(ValueExtractor<T, ? extends E> extractor, E value) Return a filter that tests for non-equality.default Filter
Return a composed predicate that represents a short-circuiting logical OR of this predicate and another.static <T> Filter
<T> Filters.predicate
(Remote.Predicate<T> predicate) Return a PredicateFilter for a givenPredicate
.static <T,
E> Filter <T> Filters.predicate
(ValueExtractor<T, ? extends E> extractor, Remote.Predicate<? super E> predicate) Return a PredicateFilter for a givenPredicate
.static <T> Filter
<T> Filters.present()
Return a filter that evaluates to true if an entry is present in the cache.static <T,
E> Filter <T> Filters.regex
(ValueExtractor<T, E> extractor, String sRegex) Return a RegexFilter for pattern match.static <V> Filter
<V> Instantiate a Filter that is implemented in a script using the specified language.default Filter
Return a composed predicate that represents a logical XOR of this predicate and another.Modifier and TypeMethodDescriptionvoid
MapListenerSupport.addListener
(MapListener listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.boolean
MapListenerSupport.addListenerWithCheck
(MapListener listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.void
ConverterCollections.ConverterObservableMap.addMapListener
(MapListener<? super TK, ? super TV> listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.void
NullImplementation.NullObservableMap.addMapListener
(MapListener listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.void
ObservableHashMap.addMapListener
(MapListener<? super K, ? super V> listener, Filter filter, boolean fLite) void
ObservableMap.addMapListener
(MapListener<? super K, ? super V> listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.void
WrapperObservableMap.addMapListener
(MapListener<? super K, ? super V> listener, Filter filter, boolean fLite) Add a map listener that receives events based on a filter evaluation.protected static void
MapListenerSupport.addSafeListener
(Map mapListeners, Filter anyFilter, MapListener listener) Ensure that the specified map has a Listeners object associated with the specified Filter and add the specified listener to it.<R> R
ConverterCollections.ConverterInvocableMap.aggregate
(Filter filter, InvocableMap.EntryAggregator<? super TK, ? super TV, R> agent) Perform an aggregating operation against the set of entries that are selected by the given Filter.<R> R
ConverterCollections.ConverterNamedCache.aggregate
(Filter filter, InvocableMap.EntryAggregator<? super TK, ? super TV, R> agent) Perform an aggregating operation against the set of entries that are selected by the given Filter.<R> R
InvocableMap.aggregate
(Filter filter, InvocableMap.EntryAggregator<? super K, ? super V, R> aggregator) Perform an aggregating operation against the set of entries that are selected by the given Filter.static <T> Filter
<T> Return a composite filter representing logical AND of all specified filters.default Filter
Return a composed filter that represents a short-circuiting logical AND of this filter and another.static <T> Filter
<T> Return a composite filter representing logical OR of all specified filters.static <K,
V, T> InvocableMap.EntryProcessor <K, V, T> Processors.conditional
(Filter<V> filter, InvocableMap.EntryProcessor<K, V, T> processor) Construct a conditional processor for a specified filter and the processor.boolean
MapListenerSupport.containsStandardListeners
(Filter filter) Checks whether or not this MapListenerSupport object contains any standard (not lite) listeners for a given filter.QueryRecord.PartialResult.ExplainStep.ensureStep
(Filter filter) Ensure an inner nested explain step for the given filter.QueryRecord.PartialResult.TraceStep.ensureStep
(Filter filter) Ensure an inner nested trace step for the given filter.SimpleQueryRecord.PartialResult.ExplainStep.ensureStep
(Filter filter) Ensure an inner nested explain step for the given filter.SimpleQueryRecord.PartialResult.TraceStep.ensureStep
(Filter filter) Ensure an inner nested trace step for the given filter.Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.ConverterCollections.ConverterNamedCache.entrySet
(Filter filter, Comparator comparator) Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.ConverterCollections.ConverterQueryMap.entrySet
(Filter filter, Comparator comparator) Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.QueryMap.entrySet
(Filter filter, Comparator comparator) Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.static <K,
V> boolean InvocableMapHelper.evaluateEntry
(Filter filter, Map.Entry<K, V> entry) Check if the entry passes the filter evaluation.static <K,
V> boolean InvocableMapHelper.evaluateEntry
(Filter filter, K oKey, V oValue) Check if an entry, expressed as a key and value, passes the filter evaluation.protected boolean
MapListenerSupport.evaluateEvent
(Filter filter, MapEvent event) Evaluate whether or not the specified event should be delivered to the listener associated with the specified filter.static boolean
InvocableMapHelper.evaluateOriginalEntry
(Filter filter, MapTrigger.Entry entry) Check if the entry, in its "original" form, passes the filter evaluation.default void
QueryMap.forEach
(Filter filter, BiConsumer<? super K, ? super V> action) Perform the given action for each entry selected by the specified filter until all entries have been processed or the action throws an exception.MapListenerSupport.getListeners
(Filter filter) Obtain the Listeners object for a given filter.MapListenerSupport.getMinVersions
(Filter filter) static <K,
V, E, R>
InvocableMap.StreamingAggregator<K, V, Map<E, Object>, Map<E, R>> Aggregators.grouping
(InvocableMap.EntryAggregator<K, V, R> aggregator, Filter filter, String... asNames) Create an instance of group aggregator based on a specified property or method name(s) and anInvocableMap.EntryAggregator
.static <K,
V, T, E, R>
InvocableMap.StreamingAggregator<K, V, Map<E, Object>, Map<E, R>> Aggregators.grouping
(ValueExtractor<? super T, ? extends E> extractor, InvocableMap.EntryAggregator<? super K, ? super V, R> aggregator, Filter filter) Create an instance of group aggregator based on a specified property or method name(s) and anInvocableMap.EntryAggregator
.SimpleQueryRecord.PartialResult.instantiateExplainStep
(Filter filter) Instantiate a new explain step for the given filter and add it to this result's list of steps.SimpleQueryRecord.PartialResult.instantiateTraceStep
(Filter filter) Instantiate a new trace step for the given filter and add it to this result's list of steps.ConverterCollections.ConverterInvocableMap.invokeAll
(Filter filter, InvocableMap.EntryProcessor<TK, TV, R> agent) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.ConverterCollections.ConverterNamedCache.invokeAll
(Filter filter, InvocableMap.EntryProcessor<TK, TV, R> agent) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.InvocableMap.invokeAll
(Filter filter, InvocableMap.EntryProcessor<K, V, R> processor) Invoke the passed EntryProcessor against the set of entries that are selected by the given Filter, returning the result of the invocation for each.boolean
Checks whether or not this MapListenerSupport object contains any listeners for a given filter.Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.static <T> Filter
<T> Return a filter that represents the logical negation of the specified filter.default Filter
Return a composed predicate that represents a short-circuiting logical OR of this predicate and another.static <K,
V> InvocableMap.EntryProcessor <K, V, V> Construct a put processor that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.static <K,
V> InvocableMap.EntryProcessor <K, V, V> Construct a put processor that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.static <K,
V> InvocableMap.EntryProcessor <K, V, V> Construct a putAll processor that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.static Set
InvocableMapHelper.query
(Map map, Filter filter, boolean fEntries, boolean fSort, Comparator comparator) Generic implementation of theQueryMap
API.static Set
InvocableMapHelper.query
(Map map, Map mapIndexes, Filter filter, boolean fEntries, boolean fSort, Comparator comparator) Generic implementation of theQueryMap
API.static <K,
V> InvocableMap.EntryProcessor <K, V, V> Construct a remove processor that removes an InvocableMap entry if and only if the filter applied to the entry evaluates to true.static <K,
V> InvocableMap.EntryProcessor <K, V, V> Construct a remove processor that removes an InvocableMap entry if and only if the filter applied to the entry evaluates to true.void
MapListenerSupport.removeListener
(MapListener listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.boolean
MapListenerSupport.removeListenerWithCheck
(MapListener listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.void
ConverterCollections.ConverterObservableMap.removeMapListener
(MapListener<? super TK, ? super TV> listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.void
NullImplementation.NullObservableMap.removeMapListener
(MapListener listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.void
ObservableHashMap.removeMapListener
(MapListener<? super K, ? super V> listener, Filter filter) void
ObservableMap.removeMapListener
(MapListener<? super K, ? super V> listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.void
WrapperObservableMap.removeMapListener
(MapListener<? super K, ? super V> listener, Filter filter) Remove a map listener that previously signed up for events based on a filter evaluation.default void
InvocableMap.replaceAll
(Filter filter, Remote.BiFunction<? super K, ? super V, ? extends V> function) Replace each entry's value with the result of invoking the given function on that entry until all entries selected by the specified filter have been processed or the function throws an exception.void
Listeners.setFilters
(Filter[] aFilter) Set the array of filters associated with this Listeners object.default RemoteStream
<InvocableMap.Entry<K, V>> Return a filtered stream of entries in this map.default <T,
E> RemoteStream <E> InvocableMap.stream
(Filter filter, ValueExtractor<T, ? extends E> extractor) Return a stream of values extracted from all the entries that satisfy the specified filter.default Collection
<V> Return a collection of the values contained in this map that satisfy the criteria expressed by the filter.default Collection
<V> QueryMap.values
(Filter filter, Comparator comparator) Return a collection of the values contained in this map that satisfy the criteria expressed by the filter.default Filter
Return a composed predicate that represents a logical XOR of this predicate and another.ModifierConstructorDescriptionAbstractRecordableStep
(Filter filter) Construct an AbstractRecordableStep.ConditionalIndex
(Filter filter, ValueExtractor extractor, boolean fOrdered, Comparator comparator, boolean fForwardIndex, BackingMapContext ctx) Construct a ConditionalIndex.ExplainStep
(Filter filter) Construct an ExplainStepFilterEnumerator
(Object[] aoItem, Filter test) Construct the Filter enumerator based on an array of objects.FilterEnumerator
(Enumeration enmr, Filter test) Construct the Filter enumerator based on an Enumeration.FilterEnumerator
(Iterator iter, Filter test) Construct the Filter enumerator based on an Iterator.FilterEvent
(MapEvent event, Filter[] aFilter) Constructs a new FilterEvent that wraps the given MapEvent.FilterEvent
(ObservableMap map, int nId, Object oKey, boolean fSynthetic, boolean fPriming, Filter[] aFilter) Constructs a new lite (no values are specified) FilterEvent.FilterEvent
(ObservableMap map, int nId, Object oKey, boolean fSynthetic, Filter[] aFilter) Constructs a new lite (no values are specified) FilterEvent.FilterEvent
(ObservableMap map, int nId, Object oKey, Object oValueOld, Object oValueNew, boolean fSynthetic, boolean fPriming, Filter[] aFilter) Constructs a new FilterEvent.FilterEvent
(ObservableMap map, int nId, Object oKey, Object oValueOld, Object oValueNew, boolean fSynthetic, CacheEvent.TransformationState transformState, boolean fPriming, boolean fExpired, Filter[] aFilter) Constructs a new FilterEvent.FilterEvent
(ObservableMap map, int nId, Object oKey, Object oValueOld, Object oValueNew, boolean fSynthetic, CacheEvent.TransformationState transformState, boolean fPriming, Filter[] aFilter) Constructs a new FilterEvent.FilterEvent
(ObservableMap map, int nId, Object oKey, Object oValueOld, Object oValueNew, boolean fSynthetic, CacheEvent.TransformationState transformState, Filter[] aFilter) Constructs a new FilterEvent.Construct a step.Construct a TraceStep -
Uses of Filter in com.tangosol.util.aggregator
Modifier and TypeFieldDescriptionprotected Filter
GroupAggregator.m_filter
The Filter object representing the "having" clause of this "group by" aggregator.Modifier and TypeMethodDescriptionstatic <K,
V, T, E, R>
GroupAggregator<K, V, T, E, R> GroupAggregator.createInstance
(ValueExtractor<? super T, ? extends E> extractor, InvocableMap.EntryAggregator<? super K, ? super V, R> aggregator, Filter filter) Create an instance of GroupAggregator based on a specified extractor and anEntryAggregator
and a result evaluation filter.static <K,
V, R> GroupAggregator <K, V, Object, Object, R> GroupAggregator.createInstance
(String sMethod, InvocableMap.EntryAggregator<K, V, R> aggregator, Filter filter) Create an instance of GroupAggregator based on a specified method name(s), anEntryAggregator
and a result evaluation filter.ModifierConstructorDescriptionprotected
GroupAggregator
(ValueExtractor<? super T, ? extends E> extractor, InvocableMap.EntryAggregator<? super K, ? super V, R> aggregator, Filter filter) Construct a GroupAggregator based on a specified ValueExtractor and underlying EntryAggregator.protected
Parallel
(ValueExtractor<? super T, ? extends E> extractor, InvocableMap.EntryAggregator<? super K, ? super V, R> aggregator, Filter<?> filter) Deprecated.Construct a Parallel aggregator based on a specified ValueExtractor and underlying ParallelAwareAggregator. -
Uses of Filter in com.tangosol.util.extractor
Modifier and TypeFieldDescriptionprotected Filter
ConditionalExtractor.m_filter
The filter used by this extractor.ModifierConstructorDescriptionConditionalExtractor
(Filter filter, ValueExtractor<T, E> extractor, boolean fForwardIndex) Construct the ConditionalExtractor.ConditionalExtractor
(Filter filter, ValueExtractor<T, E> extractor, boolean fForwardIndex, boolean fOptimizeMV) Construct the ConditionalExtractor. -
Uses of Filter in com.tangosol.util.filter
Modifier and TypeInterfaceDescriptioninterface
EntryFilter<K,
V> EntryFilter provides an extension to Filter for those cases in which both a key and a value may be necessary to evaluate the conditional inclusion of a particular object.interface
IndexAwareFilter<K,
V> IndexAwareFilter is an extension to the EntryFilter interface that allows a filter to use a Map index to fully or partially evaluate itself.interface
QueryRecorderFilter is an extension of EntryFilter that allows the projected or actual costs of query execution to be recorded.Modifier and TypeClassDescriptionclass
Abstract base class implementation ofQueryRecorderFilter
.class
Filter which returns the logical "and" of a filter array.class
AlwaysFilter<T>
Filter which always evaluates to true.class
Filter which returns the logical "and" of two other filters.class
Filter which returns the logical "or" of a filter array.class
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
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
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
Filter which limits the scope of another filter according to the key association information.class
KeyFilter<T>
EntryFilter which checks whether an entry key belongs to a set.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 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
Filter which returns the logical "or" of two other filters.class
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
Filter which returns true forInvocableMap.Entry
objects that currently exist in a Map.class
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 theString.matches(String)
contract.class
ScriptFilter<V>
ScriptFilter is aFilter
that wraps a script written in one of the languages supported by Graal VM.class
Filter which evaluates the content of a MapEvent values based on the specified value extractor.class
QueryRecorderFilter wrapper class.class
Filter which returns the logical exclusive or ("xor") of two other filters.Modifier and TypeFieldDescriptionprotected Filter[]
ArrayFilter.m_aFilter
The Filter array.protected Filter
FilterTrigger.m_filter
The underlying filter.MapEventFilter.m_filter
The event value(s) filter.Modifier and TypeMethodDescriptionprotected Filter
ArrayFilter.applyFilter
(Filter filter, int iFilter, Map mapIndexes, Set setKeys, QueryContext ctx, QueryRecord.PartialResult.TraceStep step) Apply the specified IndexAwareFilter to the specified keySet.protected Filter
AllFilter.applyIndex
(Map mapIndexes, Set setKeys, QueryContext ctx, QueryRecord.PartialResult.TraceStep step) Apply the specified IndexAwareFilter to the specified keySet.AlwaysFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.protected Filter
AnyFilter.applyIndex
(Map mapIndexes, Set setKeys, QueryContext ctx, QueryRecord.PartialResult.TraceStep step) Apply the specified IndexAwareFilter to the specified keySet.ArrayFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.protected abstract Filter
ArrayFilter.applyIndex
(Map mapIndexes, Set setKeys, QueryContext ctx, QueryRecord.PartialResult.TraceStep step) Apply the specified IndexAwareFilter to the specified keySet.BetweenFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.ContainsAllFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.ContainsAnyFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.ContainsFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.EqualsFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.ExtractorFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.GreaterEqualsFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.GreaterFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.Filter
<?> IndexAwareFilter.applyIndex
(Map<? extends ValueExtractor<? extends V, ?>, ? extends MapIndex<? extends K, ? extends V, ?>> mapIndexes, Set<? extends K> setKeys) Filter remaining keys using a Map of available indexes.InFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.InKeySetFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.KeyFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.LessEqualsFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.LessFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.LikeFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.LimitFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.NeverFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.NotEqualsFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.NotFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.PresentFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.PriorityFilter.applyIndex
(Map mapIndexes, Set setKeys) Filter remaining keys using a Map of available indexes.protected Filter
XorFilter.applyIndex
(Map mapIndexes, Set setKeys, QueryContext ctx, QueryRecord.PartialResult.TraceStep step) Apply the specified IndexAwareFilter to the specified keySet.ArrayFilter.WeightedFilter.getFilter()
Get the wrapped filter.FilterTrigger.getFilter()
Obtain the underlying Filter.InKeySetFilter.getFilter()
Obtain the underlying Filter.KeyAssociatedFilter.getFilter()
Obtain the wrapped Filter.LimitFilter.getFilter()
Obtain the Filter whose results are truncated by this filter.MapEventFilter.getFilter()
Obtain the Filter object used to evaluate the event value(s).NotFilter.getFilter()
Obtain the Filter whose results are negated by this filter.PartitionedFilter.getFilter()
Obtain the wrapped Filter.Filter[]
ArrayFilter.getFilters()
Obtain the Filter array.protected static <T> Filter
<T> AbstractQueryRecorderFilter.trace
(Filter<T> filter, Map mapIndexes, Set setKeys, QueryRecord.PartialResult.TraceStep step) Record the actual cost of applying the specified filter to the specified keySet.protected static <T> Filter
<T> AbstractQueryRecorderFilter.trace
(Filter<T> filter, Map mapIndexes, Set setKeys, QueryRecord.PartialResult.TraceStep step, ValueExtractor extractor) Record the actual cost of applying the specified filter to the specified keySet.AbstractQueryRecorderFilter.trace
(QueryContext ctx, QueryRecord.PartialResult.TraceStep step, Set setKeys) Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord
.ArrayFilter.trace
(QueryContext ctx, QueryRecord.PartialResult.TraceStep step, Set setKeys) Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord
.BetweenFilter.trace
(QueryContext ctx, QueryRecord.PartialResult.TraceStep step, Set setKeys) Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord
.QueryRecorderFilter.trace
(QueryContext ctx, QueryRecord.PartialResult.TraceStep step, Set setKeys) Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord
.WrapperQueryRecorderFilter.trace
(QueryContext ctx, QueryRecord.PartialResult.TraceStep step, Set setKeys) Filter the given keys using available indexes and record the cost of execution on the given step of theQueryRecord
.Modifier and TypeMethodDescriptionprotected Filter
ArrayFilter.applyFilter
(Filter filter, int iFilter, Map mapIndexes, Set setKeys, QueryContext ctx, QueryRecord.PartialResult.TraceStep step) Apply the specified IndexAwareFilter to the specified keySet.protected boolean
ArrayFilter.evaluateFilter
(Filter filter, Map.Entry entry, QueryContext ctx, QueryRecord.PartialResult.TraceStep step) Check if the given entry passes the given filter's evaluation.protected static <T> void
AbstractQueryRecorderFilter.explain
(Filter<T> filter, Map mapIndexes, Set setKeys, QueryRecord.PartialResult.ExplainStep step) Record an estimated cost of query execution for a given filter.protected static <T> void
AbstractQueryRecorderFilter.explain
(Filter<T> filter, Map mapIndexes, Set setKeys, QueryRecord.PartialResult.ExplainStep step, ValueExtractor extractor) Record an estimated cost of query execution for a given filter.protected static <T> boolean
AbstractQueryRecorderFilter.trace
(Filter<T> filter, Map.Entry entry, QueryRecord.PartialResult.TraceStep step) Record the actual cost of query execution for a given filter.protected static <T> Filter
<T> AbstractQueryRecorderFilter.trace
(Filter<T> filter, Map mapIndexes, Set setKeys, QueryRecord.PartialResult.TraceStep step) Record the actual cost of applying the specified filter to the specified keySet.protected static <T> Filter
<T> AbstractQueryRecorderFilter.trace
(Filter<T> filter, Map mapIndexes, Set setKeys, QueryRecord.PartialResult.TraceStep step, ValueExtractor extractor) Record the actual cost of applying the specified filter to the specified keySet.ModifierConstructorDescriptionConstruct an "all" filter.Construct an "and" filter.Construct an "any" filter.ArrayFilter
(Filter[] aFilter) Construct a logical filter that applies a binary operator to a filter array.CacheEventFilter
(int nMask, Filter<V> filter, int nMaskSynthetic) Construct a CacheEventFilter that evaluates MapEvent objects based on the specified combination of event types.CacheEventFilter
(Filter<V> filter, int nMaskSynthetic) Construct a CacheEventFilter that evaluates MapEvent objects that would affect the results of a keySet filter issued by a previous call toQueryMap.keySet(com.tangosol.util.Filter)
.FilterTrigger
(Filter<T> filter) Construct a FilterTrigger based on the specified Filter object and ACTION_ROLLBACK.FilterTrigger
(Filter<T> filter, int nAction) Construct a FilterTrigger based on the specified Filter object and the action constant.InKeySetFilter
(Filter<T> filter, Set<K> setKeys) Construct an InFilter for testing "In" condition.KeyAssociatedFilter
(Filter<T> filter, Object oHostKey) Construct a key associated filter.LimitFilter
(Filter<T> filter, int cPageSize) Construct a limit filter.MapEventFilter
(int nMask, Filter<V> filter) Construct a MapEventFilter that evaluates MapEvent objects based on the specified combination of event types.MapEventFilter
(Filter<V> filter) Construct a MapEventFilter that evaluates MapEvent objects that would affect the results of a keySet filter issued by a previous call toQueryMap.keySet(com.tangosol.util.Filter)
.MapEventTransformerFilter
(Filter<T> filter, MapEventTransformer transformer) Construct a MapEventTransformerFilter based on the specified Filter and MapEventTransformer.Construct a negation filter.Construct an "or" filter.PartitionedFilter
(Filter<T> filter, PartitionSet partitions) Construct a PartitionedFilter.protected
WeightedFilter
(Filter filter, int nEffect) Construct the WeightedFilter.WrapperQueryRecorderFilter
(Filter<T> filter) Construct a WrapperQueryRecorderFilter.Construct a "xor" filter. -
Uses of Filter in com.tangosol.util.processor
Modifier and TypeFieldDescriptionConditionalProcessor.m_filter
The underlying filter.protected Filter
ConditionalPut.m_filter
The underlying filter.protected Filter
ConditionalPutAll.m_filter
The underlying filter.protected Filter
ConditionalRemove.m_filter
The underlying filter.ModifierConstructorDescriptionConditionalProcessor
(Filter<V> filter, InvocableMap.EntryProcessor<K, V, T> processor) Construct a ConditionalProcessor for the specified filter and the processor.ConditionalPut
(Filter filter, V value) Construct a ConditionalPut that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.ConditionalPut
(Filter filter, V value, boolean fReturn) Construct a ConditionalPut that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.ConditionalPutAll
(Filter filter, Map<? extends K, ? extends V> map) Construct a ConditionalPutAll processor that updates an entry with a new value if and only if the filter applied to the entry evaluates to true.ConditionalRemove
(Filter filter) Construct a ConditionalRemove processor that removes an InvocableMap entry if and only if the filter applied to the entry evaluates to true.ConditionalRemove
(Filter filter, boolean fReturn) Construct a ConditionalRemove processor that removes an InvocableMap entry if and only if the filter applied to the entry evaluates to true.