| Package | Description | 
|---|---|
| com.hazelcast.cache.impl | 
     Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.cache.impl.client | 
     Hazelcast JSR-107 aka JCache implementation
     Client Requests | 
| com.hazelcast.cache.impl.event | 
     Event classes to define listenters for JCache other than EntryListener | 
| com.hazelcast.cache.impl.merge.entry | This package contains merge entry internal interfaces and functionality for Hazelcast cache. | 
| com.hazelcast.cache.impl.nearcache.impl.record | 
     Near cache record implementations. | 
| com.hazelcast.cache.impl.nearcache.impl.store | 
     Near cache store implementations. | 
| com.hazelcast.cache.impl.operation | Hazelcast JSR-107 aka JCache implementation | 
| com.hazelcast.cache.impl.record | 
     Hazelcast JSR-107 aka JCache implementation
     Internal record store | 
| com.hazelcast.client.cache.impl | 
     Hazelcast JSR-107 aka JCache implementation client side | 
| com.hazelcast.client.impl.protocol.task.cache | Client protocol tasks implementations for JCache | 
| com.hazelcast.client.impl.protocol.task.map | Client protocol tasks implementations for map | 
| com.hazelcast.client.impl.protocol.task.multimap | Client protocol tasks implementations for multi map | 
| com.hazelcast.client.impl.protocol.task.replicatedmap | Client protocol tasks implementations for ReplicatedMap | 
| com.hazelcast.client.impl.protocol.util | Protocol utils | 
| com.hazelcast.client.proxy | This package contains client side proxy implementations of the different Hazelcast data structures
 and operation types | 
| com.hazelcast.client.spi | Contains classes/interfaces related to Service Provider Interface
 such as ClientProxy , ClientClusterService | 
| com.hazelcast.client.spi.impl | Provides util classes for com.hazelcast.client | 
| com.hazelcast.collection.impl.collection | |
| com.hazelcast.collection.impl.collection.operations | |
| com.hazelcast.collection.impl.common | |
| com.hazelcast.collection.impl.list | This package contains IList functionality for Hazelcast. | 
| com.hazelcast.collection.impl.list.operations | |
| com.hazelcast.collection.impl.queue | |
| com.hazelcast.collection.impl.queue.operations | This package contains the IQueue operations | 
| com.hazelcast.collection.impl.set | This package contains ISet functionality for Hazelcast. | 
| com.hazelcast.collection.impl.txncollection.operations | |
| com.hazelcast.collection.impl.txnqueue | |
| com.hazelcast.collection.impl.txnqueue.operations | |
| com.hazelcast.concurrent.atomicreference | This package contains IAtomicReferece functionality for Hazelcast. The IAtomicReference is the distributed version of the AtomicReference. | 
| com.hazelcast.concurrent.atomicreference.operations | This package contains the operations on the IAtomicReference. | 
| com.hazelcast.concurrent.lock | |
| com.hazelcast.concurrent.lock.operations | This package contains the operations on the ILock. | 
| com.hazelcast.durableexecutor.impl.operations | This package contains operations for the DurableExecutorService. | 
| com.hazelcast.executor.impl.operations | This package contains operations for the IExecutorService. | 
| com.hazelcast.internal.partition.impl | Contains the actual implementation of the  InternalPartitionService. | 
| com.hazelcast.internal.serialization | Contains the private serialization API + implementation. | 
| com.hazelcast.internal.serialization.impl | |
| com.hazelcast.internal.serialization.impl.bufferpool | Contains the logic for the BufferPool. | 
| com.hazelcast.map.impl | Contains implementation specific classes of  com.hazelcast.mappackage. | 
| com.hazelcast.map.impl.event | |
| com.hazelcast.map.impl.eviction | This package contains eviction classes. | 
| com.hazelcast.map.impl.iterator | |
| com.hazelcast.map.impl.mapstore | Contains map store operations. | 
| com.hazelcast.map.impl.mapstore.writebehind | Package for processing write behind store operations. | 
| com.hazelcast.map.impl.mapstore.writethrough | Package for processing write through store operations. | 
| com.hazelcast.map.impl.nearcache | Contains near-cache specific classes. | 
| 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.event | This package contains classes for query cache events. | 
| com.hazelcast.map.impl.record | Contains record specific classes. | 
| com.hazelcast.map.impl.recordstore | |
| com.hazelcast.map.impl.tx | Contains implementation classes for  TransactionalMap | 
| com.hazelcast.map.impl.wan | Contains wan replication event classes | 
| com.hazelcast.multimap.impl | Contains classes for Hazelcast MultiMap module. | 
| com.hazelcast.multimap.impl.operations | Contains operations for Hazelcast MultiMap module. | 
| com.hazelcast.multimap.impl.txn | This package contains the Transaction behavior for the Multimap. | 
| com.hazelcast.nio | This package contains classes related to New IO | 
| com.hazelcast.query.impl | Contains the implementation classes of the query functionality. | 
| 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.client | This package contains classes for client communication on replicated map implementation | 
| com.hazelcast.replicatedmap.impl.operation | This package contains replicated map operations which are executed on remote nodes | 
| com.hazelcast.replicatedmap.impl.record | This package contains the implementation of the backing data storage for the replicated map implementation | 
| com.hazelcast.ringbuffer.impl | Contains the  Ringbufferimplementation classes. | 
| com.hazelcast.ringbuffer.impl.client | |
| com.hazelcast.ringbuffer.impl.operations | |
| com.hazelcast.spi | Provides interfaces/classes for the Hazelcast SPI for building distributed data structures and services. | 
| com.hazelcast.spi.impl | Contains implementations for Hazelcast SPI. | 
| com.hazelcast.spi.impl.operationservice.impl.operations | Contains the Operations being used by the  OperationServiceImpl. | 
| com.hazelcast.spi.partition | Contains the SPI for partition logic for Hazelcast. | 
| com.hazelcast.spi.serialization | Contains SPI related to serialization | 
| com.hazelcast.topic.impl | This package contains ITopic functionality for Hazelcast. With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics. | 
| com.hazelcast.topic.impl.reliable | |
| com.hazelcast.transaction.impl.xa.operations | |
| com.hazelcast.util | This package contains classes to support the inner workings of Hazelcast
 as well as some backports of newer Java features / data structures to
 support older Java versions in a clean and nice way. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractCacheRecordStore<R extends CacheRecord,CRM extends SampleableCacheRecordMap<Data,R>> | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | CacheEntryProcessorEntry. keyData | 
| Modifier and Type | Field and Description | 
|---|---|
| protected EvictionPolicyEvaluator<Data,R> | AbstractCacheRecordStore. evictionPolicyEvaluator | 
| protected EvictionStrategy<Data,R,CRM> | AbstractCacheRecordStore. evictionStrategy | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | CacheEventContext. getDataKey() | 
| Data | CacheEventData. getDataKey()Gets cache entry key as  Data. | 
| Data | CacheEventDataImpl. getDataKey() | 
| Data | CacheEventContext. getDataOldValue() | 
| Data | CacheEventData. getDataOldValue()Gets the old value of entry as  Data, if available. | 
| Data | CacheEventDataImpl. getDataOldValue() | 
| Data | CacheEventContext. getDataValue() | 
| Data | CacheEventData. getDataValue()Gets cache entry value as  Data. | 
| Data | CacheEventDataImpl. getDataValue() | 
| Data | CacheKeyIterationResult. getKey(int index) | 
| protected Data | CacheRecordStore. recordToData(CacheRecord record) | 
| protected abstract Data | AbstractCacheRecordStore. recordToData(R record) | 
| Data | AbstractCacheService. toData(Object object) | 
| protected abstract Data | AbstractClusterWideIterator. toData(Object obj) | 
| protected Data | ClusterWideIterator. toData(Object obj) | 
| protected Data | AbstractCacheRecordStore. toData(Object obj) | 
| Data | AbstractCacheRecordStore. toEventData(Object obj) | 
| protected Data | CacheRecordStore. toHeapData(Object obj) | 
| protected abstract Data | AbstractCacheRecordStore. toHeapData(Object obj) | 
| protected Data | CacheRecordStore. valueToData(Object value) | 
| protected abstract Data | AbstractCacheRecordStore. valueToData(Object value) | 
| Modifier and Type | Method and Description | 
|---|---|
| static CacheEntryView<Data,Data> | CacheEntryViews. createDefaultEntryView(Data key,
                      Data value,
                      CacheRecord record)Creates a  DefaultCacheEntryViewinstance. | 
| static CacheEntryView<Data,Data> | CacheEntryViews. createDefaultEntryView(Data key,
                      Data value,
                      CacheRecord record)Creates a  DefaultCacheEntryViewinstance. | 
| static CacheEntryView<Data,Data> | CacheEntryViews. createEntryView(Data key,
               Data value,
               CacheRecord record,
               CacheEntryViews.CacheEntryViewType cacheEntryViewType)Creates a  CacheEntryViewinstance. | 
| static CacheEntryView<Data,Data> | CacheEntryViews. createEntryView(Data key,
               Data value,
               CacheRecord record,
               CacheEntryViews.CacheEntryViewType cacheEntryViewType)Creates a  CacheEntryViewinstance. | 
| protected EvictionPolicyEvaluator<Data,R> | AbstractCacheRecordStore. createEvictionPolicyEvaluator(EvictionConfig evictionConfig) | 
| protected EvictionStrategy<Data,R,CRM> | AbstractCacheRecordStore. createEvictionStrategy(EvictionConfig cacheEvictionConfig) | 
| static CacheEntryView<Data,Data> | CacheEntryViews. createLazyEntryView(Data key,
                   Data value,
                   CacheRecord record)Creates a  LazyCacheEntryViewinstance. | 
| static CacheEntryView<Data,Data> | CacheEntryViews. createLazyEntryView(Data key,
                   Data value,
                   CacheRecord record)Creates a  LazyCacheEntryViewinstance. | 
| List<Map.Entry<Data,Data>> | CacheEntryIterationResult. getEntries() | 
| List<Map.Entry<Data,Data>> | CacheEntryIterationResult. getEntries() | 
| List<Data> | CacheKeyIterationResult. getKeys() | 
| Map<Data,CacheRecord> | ICacheRecordStore. getReadOnlyRecords()Returns a readonly map of the internal key value store. | 
| Map<Data,CacheRecord> | AbstractCacheRecordStore. getReadOnlyRecords() | 
| Set<Data> | ICacheRecordStore. loadAll(Set<Data> keys,
       boolean replaceExistingValues)Synchronously loads the specified entries into the cache using the
 configured  CacheLoaderfor the given keys. | 
| Set<Data> | AbstractCacheRecordStore. loadAll(Set<Data> keys,
       boolean replaceExistingValues) | 
| protected Map<Data,Object> | AbstractCacheRecordStore. loadAllCacheEntry(Set<Data> keys) | 
| Modifier and Type | Method and Description | 
|---|---|
| R | AbstractCacheRecordStore. accessRecord(Data key,
            R record,
            javax.cache.expiry.ExpiryPolicy expiryPolicy,
            long now) | 
| boolean | ICacheRecordStore. contains(Data key)Determines if this store contains an entry for the specified key. | 
| boolean | AbstractCacheRecordStore. contains(Data key) | 
| static CacheEventContext | CacheEventContextUtil. createBaseEventContext(CacheEventType eventType,
                      Data dataKey,
                      Data dataValue,
                      long expirationTime,
                      String origin,
                      int completionId) | 
| static CacheEventContext | CacheEventContextUtil. createCacheCompleteEvent(Data dataKey,
                        int completionId) | 
| static CacheEventContext | CacheEventContextUtil. createCacheCompleteEvent(Data dataKey,
                        long expirationTime,
                        String origin,
                        int completionId) | 
| static CacheEventContext | CacheEventContextUtil. createCacheCreatedEvent(Data dataKey,
                       Data dataValue,
                       long expirationTime,
                       String origin,
                       int completionId) | 
| protected CacheEntryProcessorEntry | CacheRecordStore. createCacheEntryProcessorEntry(Data key,
                              CacheRecord record,
                              long now,
                              int completionId) | 
| protected abstract CacheEntryProcessorEntry | AbstractCacheRecordStore. createCacheEntryProcessorEntry(Data key,
                              R record,
                              long now,
                              int completionId) | 
| static CacheEventContext | CacheEventContextUtil. createCacheExpiredEvent(Data dataKey,
                       Data dataValue,
                       long expirationTime,
                       String origin,
                       int completionId) | 
| static CacheEventContext | CacheEventContextUtil. createCacheRemovedEvent(Data dataKey) | 
| static CacheEventContext | CacheEventContextUtil. createCacheRemovedEvent(Data dataKey,
                       Data dataValue,
                       long expirationTime,
                       String origin,
                       int completionId) | 
| static CacheEventContext | CacheEventContextUtil. createCacheUpdatedEvent(Data dataKey,
                       Data dataValue,
                       Data dataOldValue,
                       long creationTime,
                       long expirationTime,
                       long lastAccessTime,
                       long accessHit) | 
| static CacheEventContext | CacheEventContextUtil. createCacheUpdatedEvent(Data dataKey,
                       Data dataValue,
                       Data dataOldValue,
                       long creationTime,
                       long expirationTime,
                       long lastAccessTime,
                       long accessHit,
                       String origin,
                       int completionId) | 
| Operation | CacheOperationProvider. createContainsKeyOperation(Data key) | 
| Operation | DefaultOperationProvider. createContainsKeyOperation(Data key) | 
| static CacheEntryView<Data,Data> | CacheEntryViews. createDefaultEntryView(Data key,
                      Data value,
                      CacheRecord record)Creates a  DefaultCacheEntryViewinstance. | 
| Operation | CacheOperationProvider. createEntryProcessorOperation(Data key,
                             Integer completionId,
                             javax.cache.processor.EntryProcessor entryProcessor,
                             Object... args) | 
| Operation | DefaultOperationProvider. createEntryProcessorOperation(Data key,
                             Integer completionId,
                             javax.cache.processor.EntryProcessor entryProcessor,
                             Object... arguments) | 
| static CacheEntryView<Data,Data> | CacheEntryViews. createEntryView(Data key,
               Data value,
               CacheRecord record,
               CacheEntryViews.CacheEntryViewType cacheEntryViewType)Creates a  CacheEntryViewinstance. | 
| Operation | CacheOperationProvider. createGetAndRemoveOperation(Data key,
                           int completionId) | 
| Operation | DefaultOperationProvider. createGetAndRemoveOperation(Data key,
                           int completionId) | 
| Operation | CacheOperationProvider. createGetAndReplaceOperation(Data key,
                            Data value,
                            javax.cache.expiry.ExpiryPolicy policy,
                            int completionId) | 
| Operation | DefaultOperationProvider. createGetAndReplaceOperation(Data key,
                            Data value,
                            javax.cache.expiry.ExpiryPolicy policy,
                            int completionId) | 
| Operation | CacheOperationProvider. createGetOperation(Data key,
                  javax.cache.expiry.ExpiryPolicy policy) | 
| Operation | DefaultOperationProvider. createGetOperation(Data key,
                  javax.cache.expiry.ExpiryPolicy policy) | 
| static CacheEntryView<Data,Data> | CacheEntryViews. createLazyEntryView(Data key,
                   Data value,
                   CacheRecord record)Creates a  LazyCacheEntryViewinstance. | 
| Operation | CacheOperationProvider. createPutIfAbsentOperation(Data key,
                          Data value,
                          javax.cache.expiry.ExpiryPolicy policy,
                          int completionId) | 
| Operation | DefaultOperationProvider. createPutIfAbsentOperation(Data key,
                          Data value,
                          javax.cache.expiry.ExpiryPolicy policy,
                          int completionId) | 
| Operation | CacheOperationProvider. createPutOperation(Data key,
                  Data value,
                  javax.cache.expiry.ExpiryPolicy policy,
                  boolean get,
                  int completionId) | 
| Operation | DefaultOperationProvider. createPutOperation(Data key,
                  Data value,
                  javax.cache.expiry.ExpiryPolicy policy,
                  boolean get,
                  int completionId) | 
| protected R | AbstractCacheRecordStore. createRecord(Data keyData,
            Object value,
            long expirationTime,
            int completionId) | 
| protected R | AbstractCacheRecordStore. createRecord(Data key,
            Object value,
            long expiryTime,
            long now,
            boolean disableWriteThrough,
            int completionId,
            String origin) | 
| protected R | AbstractCacheRecordStore. createRecordWithExpiry(Data key,
                      Object value,
                      javax.cache.expiry.ExpiryPolicy expiryPolicy,
                      long now,
                      boolean disableWriteThrough,
                      int completionId) | 
| protected R | AbstractCacheRecordStore. createRecordWithExpiry(Data key,
                      Object value,
                      javax.cache.expiry.ExpiryPolicy expiryPolicy,
                      long now,
                      boolean disableWriteThrough,
                      int completionId,
                      String origin) | 
| protected R | AbstractCacheRecordStore. createRecordWithExpiry(Data key,
                      Object value,
                      long expiryTime,
                      long now,
                      boolean disableWriteThrough,
                      int completionId) | 
| protected R | AbstractCacheRecordStore. createRecordWithExpiry(Data key,
                      Object value,
                      long expiryTime,
                      long now,
                      boolean disableWriteThrough,
                      int completionId,
                      String origin) | 
| Operation | CacheOperationProvider. createRemoveOperation(Data key,
                     Data value,
                     int completionId) | 
| Operation | DefaultOperationProvider. createRemoveOperation(Data key,
                     Data oldValue,
                     int completionId) | 
| Operation | CacheOperationProvider. createReplaceOperation(Data key,
                      Data oldValue,
                      Data newValue,
                      javax.cache.expiry.ExpiryPolicy policy,
                      int completionId) | 
| Operation | DefaultOperationProvider. createReplaceOperation(Data key,
                      Data oldValue,
                      Data newValue,
                      javax.cache.expiry.ExpiryPolicy policy,
                      int completionId) | 
| protected Object | CacheRecordStore. dataToValue(Data data) | 
| protected abstract Object | AbstractCacheRecordStore. dataToValue(Data data) | 
| protected void | AbstractCacheRecordStore. deleteCacheEntry(Data key) | 
| protected boolean | AbstractCacheRecordStore. deleteRecord(Data key,
            int completionId) | 
| protected boolean | AbstractCacheRecordStore. deleteRecord(Data key,
            int completionId,
            String source) | 
| protected boolean | AbstractCacheRecordStore. deleteRecord(Data key,
            int completionId,
            String source,
            String origin) | 
| R | AbstractCacheRecordStore. doPutRecord(Data key,
           R record) | 
| protected R | AbstractCacheRecordStore. doPutRecord(Data key,
           R record,
           String source) | 
| protected R | AbstractCacheRecordStore. doRemoveRecord(Data key) | 
| protected R | AbstractCacheRecordStore. doRemoveRecord(Data key,
              String source) | 
| Object | ICacheRecordStore. get(Data key,
   javax.cache.expiry.ExpiryPolicy expiryPolicy)Gets the value to which the specified key is mapped,
 or  nullif this cache contains no mapping for the key. | 
| Object | AbstractCacheRecordStore. get(Data key,
   javax.cache.expiry.ExpiryPolicy expiryPolicy) | 
| Object | ICacheRecordStore. getAndPut(Data key,
         Object value,
         javax.cache.expiry.ExpiryPolicy expiryPolicy,
         String caller,
         int completionId)Associates the specified value with the specified key in this cache,
 returning an existing value if one existed. | 
| Object | AbstractCacheRecordStore. getAndPut(Data key,
         Object value,
         javax.cache.expiry.ExpiryPolicy expiryPolicy,
         String source,
         int completionId) | 
| Object | ICacheRecordStore. getAndRemove(Data key,
            String caller,
            int completionId)Atomically removes the entry for a key only if it is currently mapped to some
 value. | 
| Object | AbstractCacheRecordStore. getAndRemove(Data key,
            String source,
            int completionId) | 
| Object | AbstractCacheRecordStore. getAndRemove(Data key,
            String source,
            int completionId,
            String origin) | 
| Object | ICacheRecordStore. getAndReplace(Data key,
             Object value,
             javax.cache.expiry.ExpiryPolicy expiryPolicy,
             String caller,
             int completionId)Atomically replaces the value for a given key if and only if there is a
 value currently mapped by the key. | 
| Object | AbstractCacheRecordStore. getAndReplace(Data key,
             Object value,
             javax.cache.expiry.ExpiryPolicy expiryPolicy,
             String source,
             int completionId) | 
| static int | CacheProxyUtil. getPartitionId(NodeEngine nodeEngine,
              Data key) | 
| CacheRecord | ICacheRecordStore. getRecord(Data key)Gets internal record of the store by key. | 
| CacheRecord | AbstractCacheRecordStore. getRecord(Data key) | 
| protected void | AbstractCacheRecordStore. invalidateEntry(Data key) | 
| protected void | AbstractCacheRecordStore. invalidateEntry(Data key,
               String source) | 
| Object | ICacheRecordStore. invoke(Data key,
      javax.cache.processor.EntryProcessor entryProcessor,
      Object[] arguments,
      int completionId)Invokes an  EntryProcessoragainst theCache.Entryspecified by
 the provided key. | 
| Object | AbstractCacheRecordStore. invoke(Data key,
      javax.cache.processor.EntryProcessor entryProcessor,
      Object[] arguments,
      int completionId) | 
| protected void | CacheEntryProcessorEntry. onCreate(Data key,
        Object value,
        javax.cache.expiry.ExpiryPolicy expiryPolicy,
        long now,
        boolean disableWriteThrough,
        int completionId,
        boolean saved) | 
| protected void | AbstractCacheRecordStore. onCreateRecordError(Data key,
                   Object value,
                   long expiryTime,
                   long now,
                   boolean disableWriteThrough,
                   int completionId,
                   String origin,
                   R record,
                   Throwable error) | 
| protected void | AbstractCacheRecordStore. onDeleteRecord(Data key,
              R record,
              Data dataValue,
              boolean deleted) | 
| protected void | AbstractCacheRecordStore. onDeleteRecordError(Data key,
                   R record,
                   Data dataValue,
                   boolean deleted,
                   Throwable error) | 
| void | AbstractCacheRecordStore. onEvict(Data key,
       R record) | 
| protected void | AbstractCacheRecordStore. onGet(Data key,
     javax.cache.expiry.ExpiryPolicy expiryPolicy,
     Object value,
     R record) | 
| protected void | AbstractCacheRecordStore. onGetError(Data key,
          javax.cache.expiry.ExpiryPolicy expiryPolicy,
          Object value,
          R record,
          Throwable error) | 
| protected void | CacheEntryProcessorEntry. onLoad(Data key,
      Object value,
      javax.cache.expiry.ExpiryPolicy expiryPolicy,
      long now,
      boolean disableWriteThrough,
      int completionId,
      boolean saved) | 
| protected void | AbstractCacheRecordStore. onProcessExpiredEntry(Data key,
                     R record,
                     long expiryTime,
                     long now,
                     String source,
                     String origin) | 
| protected void | AbstractCacheRecordStore. onPut(Data key,
     Object value,
     javax.cache.expiry.ExpiryPolicy expiryPolicy,
     String source,
     boolean getValue,
     boolean disableWriteThrough,
     R record,
     Object oldValue,
     boolean isExpired,
     boolean isNewPut,
     boolean isSaveSucceed) | 
| protected void | AbstractCacheRecordStore. onPutError(Data key,
          Object value,
          javax.cache.expiry.ExpiryPolicy expiryPolicy,
          String source,
          boolean getValue,
          boolean disableWriteThrough,
          R record,
          Object oldValue,
          boolean wouldBeNewPut,
          Throwable error) | 
| protected void | AbstractCacheRecordStore. onPutIfAbsent(Data key,
             Object value,
             javax.cache.expiry.ExpiryPolicy expiryPolicy,
             String source,
             boolean disableWriteThrough,
             R record,
             boolean isExpired,
             boolean isSaveSucceed) | 
| protected void | AbstractCacheRecordStore. onPutIfAbsentError(Data key,
                  Object value,
                  javax.cache.expiry.ExpiryPolicy expiryPolicy,
                  String source,
                  boolean disableWriteThrough,
                  R record,
                  Throwable error) | 
| protected long | AbstractCacheRecordStore. onRecordAccess(Data key,
              R record,
              javax.cache.expiry.ExpiryPolicy expiryPolicy,
              long now) | 
| protected void | AbstractCacheRecordStore. onRemove(Data key,
        Object value,
        String source,
        boolean getValue,
        R record,
        boolean removed) | 
| protected void | CacheEntryProcessorEntry. onRemove(Data key,
        String source,
        int completionId,
        boolean removed) | 
| protected void | AbstractCacheRecordStore. onRemoveError(Data key,
             Object value,
             String source,
             boolean getValue,
             R record,
             boolean removed,
             Throwable error) | 
| protected void | AbstractCacheRecordStore. onReplace(Data key,
         Object oldValue,
         Object newValue,
         javax.cache.expiry.ExpiryPolicy expiryPolicy,
         String source,
         boolean getValue,
         R record,
         boolean isExpired,
         boolean replaced) | 
| protected void | AbstractCacheRecordStore. onReplaceError(Data key,
              Object oldValue,
              Object newValue,
              javax.cache.expiry.ExpiryPolicy expiryPolicy,
              String source,
              boolean getValue,
              R record,
              boolean isExpired,
              boolean replaced,
              Throwable error) | 
| protected void | CacheEntryProcessorEntry. onUpdate(Data key,
        Object value,
        R record,
        javax.cache.expiry.ExpiryPolicy expiryPolicy,
        long now,
        boolean disableWriteThrough,
        int completionId,
        boolean saved) | 
| protected void | AbstractCacheRecordStore. onUpdateRecord(Data key,
              R record,
              Object value,
              Data oldDataValue) | 
| protected void | AbstractCacheRecordStore. onUpdateRecordError(Data key,
                   R record,
                   Object value,
                   Data newDataValue,
                   Data oldDataValue,
                   Throwable error) | 
| protected boolean | AbstractCacheRecordStore. processExpiredEntry(Data key,
                   R record,
                   long now) | 
| protected R | AbstractCacheRecordStore. processExpiredEntry(Data key,
                   R record,
                   long expiryTime,
                   long now,
                   String source) | 
| protected R | AbstractCacheRecordStore. processExpiredEntry(Data key,
                   R record,
                   long expiryTime,
                   long now,
                   String source,
                   String origin) | 
| protected boolean | AbstractCacheRecordStore. processExpiredEntry(Data key,
                   R record,
                   long now,
                   String source) | 
| protected boolean | AbstractCacheRecordStore. processExpiredEntry(Data key,
                   R record,
                   long now,
                   String source,
                   String origin) | 
| protected Object | AbstractCacheRecordStore. put(Data key,
   Object value,
   javax.cache.expiry.ExpiryPolicy expiryPolicy,
   String source,
   boolean getValue,
   boolean disableWriteThrough,
   int completionId) | 
| protected Object | AbstractCacheRecordStore. put(Data key,
   Object value,
   javax.cache.expiry.ExpiryPolicy expiryPolicy,
   String source,
   boolean getValue,
   int completionId) | 
| CacheRecord | ICacheRecordStore. put(Data key,
   Object value,
   javax.cache.expiry.ExpiryPolicy expiryPolicy,
   String caller,
   int completionId)Associates the specified value with the specified key in this cache,
 returning an existing value if one existed. | 
| R | AbstractCacheRecordStore. put(Data key,
   Object value,
   javax.cache.expiry.ExpiryPolicy expiryPolicy,
   String source,
   int completionId) | 
| protected boolean | AbstractCacheRecordStore. putIfAbsent(Data key,
           Object value,
           javax.cache.expiry.ExpiryPolicy expiryPolicy,
           String source,
           boolean disableWriteThrough,
           int completionId) | 
| boolean | ICacheRecordStore. putIfAbsent(Data key,
           Object value,
           javax.cache.expiry.ExpiryPolicy expiryPolicy,
           String caller,
           int completionId)Removes the mapping for a key from this cache if it is present. | 
| boolean | AbstractCacheRecordStore. putIfAbsent(Data key,
           Object value,
           javax.cache.expiry.ExpiryPolicy expiryPolicy,
           String source,
           int completionId) | 
| void | ICacheRecordStore. putRecord(Data key,
         CacheRecord record)Associates the specified record with the specified key. | 
| void | AbstractCacheRecordStore. putRecord(Data key,
         CacheRecord record) | 
| Object | AbstractCacheRecordStore. readThroughCache(Data key) | 
| R | AbstractCacheRecordStore. readThroughRecord(Data key,
                 long now) | 
| boolean | ICacheRecordStore. remove(Data key,
      Object value,
      String caller,
      int completionId)Atomically removes the mapping for a key only if currently mapped to the
 given value. | 
| boolean | AbstractCacheRecordStore. remove(Data key,
      Object value,
      String source,
      int completionId) | 
| boolean | AbstractCacheRecordStore. remove(Data key,
      Object value,
      String source,
      int completionId,
      String origin) | 
| boolean | ICacheRecordStore. remove(Data key,
      String caller,
      int completionId)Removes the mapping for a key from this cache if it is present. | 
| boolean | AbstractCacheRecordStore. remove(Data key,
      String source,
      int completionId) | 
| boolean | AbstractCacheRecordStore. remove(Data key,
      String source,
      int completionId,
      String origin) | 
| CacheRecord | ICacheRecordStore. removeRecord(Data key)Removes the record for a key. | 
| CacheRecord | AbstractCacheRecordStore. removeRecord(Data key) | 
| boolean | ICacheRecordStore. replace(Data key,
       Object value,
       javax.cache.expiry.ExpiryPolicy expiryPolicy,
       String caller,
       int completionId)Atomically replaces the entry for a key only if currently mapped to some
 value. | 
| boolean | AbstractCacheRecordStore. replace(Data key,
       Object value,
       javax.cache.expiry.ExpiryPolicy expiryPolicy,
       String source,
       int completionId) | 
| boolean | ICacheRecordStore. replace(Data key,
       Object oldValue,
       Object newValue,
       javax.cache.expiry.ExpiryPolicy expiryPolicy,
       String caller,
       int completionId)Atomically replaces the entry for a key only if currently mapped to a
 given value. | 
| boolean | AbstractCacheRecordStore. replace(Data key,
       Object oldValue,
       Object newValue,
       javax.cache.expiry.ExpiryPolicy expiryPolicy,
       String source,
       int completionId) | 
| void | AbstractCacheService. sendInvalidationEvent(String name,
                     Data key,
                     String sourceUuid)Sends an invalidation event for given  cacheNamewith specifiedkeyfrom mentioned source withsourceUuid. | 
| void | ICacheService. sendInvalidationEvent(String name,
                     Data key,
                     String sourceUuid) | 
| CacheEventContext | CacheEventContext. setDataKey(Data dataKey) | 
| CacheEventContext | CacheEventContext. setDataOldValue(Data dataOldValue) | 
| CacheEventContext | CacheEventContext. setDataValue(Data dataValue) | 
| protected long | AbstractCacheRecordStore. updateAccessDuration(Data key,
                    R record,
                    javax.cache.expiry.ExpiryPolicy expiryPolicy,
                    long now) | 
| protected void | AbstractCacheRecordStore. updateRecord(Data key,
            R record,
            Object value,
            long expiryTime,
            long now,
            boolean disableWriteThrough,
            int completionId,
            String source,
            String origin) | 
| protected boolean | AbstractCacheRecordStore. updateRecordWithExpiry(Data key,
                      Object value,
                      R record,
                      javax.cache.expiry.ExpiryPolicy expiryPolicy,
                      long now,
                      boolean disableWriteThrough,
                      int completionId) | 
| protected boolean | AbstractCacheRecordStore. updateRecordWithExpiry(Data key,
                      Object value,
                      R record,
                      javax.cache.expiry.ExpiryPolicy expiryPolicy,
                      long now,
                      boolean disableWriteThrough,
                      int completionId,
                      String source) | 
| protected boolean | AbstractCacheRecordStore. updateRecordWithExpiry(Data key,
                      Object value,
                      R record,
                      javax.cache.expiry.ExpiryPolicy expiryPolicy,
                      long now,
                      boolean disableWriteThrough,
                      int completionId,
                      String source,
                      String origin) | 
| protected boolean | AbstractCacheRecordStore. updateRecordWithExpiry(Data key,
                      Object value,
                      R record,
                      long expiryTime,
                      long now,
                      boolean disableWriteThrough,
                      int completionId) | 
| protected boolean | AbstractCacheRecordStore. updateRecordWithExpiry(Data key,
                      Object value,
                      R record,
                      long expiryTime,
                      long now,
                      boolean disableWriteThrough,
                      int completionId,
                      String source) | 
| protected boolean | AbstractCacheRecordStore. updateRecordWithExpiry(Data key,
                      Object value,
                      R record,
                      long expiryTime,
                      long now,
                      boolean disableWriteThrough,
                      int completionId,
                      String source,
                      String origin) | 
| void | AbstractCacheRecordStore. writeThroughCache(Data key,
                 Object value) | 
| Modifier and Type | Method and Description | 
|---|---|
| OperationFactory | CacheOperationProvider. createGetAllOperationFactory(Set<Data> keySet,
                            javax.cache.expiry.ExpiryPolicy policy) | 
| OperationFactory | DefaultOperationProvider. createGetAllOperationFactory(Set<Data> keySet,
                            javax.cache.expiry.ExpiryPolicy policy) | 
| OperationFactory | CacheOperationProvider. createLoadAllOperationFactory(Set<Data> keySet,
                             boolean replaceExistingValues) | 
| OperationFactory | DefaultOperationProvider. createLoadAllOperationFactory(Set<Data> keySet,
                             boolean replaceExistingValues) | 
| Operation | CacheOperationProvider. createPutAllOperation(List<Map.Entry<Data,Data>> entries,
                     javax.cache.expiry.ExpiryPolicy policy,
                     int completionId) | 
| Operation | CacheOperationProvider. createPutAllOperation(List<Map.Entry<Data,Data>> entries,
                     javax.cache.expiry.ExpiryPolicy policy,
                     int completionId) | 
| Operation | DefaultOperationProvider. createPutAllOperation(List<Map.Entry<Data,Data>> entries,
                     javax.cache.expiry.ExpiryPolicy policy,
                     int completionId) | 
| Operation | DefaultOperationProvider. createPutAllOperation(List<Map.Entry<Data,Data>> entries,
                     javax.cache.expiry.ExpiryPolicy policy,
                     int completionId) | 
| OperationFactory | CacheOperationProvider. createRemoveAllOperationFactory(Set<Data> keySet,
                               Integer completionId) | 
| OperationFactory | DefaultOperationProvider. createRemoveAllOperationFactory(Set<Data> keySet,
                               Integer completionId) | 
| protected void | AbstractCacheRecordStore. deleteAllCacheEntry(Set<Data> keys) | 
| MapEntries | ICacheRecordStore. getAll(Set<Data> keySet,
      javax.cache.expiry.ExpiryPolicy expiryPolicy)Gets a collection of entries from the store, returning them as
  Mapof the values associated with the set of keys requested. | 
| MapEntries | AbstractCacheRecordStore. getAll(Set<Data> keySet,
      javax.cache.expiry.ExpiryPolicy expiryPolicy) | 
| Set<Data> | ICacheRecordStore. loadAll(Set<Data> keys,
       boolean replaceExistingValues)Synchronously loads the specified entries into the cache using the
 configured  CacheLoaderfor the given keys. | 
| Set<Data> | AbstractCacheRecordStore. loadAll(Set<Data> keys,
       boolean replaceExistingValues) | 
| protected Map<Data,Object> | AbstractCacheRecordStore. loadAllCacheEntry(Set<Data> keys) | 
| CacheRecord | SplitBrainAwareCacheRecordStore. merge(CacheEntryView<Data,Data> cacheEntryView,
     CacheMergePolicy mergePolicy)Merges given record (inside given  CacheEntryView) with the existing record as givenCacheMergePolicy. | 
| CacheRecord | SplitBrainAwareCacheRecordStore. merge(CacheEntryView<Data,Data> cacheEntryView,
     CacheMergePolicy mergePolicy)Merges given record (inside given  CacheEntryView) with the existing record as givenCacheMergePolicy. | 
| CacheRecord | CacheRecordStore. merge(CacheEntryView<Data,Data> cacheEntryView,
     CacheMergePolicy mergePolicy) | 
| CacheRecord | CacheRecordStore. merge(CacheEntryView<Data,Data> cacheEntryView,
     CacheMergePolicy mergePolicy) | 
| void | ICacheRecordStore. removeAll(Set<Data> keys,
         int completionId)records of keys will be deleted one by one and will publish a REMOVE event
 for each key. | 
| void | AbstractCacheRecordStore. removeAll(Set<Data> keys,
         int completionId) | 
| Constructor and Description | 
|---|
| CacheEntryProcessorEntry(Data keyData,
                        R record,
                        AbstractCacheRecordStore cacheRecordStore,
                        long now,
                        int completionId) | 
| CacheEventDataImpl(String name,
                  CacheEventType eventType,
                  Data dataKey,
                  Data dataNewValue,
                  Data dataOldValue,
                  boolean isOldValueAvailable) | 
| Constructor and Description | 
|---|
| CacheEntryIterationResult(List<Map.Entry<Data,Data>> entries,
                         int tableIndex) | 
| CacheEntryIterationResult(List<Map.Entry<Data,Data>> entries,
                         int tableIndex) | 
| CacheKeyIterationResult(List<Data> keys,
                       int tableIndex) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | CacheSingleInvalidationMessage. getKey() | 
| Data | CacheInvalidationMessage. getKey() | 
| Constructor and Description | 
|---|
| CacheSingleInvalidationMessage(String name,
                              Data key,
                              String sourceUuid) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CacheWanEventPublisher. publishWanReplicationRemove(String cacheName,
                           Data key)This method will create a wrapper object using the given  CacheEntryViewand place it to wan replication queues. | 
| void | CacheWanEventPublisher. publishWanReplicationRemoveBackup(String cacheName,
                                 Data key)Backup operations of operations that call  this#publishWanReplicationRemove(String, Data)should call this method to provide wan event backups | 
| Modifier and Type | Method and Description | 
|---|---|
| void | CacheWanEventPublisher. publishWanReplicationUpdate(String cacheName,
                           CacheEntryView<Data,Data> entryView)This method will create a wrapper object using the given  CacheEntryViewand place it to wan replication queues. | 
| void | CacheWanEventPublisher. publishWanReplicationUpdate(String cacheName,
                           CacheEntryView<Data,Data> entryView)This method will create a wrapper object using the given  CacheEntryViewand place it to wan replication queues. | 
| void | CacheWanEventPublisher. publishWanReplicationUpdateBackup(String cacheName,
                                 CacheEntryView<Data,Data> entryView)Backup operations of operations that call  this#publishWanReplicationUpdate(String, CacheEntryView)should call this method to provide wan event backups | 
| void | CacheWanEventPublisher. publishWanReplicationUpdateBackup(String cacheName,
                                 CacheEntryView<Data,Data> entryView)Backup operations of operations that call  this#publishWanReplicationUpdate(String, CacheEntryView)should call this method to provide wan event backups | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | DefaultCacheEntryView. getKey() | 
| Data | DefaultCacheEntryView. getValue() | 
| Constructor and Description | 
|---|
| DefaultCacheEntryView(Data key,
                     Data value,
                     long creationTime,
                     long expirationTime,
                     long lastAccessTime,
                     long accessHit) | 
| Constructor and Description | 
|---|
| NearCacheDataRecord(Data value,
                   long creationTime,
                   long expiryTime) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Data | AbstractNearCacheRecordStore. toData(Object obj) | 
| protected Data | AbstractNearCacheRecordStore. valueToData(V value) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected V | AbstractNearCacheRecordStore. dataToValue(Data data) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Map<String,Map<Data,CacheRecord>> | CacheReplicationOperation. data | 
| Constructor and Description | 
|---|
| AbstractMutatingCacheOperation(String name,
                              Data key,
                              int completionId) | 
| CacheBackupEntryProcessorOperation(String name,
                                  Data key,
                                  javax.cache.processor.EntryProcessor entryProcessor,
                                  Object... arguments) | 
| CacheContainsKeyOperation(String name,
                         Data key) | 
| CacheEntryProcessorOperation(String name,
                            Data key,
                            int completionId,
                            javax.cache.processor.EntryProcessor entryProcessor,
                            Object... arguments) | 
| CacheGetAndRemoveOperation(String name,
                          Data key,
                          int completionId) | 
| CacheGetAndReplaceOperation(String name,
                           Data key,
                           Data value,
                           javax.cache.expiry.ExpiryPolicy expiryPolicy,
                           int completionId) | 
| CacheGetOperation(String name,
                 Data key,
                 javax.cache.expiry.ExpiryPolicy expiryPolicy) | 
| CacheMergeOperation(String name,
                   Data key,
                   CacheEntryView<Data,Data> entryView,
                   CacheMergePolicy policy) | 
| CachePutBackupOperation(String name,
                       Data key,
                       CacheRecord cacheRecord) | 
| CachePutBackupOperation(String name,
                       Data key,
                       CacheRecord cacheRecord,
                       boolean wanOriginated) | 
| CachePutIfAbsentOperation(String name,
                         Data key,
                         Data value,
                         javax.cache.expiry.ExpiryPolicy expiryPolicy,
                         int completionId) | 
| CachePutOperation(String name,
                 Data key,
                 Data value,
                 javax.cache.expiry.ExpiryPolicy expiryPolicy,
                 boolean get,
                 int completionId) | 
| CacheRemoveBackupOperation(String name,
                          Data key) | 
| CacheRemoveBackupOperation(String name,
                          Data key,
                          boolean wanOriginated) | 
| CacheRemoveOperation(String name,
                    Data key,
                    Data oldValue,
                    int completionId) | 
| CacheReplaceOperation(String name,
                     Data key,
                     Data oldValue,
                     Data newValue,
                     javax.cache.expiry.ExpiryPolicy expiryPolicy,
                     int completionId) | 
| Constructor and Description | 
|---|
| CacheGetAllOperation(String name,
                    Set<Data> keys,
                    javax.cache.expiry.ExpiryPolicy expiryPolicy) | 
| CacheGetAllOperationFactory(String name,
                           Set<Data> keys,
                           javax.cache.expiry.ExpiryPolicy expiryPolicy) | 
| CacheLoadAllOperation(String name,
                     Set<Data> keys,
                     boolean replaceExistingValues) | 
| CacheLoadAllOperationFactory(String name,
                            Set<Data> keys,
                            boolean replaceExistingValues) | 
| CacheMergeOperation(String name,
                   Data key,
                   CacheEntryView<Data,Data> entryView,
                   CacheMergePolicy policy) | 
| CacheMergeOperation(String name,
                   Data key,
                   CacheEntryView<Data,Data> entryView,
                   CacheMergePolicy policy) | 
| CachePutAllBackupOperation(String name,
                          Map<Data,CacheRecord> cacheRecords) | 
| CachePutAllOperation(String name,
                    List<Map.Entry<Data,Data>> entries,
                    javax.cache.expiry.ExpiryPolicy expiryPolicy,
                    int completionId) | 
| CachePutAllOperation(String name,
                    List<Map.Entry<Data,Data>> entries,
                    javax.cache.expiry.ExpiryPolicy expiryPolicy,
                    int completionId) | 
| CacheRemoveAllBackupOperation(String name,
                             Set<Data> keys) | 
| CacheRemoveAllOperation(String name,
                       Set<Data> keys,
                       int completionId) | 
| CacheRemoveAllOperationFactory(String name,
                              Set<Data> keys,
                              int completionId) | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | CacheRecordMap<K extends Data,V extends CacheRecord>Contract point for storing  CacheRecords. | 
| interface  | SampleableCacheRecordMap<K extends Data,V extends CacheRecord> | 
| Modifier and Type | Method and Description | 
|---|---|
| <C extends EvictionCandidate<Data,CacheRecord>> | CacheRecordHashMap. evict(Iterable<C> evictionCandidates,
     EvictionListener<Data,CacheRecord> evictionListener) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | CacheDataRecord. getValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected CacheRecord | CacheRecordFactory. createCacheDataRecord(Data dataValue,
                     long creationTime,
                     long expiryTime) | 
| protected com.hazelcast.cache.impl.record.CacheRecordHashMap.CacheEvictableSamplingEntry | CacheRecordHashMap. createSamplingEntry(Data key,
                   CacheRecord value) | 
| CacheRecord | CacheRecordHashMap. put(Data key,
   CacheRecord value) | 
| CacheRecord | CacheRecordHashMap. putIfAbsent(Data key,
           CacheRecord value) | 
| void | CacheDataRecord. setValue(Data value) | 
| Modifier and Type | Method and Description | 
|---|---|
| <C extends EvictionCandidate<Data,CacheRecord>> | CacheRecordHashMap. evict(Iterable<C> evictionCandidates,
     EvictionListener<Data,CacheRecord> evictionListener) | 
| Constructor and Description | 
|---|
| CacheDataRecord(Data value,
               long creationTime,
               long expiryTime) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Data | ClientClusterWideIterator. toData(Object obj) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | ClientCacheProxy. onLoadAll(Set<Data> keys,
         Object response,
         long start,
         long end) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Data | AbstractCacheMessageTask. serializeCacheConfig(Object response) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ClientMessage | MapAddEntryListenerToKeyWithPredicateMessageTask. encodeEvent(Data keyData,
           Data newValueData,
           Data oldValueData,
           Data meringValueData,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected abstract ClientMessage | AbstractMapAddEntryListenerMessageTask. encodeEvent(Data keyData,
           Data newValueData,
           Data oldValueData,
           Data meringValueData,
           int type,
           String uuid,
           int numberOfEntriesAffected) | 
| protected ClientMessage | MapAddNearCacheEntryListenerMessageTask. encodeEvent(Data keyData,
           Data newValueData,
           Data oldValueData,
           Data meringValueData,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected ClientMessage | MapAddEntryListenerToKeyMessageTask. encodeEvent(Data keyData,
           Data newValueData,
           Data oldValueData,
           Data meringValueData,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected ClientMessage | MapAddEntryListenerMessageTask. encodeEvent(Data keyData,
           Data newValueData,
           Data oldValueData,
           Data meringValueData,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected ClientMessage | MapAddEntryListenerWithPredicateMessageTask. encodeEvent(Data keyData,
           Data newValueData,
           Data oldValueData,
           Data meringValueData,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | MultiMapAddEntryListenerToKeyMessageTask. getKey() | 
| Data | AbstractMultiMapAddEntryListenerMessageTask. getKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ClientMessage | MultiMapAddEntryListenerToKeyMessageTask. encodeEvent(Data key,
           Data value,
           Data oldValue,
           int type,
           String uuid,
           int numberOfEntriesAffected) | 
| protected ClientMessage | MultiMapAddEntryListenerMessageTask. encodeEvent(Data key,
           Data value,
           Data oldValue,
           int type,
           String uuid,
           int numberOfEntriesAffected) | 
| protected abstract ClientMessage | AbstractMultiMapAddEntryListenerMessageTask. encodeEvent(Data key,
           Data value,
           Data oldValue,
           int type,
           String uuid,
           int numberOfEntriesAffected) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | ReplicatedMapAddNearCacheListenerMessageTask. getKey() | 
| Data | ReplicatedMapAddEntryListenerMessageTask. getKey() | 
| Data | ReplicatedMapAddEntryListenerToKeyMessageTask. getKey() | 
| abstract Data | AbstractReplicatedMapAddEntryListenerMessageTask. getKey() | 
| Data | ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask. getKey() | 
| Data | ReplicatedMapAddEntryListenerWithPredicateMessageTask. getKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ClientMessage | ReplicatedMapAddNearCacheListenerMessageTask. encodeEvent(Data key,
           Data newValue,
           Data oldValue,
           Data mergingValue,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected ClientMessage | ReplicatedMapAddEntryListenerMessageTask. encodeEvent(Data key,
           Data newValue,
           Data oldValue,
           Data mergingValue,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected ClientMessage | ReplicatedMapAddEntryListenerToKeyMessageTask. encodeEvent(Data key,
           Data newValue,
           Data oldValue,
           Data mergingValue,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected abstract ClientMessage | AbstractReplicatedMapAddEntryListenerMessageTask. encodeEvent(Data key,
           Data newValue,
           Data oldValue,
           Data mergingValue,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected ClientMessage | ReplicatedMapAddEntryListenerToKeyWithPredicateMessageTask. encodeEvent(Data key,
           Data newValue,
           Data oldValue,
           Data mergingValue,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| protected ClientMessage | ReplicatedMapAddEntryListenerWithPredicateMessageTask. encodeEvent(Data key,
           Data newValue,
           Data oldValue,
           Data mergingValue,
           int type,
           String uuid,
           int numberOfAffectedEntries) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | MessageFlyweight. getData() | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Data> | MessageFlyweight. getDataList() | 
| Modifier and Type | Method and Description | 
|---|---|
| static int | ParameterUtil. calculateDataSize(Data data) | 
| MessageFlyweight | MessageFlyweight. set(Data data) | 
| Modifier and Type | Method and Description | 
|---|---|
| static int | ParameterUtil. calculateDataSize(Map.Entry<Data,Data> entry) | 
| static int | ParameterUtil. calculateDataSize(Map.Entry<Data,Data> entry) | 
| MessageFlyweight | MessageFlyweight. set(Collection<Data> value) | 
| MessageFlyweight | MessageFlyweight. set(Map.Entry<Data,Data> entry) | 
| MessageFlyweight | MessageFlyweight. set(Map.Entry<Data,Data> entry) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected NearCache<Data,Object> | NearCachedClientMapProxy. nearCache | 
| Modifier and Type | Method and Description | 
|---|---|
| NearCache<Data,Object> | NearCachedClientMapProxy. getNearCache() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected boolean | NearCachedClientMapProxy. containsKeyInternal(Data keyData) | 
| protected boolean | ClientMapProxy. containsKeyInternal(Data keyData) | 
| protected void | NearCachedClientMapProxy. deleteInternal(Data keyData) | 
| protected void | ClientMapProxy. deleteInternal(Data keyData) | 
| protected boolean | NearCachedClientMapProxy. evictInternal(Data keyData) | 
| protected boolean | ClientMapProxy. evictInternal(Data keyData) | 
| Object | NearCachedClientMapProxy. executeOnKeyInternal(Data keyData,
                    EntryProcessor entryProcessor) | 
| Object | ClientMapProxy. executeOnKeyInternal(Data keyData,
                    EntryProcessor entryProcessor) | 
| ICompletableFuture<V> | NearCachedClientMapProxy. getAsyncInternal(Data key) | 
| protected ICompletableFuture<V> | ClientMapProxy. getAsyncInternal(Data keyData) | 
| protected V | NearCachedClientMapProxy. getInternal(Data key) | 
| protected V | ClientMapProxy. getInternal(Data keyData) | 
| void | NearCachedClientMapProxy.ClientMapAddNearCacheEventHandler. handle(Data key) | 
| protected void | NearCachedClientMapProxy. invalidateNearCache(Data key) | 
| protected ICompletableFuture<V> | NearCachedClientMapProxy. putAsyncInternal(long ttl,
                TimeUnit timeunit,
                Data keyData,
                Data valueData) | 
| protected ICompletableFuture<V> | ClientMapProxy. putAsyncInternal(long ttl,
                TimeUnit timeunit,
                Data keyData,
                Data valueData) | 
| protected V | NearCachedClientMapProxy. putIfAbsentInternal(long ttl,
                   TimeUnit timeunit,
                   Data keyData,
                   Data valueData) | 
| protected V | ClientMapProxy. putIfAbsentInternal(long ttl,
                   TimeUnit timeunit,
                   Data keyData,
                   Data valueData) | 
| protected V | NearCachedClientMapProxy. putInternal(long ttl,
           TimeUnit timeunit,
           Data keyData,
           Data valueData) | 
| protected V | ClientMapProxy. putInternal(long ttl,
           TimeUnit timeunit,
           Data keyData,
           Data valueData) | 
| protected void | NearCachedClientMapProxy. putTransientInternal(long ttl,
                    TimeUnit timeunit,
                    Data keyData,
                    Data valueData) | 
| protected void | ClientMapProxy. putTransientInternal(long ttl,
                    TimeUnit timeunit,
                    Data keyData,
                    Data valueData) | 
| protected ICompletableFuture<V> | NearCachedClientMapProxy. removeAsyncInternal(Data keyData) | 
| protected ICompletableFuture<V> | ClientMapProxy. removeAsyncInternal(Data keyData) | 
| protected com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.ResponseParameters | NearCachedClientMapProxy. removeInternal(Data keyData) | 
| protected com.hazelcast.client.impl.protocol.codec.MapRemoveCodec.ResponseParameters | ClientMapProxy. removeInternal(Data keyData) | 
| protected boolean | NearCachedClientMapProxy. removeInternal(Data keyData,
              Data valueData) | 
| protected boolean | ClientMapProxy. removeInternal(Data keyData,
              Data valueData) | 
| protected boolean | NearCachedClientMapProxy. replaceIfSameInternal(Data keyData,
                     Data oldValueData,
                     Data newValueData) | 
| protected boolean | ClientMapProxy. replaceIfSameInternal(Data keyData,
                     Data oldValueData,
                     Data newValueData) | 
| protected V | NearCachedClientMapProxy. replaceInternal(Data keyData,
               Data valueData) | 
| protected V | ClientMapProxy. replaceInternal(Data keyData,
               Data valueData) | 
| protected ICompletableFuture<Void> | NearCachedClientMapProxy. setAsyncInternal(long ttl,
                TimeUnit timeunit,
                Data keyData,
                Data valueData) | 
| protected ICompletableFuture<Void> | ClientMapProxy. setAsyncInternal(long ttl,
                TimeUnit timeunit,
                Data keyData,
                Data valueData) | 
| protected void | NearCachedClientMapProxy. setInternal(long ttl,
           TimeUnit timeunit,
           Data keyData,
           Data valueData) | 
| protected void | ClientMapProxy. setInternal(long ttl,
           TimeUnit timeunit,
           Data keyData,
           Data valueData) | 
| ICompletableFuture | NearCachedClientMapProxy. submitToKeyInternal(Data keyData,
                   EntryProcessor entryProcessor) | 
| ICompletableFuture | ClientMapProxy. submitToKeyInternal(Data keyData,
                   EntryProcessor entryProcessor) | 
| void | NearCachedClientMapProxy. submitToKeyInternal(Data keyData,
                   EntryProcessor entryProcessor,
                   ExecutionCallback callback) | 
| void | ClientMapProxy. submitToKeyInternal(Data keyData,
                   EntryProcessor entryProcessor,
                   ExecutionCallback callback) | 
| protected boolean | NearCachedClientMapProxy. tryPutInternal(long timeout,
              TimeUnit timeunit,
              Data keyData,
              Data valueData) | 
| protected boolean | ClientMapProxy. tryPutInternal(long timeout,
              TimeUnit timeunit,
              Data keyData,
              Data valueData) | 
| protected boolean | NearCachedClientMapProxy. tryRemoveInternal(long timeout,
                 TimeUnit timeunit,
                 Data keyData) | 
| protected boolean | ClientMapProxy. tryRemoveInternal(long timeout,
                 TimeUnit timeunit,
                 Data keyData) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected List<com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.ResponseParameters> | NearCachedClientMapProxy. getAllInternal(Map<Integer,List<Data>> pIdToKeyData,
              Map<K,V> result) | 
| protected List<com.hazelcast.client.impl.protocol.codec.MapGetAllCodec.ResponseParameters> | ClientMapProxy. getAllInternal(Map<Integer,List<Data>> partitionToKeyData,
              Map<K,V> result) | 
| void | NearCachedClientMapProxy.ClientMapAddNearCacheEventHandler. handle(Collection<Data> keys) | 
| protected void | NearCachedClientMapProxy. invalidateNearCache(Collection<Data> keys) | 
| protected void | NearCachedClientMapProxy. loadAllInternal(boolean replaceExistingValues,
               Collection<Data> dataKeys) | 
| protected void | ClientMapProxy. loadAllInternal(boolean replaceExistingValues,
               Collection<Data> dataKeys) | 
| protected Map<K,Object> | NearCachedClientMapProxy. prepareResult(Collection<Map.Entry<Data,Data>> entrySet) | 
| protected Map<K,Object> | NearCachedClientMapProxy. prepareResult(Collection<Map.Entry<Data,Data>> entrySet) | 
| protected Map<K,Object> | ClientMapProxy. prepareResult(Collection<Map.Entry<Data,Data>> entries) | 
| protected Map<K,Object> | ClientMapProxy. prepareResult(Collection<Map.Entry<Data,Data>> entries) | 
| protected void | NearCachedClientMapProxy. putAllInternal(Map<Integer,List<Map.Entry<Data,Data>>> entryMap) | 
| protected void | NearCachedClientMapProxy. putAllInternal(Map<Integer,List<Map.Entry<Data,Data>>> entryMap) | 
| protected void | ClientMapProxy. putAllInternal(Map<Integer,List<Map.Entry<Data,Data>>> entryMap) | 
| protected void | ClientMapProxy. putAllInternal(Map<Integer,List<Map.Entry<Data,Data>>> entryMap) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Data | ClientProxy. toData(Object o) | 
| Modifier and Type | Method and Description | 
|---|---|
| int | ClientPartitionService. getPartitionId(Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| int | ClientPartitionServiceImpl. getPartitionId(Data key) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | CollectionItem. value | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | CollectionEvent. getData() | 
| Data | CollectionItem. getValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Long,Data> | CollectionContainer. addAll(List<Data> valueList) | 
| Map<Long,Data> | CollectionContainer. clear() | 
| Map<Long,Data> | CollectionContainer. compareAndRemove(boolean retain,
                Set<Data> valueSet) | 
| List<Data> | CollectionContainer. getAll() | 
| Modifier and Type | Method and Description | 
|---|---|
| long | CollectionContainer. add(Data value) | 
| void | CollectionContainer. addBackup(long itemId,
         Data value) | 
| void | CollectionContainer. commitAdd(long itemId,
         Data value) | 
| void | CollectionContainer. commitAddBackup(long itemId,
               Data value) | 
| CollectionItem | CollectionContainer. remove(Data value) | 
| Long | CollectionContainer. reserveAdd(String transactionId,
          Data value) | 
| CollectionItem | CollectionContainer. reserveRemove(long reservedItemId,
             Data value,
             String transactionId) | 
| void | CollectionItem. setValue(Data value) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Long,Data> | CollectionContainer. addAll(List<Data> valueList) | 
| void | CollectionContainer. addAllBackup(Map<Long,Data> valueMap) | 
| Map<Long,Data> | CollectionContainer. compareAndRemove(boolean retain,
                Set<Data> valueSet) | 
| boolean | CollectionContainer. contains(Set<Data> valueSet) | 
| Constructor and Description | 
|---|
| CollectionEvent(String name,
               Data data,
               ItemEventType eventType,
               Address caller) | 
| CollectionItem(long itemId,
              Data value) | 
| TxCollectionItem(long itemId,
                Data value,
                String transactionId,
                boolean removeOperation) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | CollectionAddOperation. value | 
| Modifier and Type | Field and Description | 
|---|---|
| protected List<Data> | CollectionAddAllOperation. valueList | 
| protected Map<Long,Data> | CollectionAddAllOperation. valueMap | 
| protected Map<Long,Data> | CollectionAddAllBackupOperation. valueMap | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | CollectionOperation. publishEvent(ItemEventType eventType,
            Data data) | 
| Constructor and Description | 
|---|
| CollectionAddBackupOperation(String name,
                            long itemId,
                            Data value) | 
| CollectionAddOperation(String name,
                      Data value) | 
| CollectionRemoveOperation(String name,
                         Data value) | 
| Constructor and Description | 
|---|
| CollectionAddAllBackupOperation(String name,
                               Map<Long,Data> valueMap) | 
| CollectionAddAllOperation(String name,
                         List<Data> valueList) | 
| CollectionCompareAndRemoveOperation(String name,
                                   boolean retain,
                                   Set<Data> valueSet) | 
| CollectionContainsOperation(String name,
                           Set<Data> valueSet) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | DataAwareItemEvent. getItemData() | 
| Constructor and Description | 
|---|
| DataAwareItemEvent(String name,
                  ItemEventType itemEventType,
                  Data dataItem,
                  Member member,
                  SerializationService serializationService) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Long,Data> | ListContainer. addAll(int index,
      List<Data> valueList) | 
| List<Data> | ListContainer. sub(int from,
   int to) | 
| Modifier and Type | Method and Description | 
|---|---|
| CollectionItem | ListContainer. add(int index,
   Data value) | 
| int | ListContainer. indexOf(boolean last,
       Data value) | 
| CollectionItem | ListContainer. set(int index,
   long itemId,
   Data value) | 
| void | ListContainer. setBackup(long oldItemId,
         long itemId,
         Data value) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Long,Data> | ListContainer. addAll(int index,
      List<Data> valueList) | 
| Constructor and Description | 
|---|
| ListAddOperation(String name,
                int index,
                Data value) | 
| ListIndexOfOperation(String name,
                    boolean last,
                    Data value) | 
| ListSetBackupOperation(String name,
                      long oldItemId,
                      long itemId,
                      Data value) | 
| ListSetOperation(String name,
                int index,
                Data value) | 
| Constructor and Description | 
|---|
| ListAddAllOperation(String name,
                   int index,
                   List<Data> valueList) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | QueueItem. data | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | QueueItem. getData() | 
| Data | QueueContainer. getDataFromMap(long itemId) | 
| Data | QueueStoreWrapper. load(Long key) | 
| Data | QueueContainer. txnCommitPoll(long itemId) | 
| Data | QueueContainer. txnCommitPollBackup(long itemId) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Long,Data> | QueueContainer. addAll(Collection<Data> dataList) | 
| Map<Long,Data> | QueueContainer. clear() | 
| Map<Long,Data> | QueueContainer. compareAndRemove(Collection<Data> dataList,
                boolean retain)This method triggers store load | 
| Map<Long,Data> | QueueContainer. drain(int maxSize) | 
| List<Data> | QueueContainer. getAsDataList()This method triggers store load. | 
| Map<Long,Data> | QueueStoreWrapper. loadAll(Collection<Long> keys) | 
| Modifier and Type | Method and Description | 
|---|---|
| long | QueueContainer. offer(Data data) | 
| void | QueueContainer. offerBackup(Data data,
           long itemId) | 
| long | QueueContainer. remove(Data data)iterates all items, checks equality with data
 This method does not trigger store load. | 
| void | QueueItem. setData(Data data) | 
| void | QueueStoreWrapper. store(Long key,
     Data value) | 
| boolean | QueueContainer. txnCommitOffer(long itemId,
              Data data,
              boolean backup) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Long,Data> | QueueContainer. addAll(Collection<Data> dataList) | 
| void | QueueContainer. addAllBackup(Map<Long,Data> dataMap) | 
| Map<Long,Data> | QueueContainer. compareAndRemove(Collection<Data> dataList,
                boolean retain)This method triggers store load | 
| boolean | QueueContainer. contains(Collection<Data> dataSet)This method does not trigger store load. | 
| void | QueueStoreWrapper. storeAll(Map<Long,Data> map) | 
| Constructor and Description | 
|---|
| QueueEvent(String name,
          Data data,
          ItemEventType eventType,
          Address caller) | 
| QueueItem(QueueContainer container,
         long itemId,
         Data data) | 
| Constructor and Description | 
|---|
| QueueIterator(Iterator<Data> iterator,
             SerializationService serializationService,
             boolean binary) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QueueOperation. publishEvent(ItemEventType eventType,
            Data data) | 
| Constructor and Description | 
|---|
| OfferBackupOperation(String name,
                    Data data,
                    long itemId) | 
| OfferOperation(String name,
              long timeout,
              Data data) | 
| RemoveOperation(String name,
               Data data) | 
| Constructor and Description | 
|---|
| AddAllBackupOperation(String name,
                     Map<Long,Data> dataMap) | 
| AddAllOperation(String name,
               Collection<Data> dataList) | 
| CompareAndRemoveOperation(String name,
                         Collection<Data> dataList,
                         boolean retain) | 
| ContainsOperation(String name,
                 Collection<Data> dataList) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Long,Data> | SetContainer. addAll(List<Data> valueList) | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Long,Data> | SetContainer. addAll(List<Data> valueList) | 
| Constructor and Description | 
|---|
| CollectionReserveAddOperation(String name,
                             String transactionId,
                             Data value) | 
| CollectionReserveRemoveOperation(String name,
                                long reservedItemId,
                                Data value,
                                String transactionId) | 
| CollectionTxnAddBackupOperation(String name,
                               long itemId,
                               Data value) | 
| CollectionTxnAddOperation(String name,
                         long itemId,
                         Data value) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | TransactionalQueueProxySupport. peekInternal(long timeout) | 
| Data | TransactionalQueueProxySupport. pollInternal(long timeout) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | TransactionalQueueProxySupport. offerInternal(Data data,
             long timeout) | 
| Constructor and Description | 
|---|
| TxQueueItem(QueueContainer container,
           long itemId,
           Data data) | 
| Constructor and Description | 
|---|
| TxnOfferBackupOperation(String name,
                       long itemId,
                       Data data) | 
| TxnOfferOperation(String name,
                 long itemId,
                 Data data) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | AtomicReferenceContainer. get() | 
| Data | AtomicReferenceContainer. getAndSet(Data value) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | AtomicReferenceContainer. compareAndSet(Data expect,
             Data value) | 
| boolean | AtomicReferenceContainer. contains(Data expected) | 
| Data | AtomicReferenceContainer. getAndSet(Data value) | 
| void | AtomicReferenceContainer. set(Data value) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | AbstractAlterOperation. backup | 
| protected Data | AbstractAlterOperation. function | 
| protected Data | ApplyOperation. function | 
| protected Data | ApplyOperation. returnValue | 
| Constructor and Description | 
|---|
| AbstractAlterOperation(String name,
                      Data function) | 
| AlterAndGetOperation(String name,
                    Data function) | 
| AlterOperation(String name,
              Data function) | 
| ApplyOperation(String name,
              Data function) | 
| CompareAndSetOperation(String name,
                      Data expect,
                      Data update) | 
| ContainsOperation(String name,
                 Data contains) | 
| GetAndAlterOperation(String name,
                    Data function) | 
| GetAndSetOperation(String name,
                  Data newValue) | 
| SetAndGetOperation(String name,
                  Data newValue) | 
| SetBackupOperation(String name,
                  Data newValue) | 
| SetOperation(String name,
            Data newValue) | 
| Constructor and Description | 
|---|
| AtomicReferenceReplicationOperation(Map<String,Data> migrationData) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | ConditionKey. getKey() | 
| Data | LockResource. getKey() | 
| Data | LockProxy. getKeyData() | 
| Modifier and Type | Method and Description | 
|---|---|
| Set<Data> | LockStoreProxy. getLockedKeys() | 
| Set<Data> | LockStore. getLockedKeys() | 
| Set<Data> | LockStoreImpl. getLockedKeys() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LockStoreImpl. addAwait(Data key,
        String conditionId,
        String caller,
        long threadId) | 
| boolean | LockStoreProxy. canAcquireLock(Data key,
              String caller,
              long threadId) | 
| boolean | LockStore. canAcquireLock(Data key,
              String caller,
              long threadId) | 
| boolean | LockStoreImpl. canAcquireLock(Data key,
              String caller,
              long threadId) | 
| boolean | LockStoreProxy. extendLeaseTime(Data key,
               String caller,
               long threadId,
               long leaseTime) | 
| boolean | LockStore. extendLeaseTime(Data key,
               String caller,
               long threadId,
               long leaseTime) | 
| boolean | LockStoreImpl. extendLeaseTime(Data key,
               String caller,
               long threadId,
               long leaseTime) | 
| boolean | LockStoreProxy. forceUnlock(Data key) | 
| boolean | LockStore. forceUnlock(Data dataKey) | 
| boolean | LockStoreImpl. forceUnlock(Data key) | 
| void | LockProxySupport. forceUnlock(NodeEngine nodeEngine,
           Data key) | 
| com.hazelcast.concurrent.lock.LockResourceImpl | LockStoreImpl. getLock(Data key) | 
| int | LockStoreProxy. getLockCount(Data key) | 
| int | LockStore. getLockCount(Data key) | 
| int | LockStoreImpl. getLockCount(Data key) | 
| int | LockProxySupport. getLockCount(NodeEngine nodeEngine,
            Data key) | 
| WaitNotifyKey | LockStoreImpl. getNotifiedKey(Data key) | 
| String | LockStoreProxy. getOwnerInfo(Data dataKey) | 
| String | LockStore. getOwnerInfo(Data dataKey) | 
| String | LockStoreImpl. getOwnerInfo(Data key) | 
| long | LockStoreProxy. getRemainingLeaseTime(Data key) | 
| long | LockStore. getRemainingLeaseTime(Data key) | 
| long | LockStoreImpl. getRemainingLeaseTime(Data key) | 
| long | LockProxySupport. getRemainingLeaseTime(NodeEngine nodeEngine,
                     Data key) | 
| int | LockStoreImpl. getVersion(Data key) | 
| boolean | LockStoreProxy. isLocked(Data key) | 
| boolean | LockStore. isLocked(Data key) | 
| boolean | LockStoreImpl. isLocked(Data key) | 
| boolean | LockProxySupport. isLocked(NodeEngine nodeEngine,
        Data key) | 
| boolean | LockStoreProxy. isLockedBy(Data key,
          String caller,
          long threadId) | 
| boolean | LockStore. isLockedBy(Data key,
          String caller,
          long threadId) | 
| boolean | LockStoreImpl. isLockedBy(Data key,
          String caller,
          long threadId) | 
| boolean | LockProxySupport. isLockedByCurrentThread(NodeEngine nodeEngine,
                       Data key) | 
| boolean | LockStoreProxy. lock(Data key,
    String caller,
    long threadId,
    long referenceId,
    long leaseTime) | 
| boolean | LockStore. lock(Data key,
    String caller,
    long threadId,
    long referenceId,
    long leaseTime) | 
| boolean | LockStoreImpl. lock(Data key,
    String caller,
    long threadId,
    long referenceId,
    long leaseTime) | 
| void | LockProxySupport. lock(NodeEngine nodeEngine,
    Data key) | 
| void | LockProxySupport. lock(NodeEngine nodeEngine,
    Data key,
    long leaseTime) | 
| void | LockProxySupport. lockInterruptly(NodeEngine nodeEngine,
               Data key) | 
| void | LockProxySupport. lockInterruptly(NodeEngine nodeEngine,
               Data key,
               long leaseTime) | 
| AwaitOperation | LockStoreImpl. pollExpiredAwaitOp(Data key) | 
| void | LockStoreImpl. removeAwait(Data key,
           String conditionId,
           String caller,
           long threadId) | 
| boolean | LockStoreProxy. shouldBlockReads(Data key) | 
| boolean | LockStore. shouldBlockReads(Data key) | 
| boolean | LockStoreImpl. shouldBlockReads(Data key) | 
| void | LockStoreImpl. signal(Data key,
      String conditionId,
      int maxSignalCount,
      String objectName) | 
| boolean | LockProxySupport. tryLock(NodeEngine nodeEngine,
       Data key) | 
| boolean | LockProxySupport. tryLock(NodeEngine nodeEngine,
       Data key,
       long timeout,
       TimeUnit timeunit) | 
| boolean | LockProxySupport. tryLock(NodeEngine nodeEngine,
       Data key,
       long timeout,
       TimeUnit timeunit,
       long leaseTime,
       TimeUnit leaseTimeunit) | 
| boolean | LockStoreProxy. txnLock(Data key,
       String caller,
       long threadId,
       long referenceId,
       long leaseTime,
       boolean blockReads) | 
| boolean | LockStore. txnLock(Data key,
       String caller,
       long threadId,
       long referenceId,
       long leaseTime,
       boolean blockReads) | 
| boolean | LockStoreImpl. txnLock(Data key,
       String caller,
       long threadId,
       long referenceId,
       long leaseTime,
       boolean blockReads) | 
| boolean | LockStoreProxy. unlock(Data key,
      String caller,
      long threadId,
      long referenceId) | 
| boolean | LockStore. unlock(Data key,
      String caller,
      long threadId,
      long referenceId) | 
| boolean | LockStoreImpl. unlock(Data key,
      String caller,
      long threadId,
      long referenceId) | 
| void | LockProxySupport. unlock(NodeEngine nodeEngine,
      Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LockEvictionProcessor. process(EntryTaskScheduler<Data,Integer> scheduler,
       Collection<ScheduledEntry<Data,Integer>> entries) | 
| void | LockEvictionProcessor. process(EntryTaskScheduler<Data,Integer> scheduler,
       Collection<ScheduledEntry<Data,Integer>> entries) | 
| Constructor and Description | 
|---|
| ConditionKey(String name,
            Data key,
            String conditionId,
            String uuid,
            long threadId) | 
| LockWaitNotifyKey(ObjectNamespace namespace,
                 Data key) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | AbstractLockOperation. key | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | AbstractLockOperation. getKey() | 
| Constructor and Description | 
|---|
| AbstractLockOperation(ObjectNamespace namespace,
                     Data key,
                     long threadId) | 
| AbstractLockOperation(ObjectNamespace namespace,
                     Data key,
                     long threadId,
                     long timeout) | 
| AbstractLockOperation(ObjectNamespace namespace,
                     Data key,
                     long threadId,
                     long leaseTime,
                     long timeout) | 
| AwaitBackupOperation(ObjectNamespace namespace,
                    Data key,
                    long threadId,
                    String conditionId,
                    String originalCaller) | 
| AwaitOperation(ObjectNamespace namespace,
              Data key,
              long threadId,
              long timeout,
              String conditionId) | 
| AwaitOperation(ObjectNamespace namespace,
              Data key,
              long threadId,
              long timeout,
              String conditionId,
              long referenceId) | 
| BeforeAwaitBackupOperation(ObjectNamespace namespace,
                          Data key,
                          long threadId,
                          String conditionId,
                          String originalCaller) | 
| BeforeAwaitOperation(ObjectNamespace namespace,
                    Data key,
                    long threadId,
                    String conditionId) | 
| BeforeAwaitOperation(ObjectNamespace namespace,
                    Data key,
                    long threadId,
                    String conditionId,
                    long referenceId) | 
| GetLockCountOperation(ObjectNamespace namespace,
                     Data key) | 
| GetRemainingLeaseTimeOperation(ObjectNamespace namespace,
                              Data key) | 
| IsLockedOperation(ObjectNamespace namespace,
                 Data key) | 
| IsLockedOperation(ObjectNamespace namespace,
                 Data key,
                 long threadId) | 
| LocalLockCleanupOperation(ObjectNamespace namespace,
                         Data key,
                         String uuid) | 
| LockBackupOperation(ObjectNamespace namespace,
                   Data key,
                   long threadId,
                   long leaseTime,
                   String originalCallerUuid) | 
| LockOperation(ObjectNamespace namespace,
             Data key,
             long threadId,
             long leaseTime,
             long timeout) | 
| LockOperation(ObjectNamespace namespace,
             Data key,
             long threadId,
             long leaseTime,
             long timeout,
             long referenceId) | 
| SignalBackupOperation(ObjectNamespace namespace,
                     Data key,
                     long threadId,
                     String conditionId,
                     boolean all) | 
| SignalOperation(ObjectNamespace namespace,
               Data key,
               long threadId,
               String conditionId,
               boolean all) | 
| UnlockBackupOperation(ObjectNamespace namespace,
                     Data key,
                     long threadId,
                     String originalCallerUuid,
                     boolean force) | 
| UnlockIfLeaseExpiredOperation(ObjectNamespace namespace,
                             Data key,
                             int version) | 
| UnlockOperation(ObjectNamespace namespace,
               Data key,
               long threadId) | 
| UnlockOperation(ObjectNamespace namespace,
               Data key,
               long threadId,
               boolean force) | 
| UnlockOperation(ObjectNamespace namespace,
               Data key,
               long threadId,
               boolean force,
               long referenceId) | 
| Constructor and Description | 
|---|
| TaskBackupOperation(String name,
                   int sequence,
                   Data callableData) | 
| TaskOperation(String name,
             Data callableData) | 
| Constructor and Description | 
|---|
| CallableTaskOperation(String name,
                     String uuid,
                     Data callableData) | 
| MemberCallableTaskOperation(String name,
                           String uuid,
                           Data callableData) | 
| Modifier and Type | Method and Description | 
|---|---|
| int | InternalPartitionServiceImpl. getPartitionId(Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| BufferObjectDataInput | InputOutputFactory. createInput(Data data,
           InternalSerializationService service) | 
| BufferObjectDataInput | InternalSerializationService. createObjectDataInput(Data data) | 
| PortableReader | InternalSerializationService. createPortableReader(Data data) | 
| void | InternalSerializationService. disposeData(Data data) | 
| ClassDefinition | PortableContext. lookupClassDefinition(Data data) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HeapDataA  Dataimplementation where the content lives on the heap. | 
| Modifier and Type | Method and Description | 
|---|---|
| <B extends Data> | AbstractSerializationService. toData(Object obj) | 
| <B extends Data> | AbstractSerializationService. toData(Object obj,
      PartitioningStrategy strategy) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | ObjectDataInputStream. readData() | 
| Modifier and Type | Method and Description | 
|---|---|
| BufferObjectDataInput | AbstractSerializationService. createObjectDataInput(Data data) | 
| PortableReader | SerializationServiceV1. createPortableReader(Data data) | 
| void | AbstractSerializationService. disposeData(Data data) | 
| void | ObjectDataOutputStream. writeData(Data data) | 
| Modifier and Type | Method and Description | 
|---|---|
| BufferObjectDataInput | BufferPool. takeInputBuffer(Data data)Takes an BufferObjectDataInput from the pool and initializes it with the given data. | 
| BufferObjectDataInput | BufferPoolImpl. takeInputBuffer(Data data) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | EntryEventFilter. key | 
| Modifier and Type | Field and Description | 
|---|---|
| protected IFunction<Object,Data> | MapContainer. toDataFunction | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | EntryEventFilter. getKey() | 
| Data | MapEntries. getKey(int index) | 
| Data | DataAwareEntryEvent. getKeyData() | 
| Data | DataAwareEntryEvent. getMergingValueData() | 
| Data | DataAwareEntryEvent. getNewValueData() | 
| Data | DataAwareEntryEvent. getOldValueData() | 
| Data | MapEntries. getValue(int index) | 
| Data | MapServiceContext. toData(Object object) | 
| Data | MapServiceContext. toData(Object object,
      PartitioningStrategy partitionStrategy) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Map.Entry<Data,Data>> | MapEntries. entries() | 
| List<Map.Entry<Data,Data>> | MapEntries. entries() | 
| Set<Data> | MapKeySet. getKeySet() | 
| Collection<Data> | MapValueCollection. getValues() | 
| IFunction<Object,Data> | MapContainer. toData() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MapEntries. add(Data key,
   Data value) | 
| QueryableEntry | MapContainer. newQueryEntry(Data key,
             Object value) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MapEntries. putAllToList(Collection<Map.Entry<Data,Data>> targetList) | 
| void | MapEntries. putAllToList(Collection<Map.Entry<Data,Data>> targetList) | 
| Constructor and Description | 
|---|
| DataAwareEntryEvent(Member from,
                   int eventType,
                   String source,
                   Data dataKey,
                   Data dataNewValue,
                   Data dataOldValue,
                   Data dataMergingValue,
                   SerializationService serializationService) | 
| EntryEventFilter(boolean includeValue,
                Data key) | 
| LazyMapEntry(Data key,
            Object value,
            InternalSerializationService serializationService) | 
| LazyMapEntry(Data key,
            Object value,
            InternalSerializationService serializationService,
            Extractors extractors) | 
| MapRecordKey(String mapName,
            Data key) | 
| Constructor and Description | 
|---|
| MapEntries(List<Map.Entry<Data,Data>> entries) | 
| MapEntries(List<Map.Entry<Data,Data>> entries) | 
| MapKeyLoader(String mapName,
            OperationService opService,
            IPartitionService ps,
            ClusterService clusterService,
            ExecutionService execService,
            IFunction<Object,Data> serialize) | 
| MapKeySet(Set<Data> keySet) | 
| MapValueCollection(Collection<Data> values) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | EntryEventData. dataKey | 
| protected Data | EntryEventData. dataMergingValue | 
| protected Data | EntryEventData. dataNewValue | 
| protected Data | EntryEventData. dataOldValue | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | EntryEventData. getDataKey() | 
| Data | EntryEventData. getDataMergingValue() | 
| Data | EntryEventData. getDataNewValue() | 
| Data | EntryEventData. getDataOldValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| int | QueryCacheNaturalFilteringStrategy. doFilter(EventFilter filter,
        Data dataKey,
        Object dataOldValue,
        Object dataValue,
        EntryEventType eventType,
        String mapNameOrNull) | 
| int | DefaultEntryEventFilteringStrategy. doFilter(EventFilter filter,
        Data dataKey,
        Object dataOldValue,
        Object dataValue,
        EntryEventType eventType,
        String mapNameOrNull) | 
| int | FilteringStrategy. doFilter(EventFilter filter,
        Data dataKey,
        Object dataOldValue,
        Object dataValue,
        EntryEventType eventType,
        String mapNameOrNull)Main entry point for filtering events according to given filter. | 
| protected boolean | AbstractFilteringStrategy. evaluateQueryEventFilter(EventFilter filter,
                        Data dataKey,
                        Object testValue,
                        String mapNameOrNull) | 
| EntryEventData | EntryEventDataCache. getOrCreateEventData(String mapName,
                    Address caller,
                    Data dataKey,
                    Object newValue,
                    Object oldValue,
                    Object mergingValue,
                    int eventType,
                    boolean includingValues)If an  EntryEventDatafor the given parameters is already cached then return the cached value, otherwise create,
 cache and return theEntryEventData. | 
| protected boolean | AbstractFilteringStrategy. processEntryEventFilter(EventFilter filter,
                       Data dataKey) | 
| void | MapEventPublisherImpl. publishEvent(Address caller,
            String mapName,
            EntryEventType eventType,
            Data dataKey,
            Object dataOldValue,
            Object dataValue) | 
| void | MapEventPublisher. publishEvent(Address caller,
            String mapName,
            EntryEventType eventType,
            Data dataKey,
            Object dataOldValue,
            Object dataValue) | 
| void | MapEventPublisherImpl. publishEvent(Address caller,
            String mapName,
            EntryEventType eventType,
            Data dataKey,
            Object oldValue,
            Object value,
            Object mergingValue) | 
| void | MapEventPublisher. publishEvent(Address caller,
            String mapName,
            EntryEventType eventType,
            Data dataKey,
            Object dataOldValue,
            Object dataValue,
            Object dataMergingValue) | 
| void | MapEventPublisherImpl. publishWanReplicationRemove(String mapName,
                           Data key,
                           long removeTime) | 
| void | MapEventPublisher. publishWanReplicationRemove(String mapName,
                           Data key,
                           long removeTime) | 
| void | MapEventPublisherImpl. publishWanReplicationRemoveBackup(String mapName,
                                 Data key,
                                 long removeTime) | 
| void | MapEventPublisher. publishWanReplicationRemoveBackup(String mapName,
                                 Data key,
                                 long removeTime) | 
| Constructor and Description | 
|---|
| EntryEventData(String source,
              String mapName,
              Address caller,
              Data dataKey,
              Data dataNewValue,
              Data dataOldValue,
              Data dataMergingValue,
              int eventType) | 
| EntryEventData(String source,
              String mapName,
              Address caller,
              Data dataKey,
              Data dataNewValue,
              Data dataOldValue,
              int eventType) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | EvictorImpl. evict(RecordStore recordStore,
     Data excludedKey) | 
| void | Evictor. evict(RecordStore recordStore,
     Data excludedKey)Evict supplied record-store. | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | MapKeysWithCursor. getKey(int index) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Map.Entry<Data,Data>> | MapEntriesWithCursor. getEntries() | 
| List<Map.Entry<Data,Data>> | MapEntriesWithCursor. getEntries() | 
| List<Data> | MapKeysWithCursor. getKeys() | 
| Constructor and Description | 
|---|
| MapEntriesWithCursor(List<Map.Entry<Data,Data>> entries,
                    int nextTableIndexToReadFrom) | 
| MapEntriesWithCursor(List<Map.Entry<Data,Data>> entries,
                    int nextTableIndexToReadFrom) | 
| MapKeysWithCursor(List<Data> keys,
                 int nextTableIndexToReadFrom) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Data | AbstractMapDataStore. toData(Object obj) | 
| Modifier and Type | Method and Description | 
|---|---|
| Object | WriteBehindStore. add(Data key,
   Object value,
   long now) | 
| Object | WriteBehindStore. addBackup(Data key,
         Object value,
         long time) | 
| void | WriteBehindStore. addTransient(Data key,
            long now) | 
| Object | WriteBehindStore. flush(Data key,
     Object value,
     boolean backup) | 
| Object | WriteBehindStore. load(Data key) | 
| boolean | WriteBehindStore. loadable(Data key)* Used in  IMap.loadAll(boolean)calls. | 
| void | WriteBehindStore. remove(Data key,
      long now) | 
| void | WriteBehindStore. removeBackup(Data key,
            long time) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | WriteBehindStore. add(DelayedEntry<Data,Object> delayedEntry) | 
| Modifier and Type | Method and Description | 
|---|---|
| Object | WriteThroughStore. add(Data key,
   Object value,
   long time) | 
| Object | WriteThroughStore. addBackup(Data key,
         Object value,
         long time) | 
| void | WriteThroughStore. addTransient(Data key,
            long now) | 
| Object | WriteThroughStore. flush(Data key,
     Object value,
     boolean backup) | 
| Object | WriteThroughStore. load(Data key) | 
| boolean | WriteThroughStore. loadable(Data key) | 
| void | WriteThroughStore. remove(Data key,
      long time) | 
| void | WriteThroughStore. removeBackup(Data key,
            long time) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | SingleNearCacheInvalidation. getKey() | 
| protected Data | AbstractNearCacheInvalidator. toHeapData(Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<Data> | BatchInvalidator. getKeys(BatchNearCacheInvalidation batch) | 
| static List<Data> | BatchInvalidator. getKeysExcludingSource(BatchNearCacheInvalidation batch,
                      String excludedSourceUuid) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BatchInvalidator. accumulateOrInvalidate(String mapName,
                      Data key,
                      List<Data> keys,
                      String sourceUuid) | 
| static MapOperation | AbstractNearCacheInvalidator. createSingleOrBatchInvalidationOperation(String mapName,
                                        Data key,
                                        List<Data> keys) | 
| Object | NearCacheImpl. get(Data key) | 
| Object | NearCacheProvider. getFromNearCache(String mapName,
                Data key) | 
| void | NearCacheInvalidator. invalidate(String mapName,
          Data key,
          String sourceUuid)Invalidates local and remote near-caches. | 
| void | NonStopInvalidator. invalidate(String mapName,
          Data key,
          String sourceUuid) | 
| void | BatchInvalidator. invalidate(String mapName,
          Data key,
          String sourceUuid) | 
| protected void | NonStopInvalidator. invalidateClient(String mapName,
                Data key,
                List<Data> keys,
                String sourceUuid) | 
| void | AbstractNearCacheInvalidator. invalidateLocal(String mapName,
               Data key,
               List<Data> keys) | 
| protected void | NonStopInvalidator. invalidateMember(String mapName,
                Data key,
                List<Data> keys,
                String sourceUuid) | 
| void | NearCacheImpl. put(Data key,
   Object value) | 
| boolean | NearCacheImpl. remove(Data key) | 
| protected Data | AbstractNearCacheInvalidator. toHeapData(Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | BatchInvalidator. accumulateOrInvalidate(String mapName,
                      Data key,
                      List<Data> keys,
                      String sourceUuid) | 
| static MapOperation | AbstractNearCacheInvalidator. createSingleOrBatchInvalidationOperation(String mapName,
                                        Data key,
                                        List<Data> keys) | 
| void | NearCacheInvalidator. invalidate(String mapName,
          List<Data> keys,
          String sourceUuid)Invalidates local and remote near-caches. | 
| void | NonStopInvalidator. invalidate(String mapName,
          List<Data> keys,
          String sourceUuid) | 
| void | BatchInvalidator. invalidate(String mapName,
          List<Data> keys,
          String sourceUuid) | 
| protected void | NonStopInvalidator. invalidateClient(String mapName,
                Data key,
                List<Data> keys,
                String sourceUuid) | 
| void | AbstractNearCacheInvalidator. invalidateLocal(String mapName,
               Data key,
               List<Data> keys) | 
| protected void | NonStopInvalidator. invalidateMember(String mapName,
                Data key,
                List<Data> keys,
                String sourceUuid) | 
| Constructor and Description | 
|---|
| SingleNearCacheInvalidation(String mapName,
                           Data key,
                           String sourceUuid) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | MutatingKeyBasedMapOperation. dataKey | 
| protected Data | ReadonlyKeyBasedMapOperation. dataKey | 
| protected Data | BasePutOperation. dataOldValue | 
| protected Data | BaseRemoveOperation. dataOldValue | 
| protected Data | MutatingKeyBasedMapOperation. dataValue | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Set<Data> | MultipleEntryOperation. keys | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | MutatingKeyBasedMapOperation. getKey() | 
| Data | GetOperation. getResponse() | 
| Data | MutatingKeyBasedMapOperation. getValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| MapOperation | MapOperationProvider. createContainsKeyOperation(String name,
                          Data dataKey) | 
| MapOperation | DefaultMapOperationProvider. createContainsKeyOperation(String name,
                          Data dataKey) | 
| OperationFactory | MapOperationProvider. createContainsValueOperationFactory(String name,
                                   Data testValue) | 
| OperationFactory | DefaultMapOperationProvider. createContainsValueOperationFactory(String name,
                                   Data testValue) | 
| MapOperation | WANAwareOperationProvider. createDeleteOperation(String name,
                     Data key) | 
| MapOperation | MapOperationProvider. createDeleteOperation(String name,
                     Data key) | 
| MapOperation | DefaultMapOperationProvider. createDeleteOperation(String name,
                     Data key) | 
| MapOperation | WANAwareOperationProvider. createEntryOperation(String name,
                    Data dataKey,
                    EntryProcessor entryProcessor) | 
| MapOperation | MapOperationProvider. createEntryOperation(String name,
                    Data dataKey,
                    EntryProcessor entryProcessor) | 
| MapOperation | DefaultMapOperationProvider. createEntryOperation(String name,
                    Data dataKey,
                    EntryProcessor entryProcessor) | 
| MapOperation | MapOperationProvider. createEvictOperation(String name,
                    Data dataKey,
                    boolean asyncBackup) | 
| MapOperation | DefaultMapOperationProvider. createEvictOperation(String name,
                    Data dataKey,
                    boolean asyncBackup) | 
| MapOperation | MapOperationProvider. createGetEntryViewOperation(String name,
                           Data dataKey) | 
| MapOperation | DefaultMapOperationProvider. createGetEntryViewOperation(String name,
                           Data dataKey) | 
| MapOperation | MapOperationProvider. createGetOperation(String name,
                  Data dataKey) | 
| MapOperation | DefaultMapOperationProvider. createGetOperation(String name,
                  Data dataKey) | 
| MapOperation | MapOperationProvider. createMergeOperation(String name,
                    Data dataKey,
                    EntryView<Data,Data> entryView,
                    MapMergePolicy policy,
                    boolean disableWanReplicationEvent) | 
| MapOperation | DefaultMapOperationProvider. createMergeOperation(String name,
                    Data dataKey,
                    EntryView<Data,Data> entryView,
                    MapMergePolicy policy,
                    boolean disableWanReplicationEvent) | 
| MapOperation | WANAwareOperationProvider. createPutIfAbsentOperation(String name,
                          Data key,
                          Data value,
                          long ttl) | 
| MapOperation | MapOperationProvider. createPutIfAbsentOperation(String name,
                          Data key,
                          Data value,
                          long ttl) | 
| MapOperation | DefaultMapOperationProvider. createPutIfAbsentOperation(String name,
                          Data key,
                          Data value,
                          long ttl) | 
| MapOperation | WANAwareOperationProvider. createPutOperation(String name,
                  Data key,
                  Data value,
                  long ttl) | 
| MapOperation | MapOperationProvider. createPutOperation(String name,
                  Data key,
                  Data value,
                  long ttl) | 
| MapOperation | DefaultMapOperationProvider. createPutOperation(String name,
                  Data key,
                  Data value,
                  long ttl) | 
| MapOperation | WANAwareOperationProvider. createPutTransientOperation(String name,
                           Data key,
                           Data value,
                           long ttl) | 
| MapOperation | MapOperationProvider. createPutTransientOperation(String name,
                           Data key,
                           Data value,
                           long ttl) | 
| MapOperation | DefaultMapOperationProvider. createPutTransientOperation(String name,
                           Data key,
                           Data value,
                           long ttl) | 
| MapOperation | WANAwareOperationProvider. createRemoveIfSameOperation(String name,
                           Data dataKey,
                           Data value) | 
| MapOperation | MapOperationProvider. createRemoveIfSameOperation(String name,
                           Data dataKey,
                           Data value) | 
| MapOperation | DefaultMapOperationProvider. createRemoveIfSameOperation(String name,
                           Data dataKey,
                           Data value) | 
| MapOperation | WANAwareOperationProvider. createRemoveOperation(String name,
                     Data key,
                     boolean disableWanReplicationEvent) | 
| MapOperation | MapOperationProvider. createRemoveOperation(String name,
                     Data key,
                     boolean disableWanReplicationEvent) | 
| MapOperation | DefaultMapOperationProvider. createRemoveOperation(String name,
                     Data key,
                     boolean disableWanReplicationEvent) | 
| MapOperation | WANAwareOperationProvider. createReplaceIfSameOperation(String name,
                            Data dataKey,
                            Data expect,
                            Data update) | 
| MapOperation | MapOperationProvider. createReplaceIfSameOperation(String name,
                            Data dataKey,
                            Data expect,
                            Data update) | 
| MapOperation | DefaultMapOperationProvider. createReplaceIfSameOperation(String name,
                            Data dataKey,
                            Data expect,
                            Data update) | 
| MapOperation | WANAwareOperationProvider. createReplaceOperation(String name,
                      Data dataKey,
                      Data value) | 
| MapOperation | MapOperationProvider. createReplaceOperation(String name,
                      Data dataKey,
                      Data value) | 
| MapOperation | DefaultMapOperationProvider. createReplaceOperation(String name,
                      Data dataKey,
                      Data value) | 
| MapOperation | WANAwareOperationProvider. createSetOperation(String name,
                  Data dataKey,
                  Data value,
                  long ttl) | 
| MapOperation | MapOperationProvider. createSetOperation(String name,
                  Data dataKey,
                  Data value,
                  long ttl) | 
| MapOperation | DefaultMapOperationProvider. createSetOperation(String name,
                  Data dataKey,
                  Data value,
                  long ttl) | 
| MapOperation | WANAwareOperationProvider. createTryPutOperation(String name,
                     Data dataKey,
                     Data value,
                     long timeout) | 
| MapOperation | MapOperationProvider. createTryPutOperation(String name,
                     Data dataKey,
                     Data value,
                     long timeout) | 
| MapOperation | DefaultMapOperationProvider. createTryPutOperation(String name,
                     Data dataKey,
                     Data value,
                     long timeout) | 
| MapOperation | WANAwareOperationProvider. createTryRemoveOperation(String name,
                        Data dataKey,
                        long timeout) | 
| MapOperation | MapOperationProvider. createTryRemoveOperation(String name,
                        Data dataKey,
                        long timeout) | 
| MapOperation | DefaultMapOperationProvider. createTryRemoveOperation(String name,
                        Data dataKey,
                        long timeout) | 
| MapOperation | WANAwareOperationProvider. createTxnDeleteOperation(String name,
                        Data dataKey,
                        long version) | 
| MapOperation | MapOperationProvider. createTxnDeleteOperation(String name,
                        Data dataKey,
                        long version) | 
| MapOperation | DefaultMapOperationProvider. createTxnDeleteOperation(String name,
                        Data dataKey,
                        long version) | 
| MapOperation | MapOperationProvider. createTxnLockAndGetOperation(String name,
                            Data dataKey,
                            long timeout,
                            long ttl,
                            String ownerUuid,
                            boolean shouldLoad,
                            boolean blockReads) | 
| MapOperation | DefaultMapOperationProvider. createTxnLockAndGetOperation(String name,
                            Data dataKey,
                            long timeout,
                            long ttl,
                            String ownerUuid,
                            boolean shouldLoad,
                            boolean blockReads) | 
| MapOperation | WANAwareOperationProvider. createTxnSetOperation(String name,
                     Data dataKey,
                     Data value,
                     long version,
                     long ttl) | 
| MapOperation | MapOperationProvider. createTxnSetOperation(String name,
                     Data dataKey,
                     Data value,
                     long version,
                     long ttl) | 
| MapOperation | DefaultMapOperationProvider. createTxnSetOperation(String name,
                     Data dataKey,
                     Data value,
                     long version,
                     long ttl) | 
| protected void | MapOperation. evict(Data excludedKey) | 
| protected void | MapOperation. invalidateNearCache(Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| OperationFactory | MapOperationProvider. createGetAllOperationFactory(String name,
                            List<Data> keys) | 
| OperationFactory | DefaultMapOperationProvider. createGetAllOperationFactory(String name,
                            List<Data> keys) | 
| MapOperation | MapOperationProvider. createLoadAllOperation(String name,
                      List<Data> keys,
                      boolean replaceExistingValues,
                      boolean withUserSuppliedKeys) | 
| MapOperation | DefaultMapOperationProvider. createLoadAllOperation(String name,
                      List<Data> keys,
                      boolean replaceExistingValues,
                      boolean withUserSuppliedKeys) | 
| OperationFactory | MapOperationProvider. createLoadAllOperationFactory(String name,
                             List<Data> keys,
                             boolean replaceExistingValues) | 
| OperationFactory | DefaultMapOperationProvider. createLoadAllOperationFactory(String name,
                             List<Data> keys,
                             boolean replaceExistingValues) | 
| MapOperation | MapOperationProvider. createMergeOperation(String name,
                    Data dataKey,
                    EntryView<Data,Data> entryView,
                    MapMergePolicy policy,
                    boolean disableWanReplicationEvent) | 
| MapOperation | MapOperationProvider. createMergeOperation(String name,
                    Data dataKey,
                    EntryView<Data,Data> entryView,
                    MapMergePolicy policy,
                    boolean disableWanReplicationEvent) | 
| MapOperation | DefaultMapOperationProvider. createMergeOperation(String name,
                    Data dataKey,
                    EntryView<Data,Data> entryView,
                    MapMergePolicy policy,
                    boolean disableWanReplicationEvent) | 
| MapOperation | DefaultMapOperationProvider. createMergeOperation(String name,
                    Data dataKey,
                    EntryView<Data,Data> entryView,
                    MapMergePolicy policy,
                    boolean disableWanReplicationEvent) | 
| OperationFactory | WANAwareOperationProvider. createMultipleEntryOperationFactory(String name,
                                   Set<Data> keys,
                                   EntryProcessor entryProcessor) | 
| OperationFactory | MapOperationProvider. createMultipleEntryOperationFactory(String name,
                                   Set<Data> keys,
                                   EntryProcessor entryProcessor) | 
| OperationFactory | DefaultMapOperationProvider. createMultipleEntryOperationFactory(String name,
                                   Set<Data> keys,
                                   EntryProcessor entryProcessor) | 
| MapOperation | WANAwareOperationProvider. createPutFromLoadAllOperation(String name,
                             List<Data> keyValueSequence) | 
| MapOperation | MapOperationProvider. createPutFromLoadAllOperation(String name,
                             List<Data> keyValueSequence) | 
| MapOperation | DefaultMapOperationProvider. createPutFromLoadAllOperation(String name,
                             List<Data> keyValueSequence) | 
| protected void | MapOperation. invalidateNearCache(List<Data> keys) | 
| Constructor and Description | 
|---|
| BasePutOperation(String name,
                Data dataKey,
                Data value) | 
| BasePutOperation(String name,
                Data dataKey,
                Data value,
                long ttl) | 
| BaseRemoveOperation(String name,
                   Data dataKey) | 
| BaseRemoveOperation(String name,
                   Data dataKey,
                   boolean disableWanReplicationEvent) | 
| ContainsKeyOperation(String name,
                    Data dataKey) | 
| ContainsValueOperation(String name,
                      Data testValue) | 
| ContainsValueOperationFactory(String name,
                             Data value) | 
| DeleteOperation(String name,
               Data dataKey) | 
| EntryBackupOperation(String name,
                    Data dataKey,
                    EntryBackupProcessor entryProcessor) | 
| EntryOperation(String name,
              Data dataKey,
              EntryProcessor entryProcessor) | 
| EvictBackupOperation(String name,
                    Data dataKey) | 
| EvictBackupOperation(String name,
                    Data dataKey,
                    boolean unlockKey) | 
| EvictBackupOperation(String name,
                    Data dataKey,
                    boolean unlockKey,
                    boolean disableWanReplicationEvent) | 
| EvictOperation(String name,
              Data dataKey,
              boolean asyncBackup) | 
| GetEntryViewOperation(String name,
                     Data dataKey) | 
| GetOperation(String name,
            Data dataKey) | 
| LockAwareOperation(String name,
                  Data dataKey) | 
| LockAwareOperation(String name,
                  Data dataKey,
                  Data dataValue,
                  long ttl) | 
| LockAwareOperation(String name,
                  Data dataKey,
                  long ttl) | 
| MergeOperation(String name,
              Data dataKey,
              EntryView<Data,Data> entryView,
              MapMergePolicy policy) | 
| MergeOperation(String name,
              Data dataKey,
              EntryView<Data,Data> entryView,
              MapMergePolicy policy,
              boolean disableWanReplicationEvent) | 
| MutatingKeyBasedMapOperation(String name,
                            Data dataKey) | 
| MutatingKeyBasedMapOperation(String name,
                            Data dataKey,
                            Data dataValue) | 
| MutatingKeyBasedMapOperation(String name,
                            Data dataKey,
                            Data dataValue,
                            long ttl) | 
| MutatingKeyBasedMapOperation(String name,
                            Data dataKey,
                            long ttl) | 
| NearCacheSingleInvalidationOperation(String mapName,
                                    Data key) | 
| PutBackupOperation(String name,
                  Data dataKey,
                  Data dataValue,
                  RecordInfo recordInfo) | 
| PutBackupOperation(String name,
                  Data dataKey,
                  Data dataValue,
                  RecordInfo recordInfo,
                  boolean putTransient) | 
| PutBackupOperation(String name,
                  Data dataKey,
                  Data dataValue,
                  RecordInfo recordInfo,
                  boolean unlockKey,
                  boolean putTransient) | 
| PutBackupOperation(String name,
                  Data dataKey,
                  Data dataValue,
                  RecordInfo recordInfo,
                  boolean unlockKey,
                  boolean putTransient,
                  boolean disableWanReplicationEvent) | 
| PutIfAbsentOperation(String name,
                    Data dataKey,
                    Data value,
                    long ttl) | 
| PutOperation(String name,
            Data dataKey,
            Data value,
            long ttl) | 
| PutTransientOperation(String name,
                     Data dataKey,
                     Data value,
                     long ttl) | 
| ReadonlyKeyBasedMapOperation(String name,
                            Data dataKey) | 
| RemoveBackupOperation(String name,
                     Data dataKey) | 
| RemoveBackupOperation(String name,
                     Data dataKey,
                     boolean unlockKey) | 
| RemoveBackupOperation(String name,
                     Data dataKey,
                     boolean unlockKey,
                     boolean disableWanReplicationEvent) | 
| RemoveIfSameOperation(String name,
                     Data dataKey,
                     Data value) | 
| RemoveOperation(String name,
               Data dataKey,
               boolean disableWanReplicationEvent) | 
| ReplaceIfSameOperation(String name,
                      Data dataKey,
                      Data expect,
                      Data update) | 
| ReplaceOperation(String name,
                Data dataKey,
                Data value) | 
| SetOperation(String name,
            Data dataKey,
            Data value,
            long ttl) | 
| TryPutOperation(String name,
               Data dataKey,
               Data value,
               long timeout) | 
| TryRemoveOperation(String name,
                  Data dataKey,
                  long timeout) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected NearCache<Data,Object> | NearCachedMapProxyImpl. nearCache | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | NearCachedMapProxyImpl. executeOnKeyInternal(Data key,
                    EntryProcessor entryProcessor) | 
| protected Data | NearCachedMapProxyImpl. putIfAbsentInternal(Data key,
                   Data value,
                   long ttl,
                   TimeUnit timeunit) | 
| protected Data | NearCachedMapProxyImpl. putInternal(Data key,
           Data value,
           long ttl,
           TimeUnit timeunit) | 
| protected Data | NearCachedMapProxyImpl. removeInternal(Data key) | 
| protected Data | NearCachedMapProxyImpl. replaceInternal(Data key,
               Data value) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ICompletableFuture<Data> | NearCachedMapProxyImpl. getAsyncInternal(Data key) | 
| protected ICompletableFuture<Data> | NearCachedMapProxyImpl. putAsyncInternal(Data key,
                Data value,
                long ttl,
                TimeUnit timeunit) | 
| protected ICompletableFuture<Data> | NearCachedMapProxyImpl. removeAsyncInternal(Data key) | 
| protected ICompletableFuture<Data> | NearCachedMapProxyImpl. setAsyncInternal(Data key,
                Data value,
                long ttl,
                TimeUnit timeunit) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected boolean | NearCachedMapProxyImpl. containsKeyInternal(Data keyData) | 
| protected void | NearCachedMapProxyImpl. deleteInternal(Data key) | 
| protected boolean | NearCachedMapProxyImpl. evictInternal(Data key) | 
| Data | NearCachedMapProxyImpl. executeOnKeyInternal(Data key,
                    EntryProcessor entryProcessor) | 
| ICompletableFuture | NearCachedMapProxyImpl. executeOnKeyInternal(Data key,
                    EntryProcessor entryProcessor,
                    ExecutionCallback<Object> callback) | 
| protected ICompletableFuture<Data> | NearCachedMapProxyImpl. getAsyncInternal(Data key) | 
| protected Object | NearCachedMapProxyImpl. getCachedValue(Data key) | 
| protected Object | NearCachedMapProxyImpl. getInternal(Data key) | 
| protected void | NearCachedMapProxyImpl. invalidateCache(Data key) | 
| protected boolean | NearCachedMapProxyImpl. isOwn(Data key) | 
| protected ICompletableFuture<Data> | NearCachedMapProxyImpl. putAsyncInternal(Data key,
                Data value,
                long ttl,
                TimeUnit timeunit) | 
| protected Data | NearCachedMapProxyImpl. putIfAbsentInternal(Data key,
                   Data value,
                   long ttl,
                   TimeUnit timeunit) | 
| protected Data | NearCachedMapProxyImpl. putInternal(Data key,
           Data value,
           long ttl,
           TimeUnit timeunit) | 
| protected void | NearCachedMapProxyImpl. putTransientInternal(Data key,
                    Data value,
                    long ttl,
                    TimeUnit timeunit) | 
| protected ICompletableFuture<Data> | NearCachedMapProxyImpl. removeAsyncInternal(Data key) | 
| protected Data | NearCachedMapProxyImpl. removeInternal(Data key) | 
| protected boolean | NearCachedMapProxyImpl. removeInternal(Data key,
              Data value) | 
| protected Data | NearCachedMapProxyImpl. replaceInternal(Data key,
               Data value) | 
| protected boolean | NearCachedMapProxyImpl. replaceInternal(Data key,
               Data expect,
               Data update) | 
| protected ICompletableFuture<Data> | NearCachedMapProxyImpl. setAsyncInternal(Data key,
                Data value,
                long ttl,
                TimeUnit timeunit) | 
| protected void | NearCachedMapProxyImpl. setInternal(Data key,
           Data value,
           long ttl,
           TimeUnit timeunit) | 
| protected boolean | NearCachedMapProxyImpl. tryPutInternal(Data key,
              Data value,
              long timeout,
              TimeUnit timeunit) | 
| protected boolean | NearCachedMapProxyImpl. tryRemoveInternal(Data key,
                 long timeout,
                 TimeUnit timeunit) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | NearCachedMapProxyImpl. executeOnEntriesInternal(EntryProcessor entryProcessor,
                        Predicate predicate,
                        List<Data> resultingKeyValuePairs) | 
| Map | NearCachedMapProxyImpl. executeOnKeysInternal(Set<Data> keys,
                     EntryProcessor entryProcessor) | 
| protected void | NearCachedMapProxyImpl. getAllObjectInternal(List<Data> keys,
                    List<Object> resultingKeyValuePairs) | 
| protected void | NearCachedMapProxyImpl. getCachedValue(List<Data> keys,
              List<Object> resultingKeyValuePairs) | 
| protected void | NearCachedMapProxyImpl. invalidateCache(Collection<Data> keys) | 
| protected void | NearCachedMapProxyImpl. invalidateCache(Iterable<Data> keys) | 
| protected void | NearCachedMapProxyImpl. loadInternal(Iterable<Data> keys,
            boolean replaceExistingValues) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | QueryResultRow. getKey() | 
| Data | QueryResultRow. getValue() | 
| Data | QueryResultRow. setValue(Data value) | 
| Modifier and Type | Method and Description | 
|---|---|
| QueryableEntry | QueryEntryFactory. newEntry(InternalSerializationService serializationService,
        Data key,
        Object value,
        Extractors extractors) | 
| Data | QueryResultRow. setValue(Data value) | 
| Constructor and Description | 
|---|
| QueryEventFilter(boolean includeValue,
                Data key,
                Predicate predicate) | 
| QueryResultRow(Data key,
              Data valueData) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | DefaultQueryCacheEventData. getDataKey() | 
| Data | QueryCacheEventData. getDataKey() | 
| Data | DefaultQueryCacheEventData. getDataNewValue() | 
| Data | QueryCacheEventData. getDataNewValue() | 
| Data | DefaultQueryCacheEventData. getDataOldValue() | 
| Data | QueryCacheEventData. getDataOldValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DefaultQueryCacheEventData. setDataKey(Data dataKey) | 
| void | DefaultQueryCacheEventData. setDataNewValue(Data dataNewValue) | 
| void | DefaultQueryCacheEventData. setDataOldValue(Data dataOldValue) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | AbstractRecord. key | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | Record. getKey() | 
| Data | AbstractRecord. getKey() | 
| Data | RecordReplicationInfo. getKey() | 
| Data | RecordReplicationInfo. getValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| Record<Data> | DataRecordFactory. newRecord(Object value) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | AbstractRecord. setKey(Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DataRecordFactory. setValue(Record<Data> record,
        Object value) | 
| Constructor and Description | 
|---|
| RecordReplicationInfo(Data key,
                     Data value,
                     RecordInfo recordInfo) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | RecordStore. readBackupData(Data key)Called when  MapConfig.isReadBackupData()istruefromMapProxySupport.getInternal(com.hazelcast.nio.serialization.Data)Returns corresponding value for key asData. | 
| Data | DefaultRecordStore. readBackupData(Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected List<Data> | DefaultRecordStore. getKeysFromRecords(Collection<Record> clearableRecords) | 
| MapDataStore<Data,Object> | RecordStore. getMapDataStore() | 
| MapDataStore<Data,Object> | DefaultRecordStore. getMapDataStore() | 
| Set<Data> | RecordStore. keySet() | 
| Set<Data> | DefaultRecordStore. keySet() | 
| protected Map<Data,Object> | DefaultRecordStore. loadEntries(Set<Data> keys) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | RecordStore. canAcquireLock(Data key,
              String caller,
              long threadId) | 
| boolean | DefaultRecordStore. canAcquireLock(Data key,
              String caller,
              long threadId) | 
| boolean | RecordStore. containsKey(Data dataKey) | 
| boolean | DefaultRecordStore. containsKey(Data key) | 
| boolean | StorageImpl. containsKey(Data key) | 
| protected <E extends SampleableConcurrentHashMap.SamplingEntry> | StorageSCHM. createSamplingEntry(Data key,
                   R record) | 
| boolean | RecordStore. delete(Data dataKey) | 
| boolean | DefaultRecordStore. delete(Data key) | 
| Object | RecordStore. evict(Data key,
     boolean backup) | 
| Object | DefaultRecordStore. evict(Data key,
     boolean backup) | 
| void | RecordStore. evictEntries(Data excludedKey)Evicts entries from this record-store. | 
| boolean | RecordStore. extendLock(Data key,
          String caller,
          long threadId,
          long ttl) | 
| boolean | DefaultRecordStore. extendLock(Data key,
          String caller,
          long threadId,
          long ttl) | 
| boolean | RecordStore. forceUnlock(Data dataKey) | 
| boolean | DefaultRecordStore. forceUnlock(Data dataKey) | 
| R | StorageImpl. get(Data key) | 
| Object | RecordStore. get(Data dataKey,
   boolean backup)Gets record from  RecordStore. | 
| Object | DefaultRecordStore. get(Data key,
   boolean backup) | 
| R | StorageImpl. getIfSameKey(Data key) | 
| String | RecordStore. getLockOwnerInfo(Data key) | 
| String | DefaultRecordStore. getLockOwnerInfo(Data key) | 
| R | RecordStore. getRecord(Data key) | 
| Record | DefaultRecordStore. getRecord(Data key) | 
| R | RecordStore. getRecordOrNull(Data key)Returns live record or null if record is already expired. | 
| Record | DefaultRecordStore. getRecordOrNull(Data key) | 
| protected Record | DefaultRecordStore. getRecordOrNull(Data key,
               long now,
               boolean backup) | 
| protected boolean | DefaultRecordStore. isKeyAndValueLoadable(Data key,
                     Object value) | 
| boolean | RecordStore. isLocked(Data key) | 
| boolean | DefaultRecordStore. isLocked(Data dataKey) | 
| boolean | RecordStore. isTransactionallyLocked(Data key) | 
| boolean | DefaultRecordStore. isTransactionallyLocked(Data key) | 
| Record | RecordStore. loadRecordOrNull(Data key,
                boolean backup) | 
| Record | DefaultRecordStore. loadRecordOrNull(Data key,
                boolean backup) | 
| boolean | RecordStore. merge(Data dataKey,
     EntryView mergingEntryView,
     MapMergePolicy mergePolicy) | 
| boolean | DefaultRecordStore. merge(Data key,
     EntryView mergingEntry,
     MapMergePolicy mergePolicy) | 
| Object | RecordStore. put(Data dataKey,
   Object dataValue,
   long ttl) | 
| Object | DefaultRecordStore. put(Data key,
   Object value,
   long ttl) | 
| void | StorageImpl. put(Data key,
   R record) | 
| R | RecordStore. putBackup(Data key,
         Object value) | 
| Record | DefaultRecordStore. putBackup(Data key,
         Object value) | 
| R | RecordStore. putBackup(Data key,
         Object value,
         long ttl,
         boolean putTransient) | 
| Record | DefaultRecordStore. putBackup(Data key,
         Object value,
         long ttl,
         boolean putTransient) | 
| Object | RecordStore. putFromLoad(Data key,
           Object value)Puts key-value pair to map which is the result of a load from map store operation. | 
| Object | DefaultRecordStore. putFromLoad(Data key,
           Object value) | 
| Object | RecordStore. putFromLoad(Data key,
           Object value,
           long ttl)Puts key-value pair to map which is the result of a load from map store operation. | 
| Object | DefaultRecordStore. putFromLoad(Data key,
           Object value,
           long ttl) | 
| Object | RecordStore. putFromLoadBackup(Data key,
                 Object value)Puts key-value pair to map which is the result of a load from map store operation on backup. | 
| Object | DefaultRecordStore. putFromLoadBackup(Data key,
                 Object value) | 
| Object | RecordStore. putIfAbsent(Data dataKey,
           Object value,
           long ttl) | 
| Object | DefaultRecordStore. putIfAbsent(Data key,
           Object value,
           long ttl) | 
| protected Object | DefaultRecordStore. putInternal(Data key,
           Object value,
           long ttl,
           boolean loadFromStore) | 
| void | RecordStore. putRecord(Data key,
         R record)Puts a data key and a record value to record-store. | 
| void | DefaultRecordStore. putRecord(Data key,
         Record record) | 
| void | RecordStore. putTransient(Data dataKey,
            Object value,
            long ttl) | 
| void | DefaultRecordStore. putTransient(Data key,
            Object value,
            long ttl) | 
| Data | RecordStore. readBackupData(Data key)Called when  MapConfig.isReadBackupData()istruefromMapProxySupport.getInternal(com.hazelcast.nio.serialization.Data)Returns corresponding value for key asData. | 
| Data | DefaultRecordStore. readBackupData(Data key) | 
| Object | RecordStore. remove(Data dataKey) | 
| Object | DefaultRecordStore. remove(Data key) | 
| boolean | RecordStore. remove(Data dataKey,
      Object testValue) | 
| boolean | DefaultRecordStore. remove(Data key,
      Object testValue) | 
| void | RecordStore. removeBackup(Data dataKey)Similar to  RecordStore.remove(com.hazelcast.nio.serialization.Data)except removeBackup doesn't touch mapstore since it does not return previous value. | 
| void | DefaultRecordStore. removeBackup(Data key) | 
| protected Object | DefaultRecordStore. removeRecord(Data key,
            Record record,
            long now) | 
| Object | RecordStore. replace(Data dataKey,
       Object update) | 
| Object | DefaultRecordStore. replace(Data key,
       Object update) | 
| boolean | RecordStore. replace(Data dataKey,
       Object expect,
       Object update)Sets the value to the given updated value
 if  RecordFactory.isEquals(java.lang.Object, java.lang.Object)comparison
 of current value and expected value istrue. | 
| boolean | DefaultRecordStore. replace(Data key,
       Object expect,
       Object update) | 
| boolean | RecordStore. set(Data dataKey,
   Object value,
   long ttl)Returns  trueif key doesn't exist previously, otherwise returnsfalse. | 
| boolean | DefaultRecordStore. set(Data dataKey,
   Object value,
   long ttl) | 
| boolean | RecordStore. txnLock(Data key,
       String caller,
       long threadId,
       long referenceId,
       long ttl,
       boolean blockReads) | 
| boolean | DefaultRecordStore. txnLock(Data key,
       String caller,
       long threadId,
       long referenceId,
       long ttl,
       boolean blockReads) | 
| boolean | RecordStore. unlock(Data key,
      String caller,
      long threadId,
      long referenceId) | 
| boolean | DefaultRecordStore. unlock(Data key,
      String caller,
      long threadId,
      long referenceId) | 
| void | StorageImpl. updateRecordValue(Data key,
                 R record,
                 Object value) | 
| Modifier and Type | Method and Description | 
|---|---|
| MapEntries | RecordStore. getAll(Set<Data> keySet) | 
| MapEntries | DefaultRecordStore. getAll(Set<Data> keys) | 
| void | RecordStore. loadAllFromStore(List<Data> keys,
                boolean withUserSuppliedKeys)Loads all given keys from defined map store. | 
| void | DefaultRecordStore. loadAllFromStore(List<Data> keys,
                boolean withUserSuppliedKeys) | 
| protected Map<Data,Object> | DefaultRecordStore. loadEntries(Set<Data> keys) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Map<Data,VersionedValue> | TransactionalMapProxySupport. valueMap | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | TransactionalMapProxySupport. putIfAbsentInternal(Data key,
                   Data value) | 
| Data | TransactionalMapProxySupport. putInternal(Data key,
           Data value,
           long ttl,
           TimeUnit timeUnit) | 
| Data | TransactionalMapProxySupport. removeInternal(Data key) | 
| Data | TransactionalMapProxySupport. replaceInternal(Data key,
               Data value) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | TransactionalMapProxySupport. containsKeyInternal(Data key) | 
| Object | TransactionalMapProxySupport. getForUpdateInternal(Data key) | 
| Object | TransactionalMapProxySupport. getInternal(Data key) | 
| Data | TransactionalMapProxySupport. putIfAbsentInternal(Data key,
                   Data value) | 
| Data | TransactionalMapProxySupport. putInternal(Data key,
           Data value,
           long ttl,
           TimeUnit timeUnit) | 
| boolean | TransactionalMapProxySupport. removeIfSameInternal(Data key,
                    Object value) | 
| Data | TransactionalMapProxySupport. removeInternal(Data key) | 
| boolean | TransactionalMapProxySupport. replaceIfSameInternal(Data key,
                     Object oldValue,
                     Data newValue) | 
| Data | TransactionalMapProxySupport. replaceInternal(Data key,
               Data value) | 
| Constructor and Description | 
|---|
| MapTransactionLogRecord(String name,
                       Data key,
                       int partitionId,
                       Operation op,
                       long version,
                       String ownerUuid) | 
| TxnDeleteOperation(String name,
                  Data dataKey,
                  long version) | 
| TxnLockAndGetOperation(String name,
                      Data dataKey,
                      long timeout,
                      long ttl,
                      String ownerUuid,
                      boolean shouldLoad,
                      boolean blockReads) | 
| TxnPrepareBackupOperation(String name,
                         Data dataKey,
                         String lockOwner,
                         long lockThreadId) | 
| TxnPrepareOperation(int partitionId,
                   String name,
                   Data dataKey,
                   String ownerUuid) | 
| TxnRollbackBackupOperation(String name,
                          Data dataKey,
                          String lockOwner,
                          long lockThreadId) | 
| TxnRollbackOperation(int partitionId,
                    String name,
                    Data dataKey,
                    String ownerUuid) | 
| TxnSetOperation(String name,
               Data dataKey,
               Data value,
               long version) | 
| TxnSetOperation(String name,
               Data dataKey,
               Data value,
               long version,
               long ttl) | 
| TxnUnlockBackupOperation(String name,
                        Data dataKey,
                        String ownerUuid) | 
| TxnUnlockOperation(String name,
                  Data dataKey,
                  long version) | 
| VersionedValue(Data value,
              long version) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | MapReplicationRemove. getKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MapReplicationRemove. setKey(Data key) | 
| Constructor and Description | 
|---|
| MapReplicationRemove(String mapName,
                    Data key,
                    long removeTime) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | MultiMapEventFilter. getKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Data,Collection<MultiMapRecord>> | MultiMapContainer. copyCollections() | 
| Set<Data> | MultiMapContainer. keySet() | 
| protected Set<Data> | MultiMapProxySupport. keySetInternal() | 
| Set<Data> | MultiMapService. localKeySet(String name) | 
| protected Set<Data> | MultiMapProxySupport. localKeySetInternal() | 
| Modifier and Type | Method and Description | 
|---|---|
| String | MultiMapService. addListener(String name,
           EventListener listener,
           Data key,
           boolean includeValue,
           boolean local) | 
| boolean | MultiMapContainer. canAcquireLock(Data dataKey,
              String caller,
              long threadId) | 
| boolean | MultiMapContainer. containsEntry(boolean binary,
             Data key,
             Data value) | 
| protected boolean | MultiMapProxySupport. containsInternal(Data key,
                Data value) | 
| boolean | MultiMapContainer. containsKey(Data key) | 
| boolean | MultiMapContainer. containsValue(boolean binary,
             Data value) | 
| protected Integer | MultiMapProxySupport. countInternal(Data dataKey) | 
| void | MultiMapContainer. delete(Data dataKey) | 
| boolean | MultiMapContainer. extendLock(Data key,
          String caller,
          long threadId,
          long ttl) | 
| boolean | MultiMapContainer. forceUnlock(Data key) | 
| protected MultiMapResponse | MultiMapProxySupport. getAllInternal(Data dataKey) | 
| String | MultiMapContainer. getLockOwnerInfo(Data dataKey) | 
| boolean | MultiMapContainer. isLocked(Data dataKey) | 
| boolean | MultiMapContainer. isTransactionallyLocked(Data key) | 
| void | MultiMapEventsPublisher. publishEntryEvent(String multiMapName,
                 EntryEventType eventType,
                 Data key,
                 Object newValue,
                 Object oldValue) | 
| void | MultiMapService. publishEntryEvent(String multiMapName,
                 EntryEventType eventType,
                 Data key,
                 Object newValue,
                 Object oldValue) | 
| protected Boolean | MultiMapProxySupport. putInternal(Data dataKey,
           Data dataValue,
           int index) | 
| Collection<MultiMapRecord> | MultiMapContainer. remove(Data dataKey,
      boolean copyOf) | 
| protected MultiMapResponse | MultiMapProxySupport. removeInternal(Data dataKey) | 
| protected Boolean | MultiMapProxySupport. removeInternal(Data dataKey,
              Data dataValue) | 
| boolean | MultiMapContainer. txnLock(Data key,
       String caller,
       long threadId,
       long referenceId,
       long ttl,
       boolean blockReads) | 
| boolean | MultiMapContainer. unlock(Data key,
      String caller,
      long threadId,
      long referenceId) | 
| Constructor and Description | 
|---|
| MultiMapEventFilter(boolean includeValue,
                   Data key) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | MultiMapKeyBasedOperation. dataKey | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | MultiMapOperation. toData(Object obj) | 
| Modifier and Type | Method and Description | 
|---|---|
| Set<Map.Entry<Data,Data>> | EntrySetResponse. getDataEntrySet() | 
| Set<Map.Entry<Data,Data>> | EntrySetResponse. getDataEntrySet() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | MultiMapOperation. publishEvent(EntryEventType eventType,
            Data key,
            Object newValue,
            Object oldValue) | 
| Constructor and Description | 
|---|
| EntrySetResponse(Map<Data,Collection<MultiMapRecord>> map,
                NodeEngine nodeEngine) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Collection<MultiMapRecord> | TransactionalMultiMapProxySupport. getInternal(Data key) | 
| protected boolean | TransactionalMultiMapProxySupport. putInternal(Data key,
           Data value) | 
| protected Collection<MultiMapRecord> | TransactionalMultiMapProxySupport. removeAllInternal(Data key) | 
| protected boolean | TransactionalMultiMapProxySupport. removeInternal(Data key,
              Data value) | 
| protected int | TransactionalMultiMapProxySupport. valueCountInternal(Data key) | 
| Constructor and Description | 
|---|
| MultiMapTransactionLogRecord(int partitionId,
                            Data key,
                            String name,
                            long ttl,
                            long threadId) | 
| TxnCommitBackupOperation(String name,
                        Data dataKey,
                        List<Operation> opList,
                        String caller,
                        long threadId) | 
| TxnCommitOperation(int partitionId,
                  String name,
                  Data dataKey,
                  long threadId,
                  List<Operation> opList) | 
| TxnGenerateRecordIdOperation(String name,
                            Data dataKey) | 
| TxnLockAndGetOperation(String name,
                      Data dataKey,
                      long timeout,
                      long ttl,
                      long threadId,
                      boolean blockReads) | 
| TxnPrepareBackupOperation(String name,
                         Data dataKey,
                         String caller,
                         long threadId) | 
| TxnPrepareOperation(int partitionId,
                   String name,
                   Data dataKey,
                   long ttl,
                   long threadId) | 
| TxnPutBackupOperation(String name,
                     Data dataKey,
                     long recordId,
                     Data value) | 
| TxnPutOperation(String name,
               Data dataKey,
               Data value,
               long recordId) | 
| TxnRemoveAllBackupOperation(String name,
                           Data dataKey,
                           Collection<Long> recordIds) | 
| TxnRemoveAllOperation(String name,
                     Data dataKey,
                     Collection<MultiMapRecord> records) | 
| TxnRemoveBackupOperation(String name,
                        Data dataKey,
                        long recordId,
                        Data value) | 
| TxnRemoveOperation(String name,
                  Data dataKey,
                  long recordId,
                  Data value) | 
| TxnRollbackBackupOperation(String name,
                          Data dataKey,
                          String caller,
                          long threadId) | 
| TxnRollbackOperation(int partitionId,
                    String name,
                    Data dataKey,
                    long threadId) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | PacketA Packet is a piece of data send over the line. | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | ObjectDataInput. readData() | 
| Data | NodeIOService. toData(Object obj) | 
| Data | IOService. toData(Object obj) | 
| Modifier and Type | Method and Description | 
|---|---|
| static long | IOUtil. extractOperationCallId(Data data,
                      InternalSerializationService serializationService)This method has a direct dependency on how objects are serialized in
  DataSerializableSerializer. | 
| Object | NodeIOService. toObject(Data data) | 
| Object | IOService. toObject(Data data) | 
| void | ObjectDataOutput. writeData(Data data) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | CachedQueryEntry. keyData | 
| protected Data | CachedQueryEntry. valueData | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | QueryEntry. getKeyData() | 
| abstract Data | QueryableEntry. getKeyData() | 
| Data | CachedQueryEntry. getKeyData() | 
| Data | QueryEntry. getValueData() | 
| abstract Data | QueryableEntry. getValueData() | 
| Data | CachedQueryEntry. getValueData() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | QueryEntry. init(InternalSerializationService serializationService,
    Data key,
    Object value,
    Extractors extractors)It may be useful to use this  initmethod in some cases that same instance of this class can be used
 instead of creating a new one for every iteration when scanning large data sets, for example: | 
| void | CachedQueryEntry. init(InternalSerializationService serializationService,
    Data key,
    Object value,
    Extractors extractors) | 
| void | Index. removeEntryIndex(Data key,
                Object value) | 
| void | IndexImpl. removeEntryIndex(Data key,
                Object value) | 
| void | Indexes. removeEntryIndex(Data key,
                Object value) | 
| void | IndexStore. removeIndex(Object oldValue,
           Data indexKey) | 
| void | BaseIndexStore. removeIndex(Object oldValue,
           Data indexKey) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | FastMultiResultSet. addResultSet(Map<Data,QueryableEntry> resultSet) | 
| void | MultiResultSet. addResultSet(Map<Data,QueryableEntry> resultSet)TODO | 
| void | DuplicateDetectingMultiResult. addResultSet(Map<Data,QueryableEntry> resultSet) | 
| Constructor and Description | 
|---|
| CachedQueryEntry(InternalSerializationService serializationService,
                Data key,
                Object value,
                Extractors extractors) | 
| QueryEntry(InternalSerializationService serializationService,
          Data key,
          Object value,
          Extractors extractors) | 
| Constructor and Description | 
|---|
| SingleResultSet(Map<Data,QueryableEntry> records) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicatedMapEventPublishingService. fireEntryListenerEvent(Data key,
                      Data oldValue,
                      Data value,
                      EntryEventType eventType,
                      String name,
                      Address caller) | 
| void | ReplicatedMapEventPublishingService. fireEntryListenerEvent(Data key,
                      Data oldValue,
                      Data value,
                      String name,
                      Address caller) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | ReplicatedMapPortableEntryEvent. getKey() | 
| Data | ReplicatedMapEntries. getKey(int index) | 
| Data | ReplicatedMapPortableEntryEvent. getOldValue() | 
| Data | ReplicatedMapPortableEntryEvent. getValue() | 
| Data | ReplicatedMapEntries. getValue(int index) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Map.Entry<Data,Data>> | ReplicatedMapEntries. entries() | 
| List<Map.Entry<Data,Data>> | ReplicatedMapEntries. entries() | 
| List<Data> | ReplicatedMapKeys. getKeys() | 
| Collection<Data> | ReplicatedMapValueCollection. getValues() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ReplicatedMapEntries. add(Data key,
   Data value) | 
| Constructor and Description | 
|---|
| ReplicatedMapEntries(List<Map.Entry<Data,Data>> entries) | 
| ReplicatedMapEntries(List<Map.Entry<Data,Data>> entries) | 
| ReplicatedMapKeys(List<Data> keys) | 
| ReplicatedMapValueCollection(Collection<Data> values) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | AbstractReplicatedMapOperation. key | 
| protected Data | AbstractReplicatedMapOperation. value | 
| Constructor and Description | 
|---|
| ContainsKeyOperation(String name,
                    Data key) | 
| ContainsValueOperation(String name,
                      Data value) | 
| GetOperation(String name,
            Data key) | 
| PutOperation(String name,
            Data key,
            Data value) | 
| PutOperation(String name,
            Data key,
            Data value,
            long ttl) | 
| RemoveOperation(String name,
               Data key) | 
| ReplicateUpdateOperation(String name,
                        Data dataKey,
                        Data dataValue,
                        long ttl,
                        VersionResponsePair response,
                        boolean isRemove,
                        Address origin) | 
| ReplicateUpdateToCallerOperation(String name,
                                long callId,
                                Data dataKey,
                                Data dataValue,
                                VersionResponsePair response,
                                long ttl,
                                boolean isRemove) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Data | ReplicatedEntryEventFilter. key | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | RecordMigrationInfo. getKey() | 
| Data | RecordMigrationInfo. getValue() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | AbstractReplicatedRecordStore. sendReplicationOperation(boolean isRemove,
                        String name,
                        Data key,
                        Data value,
                        long ttl,
                        VersionResponsePair response) | 
| void | RecordMigrationInfo. setKey(Data key) | 
| void | RecordMigrationInfo. setValue(Data value) | 
| Constructor and Description | 
|---|
| RecordMigrationInfo(Data key,
                   Data value,
                   long ttl) | 
| ReplicatedEntryEventFilter(Data key) | 
| ReplicatedQueryEventFilter(Data key,
                          Predicate predicate) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data[] | ReadResultSetImpl. getDataItems() | 
| Data | RingbufferContainer. read(long sequence) | 
| Modifier and Type | Method and Description | 
|---|---|
| long | RingbufferContainer. add(Data item) | 
| long | RingbufferContainer. addAll(Data[] items) | 
| Modifier and Type | Method and Description | 
|---|---|
| List<Data> | PortableReadResultSet. getDataItems() | 
| Constructor and Description | 
|---|
| PortableReadResultSet(int readCount,
                     List<Data> items) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | ReadOneOperation. getResponse() | 
| Constructor and Description | 
|---|
| AddAllBackupOperation(String name,
                     Data[] items) | 
| AddAllOperation(String name,
               Data[] items,
               OverflowPolicy overflowPolicy) | 
| AddBackupOperation(String name,
                  Data item) | 
| AddOperation(String name,
            Data item,
            OverflowPolicy overflowPolicy) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Data | AbstractDistributedObject. getNameAsPartitionAwareData() | 
| Data | NodeEngine. toData(Object object)Serializes an object to a  Data. | 
| protected Data | AbstractDistributedObject. toData(Object object) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected int | AbstractDistributedObject. getPartitionId(Data key) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | PortableItemEvent. getItem() | 
| Data | PortableEntryEvent. getKey() | 
| Data | PortableEntryEvent. getMergingValue() | 
| Data | PortableEntryEvent. getOldValue() | 
| Data | PortableEntryEvent. getValue() | 
| Data | NodeEngineImpl. toData(Object object) | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<Data> | PortableCollection. getCollection() | 
| List<Data> | SerializableList. getCollection() | 
| Iterator<Data> | SerializableList. iterator() | 
| Constructor and Description | 
|---|
| BinaryOperationFactory(Data operationData) | 
| PortableEntryEvent(Data key,
                  Data value,
                  Data oldValue,
                  Data mergingValue,
                  EntryEventType eventType,
                  String uuid) | 
| PortableItemEvent(Data item,
                 ItemEventType eventType,
                 String uuid) | 
| Constructor and Description | 
|---|
| PortableCollection(Collection<Data> collection) | 
| SerializableList(List<Data> collection) | 
| Constructor and Description | 
|---|
| Backup(Data backupOpData,
      Address originalCaller,
      long[] replicaVersions,
      boolean sync) | 
| Modifier and Type | Method and Description | 
|---|---|
| int | IPartitionService. getPartitionId(Data key)Returns the partition id for a Data key. | 
| Modifier and Type | Method and Description | 
|---|---|
| <B extends Data> | SerializationService. toData(Object obj)Serializes an object to a  Data. | 
| <B extends Data> | SerializationService. toData(Object obj,
      PartitioningStrategy strategy)Serializes an object to a  Data. | 
| Modifier and Type | Field and Description | 
|---|---|
| Data | TopicEvent. data | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | DataAwareMessage. getMessageData() | 
| Modifier and Type | Method and Description | 
|---|---|
| void | TopicProxySupport. publishInternal(Data message) | 
| Constructor and Description | 
|---|
| DataAwareMessage(String topicName,
                Data messageData,
                long publishTime,
                Member publishingMember,
                SerializationService serializationService) | 
| PublishOperation(String name,
                Data message) | 
| TopicEvent(String name,
          Data data,
          Address publisherAddress) | 
| Modifier and Type | Method and Description | 
|---|---|
| Data | ReliableTopicMessage. getPayload() | 
| Constructor and Description | 
|---|
| ReliableTopicMessage(Data payload,
                    Address publisherAddress) | 
| Constructor and Description | 
|---|
| ClearRemoteTransactionBackupOperation(Data xidData) | 
| ClearRemoteTransactionOperation(Data xidData) | 
| FinalizeRemoteTransactionBackupOperation(Data xidData) | 
| FinalizeRemoteTransactionOperation(Data xidData,
                                  boolean isCommit) | 
| Modifier and Type | Method and Description | 
|---|---|
| static <C> Collection<Data> | CollectionUtil. objectToDataCollection(Collection<C> collection,
                      SerializationService serializationService)Converts a collection of any type to a collection of  Data. | 
Copyright © 2017 Hazelcast, Inc.. All Rights Reserved.