Uses of Interface
com.tangosol.util.Filter
-
Packages that use Filter Package Description com.oracle.coherence.caffeine Contains interfaces and classes related to the Caffeine backing map implementation.com.oracle.coherence.cdi Coherence CDI provides support for CDI (Contexts and Dependency Injection) within Coherence cluster members.com.oracle.coherence.cdi.events Support for adapting Coherence interceptors to standard CDI events.com.oracle.coherence.grpc.proxy The Coherence gRPC server implementation.com.oracle.coherence.repository Contains classes to enable Repository-like access to Coherence data.com.tangosol.coherence.config.builder Defines the typical runtime configuration builders for the Coherence configuration object model.com.tangosol.coherence.config.scheme Defines the Coherence configuration object model classes and interfaces for Caching and Service Schemes.com.tangosol.coherence.config.xml.processor Defines the Xml document Element and Attribute Processors for Coherence Cache Configuration files.com.tangosol.coherence.dslquery Contains packages and classes supporting the Coherence CohQL command line tool.com.tangosol.coherence.dslquery.operator This package contains implementations of theBaseOperator
interface.com.tangosol.coherence.dslquery.statement This package containsStatementBuilder
implementations.com.tangosol.coherence.jcache.common Common utilities used by Coherence JCache.com.tangosol.coherence.jcache.localcache Contains classes related to local cache implementation of Coherence JCache.com.tangosol.coherence.jcache.partitionedcache Contains classes related to partitioned cache implementation of Coherence JCache.com.tangosol.coherence.jcache.passthroughcache Contains classes related to pass-through cache implementation of Coherence JCache.com.tangosol.coherence.rest.events Contains classes related to the Coherence REST APIMapEvent
s.com.tangosol.net Contains basic cluster interfaces and factories.com.tangosol.net.cache Contains classes providing various caching strategies.com.tangosol.net.management Contains classes related to the Coherence Management Framework.com.tangosol.net.partition Contains interfaces and classes related to partitioned services.com.tangosol.net.topic Contains classes that providing topic entities for publish/subscribe messaging.com.tangosol.persistence Contains classes and helpers for implementing various types of persistence.com.tangosol.util Contains various generic utilities.com.tangosol.util.aggregator Contains concreteInvocableMap.EntryAggregator
implementations.com.tangosol.util.extractor ContainsValueExtractor
andValueUpdater
related classes.com.tangosol.util.filter Contains concreteFilter
implementations and related interfaces.com.tangosol.util.processor Contains concreteInvocableMap.EntryProcessor
implementations. -
-
Uses of Filter in com.oracle.coherence.caffeine
Methods in com.oracle.coherence.caffeine with parameters of type Filter Modifier and Type Method Description void
CaffeineCache. addMapListener(MapListener listener, Filter filter, boolean fLite)
void
CaffeineCache. removeMapListener(MapListener listener, Filter filter)
-
Uses of Filter in com.oracle.coherence.cdi
Methods in com.oracle.coherence.cdi that return Filter Modifier and Type Method Description Filter<T>
FilterFactory. create(A annotation)
Create aFilter
instance.Filter<Object>
FilterProducer.AlwaysFilterSupplier. create(AlwaysFilter annotation)
Filter<Object>
FilterProducer.WhereFilterSupplier. create(WhereFilter annotation)
<T> Filter<T>
FilterProducer. getFilter(javax.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
Methods in com.oracle.coherence.cdi.events that return Filter Modifier and Type Method Description Filter<?>
AnnotatedMapListener. getFilter()
Obtain theFilter
that should be used when registering this listener.<T> Filter<T>
AnnotatedMapListener.FilterProducer. resolve(Set<Annotation> annotations)
Produce aFilter
instance from a set of annotations. -
Uses of Filter in com.oracle.coherence.grpc.proxy
Fields in com.oracle.coherence.grpc.proxy with type parameters of type Filter Modifier and Type Field Description protected ConcurrentMap<Filter<?>,MapListenerProxy.FilterInfo>
MapListenerProxy. f_mapFilter
The map ofFilters
that thisMapListenerProxy
was registered with.Methods in com.oracle.coherence.grpc.proxy that return Filter Modifier and Type Method Description <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
.Methods in com.oracle.coherence.grpc.proxy with parameters of type Filter Modifier and Type Method Description protected 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
Methods in com.oracle.coherence.repository with parameters of type Filter Modifier and Type Method Description void
AbstractRepositoryBase. addListener(Filter<?> filter, AbstractRepositoryBase.Listener<? super T> listener)
Register a listener that will observe all events for entities that satisfy the specified criteria.CompletableFuture<BigDecimal>
AbstractAsyncRepository. average(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor)
Return the average of the specified function.CompletableFuture<Double>
AbstractAsyncRepository. average(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor)
Return the average of the specified function.CompletableFuture<Double>
AbstractAsyncRepository. average(Filter<?> filter, Remote.ToIntFunction<? super T> extractor)
Return the average of the specified function.CompletableFuture<Double>
AbstractAsyncRepository. average(Filter<?> filter, Remote.ToLongFunction<? super T> extractor)
Return the average of the specified function.BigDecimal
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.CompletableFuture<Long>
AbstractAsyncRepository. count(Filter<?> filter)
Return the number of entities in this repository that satisfy specified filter.long
AbstractRepository. count(Filter<?> filter)
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.CompletableFuture<Collection<T>>
AbstractAsyncRepository. getAll(Filter<?> filter)
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.CompletableFuture<Void>
AbstractAsyncRepository. getAll(Filter<?> filter, Consumer<? super T> callback)
Stream all entities that satisfy the specified criteria.Collection<T>
AbstractRepository. getAll(Filter<?> filter)
Return all entities that satisfy the specified criteria.<R> Map<ID,R>
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.CompletableFuture<Collection<T>>
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.Collection<T>
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.<K> Map<K,Set<T>>
AbstractRepository. groupBy(Filter<?> filter, ValueExtractor<? super T,? extends K> extractor)
Return the grouping of entities by the specified extractor.<K> Map<K,SortedSet<T>>
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.CompletableFuture<BigDecimal>
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.CompletableFuture<Double>
AbstractAsyncRepository. max(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor)
Return the maximum value of the specified function.CompletableFuture<Integer>
AbstractAsyncRepository. max(Filter<?> filter, Remote.ToIntFunction<? super T> extractor)
Return the maximum value of the specified function.CompletableFuture<Long>
AbstractAsyncRepository. max(Filter<?> filter, Remote.ToLongFunction<? super T> extractor)
Return the maximum value of the specified function.BigDecimal
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.CompletableFuture<BigDecimal>
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.CompletableFuture<Double>
AbstractAsyncRepository. min(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor)
Return the minimum value of the specified function.CompletableFuture<Integer>
AbstractAsyncRepository. min(Filter<?> filter, Remote.ToIntFunction<? super T> extractor)
Return the minimum value of the specified function.CompletableFuture<Long>
AbstractAsyncRepository. min(Filter<?> filter, Remote.ToLongFunction<? super T> extractor)
Return the minimum value of the specified function.BigDecimal
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.CompletableFuture<Boolean>
AbstractAsyncRepository. removeAll(Filter<?> filter)
Remove all entities based on the specified criteria.CompletableFuture<Map<ID,T>>
AbstractAsyncRepository. removeAll(Filter<?> filter, boolean fReturn)
Remove all entities based on the specified criteria.boolean
AbstractRepository. removeAll(Filter<?> filter)
Remove all entities based on the specified criteria.Map<ID,T>
AbstractRepository. removeAll(Filter<?> filter, boolean fReturn)
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.RemoteStream<T>
AbstractRepository. stream(Filter<?> filter)
Return a stream of all entities in this repository that satisfy the specified criteria.CompletableFuture<BigDecimal>
AbstractAsyncRepository. sum(Filter<?> filter, Remote.ToBigDecimalFunction<? super T> extractor)
Return the sum of the specified function.CompletableFuture<Double>
AbstractAsyncRepository. sum(Filter<?> filter, Remote.ToDoubleFunction<? super T> extractor)
Return the sum of the specified function.CompletableFuture<Long>
AbstractAsyncRepository. sum(Filter<?> filter, Remote.ToIntFunction<? super T> extractor)
Return the sum of the specified function.CompletableFuture<Long>
AbstractAsyncRepository. sum(Filter<?> filter, Remote.ToLongFunction<? super T> extractor)
Return the sum of the specified function.BigDecimal
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.CompletableFuture<List<T>>
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.List<T>
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.<U,R>
Map<ID,R>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.<R> Map<ID,R>
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
Methods in com.tangosol.coherence.config.builder that return Filter Modifier and Type Method Description Filter
InetAddressRangeFilterBuilder. 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
Methods in com.tangosol.coherence.config.scheme that return types with arguments of type Filter Modifier and Type Method Description ParameterizedBuilder<Filter>
ContinuousQueryCacheScheme. getFilterBuilder()
Return theParameterizedBuilder
used to construct theFilter
to be used by theContinuousQueryCache
.Method parameters in com.tangosol.coherence.config.scheme with type arguments of type Filter Modifier and Type Method Description void
ContinuousQueryCacheScheme. setFilterBuilder(ParameterizedBuilder<Filter> filterBuilder)
-
Uses of Filter in com.tangosol.coherence.config.xml.processor
Methods in com.tangosol.coherence.config.xml.processor that return types with arguments of type Filter Modifier and Type Method Description ParameterizedBuilder<Filter>
AuthorizedHostsProcessor. process(ProcessingContext context, XmlElement xmlElement)
Process anXmlElement
to return a specific type of value.ParameterizedBuilder<Filter>
TransformerProcessor. process(ProcessingContext context, XmlElement xmlElement)
-
Uses of Filter in com.tangosol.coherence.dslquery
Methods in com.tangosol.coherence.dslquery that return Filter Modifier and Type Method Description Filter
FilterBuilder. makeFilter()
Make a new Filter from the set AST.Filter
FilterBuilder. makeFilter(Term term)
Make a new Filter from the given AST.Filter
FilterBuilder. makeFilter(Term term, Object[] aoIndexedBindVars)
Make a new Filter from the given AST using given array for Bind vars.Filter
FilterBuilder. makeFilter(Term term, Object[] aoIndexedBindVars, Map mapNamedBindVars)
Make a new Filter from the given AST using the given bind variables.Filter
FilterBuilder. makeFilter(Term term, List listBindVars, ParameterResolver namedBindVars)
Make a new Filter from the given AST using the given bind variables.Filter
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
Classes in com.tangosol.coherence.dslquery.operator with type parameters of type Filter Modifier and Type Class Description class
BaseOperator<F extends Filter>
A base class for CohQL Operator implementations.Methods in com.tangosol.coherence.dslquery.operator that return Filter Modifier and Type Method Description Filter
InOperator. makeFilter(Object oLeft, Object oRight)
Filter
XorOperator. makeFilter(Object oLeft, Object oRight)
Methods in com.tangosol.coherence.dslquery.operator with parameters of type Filter Modifier and Type Method Description protected 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
Fields in com.tangosol.coherence.dslquery.statement declared as Filter Modifier and Type Field Description protected Filter
DeleteStatementBuilder.DeleteStatement. f_filter
TheFilter
to be used in the CohQL "delete" command.protected Filter
QueryRecorderStatementBuilder.QueryRecorderStatement. f_filter
TheFilter
to be explained or traced.protected Filter
SelectStatementBuilder.AsyncSelectStatement. f_filter
TheFilter
to use in the query.protected Filter
SelectStatementBuilder.SelectStatement. f_filter
TheFilter
to use in the query.protected Filter
UpdateStatementBuilder.UpdateStatement. f_filter
TheFilter
that will be used to select entries to be updated.Methods in com.tangosol.coherence.dslquery.statement that return Filter Modifier and Type Method Description protected 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.Filter
SelectStatementBuilder.AsyncSelectStatement. getFilter()
Return theFilter
to use to execute this query.Filter
SelectStatementBuilder.SelectStatement. getFilter()
Return theFilter
to use to execute this query.Constructors in com.tangosol.coherence.dslquery.statement with parameters of type Filter Constructor Description DeleteStatement(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
Classes in com.tangosol.coherence.jcache.common that implement Filter Modifier and Type Class Description class
NonSyntheticEntryFilter<T>
Server side filter to filter out both coherence and jcache synthetic events. -
Uses of Filter in com.tangosol.coherence.jcache.localcache
Classes in com.tangosol.coherence.jcache.localcache that implement Filter Modifier and Type Class Description static class
LocalCacheAsynchronousMapListener.NonSyntheticEntryFilter
Server side filter to filter out both coherence and jcache synthetic events. -
Uses of Filter in com.tangosol.coherence.jcache.partitionedcache
Classes in com.tangosol.coherence.jcache.partitionedcache that implement Filter Modifier and Type Class Description static class
PartitionedCacheAsynchronousMapListener.NonSyntheticEntryFilter
NonSyntheticEntryFilterstatic class
PartitionedCacheSyntheticDeleteMapListener.JCacheExpiryEntryFilter<T>
Server side filter for JCache ExpiryCacheEvents. -
Uses of Filter in com.tangosol.coherence.jcache.passthroughcache
Classes in com.tangosol.coherence.jcache.passthroughcache that implement Filter Modifier and Type Class Description class
PassThroughFilterAdapter<K,V>
-
Uses of Filter in com.tangosol.coherence.rest.events
Methods in com.tangosol.coherence.rest.events with parameters of type Filter Modifier and Type Method Description MapEventOutput
MapEventOutput. setFilter(Filter filter)
Set the filter to listen on. -
Uses of Filter in com.tangosol.net
Classes in com.tangosol.net that implement Filter Modifier and Type Class Description static class
InetAddressHelper.RoutableFilter
The RoutableFilter evaluates to true for any InetAddress which is externally routable.static class
InetAddressHelper.SubnetMaskFilter
SubnetMaskFilter evaluates to true for any address with matches the pattern for the masked bitsFields in com.tangosol.net declared as Filter Modifier and Type Field Description protected Filter<?>
MapViewBuilder. m_filter
TheFilter
that will be used to define the entries maintained in this view.Methods in com.tangosol.net that return Filter Modifier and Type Method Description Filter
ClusterDependencies. getAuthorizedHostFilter()
Obtain the filter that is used by the cluster to determine whether to accept a new Cluster member.Methods in com.tangosol.net with parameters of type Filter Modifier and Type Method Description <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>>>
AsyncNamedMap. entrySet(Filter<?> filter)
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.MapViewBuilder<K,V>
MapViewBuilder. filter(Filter<?> filter)
TheFilter
that will be used to define the entries maintained in this view.ViewBuilder<K,V>
ViewBuilder. filter(Filter<?> filter)
TheFilter
that will be used to define the entries maintained in this view.default CompletableFuture<Map<K,V>>
AsyncNamedMap. getAll(Filter<?> filter)
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>>
AsyncNamedMap. keySet(Filter<?> filter)
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.default CompletableFuture<Void>
AsyncNamedMap. keySet(Filter<?> filter, Consumer<? super K> callback)
Stream the keys for the entries that satisfy the specified filter to the provided callback.default CompletableFuture<Void>
AsyncNamedMap. removeAll(Filter<?> filter)
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>>
AsyncNamedMap. values(Filter<?> filter)
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>
AsyncNamedMap. values(Filter<?> filter, Consumer<? super V> callback)
Stream the values for the entries that satisfy the specified filter to the provided callback. -
Uses of Filter in com.tangosol.net.cache
Classes in com.tangosol.net.cache that implement Filter Modifier and Type Class Description protected static class
SimpleOverflowMap.FrontFilterConverter
A combination Filter and Converter used to iterate through the status map in order to iterate through the front keys.Fields in com.tangosol.net.cache declared as Filter Modifier and Type Field Description protected 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.Methods in com.tangosol.net.cache that return Filter Modifier and Type Method Description protected 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
.Filter
ContinuousQueryCache. getFilter()
protected Filter
ContinuousQueryCache. mergeFilter(Filter filter)
Methods in com.tangosol.net.cache with parameters of type Filter Modifier and Type Method Description void
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
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
OldCache. addMapListener(MapListener listener, Filter filter, boolean fLite)
Deprecated.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.Set<Map.Entry<K,V_FRONT>>
ContinuousQueryCache. entrySet(Filter filter)
Set<Map.Entry<K,V_FRONT>>
ContinuousQueryCache. entrySet(Filter filter, Comparator comparator)
Set<Map.Entry<K,V>>
NearCache. entrySet(Filter filter)
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.Set<Map.Entry<K,V>>
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.Set<Map.Entry<K,V>>
WrapperNamedCache. entrySet(Filter filter)
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.Set<Map.Entry<K,V>>
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.protected Set<Map.Entry<K,V_FRONT>>
ContinuousQueryCache. entrySetInternal(Filter filter)
Return multiple values from the back cache based on a filter, transforming them in the process if necessary.protected Set<Map.Entry<K,V_FRONT>>
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.<R> Map<K,R>
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.<R> Map<K,R>
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.<R> Map<K,R>
ReadonlyNamedCache. invokeAll(Filter filter, InvocableMap.EntryProcessor<K,V,R> agent)
Should not be called.<R> Map<K,R>
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.Set<K>
ContinuousQueryCache. keySet(Filter filter)
Set<K>
NearCache. keySet(Filter filter)
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.Set<K>
WrapperNamedCache. keySet(Filter 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
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
OldCache. removeMapListener(MapListener listener, Filter filter)
Deprecated.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.Constructors in com.tangosol.net.cache with parameters of type Filter Constructor Description ContinuousQueryCache(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
Classes in com.tangosol.net.management that implement Filter Modifier and Type Class Description class
ObjectNameExcludeFilter
Filter used to prevent registering MBeans that match the specified pattern.Fields in com.tangosol.net.management declared as Filter Modifier and Type Field Description protected Filter<MBeanAttributeInfo>
MBeanAccessor.GetAttributes. m_filter
MBean Attribute filter.protected Filter
ObjectNameExcludeFilter. m_filter
The underlying filter.Fields in com.tangosol.net.management with type parameters of type Filter Modifier and Type Field Description protected Map<String,Filter<String>>
MBeanAccessor.QueryBuilder. m_mapFilters
A map of ObjectName key to Filter.protected Map<String,Filter<String>>
MBeanAccessor.QueryBuilder.ParsedQuery. m_mapFilters
A map of ObjectName key to Filter.Methods in com.tangosol.net.management that return Filter Modifier and Type Method Description Filter<ObjectName>
MBeanAccessor.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).Methods in com.tangosol.net.management that return types with arguments of type Filter Modifier and Type Method Description protected Map<String,Filter<String>>
MBeanAccessor.QueryBuilder. ensureMapFilters()
Ensure a Map is created to storeFilter
s to apply against values of the key/value pairs within the ObjectName.Map<String,Filter<String>>
MBeanAccessor.QueryBuilder.ParsedQuery. getMapFilters()
Return a map of key to Filter used to test against the corresponding key/value within the ObjectName.Methods in com.tangosol.net.management with parameters of type Filter Modifier and Type Method Description protected void
MBeanAccessor.GetAttributes. addMBeanAttributes(ObjectName oObjName, Map<String,Object> mapAttributes, MBeanServer mBeanServer, Filter<MBeanAttributeInfo> filter)
Add attributes of an MBean to a Map.Map<String,Map<String,Object>>
MBeanAccessor. getAttributes(MBeanAccessor.QueryBuilder.ParsedQuery query, Filter<MBeanAttributeInfo> filter, boolean fAddStorageMBeanAttributes)
Return all the attributes that match the query expressed by the providedMBeanAccessor.QueryBuilder
.Map<String,Object>
MBeanServerProxy. getAttributes(String sName, Filter<String> filter)
Return a Map of attribute name to attribute value for a given MBean name.Map<String,Object>
WrapperMBeanServerProxy. getAttributes(String sName, Filter<String> filter)
Set<String>
MBeanServerProxy. queryNames(String sPattern, Filter<ObjectName> filter)
Get the names of MBeans controlled by the MBean server that is collocated with thecluster registry
.Set<String>
MBeanServerProxy. queryNames(ObjectName pattern, Filter<ObjectName> filter)
Get the names of MBeans controlled by the MBean server that is collocated with thecluster registry
.Set<String>
WrapperMBeanServerProxy. queryNames(String sPattern, Filter<ObjectName> filter)
Set<String>
WrapperMBeanServerProxy. queryNames(ObjectName pattern, Filter<ObjectName> filter)
MBeanAccessor.QueryBuilder
MBeanAccessor.QueryBuilder. withFilter(String sKey, Filter<String> predicate)
Constructors in com.tangosol.net.management with parameters of type Filter Constructor Description GetAttributes(MBeanAccessor.QueryBuilder.ParsedQuery query, Filter<MBeanAttributeInfo> filter, boolean fAddStorageMBeanAttributes)
Create a GetAttributes object.QueryExpFilter(Filter<ObjectName> filter)
Constructor parameters in com.tangosol.net.management with type arguments of type Filter Constructor Description ParsedQuery(String sQuery, Map<String,Filter<String>> mapFilters)
Construct a ParsedQuery based on the given query expression and the map of key to Filter used to test against the corresponding key/value within the ObjectName. -
Uses of Filter in com.tangosol.net.partition
Classes in com.tangosol.net.partition that implement Filter Modifier and Type Class Description class
SimpleAssignmentStrategy.AnalysisContext.NotOwnedFilter
NotOwnedFilter is a Filter implementation used to evaluate Member objects, and selects members who are not represented in the reference ownership object.class
SimpleAssignmentStrategy.AnalysisContext.SafetyFilter
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
SimpleAssignmentStrategy.AnalysisContext.UnderloadedFilter
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.Methods in com.tangosol.net.partition that return Filter Modifier and Type Method Description Filter
SimpleAssignmentStrategy.AnalysisContext. instantiateNotOwnedFilter(Ownership owners)
Instantiate and return a NotOwnedFilter with the specified ownership.Filter
SimpleAssignmentStrategy.AnalysisContext. instantiateOverloadedFilter(boolean fPrimary)
Instantiate a filter that matches members with an over-load.Filter
SimpleAssignmentStrategy.AnalysisContext. instantiateSafetyFilter(Ownership owners, int iStore)
Instantiate and return a SafetyFilter with the specified ownership.Filter
SimpleAssignmentStrategy.AnalysisContext. instantiateUnderloadedFilter(boolean fPrimary)
Instantiate a filter that matches members with an under-load.Methods in com.tangosol.net.partition with parameters of type Filter Modifier and Type Method Description void
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.Constructors in com.tangosol.net.partition with parameters of type Filter Constructor Description AbstractPartitionedIterator(Filter filter, NamedCache cache, PartitionSet setPids)
Create AbstractPartitionedIterator instance.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
Methods in com.tangosol.net.topic that return Filter Modifier and Type Method Description Filter<? super V>
Subscriber.Filtered. getFilter()
Return the option's filter.Methods in com.tangosol.net.topic with parameters of type Filter Modifier and Type Method Description static <V> Subscriber.Filtered<V>
Subscriber.Filtered. by(Filter<? super V> filter)
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.Constructors in com.tangosol.net.topic with parameters of type Filter Constructor Description Filtered(Filter<? super V> filter)
-
Uses of Filter in com.tangosol.persistence
Methods in com.tangosol.persistence with parameters of type Filter Modifier and Type Method Description static 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
Classes in com.tangosol.util that implement Filter Modifier and Type Class Description class
ClassFilter
Filter which discards all objects that are not of a certain class.class
NullFilter
Filter which discards null references.Fields in com.tangosol.util declared as Filter Modifier and Type Field Description protected Filter[]
MapListenerSupport.FilterEvent. f_aFilter
Filters that caused the event.protected Filter
FilterEnumerator. m_test
Test to perform on each item.Fields in com.tangosol.util with type parameters of type Filter Modifier and Type Field Description protected Map<Filter,SimpleQueryRecord.PartialResult.Step>
SimpleQueryRecord.PartialResult.AbstractRecordableStep. m_mapSteps
The Map of child steps.Methods in com.tangosol.util that return Filter Modifier and Type Method Description static <T> Filter<T>
Filters. all(Filter<? super T>... filters)
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
Filter. and(Filter other)
Return a composed filter that represents a short-circuiting logical AND of this filter and another.static <T> Filter<T>
Filters. any(Filter<? super T>... filters)
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>Filters. equal(String fieldName, E value)
Return a filter that tests for equality using aUniversalExtractor
instance to extract the specified field.Filter
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>
Filters. not(Filter<T> filter)
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
Filter. or(Filter other)
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>
Filters. script(String sLanguage, String sScriptPath, Object... aoArgs)
Instantiate a Filter that is implemented in a script using the specified language.default Filter
Filter. xor(Filter other)
Return a composed predicate that represents a logical XOR of this predicate and another.Methods in com.tangosol.util with parameters of type Filter Modifier and Type Method Description void
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>
Filters. all(Filter<? super T>... filters)
Return a composite filter representing logical AND of all specified filters.default Filter
Filter. and(Filter other)
Return a composed filter that represents a short-circuiting logical AND of this filter and another.static <T> Filter<T>
Filters. any(Filter<? super T>... filters)
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
QueryRecord.PartialResult.ExplainStep. ensureStep(Filter filter)
Ensure an inner nested explain step for the given filter.QueryRecord.PartialResult.TraceStep
QueryRecord.PartialResult.TraceStep. ensureStep(Filter filter)
Ensure an inner nested trace step for the given filter.QueryRecord.PartialResult.ExplainStep
SimpleQueryRecord.PartialResult.ExplainStep. ensureStep(Filter filter)
Ensure an inner nested explain step for the given filter.QueryRecord.PartialResult.TraceStep
SimpleQueryRecord.PartialResult.TraceStep. ensureStep(Filter filter)
Ensure an inner nested trace step for the given filter.Set<Map.Entry<TK,TV>>
ConverterCollections.ConverterNamedCache. entrySet(Filter filter)
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.Set<Map.Entry<TK,TV>>
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.Set<Map.Entry<TK,TV>>
ConverterCollections.ConverterQueryMap. entrySet(Filter filter)
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.Set<Map.Entry<TK,TV>>
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.Set<Map.Entry<K,V>>
QueryMap. entrySet(Filter filter)
Return a set view of the entries contained in this map that satisfy the criteria expressed by the filter.Set<Map.Entry<K,V>>
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>
booleanInvocableMapHelper. evaluateEntry(Filter filter, Map.Entry<K,V> entry)
Check if the entry passes the filter evaluation.static <K,V>
booleanInvocableMapHelper. 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.Listeners
MapListenerSupport. getListeners(Filter filter)
Obtain the Listeners object for a given filter.VersionedPartitions
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
.QueryRecord.PartialResult.ExplainStep
SimpleQueryRecord.PartialResult. instantiateExplainStep(Filter filter)
Instantiate a new explain step for the given filter and add it to this result's list of steps.QueryRecord.PartialResult.TraceStep
SimpleQueryRecord.PartialResult. instantiateTraceStep(Filter filter)
Instantiate a new trace step for the given filter and add it to this result's list of steps.<R> Map<TK,R>
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.<R> Map<TK,R>
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.<R> Map<K,R>
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
MapListenerSupport. isEmpty(Filter filter)
Checks whether or not this MapListenerSupport object contains any listeners for a given filter.Set<TK>
ConverterCollections.ConverterNamedCache. keySet(Filter filter)
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.Set<TK>
ConverterCollections.ConverterQueryMap. keySet(Filter filter)
Return a set view of the keys contained in this map for entries that satisfy the criteria expressed by the filter.Set<K>
QueryMap. keySet(Filter 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>
Filters. not(Filter<T> filter)
Return a filter that represents the logical negation of the specified filter.default Filter
Filter. or(Filter other)
Return a composed predicate that represents a short-circuiting logical OR of this predicate and another.static <K,V>
InvocableMap.EntryProcessor<K,V,V>Processors. put(Filter filter, V value)
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>Processors. put(Filter filter, V value, boolean fReturn)
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>Processors. putAll(Filter filter, Map<? extends K,? extends V> map)
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>Processors. remove(Filter filter)
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>Processors. remove(Filter filter, boolean fReturn)
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>>
InvocableMap. stream(Filter filter)
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>
QueryMap. values(Filter filter)
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
Filter. xor(Filter other)
Return a composed predicate that represents a logical XOR of this predicate and another.Constructors in com.tangosol.util with parameters of type Filter Constructor Description AbstractRecordableStep(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.Step(Filter filter)
Construct a step.TraceStep(Filter filter)
Construct a TraceStep -
Uses of Filter in com.tangosol.util.aggregator
Fields in com.tangosol.util.aggregator declared as Filter Modifier and Type Field Description protected Filter
GroupAggregator. m_filter
The Filter object representing the "having" clause of this "group by" aggregator.Methods in com.tangosol.util.aggregator with parameters of type Filter Modifier and Type Method Description static <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.Constructors in com.tangosol.util.aggregator with parameters of type Filter Constructor Description 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.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
Fields in com.tangosol.util.extractor declared as Filter Modifier and Type Field Description protected Filter
ConditionalExtractor. m_filter
The filter used by this extractor.Constructors in com.tangosol.util.extractor with parameters of type Filter Constructor Description ConditionalExtractor(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
Subinterfaces of Filter in com.tangosol.util.filter Modifier and Type Interface Description interface
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<T>
QueryRecorderFilter is an extension of EntryFilter that allows the projected or actual costs of query execution to be recorded.Classes in com.tangosol.util.filter that implement Filter Modifier and Type Class Description class
AbstractQueryRecorderFilter<T>
Abstract base class implementation ofQueryRecorderFilter
.class
AllFilter
Filter which returns the logical "and" of a filter array.class
AlwaysFilter<T>
Filter which always evaluates to true.class
AndFilter
Filter which returns the logical "and" of two other filters.class
AnyFilter
Filter which returns the logical "or" of a filter array.class
ArrayFilter
Filter which is a logical operator of a filter array.class
BetweenFilter<T,E extends Comparable<? super E>>
Filter which compares the result of a method invocation with a value for "Between" condition.class
CacheEventFilter<K,V>
An extension of theMapEventFilter
which allows selection of client driven (natural) events, cache internal (synthetic) events, or both.class
ComparisonFilter<T,E,C>
Filter which compares the result of a method invocation with a value.class
ContainsAllFilter<T,E>
Filter which tests aCollection
or Object array value returned from a method invocation for containment of all values in a Set.class
ContainsAnyFilter<T,E>
Filter which tests aCollection
or Object array value returned from a method invocation for containment of any value in a Set.class
ContainsFilter<T,E>
Filter which tests aCollection
or Object array value returned from a method invocation for containment of a given value.class
EqualsFilter<T,E>
Filter which compares the result of a method invocation with a value for equality.class
ExtractorFilter<T,E>
Base Filter implementation for doing extractor-based processing.class
GreaterEqualsFilter<T,E extends Comparable<? super E>>
Filter which compares the result of a method invocation with a value for "Greater or Equal" condition.class
GreaterFilter<T,E extends Comparable<? super E>>
Filter which compares the result of a method invocation with a value for "Greater" condition.class
InFilter<T,E>
Filter which checks whether the result of a method invocation belongs to a predefined set of values.class
InKeySetFilter<T>
Filter that limits the underlying filter evaluation only to the specified set of keys.class
IsNotNullFilter<T,E>
Filter which tests the result of a method invocation for inequality to null.class
IsNullFilter<T,E>
Filter which compares the result of a method invocation with null.class
KeyAssociatedFilter<T>
Filter which limits the scope of another filter according to the key association information.class
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<T>
MapEventTransformerFilter is a generic multiplexing wrapper that combines two implementations: a Filter (most commonly aMapEventFilter
) and a MapEventTransformer and is used to register event listeners that allow to change the content of a MapEvent.class
NeverFilter<T>
Filter which always evaluates to false.class
NotEqualsFilter<T,E>
Filter which compares the result of a method invocation with a value for inequality.class
NotFilter<T>
Filter which negates the results of another filter.class
OrFilter
Filter which returns the logical "or" of two other filters.class
PartitionedFilter<T>
Filter which limits the scope of another filter to those entries that have keys that belong to the specified partition set.class
PredicateFilter<T,E>
Ajava.util.function.Predicate
basedExtractorFilter
.class
PresentFilter<T>
Filter which returns true forInvocableMap.Entry
objects that currently exist in a Map.class
PriorityFilter<T>
PriorityFilter is used to explicitly control the scheduling priority and timeouts for execution of filter-based methods.class
RegexFilter<T,E>
Filter which uses the regular expression pattern match defined by thePattern.matches(String, CharSequence)
contract.class
ScriptFilter<V>
ScriptFilter is aFilter
that wraps a script written in one of the languages supported by Graal VM.class
ValueChangeEventFilter<V,E>
Filter which evaluates the content of a MapEvent values based on the specified value extractor.class
WrapperQueryRecorderFilter<T>
QueryRecorderFilter wrapper class.class
XorFilter
Filter which returns the logical exclusive or ("xor") of two other filters.Fields in com.tangosol.util.filter declared as Filter Modifier and Type Field Description protected Filter[]
ArrayFilter. m_aFilter
The Filter array.protected Filter
FilterTrigger. m_filter
The underlying filter.protected Filter<V>
MapEventFilter. m_filter
The event value(s) filter.Methods in com.tangosol.util.filter that return Filter Modifier and Type Method Description protected 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)
Filter
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.Filter
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.Filter
BetweenFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
ContainsAllFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
ContainsAnyFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
ContainsFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
EqualsFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
ExtractorFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
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.Filter
InFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
InKeySetFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
KeyFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
LessFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
LikeFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
LimitFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
NeverFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
NotEqualsFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
NotFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
PresentFilter. applyIndex(Map mapIndexes, Set setKeys)
Filter remaining keys using a Map of available indexes.Filter
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.Filter
ArrayFilter.WeightedFilter. getFilter()
Get the wrapped filter.Filter
FilterTrigger. getFilter()
Obtain the underlying Filter.Filter<T>
InKeySetFilter. getFilter()
Obtain the underlying Filter.Filter<T>
KeyAssociatedFilter. getFilter()
Obtain the wrapped Filter.Filter<T>
LimitFilter. getFilter()
Obtain the Filter whose results are truncated by this filter.Filter<V>
MapEventFilter. getFilter()
Obtain the Filter object used to evaluate the event value(s).Filter<T>
NotFilter. getFilter()
Obtain the Filter whose results are negated by this filter.Filter<T>
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.Filter
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
.Filter
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
.Filter
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
.Filter
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
.Filter
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
.Methods in com.tangosol.util.filter that return types with arguments of type Filter Modifier and Type Method Description protected Set<Filter<?>>
AllFilter. simplifyFilters()
protected Set<Filter<?>>
AnyFilter. simplifyFilters()
Simplify internal filter array by merging and replacing filters if possible to reduce the overall number and nesting of the filters.protected abstract Set<Filter<?>>
ArrayFilter. simplifyFilters()
Simplify internal filter array by merging and replacing filters if possible to reduce the overall number and nesting of the filters.protected Set<Filter<?>>
BetweenFilter. simplifyFilters()
protected Set<Filter<?>>
XorFilter. simplifyFilters()
Simplify internal filter array by merging and replacing filters if possible to reduce the overall number and nesting of the filters.Methods in com.tangosol.util.filter with parameters of type Filter Modifier and Type Method Description protected 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.Constructors in com.tangosol.util.filter with parameters of type Filter Constructor Description AllFilter(Filter[] afilter)
Construct an "all" filter.AndFilter(Filter filterLeft, Filter filterRight)
Construct an "and" filter.AnyFilter(Filter[] afilter)
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.NotFilter(Filter<T> filter)
Construct a negation filter.OrFilter(Filter filterLeft, Filter filterRight)
Construct an "or" filter.PartitionedFilter(Filter<T> filter, PartitionSet partitions)
Construct a PartitionedFilter.WeightedFilter(Filter filter, int nEffect)
Construct the WeightedFilter.WrapperQueryRecorderFilter(Filter<T> filter)
Construct a WrapperQueryRecorderFilter.XorFilter(Filter filterLeft, Filter filterRight)
Construct a "xor" filter. -
Uses of Filter in com.tangosol.util.processor
Fields in com.tangosol.util.processor declared as Filter Modifier and Type Field Description protected Filter<V>
ConditionalProcessor. 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.Constructors in com.tangosol.util.processor with parameters of type Filter Constructor Description ConditionalProcessor(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.
-