| Package | Description | 
|---|---|
| com.hazelcast.client.impl.protocol.task.map | Client protocol tasks implementations for map | 
| com.hazelcast.client.impl.protocol.task.replicatedmap | Client protocol tasks implementations for ReplicatedMap | 
| com.hazelcast.client.map.impl | |
| com.hazelcast.client.proxy | This package contains client side proxy implementations of the different Hazelcast data structures
 and operation types | 
| com.hazelcast.client.proxy.txn | Contains classes related to proxy for client transactions | 
| com.hazelcast.config | Provides classes for configuring HazelcastInstance. | 
| com.hazelcast.core | Provides core API interfaces/classes. | 
| com.hazelcast.internal.adapter | Data structure adapters for Near Cache. | 
| com.hazelcast.map | Contains Hazelcast map module classes. | 
| com.hazelcast.map.impl.iterator | |
| com.hazelcast.map.impl.operation | Package for map operations. | 
| com.hazelcast.map.impl.proxy | Contains map proxy implementation and support classes. | 
| com.hazelcast.map.impl.query | |
| com.hazelcast.map.impl.querycache.accumulator | Contains  Accumulatorspecific classes. | 
| com.hazelcast.map.impl.querycache.subscriber | This package contains classes which are used for  QueryCacheevent subscription side. | 
| com.hazelcast.map.impl.tx | Contains implementation classes for  TransactionalMap | 
| com.hazelcast.mapreduce.aggregation | This package contains the aggregation API and the convenience helper classes
 to retrieve predefined aggregation implementations. | 
| com.hazelcast.mapreduce.aggregation.impl | This package contains a set of predefined aggregation implementations | 
| com.hazelcast.query | Contains interfaces/classes related to Hazelcast query and indexing support. | 
| com.hazelcast.query.impl | Contains the implementation classes of the query functionality. | 
| com.hazelcast.query.impl.predicates | |
| com.hazelcast.replicatedmap.impl | This package contains the implementation of the replicated map service itself and some connection interfaces only used
 internally. | 
| com.hazelcast.replicatedmap.impl.record | This package contains the implementation of the backing data storage for the replicated map implementation | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Predicate | MapEntriesWithPagingPredicateMessageTask. getPredicate() | 
| protected Predicate | MapKeySetMessageTask. getPredicate() | 
| protected Predicate | MapEntriesWithPredicateMessageTask. getPredicate() | 
| protected Predicate | DefaultMapProjectMessageTask. getPredicate() | 
| protected Predicate | MapValuesMessageTask. getPredicate() | 
| protected Predicate | MapAggregateWithPredicateMessageTask. getPredicate() | 
| protected Predicate | MapKeySetWithPagingPredicateMessageTask. getPredicate() | 
| protected abstract Predicate | AbstractMapQueryMessageTask. getPredicate() | 
| protected Predicate | DefaultMapAggregateMessageTask. getPredicate() | 
| protected Predicate | MapKeySetWithPredicateMessageTask. getPredicate() | 
| protected Predicate | MapEntrySetMessageTask. getPredicate() | 
| protected Predicate | MapValuesWithPagingPredicateMessageTask. getPredicate() | 
| protected Predicate | MapProjectionWithPredicateMessageTask. getPredicate() | 
| protected Predicate | MapValuesWithPredicateMessageTask. getPredicate() | 
| Modifier and Type | Method and Description | 
|---|---|
| Predicate | ReplicatedMapAddNearCacheListenerMessageTask. getPredicate() | 
| Predicate | ReplicatedMapAddEntryListenerMessageTask. getPredicate() | 
| Predicate | ReplicatedMapAddEntryListenerToKeyMessageTask. getPredicate() | 
| abstract Predicate | AbstractReplicatedMapAddEntryListenerMessageTask. getPredicate() | 
| Predicate | ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask. getPredicate() | 
| Predicate | ReplicatedMapAddEntryListenerWithPredicateMessageTask. getPredicate() | 
| Constructor and Description | 
|---|
| ClientMapQueryPartitionIterator(ClientMapProxy<K,V> mapProxy,
                               ClientContext context,
                               int fetchSize,
                               int partitionId,
                               Predicate<K,V> predicate,
                               Projection<Map.Entry<K,V>,R> projection) | 
| Modifier and Type | Method and Description | 
|---|---|
| String | ClientReplicatedMapProxy. addEntryListener(EntryListener<K,V> listener,
                Predicate<K,V> predicate) | 
| String | ClientReplicatedMapProxy. addEntryListener(EntryListener<K,V> listener,
                Predicate<K,V> predicate,
                K key) | 
| String | ClientMapProxy. addEntryListener(EntryListener listener,
                Predicate<K,V> predicate,
                boolean includeValue) | 
| String | ClientMapProxy. addEntryListener(EntryListener listener,
                Predicate<K,V> predicate,
                K key,
                boolean includeValue) | 
| String | ClientMapProxy. addEntryListener(MapListener listener,
                Predicate<K,V> predicate,
                boolean includeValue) | 
| String | ClientMapProxy. addEntryListener(MapListener listener,
                Predicate<K,V> predicate,
                K key,
                boolean includeValue) | 
| String | ClientMapProxy. addLocalEntryListener(EntryListener listener,
                     Predicate<K,V> predicate,
                     boolean includeValue) | 
| String | ClientMapProxy. addLocalEntryListener(EntryListener listener,
                     Predicate<K,V> predicate,
                     K key,
                     boolean includeValue) | 
| String | ClientMapProxy. addLocalEntryListener(MapListener listener,
                     Predicate<K,V> predicate,
                     boolean includeValue) | 
| String | ClientMapProxy. addLocalEntryListener(MapListener listener,
                     Predicate<K,V> predicate,
                     K key,
                     boolean includeValue) | 
| <R> R | ClientMapProxy. aggregate(Aggregator<Map.Entry<K,V>,R> aggregator,
         Predicate<K,V> predicate) | 
| Set<Map.Entry<K,V>> | ClientMapProxy. entrySet(Predicate predicate) | 
| Map<K,Object> | ClientMapProxy. executeOnEntries(EntryProcessor entryProcessor,
                Predicate predicate) | 
| QueryCache<K,V> | ClientMapProxy. getQueryCache(String name,
             MapListener listener,
             Predicate<K,V> predicate,
             boolean includeValue) | 
| QueryCache<K,V> | ClientMapProxy. getQueryCache(String name,
             Predicate<K,V> predicate,
             boolean includeValue) | 
| <R> Iterator<R> | ClientMapProxy. iterator(int fetchSize,
        int partitionId,
        Projection<Map.Entry<K,V>,R> projection,
        Predicate<K,V> predicate)Returns an iterator for iterating the result of the projection on entries in the  partitionIdwhich
 satisfy thepredicate. | 
| Set<K> | ClientMapProxy. keySet(Predicate predicate) | 
| Set<K> | ClientMapProxy. localKeySet(Predicate predicate) | 
| <R> Collection<R> | ClientMapProxy. project(Projection<Map.Entry<K,V>,R> projection,
       Predicate<K,V> predicate) | 
| void | ClientMapProxy. removeAll(Predicate<K,V> predicate) | 
| protected void | NearCachedClientMapProxy. removeAllInternal(Predicate predicate) | 
| protected void | ClientMapProxy. removeAllInternal(Predicate predicate) | 
| Collection<V> | ClientMapProxy. values(Predicate predicate) | 
| Modifier and Type | Method and Description | 
|---|---|
| Set<K> | ClientTxnMapProxy. keySet(Predicate predicate) | 
| Collection<V> | ClientTxnMapProxy. values(Predicate predicate) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Predicate | PredicateConfig. implementation | 
| Modifier and Type | Method and Description | 
|---|---|
| Predicate | PredicateConfig. getImplementation()Returns the Predicate implementation. | 
| Modifier and Type | Method and Description | 
|---|---|
| PredicateConfig | PredicateConfig. setImplementation(Predicate implementation)Sets the Predicate implementation. | 
| Constructor and Description | 
|---|
| PredicateConfig(Predicate implementation)Creates a PredicateConfig with the given implementation. | 
| Modifier and Type | Method and Description | 
|---|---|
| String | ReplicatedMap. addEntryListener(EntryListener<K,V> listener,
                Predicate<K,V> predicate)Adds an continuous entry listener for this map. | 
| String | ReplicatedMap. addEntryListener(EntryListener<K,V> listener,
                Predicate<K,V> predicate,
                K key)Adds an continuous entry listener for this map. | 
| String | IMap. addEntryListener(EntryListener listener,
                Predicate<K,V> predicate,
                boolean includeValue)Deprecated. 
 please use  IMap.addEntryListener(MapListener, com.hazelcast.query.Predicate, boolean)instead | 
| String | IMap. addEntryListener(EntryListener listener,
                Predicate<K,V> predicate,
                K key,
                boolean includeValue)Deprecated. 
 | 
| String | IMap. addEntryListener(MapListener listener,
                Predicate<K,V> predicate,
                boolean includeValue)Adds a  MapListenerfor this map. | 
| String | IMap. addEntryListener(MapListener listener,
                Predicate<K,V> predicate,
                K key,
                boolean includeValue)Adds a  MapListenerfor this map. | 
| String | IMap. addLocalEntryListener(EntryListener listener,
                     Predicate<K,V> predicate,
                     boolean includeValue)Deprecated. 
 | 
| String | IMap. addLocalEntryListener(EntryListener listener,
                     Predicate<K,V> predicate,
                     K key,
                     boolean includeValue)Deprecated. 
 | 
| String | IMap. addLocalEntryListener(MapListener listener,
                     Predicate<K,V> predicate,
                     boolean includeValue)Adds a  MapListenerfor this map. | 
| String | IMap. addLocalEntryListener(MapListener listener,
                     Predicate<K,V> predicate,
                     K key,
                     boolean includeValue)Adds a local entry listener for this map. | 
| <R> R | IMap. aggregate(Aggregator<Map.Entry<K,V>,R> aggregator,
         Predicate<K,V> predicate)Applies the aggregation logic on map entries filtered with the Predicated and returns the result | 
| Set<Map.Entry<K,V>> | IMap. entrySet(Predicate predicate)Queries the map based on the specified predicate and returns the matching entries. | 
| Map<K,Object> | IMap. executeOnEntries(EntryProcessor entryProcessor,
                Predicate predicate)Applies the user defined EntryProcessor to the entries in the map which satisfies provided predicate. | 
| QueryCache<K,V> | IMap. getQueryCache(String name,
             MapListener listener,
             Predicate<K,V> predicate,
             boolean includeValue)Creates an always up to date snapshot of this  IMapaccording to the supplied parameters. | 
| QueryCache<K,V> | IMap. getQueryCache(String name,
             Predicate<K,V> predicate,
             boolean includeValue)Creates an always up to date snapshot of this  IMapaccording to the supplied parameters. | 
| Set<K> | IMap. keySet(Predicate predicate)Queries the map based on the specified predicate and
 returns the keys of matching entries. | 
| Set<K> | TransactionalMap. keySet(Predicate predicate)Transactional implementation of  IMap.keySet(com.hazelcast.query.Predicate). | 
| Set<K> | BaseMap. keySet(Predicate predicate)Queries the map based on the specified predicate and
 returns the keys of matching entries. | 
| Set<K> | IMap. localKeySet(Predicate predicate)Returns the keys of matching locally owned entries. | 
| <R> Collection<R> | IMap. project(Projection<Map.Entry<K,V>,R> projection,
       Predicate<K,V> predicate)Applies the projection logic on map entries filtered with the Predicated and returns the result | 
| void | IMap. removeAll(Predicate<K,V> predicate)Removes all entries which match with the supplied predicate. | 
| Collection<V> | IMap. values(Predicate predicate)Queries the map based on the specified predicate and returns the values of matching entries. | 
| Collection<V> | TransactionalMap. values(Predicate predicate)Transactional implementation of  IMap.values(com.hazelcast.query.Predicate). | 
| Collection<V> | BaseMap. values(Predicate predicate)Queries the map based on the specified predicate and
 returns the values of matching entries. | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<K,Object> | IMapDataStructureAdapter. executeOnEntries(EntryProcessor entryProcessor,
                Predicate predicate) | 
| Map<K,Object> | TransactionalMapDataStructureAdapter. executeOnEntries(EntryProcessor entryProcessor,
                Predicate predicate) | 
| Map<K,Object> | DataStructureAdapter. executeOnEntries(EntryProcessor entryProcessor,
                Predicate predicate) | 
| Map<K,Object> | ReplicatedMapDataStructureAdapter. executeOnEntries(EntryProcessor entryProcessor,
                Predicate predicate) | 
| Map<K,Object> | ICacheDataStructureAdapter. executeOnEntries(EntryProcessor entryProcessor,
                Predicate predicate) | 
| Modifier and Type | Method and Description | 
|---|---|
| String | QueryCache. addEntryListener(MapListener listener,
                Predicate<K,V> predicate,
                boolean includeValue) | 
| String | QueryCache. addEntryListener(MapListener listener,
                Predicate<K,V> predicate,
                K key,
                boolean includeValue) | 
| Set<Map.Entry<K,V>> | QueryCache. entrySet(Predicate predicate) | 
| Set<K> | QueryCache. keySet(Predicate predicate) | 
| Collection<V> | QueryCache. values(Predicate predicate) | 
| Constructor and Description | 
|---|
| AbstractMapQueryPartitionIterator(IMap<K,V> map,
                                 int fetchSize,
                                 int partitionId,
                                 Predicate<K,V> predicate,
                                 Projection<Map.Entry<K,V>,R> projection) | 
| MapQueryPartitionIterator(MapProxyImpl<K,V> mapProxy,
                         int fetchSize,
                         int partitionId,
                         Predicate<K,V> predicate,
                         Projection<Map.Entry<K,V>,R> projection) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Predicate | MultipleEntryOperation. getPredicate() | 
| protected Predicate | PartitionWideEntryWithPredicateOperation. getPredicate() | 
| protected Predicate | PartitionWideEntryOperation. getPredicate() | 
| Predicate | MultipleEntryWithPredicateBackupOperation. getPredicate() | 
| Predicate | MultipleEntryWithPredicateOperation. getPredicate() | 
| protected Predicate | PartitionWideEntryWithPredicateBackupOperation. getPredicate() | 
| Modifier and Type | Method and Description | 
|---|---|
| OperationFactory | WANAwareOperationProvider. createPartitionWideEntryWithPredicateOperationFactory(String name,
                                                     EntryProcessor entryProcessor,
                                                     Predicate predicate) | 
| OperationFactory | MapOperationProvider. createPartitionWideEntryWithPredicateOperationFactory(String name,
                                                     EntryProcessor entryProcessor,
                                                     Predicate predicate) | 
| OperationFactory | DefaultMapOperationProvider. createPartitionWideEntryWithPredicateOperationFactory(String name,
                                                     EntryProcessor entryProcessor,
                                                     Predicate predicate) | 
| static EntryOperator | EntryOperator. operator(MapOperation mapOperation,
        Object processor,
        Predicate predicate) | 
| static EntryOperator | EntryOperator. operator(MapOperation mapOperation,
        Object processor,
        Predicate predicate,
        boolean collectWanEvents) | 
| Constructor and Description | 
|---|
| MultipleEntryWithPredicateBackupOperation(String name,
                                         Set<Data> keys,
                                         EntryBackupProcessor backupProcessor,
                                         Predicate predicate) | 
| MultipleEntryWithPredicateOperation(String name,
                                   Set<Data> keys,
                                   EntryProcessor entryProcessor,
                                   Predicate predicate) | 
| PartitionWideEntryWithPredicateBackupOperation(String name,
                                              EntryBackupProcessor entryProcessor,
                                              Predicate predicate) | 
| PartitionWideEntryWithPredicateOperation(String name,
                                        EntryProcessor entryProcessor,
                                        Predicate predicate) | 
| PartitionWideEntryWithPredicateOperationFactory(String name,
                                               EntryProcessor entryProcessor,
                                               Predicate predicate) | 
| PartitionWideEntryWithPredicateOperationFactory(String name,
                                               EntryProcessor entryProcessor,
                                               Predicate predicate,
                                               Map<Integer,List<Data>> partitionIdToKeysMap) | 
| Modifier and Type | Method and Description | 
|---|---|
| String | MapProxyImpl. addEntryListener(EntryListener listener,
                Predicate<K,V> predicate,
                boolean includeValue) | 
| String | MapProxyImpl. addEntryListener(EntryListener listener,
                Predicate<K,V> predicate,
                K key,
                boolean includeValue) | 
| String | MapProxyImpl. addEntryListener(MapListener listener,
                Predicate<K,V> predicate,
                boolean includeValue) | 
| String | MapProxyImpl. addEntryListener(MapListener listener,
                Predicate<K,V> predicate,
                K key,
                boolean includeValue) | 
| String | MapProxyImpl. addLocalEntryListener(EntryListener listener,
                     Predicate<K,V> predicate,
                     boolean includeValue) | 
| String | MapProxyImpl. addLocalEntryListener(EntryListener listener,
                     Predicate<K,V> predicate,
                     K key,
                     boolean includeValue) | 
| String | MapProxyImpl. addLocalEntryListener(MapListener listener,
                     Predicate<K,V> predicate,
                     boolean includeValue) | 
| String | MapProxyImpl. addLocalEntryListener(MapListener listener,
                     Predicate<K,V> predicate,
                     K key,
                     boolean includeValue) | 
| <R> R | MapProxyImpl. aggregate(Aggregator<Map.Entry<K,V>,R> aggregator,
         Predicate<K,V> predicate) | 
| Set<Map.Entry<K,V>> | MapProxyImpl. entrySet(Predicate predicate) | 
| Map<K,Object> | MapProxyImpl. executeOnEntries(EntryProcessor entryProcessor,
                Predicate predicate) | 
| void | NearCachedMapProxyImpl. executeOnEntriesInternal(EntryProcessor entryProcessor,
                        Predicate predicate,
                        List<Data> resultingKeyValuePairs) | 
| QueryCache<K,V> | MapProxyImpl. getQueryCache(String name,
             MapListener listener,
             Predicate<K,V> predicate,
             boolean includeValue) | 
| QueryCache<K,V> | MapProxyImpl. getQueryCache(String name,
             Predicate<K,V> predicate,
             boolean includeValue) | 
| <R> Iterator<R> | MapProxyImpl. iterator(int fetchSize,
        int partitionId,
        Projection<Map.Entry<K,V>,R> projection,
        Predicate<K,V> predicate)Returns an iterator for iterating the result of the projection on entries in the  partitionIdwhich
 satisfy thepredicate. | 
| Set<K> | MapProxyImpl. keySet(Predicate predicate) | 
| Set<K> | MapProxyImpl. localKeySet(Predicate predicate) | 
| <R> Collection<R> | MapProxyImpl. project(Projection<Map.Entry<K,V>,R> projection,
       Predicate<K,V> predicate) | 
| void | MapProxyImpl. removeAll(Predicate<K,V> predicate) | 
| protected void | NearCachedMapProxyImpl. removeAllInternal(Predicate predicate) | 
| Collection<V> | MapProxyImpl. values(Predicate predicate) | 
| Modifier and Type | Method and Description | 
|---|---|
| Predicate | Query. getPredicate() | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<QueryableEntry> | PartitionScanExecutor. execute(String mapName,
       Predicate predicate,
       Collection<Integer> partitions) | 
| Collection<QueryableEntry> | CallerRunsPartitionScanExecutor. execute(String mapName,
       Predicate predicate,
       Collection<Integer> partitions) | 
| List<QueryableEntry> | ParallelPartitionScanExecutor. execute(String mapName,
       Predicate predicate,
       Collection<Integer> partitions) | 
| QueryableEntriesSegment | PartitionScanExecutor. execute(String mapName,
       Predicate predicate,
       int partitionId,
       int tableIndex,
       int fetchSize)Executes the predicate on a partition chunk. | 
| QueryableEntriesSegment | CallerRunsPartitionScanExecutor. execute(String mapName,
       Predicate predicate,
       int partitionId,
       int tableIndex,
       int fetchSize) | 
| QueryableEntriesSegment | ParallelPartitionScanExecutor. execute(String mapName,
       Predicate predicate,
       int partitionId,
       int tableIndex,
       int fetchSize)Executes the predicate on a partition chunk. | 
| Query.QueryBuilder | Query.QueryBuilder. predicate(Predicate predicate) | 
| Collection<QueryableEntry> | PartitionScanRunner. run(String mapName,
   Predicate predicate,
   int partitionId) | 
| QueryableEntriesSegment | PartitionScanRunner. run(String mapName,
   Predicate predicate,
   int partitionId,
   int tableIndex,
   int fetchSize)Executes the predicate on a partition chunk. | 
| protected Future<Collection<QueryableEntry>> | ParallelPartitionScanExecutor. runPartitionScanForPartition(String name,
                            Predicate predicate,
                            int partitionId) | 
| protected Collection<QueryableEntry> | QueryRunner. runUsingGlobalIndexSafely(Predicate predicate,
                         MapContainer mapContainer,
                         int migrationStamp) | 
| protected Collection<QueryableEntry> | QueryRunner. runUsingPartitionScanSafely(String name,
                           Predicate predicate,
                           Collection<Integer> partitions,
                           int migrationStamp) | 
| protected List<QueryableEntry> | ParallelPartitionScanExecutor. runUsingPartitionScanWithoutPaging(String name,
                                  Predicate predicate,
                                  Collection<Integer> partitions) | 
| static Set | QueryResultUtils. transformToSet(SerializationService ss,
              QueryResult queryResult,
              Predicate predicate,
              IterationType iterationType,
              boolean unique,
              boolean binary) | 
| Constructor and Description | 
|---|
| Query(String mapName,
     Predicate predicate,
     IterationType iterationType,
     Aggregator aggregator,
     Projection projection) | 
| QueryEventFilter(boolean includeValue,
                Data key,
                Predicate predicate) | 
| Modifier and Type | Method and Description | 
|---|---|
| Predicate | AccumulatorInfo. getPredicate() | 
| Modifier and Type | Method and Description | 
|---|---|
| static AccumulatorInfo | AccumulatorInfo. createAccumulatorInfo(QueryCacheConfig config,
                     String mapName,
                     String cacheId,
                     Predicate predicate) | 
| static AccumulatorInfo | AccumulatorInfo. createAccumulatorInfo(String mapName,
                     String cacheId,
                     Predicate predicate,
                     int batchSize,
                     int bufferSize,
                     long delaySeconds,
                     boolean includeValue,
                     boolean populate,
                     boolean coalesce) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Predicate | AbstractQueryCacheEndToEndConstructor. predicate | 
| Modifier and Type | Method and Description | 
|---|---|
| Predicate | QueryCacheRequest. getPredicate()Returns predicate which is set. | 
| Modifier and Type | Method and Description | 
|---|---|
| String | NullQueryCache. addEntryListener(MapListener listener,
                Predicate predicate,
                boolean includeValue) | 
| String | NullQueryCache. addEntryListener(MapListener listener,
                Predicate predicate,
                Object key,
                boolean includeValue) | 
| Set<Map.Entry> | NullQueryCache. entrySet(Predicate predicate) | 
| Set | NullQueryCache. keySet(Predicate predicate) | 
| Collection | NullQueryCache. values(Predicate predicate) | 
| QueryCacheRequest | QueryCacheRequest. withPredicate(Predicate predicate)Setter for the predicate which will be used to filter underlying  IMapof thisQueryCache. | 
| Modifier and Type | Method and Description | 
|---|---|
| Set | TransactionalMapProxy. keySet(Predicate predicate) | 
| Collection | TransactionalMapProxy. values(Predicate predicate) | 
| Modifier and Type | Method and Description | 
|---|---|
| static <KeyIn,ValueIn,ValueOut> | Supplier. fromPredicate(Predicate<KeyIn,ValueIn> predicate)Deprecated.  The predefined Supplier selects values using the given  Predicateand does not perform any kind of data transformation. | 
| static <KeyIn,ValueIn,ValueOut> | Supplier. fromPredicate(Predicate<KeyIn,ValueIn> predicate,
             Supplier<KeyIn,ValueIn,ValueOut> chainedSupplier)Deprecated.  The predefined Supplier selects values using the given  Predicateand chains the filtered value to the given Supplier which might perform data transformation. | 
| Constructor and Description | 
|---|
| PredicateSupplier(Predicate<KeyIn,ValueIn> predicate) | 
| PredicateSupplier(Predicate<KeyIn,ValueIn> predicate,
                 Supplier<KeyIn,ValueIn,ValueOut> chainedSupplier) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | IndexAwarePredicate<K,V>This interface is used for create filterable Predicates. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PagingPredicate<K,V>This class is a special Predicate which helps to get a page-by-page result of a query. | 
| class  | PartitionPredicate<K,V>A  Predicatethat restricts the execution of a Predicate to a single Partition. | 
| class  | PredicateBuilderThis class provides functionality to build predicate. | 
| class  | SqlPredicateThis class contains methods related to conversion of sql query to predicate. | 
| class  | TruePredicate<K,V>A  Predicatewhich always returns true. | 
| Modifier and Type | Method and Description | 
|---|---|
| Predicate | VisitablePredicate. accept(Visitor visitor,
      Indexes indexes)Accept visitor. | 
| Predicate | SqlPredicate. accept(Visitor visitor,
      Indexes indexes) | 
| static Predicate | Predicates. and(Predicate... predicates) | 
| static Predicate | Predicates. between(String attribute,
       Comparable from,
       Comparable to) | 
| static Predicate | Predicates. equal(String attribute,
     Comparable y) | 
| Predicate<K,V> | PagingPredicate. getPredicate() | 
| Predicate | SqlPredicate. getPredicate() | 
| Predicate<K,V> | PartitionPredicate. getTarget()Returns the target  Predicate. | 
| static Predicate | Predicates. greaterEqual(String x,
            Comparable y) | 
| static Predicate | Predicates. greaterThan(String x,
           Comparable y) | 
| static Predicate | Predicates. ilike(String attribute,
     String pattern) | 
| static Predicate | Predicates. in(String attribute,
  Comparable... values) | 
| static Predicate | Predicates. instanceOf(Class klass) | 
| static Predicate | Predicates. lessEqual(String x,
         Comparable y) | 
| static Predicate | Predicates. lessThan(String x,
        Comparable y) | 
| static Predicate | Predicates. like(String attribute,
    String pattern) | 
| static Predicate | Predicates. not(Predicate predicate) | 
| static Predicate | Predicates. notEqual(String attribute,
        Comparable y) | 
| static Predicate | Predicates. or(Predicate... predicates)Or predicate | 
| static Predicate | Predicates. regex(String attribute,
     String pattern) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Predicate | Predicates. and(Predicate... predicates) | 
| PredicateBuilder | PredicateBuilder. and(Predicate predicate) | 
| static Predicate | Predicates. not(Predicate predicate) | 
| static Predicate | Predicates. or(Predicate... predicates)Or predicate | 
| PredicateBuilder | PredicateBuilder. or(Predicate predicate) | 
| Constructor and Description | 
|---|
| PagingPredicate(Predicate<K,V> predicate,
               Comparator<Map.Entry<K,V>> comparator,
               int pageSize)Construct with an inner predicate, comparator and pageSize
 results will be filtered via inner predicate
 results will be ordered via comparator
 throws  IllegalArgumentExceptionif pageSize is not greater than 0
 throwsIllegalArgumentExceptionif inner predicate is alsoPagingPredicate | 
| PagingPredicate(Predicate predicate,
               int pageSize)Construct with an inner predicate and pageSize
 results will be filtered via inner predicate
 results will be natural ordered
 throws  IllegalArgumentExceptionif pageSize is not greater than 0
 throwsIllegalArgumentExceptionif inner predicate is alsoPagingPredicate | 
| PartitionPredicate(Object partitionKey,
                  Predicate<K,V> target)Creates a new PartitionPredicate. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | FalsePredicate<K,V>A  Predicatewhich always returns false. | 
| Modifier and Type | Method and Description | 
|---|---|
| Set<QueryableEntry> | Indexes. query(Predicate predicate) | 
| Constructor and Description | 
|---|
| AndResultSet(Set<QueryableEntry> setSmallest,
            List<Set<QueryableEntry>> otherIndexedResults,
            List<Predicate> lsNoIndexPredicates) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractIndexAwarePredicate<K,V> | 
| class  | AbstractPredicate<K,V>Provides base features for predicates, such as extraction and convertion of the attribute's value. | 
| class  | AndPredicateAnd Predicate | 
| class  | BetweenPredicateBetween Predicate | 
| class  | EqualPredicateEqual Predicate | 
| class  | GreaterLessPredicateGreater Less Predicate | 
| class  | ILikePredicateIlike Predicate | 
| class  | InPredicateIn Predicate | 
| class  | InstanceOfPredicatePredicate version of `instaceof` operator from Java. | 
| class  | LikePredicateLike Predicate | 
| class  | NotEqualPredicateNot Equal Predicate | 
| class  | NotPredicateNot Predicate | 
| class  | OrPredicateOr Predicate | 
| class  | RegexPredicateRegex Predicate | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Predicate | NotPredicate. predicate | 
| protected Predicate[] | OrPredicate. predicates | 
| protected Predicate[] | AndPredicate. predicates | 
| Modifier and Type | Method and Description | 
|---|---|
| Predicate | OrPredicate. accept(Visitor visitor,
      Indexes indexes) | 
| Predicate | NotPredicate. accept(Visitor visitor,
      Indexes indexes) | 
| Predicate | AndPredicate. accept(Visitor visitor,
      Indexes indexes) | 
| static Predicate[] | VisitorUtils. acceptVisitor(Predicate[] predicates,
             Visitor visitor,
             Indexes indexes)Accept visitor by all predicates. | 
| <K,V> Predicate<K,V>[] | OrPredicate. getPredicates()Visitable predicates are treated as effectively immutable, therefore callers should not make any changes to
 the returned array. | 
| <K,V> Predicate<K,V>[] | AndPredicate. getPredicates()Visitable predicates are treated as effectively immutable, therefore callers should not make any changes to
 the returned array. | 
| <K,V> Predicate<K,V>[] | CompoundPredicate. getPredicates()An array of predicates which compose this predicate. | 
| Predicate | EqualPredicate. negate() | 
| Predicate | NotEqualPredicate. negate() | 
| Predicate | GreaterLessPredicate. negate() | 
| Predicate | OrPredicate. negate() | 
| Predicate | NegatablePredicate. negate()Create logical negation of itself. | 
| Predicate | NotPredicate. negate() | 
| Predicate | AndPredicate. negate() | 
| <K,V> Predicate<K,V> | EmptyOptimizer. optimize(Predicate<K,V> predicate,
        Indexes indexes) | 
| <K,V> Predicate<K,V> | QueryOptimizer. optimize(Predicate<K,V> predicate,
        Indexes indexes) | 
| <K,V> Predicate<K,V> | RuleBasedQueryOptimizer. optimize(Predicate<K,V> predicate,
        Indexes indexes) | 
| Predicate | BetweenVisitor. visit(AndPredicate andPredicate,
     Indexes indexes) | 
| Predicate | FlatteningVisitor. visit(AndPredicate andPredicate,
     Indexes indexes) | 
| Predicate | AbstractVisitor. visit(AndPredicate predicate,
     Indexes indexes) | 
| Predicate | Visitor. visit(AndPredicate predicate,
     Indexes indexes) | 
| Predicate | FlatteningVisitor. visit(NotPredicate predicate,
     Indexes indexes) | 
| Predicate | AbstractVisitor. visit(NotPredicate predicate,
     Indexes indexes) | 
| Predicate | Visitor. visit(NotPredicate predicate,
     Indexes indexes) | 
| Predicate | FlatteningVisitor. visit(OrPredicate orPredicate,
     Indexes indexes) | 
| Predicate | OrToInVisitor. visit(OrPredicate orPredicate,
     Indexes indexes) | 
| Predicate | AbstractVisitor. visit(OrPredicate predicate,
     Indexes indexes) | 
| Predicate | Visitor. visit(OrPredicate predicate,
     Indexes indexes) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Predicate[] | VisitorUtils. acceptVisitor(Predicate[] predicates,
             Visitor visitor,
             Indexes indexes)Accept visitor by all predicates. | 
| <K,V> Predicate<K,V> | EmptyOptimizer. optimize(Predicate<K,V> predicate,
        Indexes indexes) | 
| <K,V> Predicate<K,V> | QueryOptimizer. optimize(Predicate<K,V> predicate,
        Indexes indexes) | 
| <K,V> Predicate<K,V> | RuleBasedQueryOptimizer. optimize(Predicate<K,V> predicate,
        Indexes indexes) | 
| <K,V> void | OrPredicate. setPredicates(Predicate<K,V>[] predicates)Visitable predicates are treated as effectively immutable, therefore callers should not make any changes to
 the array passed as argument after is has been set. | 
| <K,V> void | AndPredicate. setPredicates(Predicate<K,V>[] predicates)Visitable predicates are treated as effectively immutable, therefore callers should not make any changes to
 the array passed as argument after is has been set. | 
| <K,V> void | CompoundPredicate. setPredicates(Predicate<K,V>[] predicates)Set the sub-predicates of this  CompoundPredicate. | 
| Constructor and Description | 
|---|
| AndPredicate(Predicate... predicates) | 
| NotPredicate(Predicate predicate) | 
| OrPredicate(Predicate... predicates) | 
| Modifier and Type | Method and Description | 
|---|---|
| String | ReplicatedMapProxy. addEntryListener(EntryListener<K,V> listener,
                Predicate<K,V> predicate) | 
| String | ReplicatedMapProxy. addEntryListener(EntryListener<K,V> listener,
                Predicate<K,V> predicate,
                K key) | 
| Constructor and Description | 
|---|
| ReplicatedQueryEventFilter(Data key,
                          Predicate predicate) | 
Copyright © 2018 Hazelcast, Inc.. All Rights Reserved.