A B C D E F G H I J K L M N O P Q R S T U V W X

A

AbstractAccessDelegate<T extends HazelcastRegion> - Class in com.hazelcast.hibernate.access
Base implementation for consistency guarantees
AbstractAccessDelegate(T, Properties) - Constructor for class com.hazelcast.hibernate.access.AbstractAccessDelegate
 
AbstractAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
AbstractAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
AbstractAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
AbstractAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
AbstractAlterRequest - Class in com.hazelcast.concurrent.atomiclong.client
 
AbstractAlterRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
 
AbstractAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
 
AbstractAlterRequest - Class in com.hazelcast.concurrent.atomicreference.client
 
AbstractAlterRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
 
AbstractAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
 
AbstractCacheRecord<V> - Class in com.hazelcast.cache.impl.record
Abstract implementation of CacheRecord with key, value and expiration time as internal state.
AbstractCacheRecord() - Constructor for class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
AbstractCacheRecord(long, long) - Constructor for class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
AbstractCacheRecordStore<R extends CacheRecord,CRM extends SampleableCacheRecordMap<Data,R>> - Class in com.hazelcast.cache.impl
 
AbstractCacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
AbstractCacheRecordStore.MaxSizeEvictionChecker - Class in com.hazelcast.cache.impl
 
AbstractCacheRecordStore.MaxSizeEvictionChecker() - Constructor for class com.hazelcast.cache.impl.AbstractCacheRecordStore.MaxSizeEvictionChecker
 
AbstractCacheRequest - Class in com.hazelcast.cache.impl.client
Abstract cache request to handle a completion id registration.
AbstractCacheRequest() - Constructor for class com.hazelcast.cache.impl.client.AbstractCacheRequest
 
AbstractCacheRequest(String, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.AbstractCacheRequest
 
AbstractCacheService - Class in com.hazelcast.cache.impl
 
AbstractCacheService() - Constructor for class com.hazelcast.cache.impl.AbstractCacheService
 
AbstractClientCollectionProxy<E> - Class in com.hazelcast.client.proxy
 
AbstractClientCollectionProxy(String, String) - Constructor for class com.hazelcast.client.proxy.AbstractClientCollectionProxy
 
AbstractClientSelectionHandler - Class in com.hazelcast.client.connection.nio
 
AbstractClientSelectionHandler(ClientConnection, IOSelector) - Constructor for class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
 
AbstractClientTxnCollectionProxy<E> - Class in com.hazelcast.client.txn.proxy
 
AbstractClientTxnCollectionProxy(String, TransactionContextProxy) - Constructor for class com.hazelcast.client.txn.proxy.AbstractClientTxnCollectionProxy
 
AbstractClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
AbstractClusterWideIterator provides the core iterator functionality shared by its descendants.
AbstractClusterWideIterator(ICache<K, V>, int) - Constructor for class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
AbstractCollectionProxyImpl<S extends RemoteService,E> - Class in com.hazelcast.collection
 
AbstractCollectionProxyImpl(String, NodeEngine, S) - Constructor for class com.hazelcast.collection.AbstractCollectionProxyImpl
 
AbstractCompletableFuture<V> - Class in com.hazelcast.spi.impl
 
AbstractCompletableFuture(NodeEngine, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractCompletableFuture
 
AbstractCredentials - Class in com.hazelcast.security
Abstract implementation of Credentials
AbstractCredentials() - Constructor for class com.hazelcast.security.AbstractCredentials
 
AbstractCredentials(String) - Constructor for class com.hazelcast.security.AbstractCredentials
 
AbstractDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi
Abstract DistributedObject implementation.
AbstractDistributedObject(NodeEngine, S) - Constructor for class com.hazelcast.spi.AbstractDistributedObject
 
AbstractEntryProcessor<K,V> - Class in com.hazelcast.map
An abstract EntryProcessor that already has implemented the AbstractEntryProcessor.getBackupProcessor().
AbstractEntryProcessor() - Constructor for class com.hazelcast.map.AbstractEntryProcessor
Creates an AbstractEntryProcessor that applies the EntryProcessor.process(java.util.Map.Entry) to primary and backups.
AbstractEntryProcessor(boolean) - Constructor for class com.hazelcast.map.AbstractEntryProcessor
Creates an AbstractEntryProcessor.
AbstractEvictionPolicyEvaluator<A,E extends Evictable> - Class in com.hazelcast.cache.impl.eviction.impl.evaluator
Base class for evaluation implementations of EvictionPolicy.
AbstractEvictionPolicyEvaluator() - Constructor for class com.hazelcast.cache.impl.eviction.impl.evaluator.AbstractEvictionPolicyEvaluator
 
AbstractEvictionStrategy<A,E extends Evictable,S extends EvictableStore<A,E>> - Class in com.hazelcast.cache.impl.eviction.impl.strategy
Base class for eviction implementations to evict EvictableStore implementations as specified EvictionPolicyEvaluator.
AbstractEvictionStrategy() - Constructor for class com.hazelcast.cache.impl.eviction.impl.strategy.AbstractEvictionStrategy
 
AbstractExecutorThreadFactory - Class in com.hazelcast.util.executor
 
AbstractExecutorThreadFactory(ThreadGroup, ClassLoader) - Constructor for class com.hazelcast.util.executor.AbstractExecutorThreadFactory
 
AbstractHazelcastBeanDefinitionParser - Class in com.hazelcast.spring
Base class of all Hazelcast BeanDefinitionParser implementations.
AbstractHazelcastBeanDefinitionParser() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser
 
AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper - Class in com.hazelcast.spring
Base Helper class for Spring Xml Builder
AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper() - Constructor for class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
AbstractHazelcastCacheManager - Class in com.hazelcast.cache.impl
Abstract HazelcastCacheManager (also CacheManager as indirect) implementation provides shared functionality to server and client cache managers.
AbstractHazelcastCacheManager(CachingProvider, HazelcastInstance, URI, ClassLoader, Properties) - Constructor for class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
AbstractHazelcastCacheRegionFactory - Class in com.hazelcast.hibernate
Abstract superclass of Hazelcast based RegionFactory implementations
AbstractHazelcastCacheRegionFactory() - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
AbstractHazelcastCacheRegionFactory(Properties) - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
AbstractHazelcastCacheRegionFactory(HazelcastInstance) - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
AbstractHazelcastCachingProvider - Class in com.hazelcast.cache.impl
Abstract CachingProvider implementation providing shared functionality to server and client caching providers.
AbstractHazelcastCachingProvider() - Constructor for class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
AbstractIMapEvent - Class in com.hazelcast.core
The abstract class for a map event IMapEvent.
AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.core.AbstractIMapEvent
Constructs a prototypical map Event.
AbstractIOSelector - Class in com.hazelcast.nio.tcp
 
AbstractIOSelector(ThreadGroup, String, ILogger, IOSelectorOutOfMemoryHandler) - Constructor for class com.hazelcast.nio.tcp.AbstractIOSelector
 
AbstractIsLockedRequest - Class in com.hazelcast.concurrent.lock.client
 
AbstractIsLockedRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
 
AbstractIsLockedRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
 
AbstractIsLockedRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
 
AbstractJob<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl
Base class for all map reduce job implementations
AbstractJob(String, JobTracker, KeyValueSource<KeyIn, ValueIn>) - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob
 
AbstractJob.MappingJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
This class is just used to comply to the public DSL style API
AbstractJob.MappingJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
 
AbstractJob.ReducingJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
This class is just used to comply to the public DSL style API
AbstractJob.ReducingJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
 
AbstractJob.ReducingSubmittableJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
This class is just used to comply to the public DSL style API
AbstractJob.ReducingSubmittableJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
 
AbstractJobTracker - Class in com.hazelcast.mapreduce.impl
This is the base class for all JobTracker implementations on node and client side.
It combines a lot of the base functionality to handle remote operations.
AbstractJoiner - Class in com.hazelcast.cluster.impl
 
AbstractJoiner(Node) - Constructor for class com.hazelcast.cluster.impl.AbstractJoiner
 
AbstractLoadBalancer - Class in com.hazelcast.client.util
An abstract LoadBalancer implementation.
AbstractLoadBalancer() - Constructor for class com.hazelcast.client.util.AbstractLoadBalancer
 
AbstractLockRequest - Class in com.hazelcast.concurrent.lock.client
 
AbstractLockRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
 
AbstractLockRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
 
AbstractLockRequest(Data, long, long, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
 
AbstractLogger - Class in com.hazelcast.logging
Abstract ILogger implementation that provides implementations for the convenience methods like finest,info,warning and severe.
AbstractLogger() - Constructor for class com.hazelcast.logging.AbstractLogger
 
AbstractMapAddEntryListenerRequest - Class in com.hazelcast.map.impl.client
Base class for adding entry listener to map
AbstractMapAddEntryListenerRequest() - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
 
AbstractMapAddEntryListenerRequest(String, boolean) - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
 
AbstractMapAddEntryListenerRequest(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
 
AbstractMapDataStore<K,V> - Class in com.hazelcast.map.impl.mapstore
Abstract map data store contains common functionality of map data stores.
AbstractMapDataStore(MapStoreWrapper, SerializationService) - Constructor for class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
 
AbstractMapOperation - Class in com.hazelcast.map.impl.operation
 
AbstractMapOperation() - Constructor for class com.hazelcast.map.impl.operation.AbstractMapOperation
 
AbstractMapOperation(String) - Constructor for class com.hazelcast.map.impl.operation.AbstractMapOperation
 
AbstractMutatingCacheOperation - Class in com.hazelcast.cache.impl.operation
Base class for all mutable cache operations.
AbstractMutatingCacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
 
AbstractMutatingCacheOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
 
AbstractNamedOperation - Class in com.hazelcast.spi.impl
 
AbstractNamedOperation(String) - Constructor for class com.hazelcast.spi.impl.AbstractNamedOperation
 
AbstractNamedOperation() - Constructor for class com.hazelcast.spi.impl.AbstractNamedOperation
 
AbstractOperation - Class in com.hazelcast.spi
Abstract Operation implementation with some basic methods implemented.
AbstractOperation() - Constructor for class com.hazelcast.spi.AbstractOperation
 
AbstractReplicatedMapClientRequest - Class in com.hazelcast.replicatedmap.impl.client
Base class for all ReplicatedMap client request.
AbstractReplicatedMapClientRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
 
AbstractReplicatedMapClientRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
 
AbstractReplicatedMapOperation - Class in com.hazelcast.replicatedmap.impl.operation
Base class for replicated map remote operations
AbstractReplicatedMapOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
AbstractReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
This is the base class for all ReplicatedRecordStore implementations
AbstractReplicatedRecordStore(String, NodeEngine, ReplicatedMapService) - Constructor for class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
AbstractTextCommand - Class in com.hazelcast.ascii
 
AbstractTextCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.AbstractTextCommand
 
AbstractTextCommandProcessor<T> - Class in com.hazelcast.ascii
 
AbstractTextCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.ascii.AbstractTextCommandProcessor
 
AbstractTransactionalCollectionProxy<S extends RemoteService,E> - Class in com.hazelcast.collection.txn
 
AbstractTransactionalCollectionProxy(String, TransactionSupport, NodeEngine, S) - Constructor for class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
 
AbstractTransactionalDataRegion<Cache extends RegionCache> - Class in com.hazelcast.hibernate.region
Abstract base class of all regions
AbstractTransactionalDataRegion(HazelcastInstance, String, Properties, CacheDataDescription, Cache) - Constructor for class com.hazelcast.hibernate.region.AbstractTransactionalDataRegion
 
AbstractTxnMapRequest - Class in com.hazelcast.map.impl.client
 
AbstractTxnMapRequest() - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
 
AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
 
AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
 
AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
 
AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
 
AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data, long, TimeUnit) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
 
AbstractTxnMapRequest.TxnMapRequestType - Enum in com.hazelcast.map.impl.client
 
AbstractUnlockRequest - Class in com.hazelcast.concurrent.lock.client
 
AbstractUnlockRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
 
AbstractUnlockRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
 
AbstractUnlockRequest(Data, long, boolean) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
 
AbstractWaitNotifyKey - Class in com.hazelcast.spi
Abstract implementation of the WaitNotifyKey.
AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.AbstractWaitNotifyKey
 
AbstractWebDataEntryProcessor<T> - Class in com.hazelcast.web
A base class for EntryProcessors which will use the web data serializer.
AbstractWebDataEntryProcessor() - Constructor for class com.hazelcast.web.AbstractWebDataEntryProcessor
 
AbstractXmlConfigHelper - Class in com.hazelcast.config
Contains Hazelcast Xml Configuration helper methods and variables.
AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
 
AbstractXmlConfigHelper.IterableNodeList - Class in com.hazelcast.config
Iterator for NodeList
AbstractXmlConfigHelper.IterableNodeList(Node) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
 
AbstractXmlConfigHelper.IterableNodeList(NodeList) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
 
AbstractXmlConfigHelper.IterableNodeList(Node, short) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
 
AbstractXmlConfigHelper.IterableNodeList(NodeList, short) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
 
ACCEPT_ALL_SUPPLIER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
AcceptAllSupplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation.impl
A standard implementation of the Supplier interface which accepts all input values and may apply a given PropertyExtractor on those.
AcceptAllSupplier(PropertyExtractor<ValueIn, ValueOut>) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
 
acceptMasterConfirmation(MemberImpl) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
 
access() - Method in class com.hazelcast.map.impl.record.RecordStatistics
 
access() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
AccessDelegate<T extends HazelcastRegion> - Interface in com.hazelcast.hibernate.access
This interface is used to implement basic transactional guarantees
accessHit - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
accessRecord(R, ExpiryPolicy, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
accessTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
 
accumulate(CacheStatisticsImpl) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Simple CacheStatistics adder.
acquire() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
 
acquire(int, String) - Method in class com.hazelcast.concurrent.semaphore.Permit
 
acquire() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
acquire(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
acquire() - Method in interface com.hazelcast.core.ISemaphore
Acquires a permit if one is available, and returns immediately, reducing the number of available permits by one.
acquire(int) - Method in interface com.hazelcast.core.ISemaphore
Acquires the given number of permits if they are available, and returns immediately, reducing the number of available permits by the given amount.
ACQUIRE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
ACQUIRE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
AcquireBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AcquireBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
 
AcquireBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
 
AcquireOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AcquireOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
AcquireOperation(String, int, long) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
 
AcquireRequest - Class in com.hazelcast.concurrent.semaphore.client
 
AcquireRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
 
AcquireRequest(String, int, long) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
 
AcquireRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
 
AcquireRequest(String) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
 
ACTION_ACQUIRE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_ADD - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_ALL - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_CREATE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_DESTROY - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_INDEX - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_INTERCEPT - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_LISTEN - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_LOCK - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_MODIFY - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_PUBLISH - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_PUT - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_READ - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_RELEASE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ACTION_REMOVE - Static variable in class com.hazelcast.security.permission.ActionConstants
 
ActionConstants - Class in com.hazelcast.security.permission
 
actions - Variable in class com.hazelcast.security.permission.InstancePermission
 
Activator - Class in com.hazelcast.osgi
Hazelcast OSGi bundle activator

initializes script Engines

Activator() - Constructor for class com.hazelcast.osgi.Activator
 
add(E) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
 
add(int, E) - Method in class com.hazelcast.client.proxy.ClientListProxy
 
add(E) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
add(E) - Method in class com.hazelcast.client.txn.proxy.ClientTxnListProxy
 
add(E) - Method in class com.hazelcast.client.txn.proxy.ClientTxnSetProxy
 
add(E) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
 
add(Data) - Method in class com.hazelcast.collection.CollectionContainer
 
add(int, Data) - Method in class com.hazelcast.collection.list.ListContainer
 
add(int, E) - Method in class com.hazelcast.collection.list.ListProxyImpl
 
add(E) - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
 
add(E) - Method in class com.hazelcast.collection.txn.TransactionalSetProxy
 
add(CountDownLatchInfo) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
add(E) - Method in interface com.hazelcast.core.TransactionalList
Adds a new item to the transactional list.
add(E) - Method in interface com.hazelcast.core.TransactionalSet
Add new item to transactional set.
add(Map.Entry<Data, Data>) - Method in class com.hazelcast.map.impl.MapEntrySet
 
add(Data, Data) - Method in class com.hazelcast.map.impl.MapEntrySet
 
add(K, V, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
add(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
add(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
add(QueryResultEntry) - Method in class com.hazelcast.map.impl.QueryResult
 
add(long) - Method in interface com.hazelcast.map.impl.SizeEstimator
 
add(QueryableEntry) - Method in class com.hazelcast.query.impl.MultiResultSet
 
add(E) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
 
add(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
add(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
add(PermissionCollection) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
add(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
 
add(QueryResultEntry) - Method in class com.hazelcast.util.QueryResultSet
 
add(Object) - Method in class com.hazelcast.util.QueryResultSet
 
add(Map.Entry) - Method in class com.hazelcast.util.SortedQueryResultSet
 
ADD_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
ADD_ALL - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
 
ADD_ALL - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
 
ADD_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
ADD_ALL_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
 
ADD_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ADD_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
 
ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
 
ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
 
ADD_ENTRY_LISTENER_SQL - Static variable in class com.hazelcast.map.impl.MapPortableHook
 
ADD_INDEX - Static variable in class com.hazelcast.map.impl.MapPortableHook
 
ADD_INTERCEPTOR - Static variable in class com.hazelcast.map.impl.MapPortableHook
 
ADD_INVALIDATION_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
 
ADD_LISTENER - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
 
ADD_LISTENER - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
ADD_LISTENER - Static variable in class com.hazelcast.topic.impl.TopicPortableHook
 
ADD_NEAR_CACHE_ENTRY_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
 
ADD_SESSION_ID - Static variable in class com.hazelcast.web.WebDataSerializerHook
 
addAction(String) - Method in class com.hazelcast.config.PermissionConfig
 
addAddress(String...) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
addAddress(String...) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Adds given addresses to candidate address list that client will use to establish initial connection
addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
 
addAll(int, Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientListProxy
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
 
addAll(List<Data>) - Method in class com.hazelcast.collection.CollectionContainer
 
addAll(int, List<Data>) - Method in class com.hazelcast.collection.list.ListContainer
 
addAll(int, Collection<? extends E>) - Method in class com.hazelcast.collection.list.ListProxyImpl
 
addAll(List<Data>) - Method in class com.hazelcast.collection.set.SetContainer
 
addAll(Collection<? extends E>) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
 
addAll(Collection<Data>) - Method in class com.hazelcast.queue.impl.QueueContainer
 
addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.CollectionContainer
 
addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.queue.impl.QueueContainer
 
AddAllBackupOperation - Class in com.hazelcast.queue.impl.operations
Provides backup functionality for AddAllOperation
AddAllBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.AddAllBackupOperation
 
AddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.queue.impl.operations.AddAllBackupOperation
 
AddAllOperation - Class in com.hazelcast.queue.impl.operations
Add collection items to the Queue.
AddAllOperation() - Constructor for class com.hazelcast.queue.impl.operations.AddAllOperation
 
AddAllOperation(String, Collection<Data>) - Constructor for class com.hazelcast.queue.impl.operations.AddAllOperation
 
AddAllRequest - Class in com.hazelcast.queue.impl.client
Provides the request service for AddAllOperation
AddAllRequest() - Constructor for class com.hazelcast.queue.impl.client.AddAllRequest
 
AddAllRequest(String, Collection<Data>) - Constructor for class com.hazelcast.queue.impl.client.AddAllRequest
 
addAndGet(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.LongWrapper
 
addAndGet(long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically adds the given value to the current value.
addAndGet(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
 
AddAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AddAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
AddAndGetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
 
AddAndGetRequest - Class in com.hazelcast.concurrent.atomiclong.client
 
AddAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
 
AddAndGetRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
 
addAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
addBackup(long, Data) - Method in class com.hazelcast.collection.CollectionContainer
 
addBackup(K, V, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
addBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
addBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
AddBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AddBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
AddBackupOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
 
addBooleanField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addByteArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addByteField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addCacheConfig(CacheSimpleConfig) - Method in class com.hazelcast.config.Config
 
addCacheConfigIfAbsent(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
addCacheConfigIfAbsent(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
 
addCacheConfigIfAbsent(CacheConfig<K, V>) - Method in class com.hazelcast.client.cache.impl.HazelcastClientCacheManager
 
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
 
addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
Add a configuration for a CacheEntryListener.
addCharArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addCharField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addClassDefinition(ClassDefinition) - Method in class com.hazelcast.config.SerializationConfig
 
addClassDefinition(ClassDefinition) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
addClassDefinition(ClassDefinition) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
 
addClientListener(ClientListener) - Method in class com.hazelcast.client.impl.ClientServiceProxy
 
addClientListener(ClientListener) - Method in interface com.hazelcast.core.ClientService
Adds a ClientListener.
addClientLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addClientRecoveredTransaction(RecoveredTransaction) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
addConnectionEventListener(ConnectionEventListener) - Method in class com.hazelcast.jca.ManagedConnectionImpl
 
addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.nio.ConnectionManager
 
addConnectionListener(ConnectionListener) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
 
addContainer(String, CollectionContainer) - Method in class com.hazelcast.collection.CollectionService
 
addContainer(String, QueueContainer) - Method in class com.hazelcast.queue.impl.QueueService
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
 
addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.HazelcastClientInstanceImpl
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.impl.HazelcastClientProxy
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.spi.ProxyManager
 
addDistributedObjectListener(DistributedObjectListener) - Method in interface com.hazelcast.core.HazelcastInstance
Adds a Distributed Object listener which will be notified when a new DistributedObject will be created or destroyed.
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.jca.HazelcastConnectionImpl
 
addDoubleArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addEnd(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Add this collection to the end of the queue.
addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
 
addEndpoint(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
 
addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
addEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, K) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds an entry listener for this map.
addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.MultiMap
Adds an entry listener for this multimap.
addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.MultiMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an entry listener for this map.
addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
Adds the specified entry listener for the specified key.
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
Adds an continuous entry listener for this map.
addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
addEntryListener(EntryListener, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
addEntryListener(EntryListener, Predicate, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
addEntryListener(EntryListener, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
addEntryListener(EntryListener, Predicate, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
addEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, K) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
 
addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfig
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
 
addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
 
AddEntryListenerRequest - Class in com.hazelcast.multimap.impl.client
 
AddEntryListenerRequest() - Constructor for class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
 
AddEntryListenerRequest(String, Data, boolean) - Constructor for class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
 
addEventData(CacheEventData) - Method in class com.hazelcast.cache.impl.CacheEventSet
Helper method for adding multiple CacheEventData into this Set
addEventListener(EntryListener, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
addEventListener(EventListener, EventFilter, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
 
addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
Adds a new ExecutorConfig by name
addFloatArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addFront(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Add this collection to the front of the queue.
addGetTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increments the getCache time accumulator.
addIndex(String, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addIndex(String, boolean) - Method in interface com.hazelcast.core.IMap
Adds an index to this map for the specified entries so that queries can run faster.
AddIndexOperation - Class in com.hazelcast.map.impl.operation
 
AddIndexOperation(String, String, boolean) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
 
AddIndexOperation() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
 
AddIndexOperationFactory - Class in com.hazelcast.map.impl.operation
 
AddIndexOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
AddIndexOperationFactory(String, String, boolean) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
 
addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addInterceptor(MapInterceptor) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addInterceptor(MapInterceptor) - Method in interface com.hazelcast.core.IMap
Adds an interceptor for this map.
addInterceptor(MapInterceptor) - Method in class com.hazelcast.map.impl.MapContainer
 
addInterceptor(String, MapInterceptor) - Method in class com.hazelcast.map.impl.MapContainer
 
addInterceptor(String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
 
addInterceptor(MapInterceptor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
AddInterceptorOperation - Class in com.hazelcast.map.impl.operation
 
AddInterceptorOperation(String, MapInterceptor, String) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
AddInterceptorOperation() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
 
AddInterceptorOperationFactory - Class in com.hazelcast.map.impl.operation
 
AddInterceptorOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
 
AddInterceptorOperationFactory(String, String, MapInterceptor) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
 
addInterface(String) - Method in class com.hazelcast.config.InterfacesConfig
Adds a new interface
addInterface(String) - Method in class com.hazelcast.config.MemberGroupConfig
Adds an interface to the member group.
addIntField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
 
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
 
addItemListener(ItemListener<E>, boolean) - Method in interface com.hazelcast.core.ICollection
Adds an item listener for this collection.
addItemListener(String, ItemListener, boolean) - Method in class com.hazelcast.queue.impl.QueueService
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.CollectionConfig
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.ListConfigReadOnly
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfig
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
 
addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.config.Config
 
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.client.impl.LifecycleServiceImpl
 
addLifecycleListener(LifecycleListener) - Method in interface com.hazelcast.core.LifecycleService
Add a listener object to listen for lifecycle events.
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.LifecycleServiceImpl
 
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.instance.TerminatedLifecycleService
 
addListConfig(ListConfig) - Method in class com.hazelcast.config.Config
 
addListener(String, EventListener, Data, boolean, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new ListenerConfig
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.Config
 
AddListenerRequest - Class in com.hazelcast.queue.impl.client
this class is used to attach a listener to targeted node which sends back the events to client for a queue
AddListenerRequest() - Constructor for class com.hazelcast.queue.impl.client.AddListenerRequest
 
AddListenerRequest(String, boolean) - Constructor for class com.hazelcast.queue.impl.client.AddListenerRequest
 
addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.IMap
Adds a local entry listener for this map.
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
Adds a local entry listener for this map.
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
Adds a local entry listener for this map.
addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.MultiMap
Adds a local entry listener for this multimap.
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
addLocalEventListener(EntryListener, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
addLocalEventListener(EntryListener, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
 
addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
 
addLogListener(Level, LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
 
addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addManagedTransaction(Xid, TransactionProxy) - Method in class com.hazelcast.client.txn.ClientTransactionManager
 
addManagedTransaction(Xid, Transaction) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
 
addMapIndex(MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfig
 
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
 
addMapInterceptors(MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
 
addMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Adds a 'well known' member.
addMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
addMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
addMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
Adds a MemberGroupConfig.
addMemberInfo(MemberInfo, Map<Address, Integer>, int) - Method in class com.hazelcast.partition.PartitionRuntimeState
 
addMemberLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
 
addMembers(Collection<Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
 
addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.client.spi.ClientClusterService
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.cluster.impl.ClusterProxy
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.core.Cluster
Adds MembershipListener to listen for membership updates.
AddMembershipListenerRequest - Class in com.hazelcast.cluster.client
 
AddMembershipListenerRequest() - Constructor for class com.hazelcast.cluster.client.AddMembershipListenerRequest
 
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.client.proxy.ClientTopicProxy
 
addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.core.ITopic
Subscribes to this topic.
addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.TopicProxy
 
addMessageListener(String, MessageListener) - Method in class com.hazelcast.topic.impl.TopicService
 
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
 
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfigReadOnly
 
AddMessageListenerRequest - Class in com.hazelcast.topic.impl.client
 
AddMessageListenerRequest() - Constructor for class com.hazelcast.topic.impl.client.AddMessageListenerRequest
 
AddMessageListenerRequest(String) - Constructor for class com.hazelcast.topic.impl.client.AddMessageListenerRequest
 
addMigrationListener(MigrationListener) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
 
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.core.PartitionService
Adds a MigrationListener.
addMigrationListener(MigrationListener) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
 
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.partition.InternalPartitionService
 
addMigrationListener(MigrationListener) - Method in class com.hazelcast.partition.PartitionServiceProxy
 
addMulticastListener(MulticastListener) - Method in class com.hazelcast.cluster.impl.MulticastService
 
addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.config.Config
 
addNearCacheConfig(String, NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
addNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new NearCacheConfig
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
 
addOperation(Operation) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
 
addOrGetIndex(String, boolean) - Method in class com.hazelcast.query.impl.IndexService
 
addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
 
addOwnershipMapping(String, String) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
addPortableArrayField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
addPortableFactory(int, PortableFactory) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
 
addPortableFactoryClass(int, Class<? extends PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addPortableField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addProcessedRecords(int) - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
 
addProperty(String, String) - Method in class com.hazelcast.config.ServiceConfig
 
addProxyFactoryConfig(ProxyFactoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
Helper method to add a new ProxyFactoryConfig
addProxyListener(DistributedObjectListener) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
 
addProxyListener(DistributedObjectListener) - Method in interface com.hazelcast.spi.ProxyService
 
addPutTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increments the put time accumulator.
addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
 
addRemoveTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Increments the remove time accumulator.
addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.config.Config
 
ADDRESS - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
 
address - Variable in class com.hazelcast.cluster.impl.JoinMessage
 
address - Variable in class com.hazelcast.instance.Node
 
Address - Class in com.hazelcast.nio
Represents an address of a member in the cluster.
Address() - Constructor for class com.hazelcast.nio.Address
 
Address(String, int) - Constructor for class com.hazelcast.nio.Address
 
Address(InetAddress, int) - Constructor for class com.hazelcast.nio.Address
 
Address(InetSocketAddress) - Constructor for class com.hazelcast.nio.Address
Creates a new Address
Address(String, InetAddress, int) - Constructor for class com.hazelcast.nio.Address
 
Address(Address) - Constructor for class com.hazelcast.nio.Address
 
address - Variable in class com.hazelcast.util.AddressUtil.AddressMatcher
 
AddressHelper - Class in com.hazelcast.client.util
This is a client side utility class for working with addresses and cluster connections
AddressPicker - Interface in com.hazelcast.instance
 
AddressProvider - Interface in com.hazelcast.client.connection
Provides initial addresses for client to find and connect to a node
AddressTranslator - Interface in com.hazelcast.client.connection
Address Translator is used for resolve private ip addresses of cloud services.
AddressUtil - Class in com.hazelcast.util
AddressUtil contains Address helper methods
AddressUtil.AddressHolder - Class in com.hazelcast.util
Holds address
AddressUtil.AddressHolder(String, int, String) - Constructor for class com.hazelcast.util.AddressUtil.AddressHolder
 
AddressUtil.AddressMatcher - Class in com.hazelcast.util
http://docs.oracle.com/javase/1.5.0/docs/guide/net/ipv6_guide/index.html
AddressUtil.AddressMatcher(String[]) - Constructor for class com.hazelcast.util.AddressUtil.AddressMatcher
 
AddressUtil.InvalidAddressException - Exception in com.hazelcast.util
Thrown when given address is not valid.
AddressUtil.InvalidAddressException(String) - Constructor for exception com.hazelcast.util.AddressUtil.InvalidAddressException
 
addResultSet(ConcurrentMap<Data, QueryableEntry>) - Method in class com.hazelcast.query.impl.MultiResultSet
 
addSecurityInterceptorConfig(SecurityInterceptorConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addSemaphoreConfig(SemaphoreConfig) - Method in class com.hazelcast.config.Config
Adds a new SemaphoreConfig by name
addSerializerConfig(SerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
 
addServiceConfig(ServiceConfig) - Method in class com.hazelcast.config.ServicesConfig
 
AddSessionEntryProcessor - Class in com.hazelcast.web
Sets the initial reference count to 1.
AddSessionEntryProcessor() - Constructor for class com.hazelcast.web.AddSessionEntryProcessor
 
addSetConfig(SetConfig) - Method in class com.hazelcast.config.Config
 
addShortArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addShortField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addStoreListener(StoreListener) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
 
addTargetClusterConfig(WanTargetClusterConfig) - Method in class com.hazelcast.config.WanReplicationConfig
 
addTask(Runnable) - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
 
addTask(Runnable) - Method in interface com.hazelcast.nio.tcp.IOSelector
 
addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
 
addTransactionLog(TransactionLog) - Method in interface com.hazelcast.transaction.impl.TransactionSupport
 
addTransient(K, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
 
addTransient(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
addTransient(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
addTrustedInterface(String) - Method in class com.hazelcast.config.MulticastConfig
Adds a trusted interface.
addTxBackupLogForClientRecovery(Transaction) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
 
advance() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
after(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
afterGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
Called after get(..) operation is completed.
afterInsert(Object, Object, Object) - Method in interface com.hazelcast.hibernate.access.AccessDelegate
Called after an item has been inserted (after the transaction completes), instead of calling release().
afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.access.NonStrictReadWriteAccessDelegate
 
afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.access.ReadWriteAccessDelegate
 
afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
 
afterInsert(Object, Object) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
 
afterInsert(Object, Object, Object) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
 
afterPut(Object) - Method in interface com.hazelcast.map.MapInterceptor
Called after put(..) operation is completed.
afterRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
Called after remove(..) operation is completed.
afterResponse() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
Called on node side, after sending the response to the client.
afterRun() - Method in class com.hazelcast.collection.CollectionAddAllBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionAddAllOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionAddBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionAddOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionClearBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionClearOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionCompareAndRemoveOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionContainsOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionGetAllOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionIsEmptyOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionRemoveBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionRemoveOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionSizeOperation
 
afterRun() - Method in class com.hazelcast.collection.CollectionTransactionRollbackOperation
 
afterRun() - Method in class com.hazelcast.collection.list.ListGetOperation
 
afterRun() - Method in class com.hazelcast.collection.list.ListIndexOfOperation
 
afterRun() - Method in class com.hazelcast.collection.list.ListRemoveOperation
 
afterRun() - Method in class com.hazelcast.collection.list.ListSetBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.list.ListSetOperation
 
afterRun() - Method in class com.hazelcast.collection.list.ListSubOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionPrepareOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionReserveAddOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionRollbackOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionTxnAddOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
 
afterRun() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
 
afterRun() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
 
afterRun() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
 
afterRun() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
 
afterRun() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
 
afterRun() - Method in class com.hazelcast.management.operation.GetMapConfigOperation
 
afterRun() - Method in class com.hazelcast.management.operation.ScriptExecutorOperation
 
afterRun() - Method in class com.hazelcast.management.operation.ThreadDumpOperation
 
afterRun() - Method in class com.hazelcast.management.operation.UpdateManagementCenterUrlOperation
 
afterRun() - Method in class com.hazelcast.management.operation.UpdateMapConfigOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.AbstractMapOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.EntryOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.EvictOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.GetOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.MergeOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.SetOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
 
afterRun() - Method in class com.hazelcast.map.impl.operation.WanOriginatedDeleteOperation
 
afterRun() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
 
afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
 
afterRun() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
 
afterRun() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
 
afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
 
afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
 
afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.ClearOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.ContainsOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.DrainOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.IsEmptyOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.IteratorOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.PeekOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.PollOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.RemainingCapacityOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.operations.SizeOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.tx.TxnPeekOperation
 
afterRun() - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
 
afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
afterRun() - Method in class com.hazelcast.spi.AbstractOperation
 
afterRun() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation
 
afterRun() - Method in class com.hazelcast.spi.Operation
 
afterRun() - Method in class com.hazelcast.transaction.impl.BeginTxBackupOperation
 
afterRun() - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
 
afterRun() - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
 
afterRun() - Method in class com.hazelcast.transaction.impl.RecoverTxnOperation
 
afterRun() - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
 
afterRun() - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
 
afterRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
Called after inner run method and can be overridden to customize.
afterStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.ClientExtension
Called after node is started
afterStart(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.DefaultClientExtension
 
afterStart(Node) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
afterStart(Node) - Method in interface com.hazelcast.instance.NodeExtension
Called after node is started
afterStore(StoreEvent<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.StoreListener
 
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in interface com.hazelcast.hibernate.access.AccessDelegate
Called after an item has been updated (after the transaction completes), instead of calling release().
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.access.NonStrictReadWriteAccessDelegate
 
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.access.ReadOnlyAccessDelegate
 
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.access.ReadWriteAccessDelegate
Called after an item has been updated (after the transaction completes), instead of calling release().
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.region.EntityRegionAccessStrategyAdapter
 
afterUpdate(Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
 
afterUpdate(Object, Object, Object, Object, SoftLock) - Method in class com.hazelcast.hibernate.region.NaturalIdRegionAccessStrategyAdapter
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.IMap
Executes a predefined aggregation on the maps data set.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.IMap
Executes a predefined aggregation on the maps data set.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.MultiMap
Executes a predefined aggregation on the multimaps data set.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.MultiMap
Executes a predefined aggregation on the multimaps data set.
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
Aggregation<Key,Supplied,Result> - Interface in com.hazelcast.mapreduce.aggregation
The Aggregation interface combines multiple map-reduce operations steps to a single operation definition.
Aggregations - Class in com.hazelcast.mapreduce.aggregation
This class is used to access the Hazelcast predefined set of aggregations in a type-safe way.
AGGREGATIONS_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
AGGREGATIONS_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
AggregationsDataSerializerHook - Class in com.hazelcast.mapreduce.aggregation.impl
This class contains all the ID hooks for IdentifiedDataSerializable classes used for aggregations.
AggregationsDataSerializerHook() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
AggType<KeyIn,ValueIn,KeyOut,SuppliedValue,CombinerValue,ReducerValue,Result> - Interface in com.hazelcast.mapreduce.aggregation.impl
The internal interface for Aggregation definitions to make those implementations more type-safe.
all() - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
The predefined Supplier selects all values and does not perform any kind of data transformation.
all(PropertyExtractor<ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
The predefined Supplier selects all values and performs the given PropertyExtractors transformation to the input data.
allowUnsafe - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
AllPartitionsClientRequest - Class in com.hazelcast.client.impl.client
Base class for client request that will run on all partitions.
AllPartitionsClientRequest() - Constructor for class com.hazelcast.client.impl.client.AllPartitionsClientRequest
 
AllPermissions - Class in com.hazelcast.security.permission
 
AllPermissions() - Constructor for class com.hazelcast.security.permission.AllPermissions
 
AllPermissions.AllPermissionsCollection - Class in com.hazelcast.security.permission
 
AllPermissions.AllPermissionsCollection() - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
AllPermissions.AllPermissionsCollection(boolean) - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
 
alter(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
alter(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
ALTER - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
alter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
ALTER - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
alter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
Alters the currently stored value by applying a function on it.
alter(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
Alters the currently stored reference by applying a function on it.
ALTER_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
ALTER_AND_GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
alterAndGet(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
alterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
alterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
alterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
Alters the currently stored value by applying a function on it and gets the result.
alterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
AlterAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
 
AlterAndGetOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
 
AlterAndGetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
 
AlterAndGetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
 
AlterAndGetRequest - Class in com.hazelcast.concurrent.atomiclong.client
 
AlterAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
 
AlterAndGetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
 
AlterAndGetRequest - Class in com.hazelcast.concurrent.atomicreference.client
 
AlterAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
 
AlterAndGetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
 
AlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
 
AlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
 
AlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
 
AlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
 
AlterRequest - Class in com.hazelcast.concurrent.atomiclong.client
 
AlterRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterRequest
 
AlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterRequest
 
AlterRequest - Class in com.hazelcast.concurrent.atomicreference.client
 
AlterRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterRequest
 
AlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterRequest
 
and(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
 
and(Predicate...) - Static method in class com.hazelcast.query.Predicates
 
AndResultSet - Class in com.hazelcast.query.impl
And Result set for Predicates.
AndResultSet(Set<QueryableEntry>, List<Set<QueryableEntry>>, List<Predicate>) - Constructor for class com.hazelcast.query.impl.AndResultSet
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.client.spi.impl.ClientCallFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.client.spi.impl.ClientCallFuture
 
andThen(ExecutionCallback<V>) - Method in interface com.hazelcast.core.ICompletableFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in interface com.hazelcast.core.ICompletableFuture
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.CompletableFutureTask
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.CompletableFutureTask
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.CompletedFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.CompletedFuture
 
andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
andThenInternal(ExecutionCallback<Data>) - Method in class com.hazelcast.client.spi.impl.ClientCallFuture
 
answerMasterQuestion(JoinMessage) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
 
appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
apply(IFunction<Long, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
apply(IFunction<E, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
APPLY - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
apply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
APPLY - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
apply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
apply(IFunction<Long, R>) - Method in interface com.hazelcast.core.IAtomicLong
Applies a function on the value, the actual stored value will not change.
apply(IFunction<E, R>) - Method in interface com.hazelcast.core.IAtomicReference
Applies a function on the value, the actual stored value will not change.
apply(T) - Method in interface com.hazelcast.core.IFunction
 
apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
 
apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
 
apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
 
apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.Supplier
The apply method is used to apply the actual filtering or extraction / transformation to the input entry.
If the input value should be ignored by the aggregation, the Supplier has to return
apply(Map.Entry) - Method in class com.hazelcast.query.PagingPredicate
Used for delegating filtering to inner predicate
apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.PredicateBuilder
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.AndPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.BetweenPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.EqualPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.GreaterLessPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.InPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.LikePredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.NotEqualPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.NotPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.OrPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.RegexPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.SqlPredicate
 
apply(Map.Entry) - Method in class com.hazelcast.query.TruePredicate
 
apply(Map.Entry) - Method in class com.hazelcast.web.SessionAttributePredicate
 
applyAndIncrementVectorClock(VectorClockTimestamp, Member) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
applyChanges() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
Provides a similar functionality as committing a transaction.
ApplyOperation<R> - Class in com.hazelcast.concurrent.atomiclong.operations
 
ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
ApplyOperation(String, IFunction<Long, R>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
 
ApplyOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
ApplyOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
 
applyRecordInfo(Record, RecordInfo) - Static method in class com.hazelcast.map.impl.record.Records
 
ApplyRequest - Class in com.hazelcast.concurrent.atomiclong.client
 
ApplyRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
 
ApplyRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
 
ApplyRequest - Class in com.hazelcast.concurrent.atomicreference.client
 
ApplyRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
 
ApplyRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
 
applyVectorClock(VectorClockTimestamp) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
 
array() - Method in class com.hazelcast.nio.DynamicByteBuffer
 
ArrayDataSerializableFactory - Class in com.hazelcast.nio.serialization
 
ArrayDataSerializableFactory(ConstructorFunction<Integer, IdentifiedDataSerializable>[]) - Constructor for class com.hazelcast.nio.serialization.ArrayDataSerializableFactory
 
ArrayListSerializerHook - Class in com.hazelcast.nio.serialization.serializers
This class is the auto registered serializer hook for a ArrayList.
ArrayListSerializerHook() - Constructor for class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook
 
ArrayListSerializerHook.ArrayListStreamSerializer - Class in com.hazelcast.nio.serialization.serializers
The ArrayList serializer
ArrayListSerializerHook.ArrayListStreamSerializer() - Constructor for class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook.ArrayListStreamSerializer
 
ArrayPortableFactory - Class in com.hazelcast.nio.serialization
 
ArrayPortableFactory(ConstructorFunction<Integer, Portable>[]) - Constructor for class com.hazelcast.nio.serialization.ArrayPortableFactory
 
asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.ExecutionService
 
asCompletableFuture(Future<V>) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
 
asList() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
Returns list representation of this queue.
asMap() - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
 
asMap() - Method in class com.hazelcast.hibernate.local.LocalRegionCache
 
asMap() - Method in interface com.hazelcast.hibernate.RegionCache
 
asMap() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation.PartitionResponse
 
asReadOnly() - Method in class com.hazelcast.config.MemberAttributeConfig
 
assignKeyReducerAddress(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
 
assignKeyReducerAddress(Object, Address) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
 
assignMemberId(Address, String, JobTaskConfiguration) - Method in class com.hazelcast.mapreduce.impl.task.MemberAssigningJobProcessInformationImpl
 
AssignPartitions - Class in com.hazelcast.partition.impl
 
AssignPartitions() - Constructor for class com.hazelcast.partition.impl.AssignPartitions
 
associateConnection(Object) - Method in class com.hazelcast.jca.ManagedConnectionImpl
 
async - Variable in class com.hazelcast.map.impl.client.MapPutRequest
 
async - Variable in class com.hazelcast.map.impl.client.MapRemoveRequest
 
ASYNC_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the async executor.
asyncAddAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAddAndGet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Atomically adds the given value to the current value.
asyncAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Alters the currently stored value by applying a function on it.
asyncAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Alters the currently stored reference by applying a function on it.
asyncAlterAndGet(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncAlterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncAlterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Alters the currently stored value by applying a function on it and gets the result.
asyncAlterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Alters the currently stored reference by applying a function on it and gets the result.
asyncApply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncApply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncApply(IFunction<Long, R>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Applies a function on the value, the actual stored value will not change.
asyncApply(IFunction<E, R>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Applies a function on the value, the actual stored value will not change.
AsyncAtomicLong - Interface in com.hazelcast.core
This interface is an IAtomicLong interface that exposes its operations using an ICompletableFuture interface so it can be used in the reactive programming model approach.
AsyncAtomicReference<E> - Interface in com.hazelcast.core
A IAtomicReference that exposes its operations using a ICompletableFuture so it can be used in the reactive programming model approach.
asyncClear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncClear() - Method in interface com.hazelcast.core.AsyncAtomicReference
Clears the current stored reference.
asyncCompareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncCompareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncCompareAndSet(long, long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Atomically sets the value to the given updated value only if the current value == the expected value.
asyncCompareAndSet(E, E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Atomically sets the value to the given updated value only if the current value == the expected value.
asyncContains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncContains(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Checks if the reference contains the value.
asyncDecrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncDecrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Atomically decrements the current value by one.
asyncGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGet() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Gets the current value.
asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicReference
Gets the current value.
asyncGetAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndAdd(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Atomically adds the given value to the current value.
asyncGetAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGetAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.AsyncAtomicLong
Alters the currently stored value by applying a function on it on and gets the old value.
asyncGetAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
Alters the currently stored reference by applying a function on it on and gets the old value.
asyncGetAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndIncrement() - Method in interface com.hazelcast.core.AsyncAtomicLong
Atomically increments the current value by one.
asyncGetAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncGetAndSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncGetAndSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Atomically sets the given value and returns the old value.
asyncGetAndSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Gets the value and sets the new value.
asyncIncrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncIncrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
Atomically increments the current value by one.
asyncIsNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncIsNull() - Method in interface com.hazelcast.core.AsyncAtomicReference
Checks if the stored reference is null.
asyncSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
asyncSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
Atomically sets the given value.
asyncSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Atomically sets the given value.
asyncSetAndGet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
asyncSetAndGet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
Deprecated. will be removed from Hazelcast 3.4 since it doesn't really serve a purpose.
ATOMIC_LONG_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
ATOMIC_LONG_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
 
ATOMIC_LONG_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
ATOMIC_REFERENCE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
ATOMIC_REFERENCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
AtomicLongBackupAwareOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AtomicLongBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
AtomicLongBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
 
AtomicLongBaseOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AtomicLongBaseOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
 
AtomicLongBaseOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
 
AtomicLongDataSerializerHook - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
AtomicLongMBean - Class in com.hazelcast.jmx
Management bean for IAtomicLong
AtomicLongMBean(IAtomicLong, ManagementService) - Constructor for class com.hazelcast.jmx.AtomicLongMBean
 
AtomicLongPermission - Class in com.hazelcast.security.permission
 
AtomicLongPermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicLongPermission
 
AtomicLongPortableHook - Class in com.hazelcast.concurrent.atomiclong.client
 
AtomicLongPortableHook() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
 
AtomicLongProxy - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongProxy(String, NodeEngine, AtomicLongService) - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
AtomicLongReplicationOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
AtomicLongReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
AtomicLongReplicationOperation(Map<String, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
 
AtomicLongRequest - Class in com.hazelcast.concurrent.atomiclong.client
 
AtomicLongRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
 
AtomicLongRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
 
AtomicLongService - Class in com.hazelcast.concurrent.atomiclong
 
AtomicLongService() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
AtomicReferenceBackupAwareOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AtomicReferenceBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
AtomicReferenceBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
 
AtomicReferenceBaseOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AtomicReferenceBaseOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
 
AtomicReferenceBaseOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
 
AtomicReferenceDataSerializerHook - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
AtomicReferenceMBean - Class in com.hazelcast.jmx
Management bean for IAtomicReference
AtomicReferenceMBean(IAtomicReference, ManagementService) - Constructor for class com.hazelcast.jmx.AtomicReferenceMBean
 
AtomicReferencePermission - Class in com.hazelcast.security.permission
 
AtomicReferencePermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicReferencePermission
 
AtomicReferencePortableHook - Class in com.hazelcast.concurrent.atomicreference.client
 
AtomicReferencePortableHook() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
 
AtomicReferenceProxy<E> - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceProxy(String, NodeEngine, AtomicReferenceService) - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
AtomicReferenceReplicationOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
AtomicReferenceReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
AtomicReferenceReplicationOperation(Map<String, Data>) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
 
AtomicReferenceService - Class in com.hazelcast.concurrent.atomicreference
 
AtomicReferenceService() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
attribute - Variable in class com.hazelcast.query.Predicates.AbstractPredicate
 
attribute - Variable in class com.hazelcast.query.Predicates.LikePredicate
 
attributeMap - Variable in class com.hazelcast.jmx.HazelcastMBean
 
AttributeType - Enum in com.hazelcast.query.impl
Type of Attribute
auth(ClientConnection) - Method in interface com.hazelcast.client.connection.Authenticator
Authenticates a ClientConnection.
auth(ClientConnection) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl.ManagerAuthenticator
 
AUTH - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
 
authenticated(ClientPrincipal, Credentials, boolean) - Method in interface com.hazelcast.client.ClientEndpoint
 
authenticated(ClientPrincipal) - Method in interface com.hazelcast.client.ClientEndpoint
 
authenticated(ClientPrincipal, Credentials, boolean) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
authenticated(ClientPrincipal) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
AuthenticationException - Exception in com.hazelcast.client
A HazelcastException that is thrown when there is an Authentication failure: e.g.
AuthenticationException() - Constructor for exception com.hazelcast.client.AuthenticationException
Creates a AuthenticationException with a default message.
AuthenticationException(String) - Constructor for exception com.hazelcast.client.AuthenticationException
Creates a AuthenticationException with the given message.
AuthenticationFailureOperation - Class in com.hazelcast.cluster.impl.operations
 
AuthenticationFailureOperation() - Constructor for class com.hazelcast.cluster.impl.operations.AuthenticationFailureOperation
 
AuthenticationRequest - Class in com.hazelcast.client.impl.client
Client Authentication Request that holds credentials
AuthenticationRequest() - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
 
AuthenticationRequest(Credentials) - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
 
AuthenticationRequest(Credentials, ClientPrincipal) - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
 
Authenticator - Interface in com.hazelcast.client.connection
The Authenticator is responsible for authenticating a ClientConnection.
AuthorizationOperation - Class in com.hazelcast.cluster.impl.operations
 
AuthorizationOperation() - Constructor for class com.hazelcast.cluster.impl.operations.AuthorizationOperation
 
AuthorizationOperation(String, String) - Constructor for class com.hazelcast.cluster.impl.operations.AuthorizationOperation
 
AUTO_TYPE_ARRAY_LIST - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
AUTO_TYPE_JOB_PARTITION_STATE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
AUTO_TYPE_JOB_PARTITION_STATE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
AUTO_TYPE_LINKED_LIST - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
available() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
AVAILABLE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
 
AvailableOperation - Class in com.hazelcast.concurrent.semaphore.operations
 
AvailableOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
 
AvailableOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
 
availablePermits() - Method in class com.hazelcast.client.proxy.ClientSemaphoreProxy
 
availablePermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
 
availablePermits() - Method in interface com.hazelcast.core.ISemaphore
Returns the current number of permits currently available in this semaphore.
AvailableRequest - Class in com.hazelcast.concurrent.semaphore.client
 
AvailableRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.AvailableRequest
 
AvailableRequest(String) - Constructor for class com.hazelcast.concurrent.semaphore.client.AvailableRequest
 
AVG_TUPLE - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
AvgTuple<F,S> - Class in com.hazelcast.mapreduce.aggregation.impl
Internal tuple type for average calculations, used to transmit data between Combiner and Reducer implementations.
AvgTuple(F, S) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
 
await() - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
await(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
await(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientCountDownLatchProxy
 
await(long, TimeUnit) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
 
AWAIT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
await(long, TimeUnit) - Method in interface com.hazelcast.core.ICountDownLatch
Causes the current thread to wait until the latch has counted down to zero, or an exception is thrown, or the specified waiting time elapses.
await(WaitSupport) - Method in interface com.hazelcast.spi.WaitNotifyService
Causes the current operation to wait in WaitNotifyService until it is notified by a Notifier operation or timeout specified by WaitSupport.getWaitTimeout() passes.
AWAIT_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
AWAIT_COMPLETION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.cache.impl.CacheProxyUtil
 
AWAIT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
 
AwaitBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
AwaitBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
AwaitBackupOperation(ObjectNamespace, Data, long, String, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
 
awaitNanos(long) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
AwaitOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
 
AwaitOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
AwaitOperation(String, long) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
 
AwaitOperation - Class in com.hazelcast.concurrent.lock.operations
 
AwaitOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
AwaitOperation(ObjectNamespace, Data, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
AwaitRequest - Class in com.hazelcast.concurrent.countdownlatch.client
 
AwaitRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
 
AwaitRequest(String, long) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
 
AwaitRequest - Class in com.hazelcast.concurrent.lock.client
 
AwaitRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AwaitRequest
 
AwaitRequest(ObjectNamespace, String, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.client.AwaitRequest
 
awaitShutdown() - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
 
awaitShutdown() - Method in interface com.hazelcast.nio.tcp.IOSelector
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
 
awaitTermination(long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
awaitUninterruptibly() - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
awaitUntil(Date) - Method in class com.hazelcast.client.proxy.ClientConditionProxy
 
AwsAddressProvider - Class in com.hazelcast.client.spi.impl
Aws Address Loader.
AwsAddressTranslator - Class in com.hazelcast.client.spi.impl
AwsLookupTable loads ec2 ip addresses with given aws credentials.
AwsAddressTranslator(ClientAwsConfig) - Constructor for class com.hazelcast.client.spi.impl.AwsAddressTranslator
 
AWSClient - Class in com.hazelcast.aws
 
AWSClient(AwsConfig) - Constructor for class com.hazelcast.aws.AWSClient
 
AwsConfig - Class in com.hazelcast.config
The AWSConfig contains the configuration for AWS join mechanism.
AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
 
AwsURLEncoder - Class in com.hazelcast.aws.utility
 

B

BACKPRESSURE_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
 
BACKPRESSURE_SYNCWINDOW - Variable in class com.hazelcast.instance.GroupProperties
 
backup - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
 
backup - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
 
BACKUP_ENTRY_PROCESSOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
BackupAwareEntryProcessor<K,V,T> - Interface in com.hazelcast.cache
An invocable function that allows applications to perform compound operations on a Cache.Entry atomically, according the defined consistency of a Cache.
BackupAwareOperation - Interface in com.hazelcast.spi
A BackupAwareOperation is an Operation to indicate then when a change is made, a BackupOperation is created to replicate the backup.
BackupOperation - Interface in com.hazelcast.spi
When an BackupAwareOperation makes a change, the backups need to be replicated to other members (depending on the configuration and if change really happened).
backupSize() - Method in class com.hazelcast.queue.impl.QueueContainer
 
Base64 - Class in com.hazelcast.util
This class provides encode/decode for RFC 2045 Base64 as defined by RFC 2045, N.
BaseClientRemoveListenerRequest - Class in com.hazelcast.client.impl.client
 
BaseClientRemoveListenerRequest() - Constructor for class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
 
BaseClientRemoveListenerRequest(String, String) - Constructor for class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
 
BaseIndexStore - Class in com.hazelcast.query.impl
Base class for concrete index store implementations
BaseIndexStore() - Constructor for class com.hazelcast.query.impl.BaseIndexStore
 
BaseMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed maps.
BaseMigrationOperation - Class in com.hazelcast.partition.impl
 
BaseMigrationOperation() - Constructor for class com.hazelcast.partition.impl.BaseMigrationOperation
 
BaseMigrationOperation(MigrationInfo) - Constructor for class com.hazelcast.partition.impl.BaseMigrationOperation
 
BaseMultiMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed multi-maps.
BasePutOperation - Class in com.hazelcast.map.impl.operation
 
BasePutOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.BasePutOperation
 
BasePutOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.operation.BasePutOperation
 
BasePutOperation() - Constructor for class com.hazelcast.map.impl.operation.BasePutOperation
 
BaseQueue<E> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed queues.
BaseRemoveOperation - Class in com.hazelcast.map.impl.operation
 
BaseRemoveOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
BaseRemoveOperation() - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
 
BaseTransactionRequest - Class in com.hazelcast.transaction.client
 
BaseTransactionRequest() - Constructor for class com.hazelcast.transaction.client.BaseTransactionRequest
 
BasicBackPressureService - Class in com.hazelcast.spi.impl
A service responsible for figuring out if back pressure needs to be applied to a certain operation.
BasicBackPressureService(GroupProperties, ILogger) - Constructor for class com.hazelcast.spi.impl.BasicBackPressureService
 
BasicDispatcher - Interface in com.hazelcast.spi.impl
To keep the BasicOperationScheduler clean of operations/packets etc, the scheduler takes care of scheduling, but forwards the actual handling of the task to the BasicDispatcher.
BasicInvocationBuilder - Class in com.hazelcast.spi.impl
An InvocationBuilder that is tied to the BasicOperationService.
BasicInvocationBuilder(NodeEngineImpl, String, Operation, int) - Constructor for class com.hazelcast.spi.impl.BasicInvocationBuilder
 
BasicInvocationBuilder(NodeEngineImpl, String, Operation, Address) - Constructor for class com.hazelcast.spi.impl.BasicInvocationBuilder
 
BasicOperationScheduler - Class in com.hazelcast.spi.impl
The BasicOperationProcessor belongs to the BasicOperationService and is responsible for scheduling operations/packets to the correct threads.
BasicOperationScheduler(Node, ExecutionService, BasicDispatcher) - Constructor for class com.hazelcast.spi.impl.BasicOperationScheduler
 
BasicPartitionInvocation - Class in com.hazelcast.spi.impl
A BasicInvocation evaluates a Operation Invocation for a particular partition running on top of the BasicOperationService.
BasicPartitionInvocation(NodeEngineImpl, String, Operation, int, int, int, long, long, Callback<Object>, String, boolean) - Constructor for class com.hazelcast.spi.impl.BasicPartitionInvocation
 
BasicSSLContextFactory - Class in com.hazelcast.nio.ssl
 
BasicSSLContextFactory() - Constructor for class com.hazelcast.nio.ssl.BasicSSLContextFactory
 
BasicTargetInvocation - Class in com.hazelcast.spi.impl
A BasicInvocation evaluates a Operation Invocation for a particular target running on top of the BasicOperationService.
BasicTargetInvocation(NodeEngineImpl, String, Operation, Address, int, long, long, Callback<Object>, String, boolean) - Constructor for class com.hazelcast.spi.impl.BasicTargetInvocation
 
batchEvent - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
before(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
 
BEFORE_AWAIT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
BEFORE_AWAIT_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
 
BeforeAwaitBackupOperation - Class in com.hazelcast.concurrent.lock.operations
 
BeforeAwaitBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
BeforeAwaitBackupOperation(ObjectNamespace, Data, long, String, String) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
 
BeforeAwaitOperation - Class in com.hazelcast.concurrent.lock.operations
 
BeforeAwaitOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
BeforeAwaitOperation(ObjectNamespace, Data, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
BeforeAwaitRequest - Class in com.hazelcast.concurrent.lock.client
 
BeforeAwaitRequest() - Constructor for class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
 
BeforeAwaitRequest(ObjectNamespace, long, String, Data) - Constructor for class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
 
beforeListenerRegister() - Method in interface com.hazelcast.client.spi.EventHandler
This method is called before registration request is sent to node.
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.CollectionService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.queue.impl.QueueService
 
beforeMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
 
beforeProcess() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
Called on node side, before starting any operation.
beforeProcess() - Method in class com.hazelcast.map.impl.client.MapGetRequest
 
beforeProcess() - Method in class com.hazelcast.map.impl.client.MapPutRequest
 
beforeProcess() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
 
beforeResponse() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
Called on node side, after process is run and right before sending the response to the client.
beforeResponse() - Method in class com.hazelcast.map.impl.client.MapGetRequest
 
beforeResponse() - Method in class com.hazelcast.map.impl.client.MapPutRequest
 
beforeResponse() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
beforeRun() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
beforeRun() - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionAddAllBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionAddAllOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionAddBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionAddOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionClearBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionClearOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionCompareAndRemoveOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionContainsOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionGetAllOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionIsEmptyOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionRemoveBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionRemoveOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionSizeOperation
 
beforeRun() - Method in class com.hazelcast.collection.CollectionTransactionRollbackOperation
 
beforeRun() - Method in class com.hazelcast.collection.list.ListGetOperation
 
beforeRun() - Method in class com.hazelcast.collection.list.ListIndexOfOperation
 
beforeRun() - Method in class com.hazelcast.collection.list.ListRemoveOperation
 
beforeRun() - Method in class com.hazelcast.collection.list.ListSetBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.list.ListSetOperation
 
beforeRun() - Method in class com.hazelcast.collection.list.ListSubOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionPrepareOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionReserveAddOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionRollbackOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionTxnAddOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
 
beforeRun() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
 
beforeRun() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
 
beforeRun() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
 
beforeRun() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
 
beforeRun() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
 
beforeRun() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
 
beforeRun() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
 
beforeRun() - Method in class com.hazelcast.management.operation.GetMapConfigOperation
 
beforeRun() - Method in class com.hazelcast.management.operation.ScriptExecutorOperation
 
beforeRun() - Method in class com.hazelcast.management.operation.ThreadDumpOperation
 
beforeRun() - Method in class com.hazelcast.management.operation.UpdateManagementCenterUrlOperation
 
beforeRun() - Method in class com.hazelcast.management.operation.UpdateMapConfigOperation
 
beforeRun() - Method in class com.hazelcast.map.impl.operation.AbstractMapOperation
 
beforeRun() - Method in class com.hazelcast.map.impl.operation.ClearBackupOperation
 
beforeRun() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
 
beforeRun() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
 
beforeRun() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
 
beforeRun() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
 
beforeRun() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
 
beforeRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
 
beforeRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
 
beforeRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
 
beforeRun() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
 
beforeRun() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
 
beforeRun() - Method in class com.hazelcast.spi.AbstractOperation
 
beforeRun() - Method in class com.hazelcast.spi.Operation
 
beforeRun() - Method in class com.hazelcast.topic.impl.PublishOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.BeginTxBackupOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.RecoverTxnOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
 
beforeRun() - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
 
beforeRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
Called before inner run method and can be overridden to customize.
beforeStart(HazelcastClientInstanceImpl) - Method in interface com.hazelcast.client.ClientExtension
Called before client is started
beforeStart(HazelcastClientInstanceImpl) - Method in class com.hazelcast.client.impl.DefaultClientExtension
 
beforeStart(Node) - Method in class com.hazelcast.instance.DefaultNodeExtension
 
beforeStart(Node) - Method in interface com.hazelcast.instance.NodeExtension
Called before node is started
beforeStore(StoreEvent<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.StoreListener
 
begin() - Method in class com.hazelcast.jca.HazelcastTransactionImpl
 
begin() - Method in interface com.hazelcast.transaction.impl.Transaction
 
beginCombine() - Method in class com.hazelcast.mapreduce.Combiner
This method is called before the first value is submitted to this Combiner instance.
beginReduce() - Method in class com.hazelcast.mapreduce.Reducer
This method is called before the first value is submitted to this Reducer instance.
beginTransaction() - Method in class com.hazelcast.client.txn.TransactionContextProxy
 
beginTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Begins a transaction.
BeginTxBackupOperation - Class in com.hazelcast.transaction.impl
 
BeginTxBackupOperation() - Constructor for class com.hazelcast.transaction.impl.BeginTxBackupOperation
 
BeginTxBackupOperation(String, String, SerializableXID) - Constructor for class com.hazelcast.transaction.impl.BeginTxBackupOperation
 
Beta - Annotation Type in com.hazelcast.spi.annotation
An element annotated with this annotation is considered beta status.
Beta in this case means it is a fully new feature and in general seems ready for production use but can be subject to change in the near future when problems coming up with the proposed API.
between(Comparable, Comparable) - Method in class com.hazelcast.query.EntryObject
 
between(String, Comparable, Comparable) - Static method in class com.hazelcast.query.Predicates
 
BIG_DECIMAL_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_DECIMAL_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
BIG_INTEGER_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
bigDecimalAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to calculate the BigDecimal average of all supplied values.
This aggregation is similar to
BigDecimalAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined average aggregation for values of type BigDecimal.
BigDecimalAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
 
bigDecimalMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to find the BigDecimal maximum of all supplied values.
This aggregation is similar to
BigDecimalMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined maximum aggregation for values of type BigDecimal.
BigDecimalMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
 
bigDecimalMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to find the BigDecimal minimum of all supplied values.
This aggregation is similar to
BigDecimalMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined minimum aggregation for values of type BigDecimal.
BigDecimalMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
 
bigDecimalSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to calculate the BigDecimal sum of all supplied values.
This aggregation is similar to
BigDecimalSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined sum aggregation for values of type BigDecimal.
BigDecimalSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
 
bigIntegerAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to calculate the BigInteger average of all supplied values.
This aggregation is similar to
BigIntegerAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined average aggregation for values of type BigInteger.
BigIntegerAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
 
bigIntegerMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to find the BigInteger maximum of all supplied values.
This aggregation is similar to
BigIntegerMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined maximum aggregation for values of type BigInteger.
BigIntegerMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
 
bigIntegerMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to find the BigInteger minimum of all supplied values.
This aggregation is similar to
BigIntegerMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined minimum aggregation for values of type BigInteger.
BigIntegerMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
 
bigIntegerSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to calculate the BigInteger sum of all supplied values.
This aggregation is similar to
BigIntegerSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined sum aggregation for values of type BigInteger.
BigIntegerSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
 
BinaryClassDefinitionProxy - Class in com.hazelcast.nio.serialization
 
BinaryClassDefinitionProxy(int, int, int) - Constructor for class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
BinaryClassDefinitionProxy(int, int, int, byte[]) - Constructor for class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
BinaryOperationFactory - Class in com.hazelcast.spi.impl
 
BinaryOperationFactory() - Constructor for class com.hazelcast.spi.impl.BinaryOperationFactory
 
BinaryOperationFactory(Operation, NodeEngine) - Constructor for class com.hazelcast.spi.impl.BinaryOperationFactory
 
BinaryOperationFactory(Data) - Constructor for class com.hazelcast.spi.impl.BinaryOperationFactory
 
bind(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEngineImpl
 
bind(TcpIpConnection, Address, Address, boolean) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
 
BIND_MESSAGE - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
 
BindMessage - Class in com.hazelcast.cluster.impl
 
BindMessage() - Constructor for class com.hazelcast.cluster.impl.BindMessage
 
BindMessage(Address, Address, boolean) - Constructor for class com.hazelcast.cluster.impl.BindMessage
 
Bits - Class in com.hazelcast.nio
Access and manipulate bits, bytes, primitives ...
blacklist(Address, boolean) - Method in class com.hazelcast.cluster.impl.AbstractJoiner
 
blacklist(Address, boolean) - Method in interface com.hazelcast.cluster.Joiner
Adds an address to the blacklist.
blacklistedAddresses - Variable in class com.hazelcast.cluster.impl.AbstractJoiner
 
BLOCK_SIZE - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
 
BroadcastTxRollbackOperation - Class in com.hazelcast.transaction.impl
 
BroadcastTxRollbackOperation() - Constructor for class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
 
BroadcastTxRollbackOperation(String) - Constructor for class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
 
BufferObjectDataInput - Interface in com.hazelcast.nio
 
BufferObjectDataOutput - Interface in com.hazelcast.nio
 
build() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build() - Method in interface com.hazelcast.config.ConfigBuilder
Builds Config object.
build() - Method in class com.hazelcast.config.XmlConfigBuilder
 
build() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
build() - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
build() - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
 
buildAccessStrategy(AccessType) - Method in class com.hazelcast.hibernate.region.HazelcastCollectionRegion
 
buildAccessStrategy(AccessType) - Method in class com.hazelcast.hibernate.region.HazelcastEntityRegion
 
buildAccessStrategy(AccessType) - Method in class com.hazelcast.hibernate.region.HazelcastNaturalIdRegion
 
buildCollectionRegion(String, Properties, CacheDataDescription) - Method in class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
buildCollectionRegion(String, Properties, CacheDataDescription) - Method in class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
buildEntityRegion(String, Properties, CacheDataDescription) - Method in class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
buildEntityRegion(String, Properties, CacheDataDescription) - Method in class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
buildExecutorName(String) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
 
BuildInfo - Class in com.hazelcast.instance
 
BuildInfo(String, String, String, int, boolean) - Constructor for class com.hazelcast.instance.BuildInfo
 
BuildInfoProvider - Class in com.hazelcast.instance
Provides information about current Hazelcast build.
buildNumber - Variable in class com.hazelcast.cluster.impl.JoinMessage
 
buildQueryResultsRegion(String, Properties) - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
buildRandomUUID() - Static method in class com.hazelcast.util.UuidUtil
 
buildRandomUuidString() - Static method in class com.hazelcast.util.UuidUtil
 
buildRecordInfo(Record) - Static method in class com.hazelcast.map.impl.record.Records
 
buildTimestampsRegion(String, Properties) - Method in class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
buildTimestampsRegion(String, Properties) - Method in class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
byOrdinal(int) - Static method in enum com.hazelcast.mapreduce.impl.operation.RequestPartitionResult.ResultState
 
byOrdinal(int) - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
Returns an processing state by its given ordinal
BYTE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
 
BYTE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
 
ByteArraySerializer<T> - Interface in com.hazelcast.nio.serialization
For sample usage custom serialization and other way of custom serialization see StreamSerializer.
byteArrayToLong(byte[]) - Static method in class com.hazelcast.ascii.memcache.MemcacheCommandProcessor
 
byteOrder - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
bytes() - Method in class com.hazelcast.memory.MemorySize
Returns value of memory size in bytes.
bytesToString(byte[], int, int) - Static method in class com.hazelcast.util.StringUtil
 
bytesToString(byte[]) - Static method in class com.hazelcast.util.StringUtil
 

C

cache - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
 
cache - Variable in class com.hazelcast.hibernate.access.AbstractAccessDelegate
 
cache - Variable in class com.hazelcast.hibernate.local.LocalRegionCache
 
CACHE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
CACHE_EVENT_DATA - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_EVENT_DATA_SET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CACHE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
CacheAddEntryListenerRequest - Class in com.hazelcast.cache.impl.client
Client request which registers an event listener on behalf of the client and delegates the received events back to client.
CacheAddEntryListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
 
CacheAddEntryListenerRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
 
CacheBackupEntryProcessorOperation - Class in com.hazelcast.cache.impl.operation
Operation of the Cache Backup Entry Processor.
CacheBackupEntryProcessorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
 
CacheBackupEntryProcessorOperation(String, Data, EntryProcessor, Object...) - Constructor for class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
 
CacheClearBackupOperation - Class in com.hazelcast.cache.impl.operation
Backup operation of CacheClearOperation.
CacheClearBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
CacheClearBackupOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
 
CacheClearOperation - Class in com.hazelcast.cache.impl.operation
Cache Clear will clear all internal cache data without sending any event
CacheClearOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperation
 
CacheClearOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperation
 
CacheClearOperationFactory - Class in com.hazelcast.cache.impl.operation
OperationFactory implementation for Clear Operations.
CacheClearOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
 
CacheClearOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
 
CacheClearRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheClearOperationFactory on the server side.
CacheClearRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheClearRequest
 
CacheClearRequest(String, Set<Data>, boolean, int) - Constructor for class com.hazelcast.cache.impl.client.CacheClearRequest
 
CacheClearResponse - Class in com.hazelcast.cache.impl
This class is a simple object wrapper to be used by CacheClearOperation.
CacheClearResponse() - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
 
CacheClearResponse(Object) - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
 
CacheConcurrentHashMap<K,V> - Class in com.hazelcast.util
ConcurrentHashMap to extend iterator capability
CacheConcurrentHashMap(int) - Constructor for class com.hazelcast.util.CacheConcurrentHashMap
 
CacheConcurrentHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.CacheConcurrentHashMap
 
cacheConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
CacheConfig<K,V> - Class in com.hazelcast.config
Contains all the configuration for the ICache
CacheConfig() - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheConfig
 
CacheConfigReadOnly<K,V> - Class in com.hazelcast.config
Contains the configuration for an ICache (read-only).
CacheConfiguration<K,V> - Interface in com.hazelcast.config
Mutable extension to CompleteConfiguration
CacheContainsKeyOperation - Class in com.hazelcast.cache.impl.operation
Cache contains key operation, determines if the cache contains an entry for the specified key.
CacheContainsKeyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
 
CacheContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
 
CacheContainsKeyRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheContainsKeyOperation on the server side.
CacheContainsKeyRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
 
CacheContainsKeyRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
 
CacheCreateConfigOperation - Class in com.hazelcast.cache.impl.operation
Used to create cluster wide cache configuration.
CacheCreateConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
 
CacheCreateConfigOperation(CacheConfig) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
 
CacheCreateConfigOperation(CacheConfig, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
 
CacheCreateConfigRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheCreateConfigOperation on the server side.
CacheCreateConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
 
CacheCreateConfigRequest(CacheConfig, boolean, int) - Constructor for class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
 
CacheDataRecord - Class in com.hazelcast.cache.impl.record
Implementation of CacheRecord where value has an internal serialized format.
CacheDataRecord() - Constructor for class com.hazelcast.cache.impl.record.CacheDataRecord
 
CacheDataRecord(Data, long, long) - Constructor for class com.hazelcast.cache.impl.record.CacheDataRecord
 
CacheDataSerializerHook - Class in com.hazelcast.cache.impl
CacheDataSerializerHook contains all the ID hooks for IdentifiedDataSerializable classes used inside the JCache framework.
CacheDataSerializerHook() - Constructor for class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CacheDestroyOperation - Class in com.hazelcast.cache.impl.operation
Destroys the cache on the cluster or on a single node by calling AbstractCacheService.destroyCache(String, boolean, String).
CacheDestroyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CacheDestroyOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CacheDestroyOperation(String, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheDestroyOperation
 
CacheDestroyRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheDestroyOperation on the server side.
CacheDestroyRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheDestroyRequest
 
CacheDestroyRequest(String, int) - Constructor for class com.hazelcast.cache.impl.client.CacheDestroyRequest
 
CachedExecutorServiceDelegate - Class in com.hazelcast.util.executor
 
CachedExecutorServiceDelegate(NodeEngine, String, ExecutorService, int, int) - Constructor for class com.hazelcast.util.executor.CachedExecutorServiceDelegate
 
CacheDistributedObject - Class in com.hazelcast.cache.impl
Basic distributed object which serves as an accessor to CacheService and NodeEngine.
CacheDistributedObject(String, NodeEngine, ICacheService) - Constructor for class com.hazelcast.cache.impl.CacheDistributedObject
 
CacheEntry<K,V> - Class in com.hazelcast.cache.impl
Simple Cache.Entry implementation for wrapping a "key,value" pair.
CacheEntry(K, V) - Constructor for class com.hazelcast.cache.impl.CacheEntry
 
CacheEntryEventImpl<K,V> - Class in com.hazelcast.cache.impl
CacheEntryEvent implementation is the actual event object received by sub-interfaces of CacheEntryListener.
CacheEntryEventImpl(ICache<K, V>, EventType, K, V, V) - Constructor for class com.hazelcast.cache.impl.CacheEntryEventImpl
 
CacheEntryProcessorEntry<K,V,R extends CacheRecord> - Class in com.hazelcast.cache.impl
This class is an implementation of MutableEntry which is provided into EntryProcessor.process(javax.cache.processor.MutableEntry, Object...).
CacheEntryProcessorEntry(Data, R, AbstractCacheRecordStore, long, int) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
CacheEntryProcessorEntry.State - Enum in com.hazelcast.cache.impl
 
CacheEntryProcessorOperation - Class in com.hazelcast.cache.impl.operation
Operation of the Cache Entry Processor.
CacheEntryProcessorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
CacheEntryProcessorOperation(String, Data, int, EntryProcessor, Object...) - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
 
CacheEntryProcessorRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheEntryProcessorOperation on the server side.
CacheEntryProcessorRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
 
CacheEntryProcessorRequest(String, Data, EntryProcessor, InMemoryFormat, Object...) - Constructor for class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
 
CacheEntryProcessorResult<T> - Class in com.hazelcast.cache.impl
This simple implementation of EntryProcessorResult wraps the result returned or exception thrown in a single object so that multiple exceptions from multiple entry processes can be returned.
CacheEntryProcessorResult(T) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorResult
 
CacheEntryProcessorResult(Throwable) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorResult
 
CacheEnvironment - Class in com.hazelcast.hibernate
This class is used to help in setup the internal caches.
CacheEventData - Interface in com.hazelcast.cache.impl
Internal event data wrapper used during publishing and dispatching events.
CacheEventDataImpl - Class in com.hazelcast.cache.impl
Implementation of CacheEventData.
CacheEventDataImpl() - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
 
CacheEventDataImpl(String, CacheEventType, Data, Data, Data, boolean) - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
 
CacheEventListener - Interface in com.hazelcast.cache.impl
Cache Event Listener interface is designated for handling cache events internally such as delegating events to cache event listener.
CacheEventListenerAdaptor<K,V> - Class in com.hazelcast.cache.impl
This implementation of CacheEventListener uses the adapter pattern for wrapping all cache event listener types into a single listener.
CacheEventListenerAdaptor(ICache<K, V>, CacheEntryListenerConfiguration<K, V>, SerializationService) - Constructor for class com.hazelcast.cache.impl.CacheEventListenerAdaptor
 
CacheEventSet - Class in com.hazelcast.cache.impl
Internal Set wrapper of CacheEventData items used during publishing and dispatching events.
CacheEventSet() - Constructor for class com.hazelcast.cache.impl.CacheEventSet
 
CacheEventSet(CacheEventType, Set<CacheEventData>) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
 
CacheEventSet(CacheEventType, int) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
 
CacheEventType - Enum in com.hazelcast.cache.impl
Hazelcast JCache implementation's internal event types.
CacheEvictionConfig - Class in com.hazelcast.config
Configuration for cache's capacity.
CacheEvictionConfig() - Constructor for class com.hazelcast.config.CacheEvictionConfig
 
CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
 
CacheEvictionConfig(CacheEvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfig
 
CacheEvictionConfig.CacheMaxSizePolicy - Enum in com.hazelcast.config
Maximum Size Policy
CacheEvictionConfigReadOnly - Class in com.hazelcast.config
Contains the configuration for a size of cache.
CacheEvictionConfigReadOnly(CacheEvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfigReadOnly
 
CacheGetAllOperation - Class in com.hazelcast.cache.impl.operation
Gets all keys from the cache.
CacheGetAllOperation(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperation
 
CacheGetAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperation
 
CacheGetAllOperationFactory - Class in com.hazelcast.cache.impl.operation
Factory implementation for CacheGetAllOperation.
CacheGetAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
 
CacheGetAllOperationFactory(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
 
CacheGetAllRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheGetAllOperationFactory on the server side.
CacheGetAllRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAllRequest
 
CacheGetAllRequest(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAllRequest
 
CacheGetAndRemoveOperation - Class in com.hazelcast.cache.impl.operation
Cache GetAndRemove Operation.
CacheGetAndRemoveOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
 
CacheGetAndRemoveOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
 
CacheGetAndRemoveRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheGetAndRemoveOperation on the server side.
CacheGetAndRemoveRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
 
CacheGetAndRemoveRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
 
CacheGetAndReplaceOperation - Class in com.hazelcast.cache.impl.operation
Cache GetAndReplace Operation.
CacheGetAndReplaceOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
CacheGetAndReplaceOperation(String, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
 
CacheGetAndReplaceRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheGetAndReplaceOperation on the server side.
CacheGetAndReplaceRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
 
CacheGetAndReplaceRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
 
CacheGetConfigOperation - Class in com.hazelcast.cache.impl.operation
Cache GetConfig Operation.
CacheGetConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
CacheGetConfigOperation(String, String) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
 
CacheGetConfigRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheGetConfigOperation on the server side.
CacheGetConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetConfigRequest
 
CacheGetConfigRequest(String, String, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetConfigRequest
 
CacheGetOperation - Class in com.hazelcast.cache.impl.operation
Cache Get Operation.
CacheGetOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetOperation
 
CacheGetOperation(String, Data, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetOperation
 
CacheGetRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheGetOperation on the server side.
CacheGetRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetRequest
 
CacheGetRequest(String, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetRequest
 
CacheIterateRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheKeyIteratorOperation on the server side.
CacheIterateRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheIterateRequest
 
CacheIterateRequest(String, int, int, int, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheIterateRequest
 
cacheIterator() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
CacheKeyIteratorOperation - Class in com.hazelcast.cache.impl.operation
Provides iterator functionality for ICache.
CacheKeyIteratorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
 
CacheKeyIteratorOperation(String, int, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
 
CacheKeyIteratorResult - Class in com.hazelcast.cache.impl
Response data object returned by CacheKeyIteratorOperation.
CacheKeyIteratorResult() - Constructor for class com.hazelcast.cache.impl.CacheKeyIteratorResult
 
CacheKeyIteratorResult(List<Data>, int) - Constructor for class com.hazelcast.cache.impl.CacheKeyIteratorResult
 
CacheListenerRegistrationOperation - Class in com.hazelcast.cache.impl.operation
Listener can be registered and unregistered by CacheService.
CacheListenerRegistrationOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
 
CacheListenerRegistrationOperation(String, CacheEntryListenerConfiguration, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
 
CacheListenerRegistrationRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheListenerRegistrationOperation on the server side.
CacheListenerRegistrationRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
 
CacheListenerRegistrationRequest(String, CacheEntryListenerConfiguration, boolean, Address) - Constructor for class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
 
CacheLoadAllOperation - Class in com.hazelcast.cache.impl.operation
Loads all entries of the keys to partition record store ICacheRecordStore.
CacheLoadAllOperation(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
CacheLoadAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
 
CacheLoadAllOperationFactory - Class in com.hazelcast.cache.impl.operation
Factory implementation for CacheLoadAllOperation.
CacheLoadAllOperationFactory(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
 
CacheLoadAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
 
CacheLoadAllRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheLoadAllOperationFactory on the server side.
CacheLoadAllRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheLoadAllRequest
 
CacheLoadAllRequest(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.client.CacheLoadAllRequest
 
cacheLoader - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
CacheManagementConfigOperation - Class in com.hazelcast.cache.impl.operation
Cache ManagementConfig Operation provides enabling/disabling the functionality of management and statistics mxbeans of the cache.
CacheManagementConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
 
CacheManagementConfigOperation(String, boolean, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
 
CacheManagementConfigRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheManagementConfigOperation on the server side.
CacheManagementConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
 
CacheManagementConfigRequest(String, boolean, boolean, Address) - Constructor for class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
 
CacheMaxSizeChecker - Interface in com.hazelcast.cache.impl.maxsize
Interface for implementations of com.hazelcast.config.CacheMaxSizeConfig.CacheMaxSizePolicy.
CacheMXBeanImpl - Class in com.hazelcast.cache.impl
Implementation of CacheMXBean.
CacheMXBeanImpl(CacheConfig) - Constructor for class com.hazelcast.cache.impl.CacheMXBeanImpl
 
cacheNamePrefix - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
cacheNamePrefix() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
This method calculates a fixed string based on the URI and classloader using the formula:
CacheNotExistsException - Exception in com.hazelcast.cache
This exception class is thrown while creating CacheRecordStore instances but the cache config is not existing on the node to create the instance on.
CacheNotExistsException(String) - Constructor for exception com.hazelcast.cache.CacheNotExistsException
 
CacheObjectRecord - Class in com.hazelcast.cache.impl.record
Implementation of CacheRecord which has an internal object format.
CacheObjectRecord() - Constructor for class com.hazelcast.cache.impl.record.CacheObjectRecord
 
CacheObjectRecord(Object, long, long) - Constructor for class com.hazelcast.cache.impl.record.CacheObjectRecord
 
CacheOperationProvider - Interface in com.hazelcast.cache.impl
Provide InMemoryFormat specific operations for cache
CachePartitionSegment - Class in com.hazelcast.cache.impl
Cache Partition Segment
CachePortableHook - Class in com.hazelcast.cache.impl
CachePortableHook contains all the ID hooks for classes used inside the JCache framework which implement Portable.
CachePortableHook() - Constructor for class com.hazelcast.cache.impl.CachePortableHook
 
CacheProxy<K,V> - Class in com.hazelcast.cache.impl
ICache implementation
CacheProxy(CacheConfig, NodeEngine, ICacheService, HazelcastServerCacheManager) - Constructor for class com.hazelcast.cache.impl.CacheProxy
 
CacheProxyUtil - Class in com.hazelcast.cache.impl
Static util methods for ICache implementations.
CachePutAllBackupOperation - Class in com.hazelcast.cache.impl.operation
Cache PutAllBackup Operation is the backup operation used by load all operation.
CachePutAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
 
CachePutAllBackupOperation(String, Map<Data, CacheRecord>) - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
 
CachePutBackupOperation - Class in com.hazelcast.cache.impl.operation
Backup operation for the operation of adding cache entries into record stores.
CachePutBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
CachePutBackupOperation(String, Data, CacheRecord) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
 
CachePutIfAbsentOperation - Class in com.hazelcast.cache.impl.operation
Operation implementation for calling ICacheRecordStore.putIfAbsent(Data, Object, ExpiryPolicy, String, int).
CachePutIfAbsentOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
CachePutIfAbsentOperation(String, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
 
CachePutIfAbsentRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CachePutIfAbsentOperation on the server side.
CachePutIfAbsentRequest() - Constructor for class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
 
CachePutIfAbsentRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
 
CachePutOperation - Class in com.hazelcast.cache.impl.operation
Operation implementation for com.hazelcast.cache.impl.ICacheRecordStore#put(Data, Object, ExpiryPolicy, String) and com.hazelcast.cache.impl.ICacheRecordStore#getAndPut(Data, Object, ExpiryPolicy, String).
CachePutOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
 
CachePutOperation(String, Data, Data, ExpiryPolicy, boolean, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
 
CachePutRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CachePutOperation on the server side.
CachePutRequest() - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
 
CachePutRequest(String, Data, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
 
CachePutRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
 
CachePutRequest(String, Data, Data, ExpiryPolicy, boolean, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
 
CacheRecord<V> - Interface in com.hazelcast.cache.impl.record
An expirable and evictable data object which represents a cache entry.
cacheRecordFactory - Variable in class com.hazelcast.cache.impl.CacheRecordStore
 
CacheRecordFactory<R extends CacheRecord> - Class in com.hazelcast.cache.impl.record
Provides factory for CacheRecord.
CacheRecordFactory(InMemoryFormat, SerializationService) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordFactory
 
CacheRecordHashMap - Class in com.hazelcast.cache.impl.record
 
CacheRecordHashMap(int) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
CacheRecordHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
 
CacheRecordHashMap.EvictableSamplingEntry - Class in com.hazelcast.cache.impl.record
 
CacheRecordHashMap.EvictableSamplingEntry(Data, CacheRecord) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap.EvictableSamplingEntry
 
CacheRecordMap<K extends Data,V extends CacheRecord> - Interface in com.hazelcast.cache.impl.record
 
cacheRecordStore - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
CacheRecordStore - Class in com.hazelcast.cache.impl
On-Heap implementation of the ICacheRecordStore
CacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.CacheRecordStore
 
CacheRemoveAllBackupOperation - Class in com.hazelcast.cache.impl.operation
Backup operation of CacheRemoveAllOperation.
CacheRemoveAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
CacheRemoveAllBackupOperation(String, Set<Data>) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
 
CacheRemoveAllOperation - Class in com.hazelcast.cache.impl.operation
TODO add a proper JavaDoc
CacheRemoveAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
CacheRemoveAllOperation(String, Set<Data>, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
 
CacheRemoveAllOperationFactory - Class in com.hazelcast.cache.impl.operation
OperationFactory implementation for RemoveAll Operations.
CacheRemoveAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
 
CacheRemoveAllOperationFactory(String, Set<Data>, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
 
CacheRemoveBackupOperation - Class in com.hazelcast.cache.impl.operation
Backup operation used by remove operations.
CacheRemoveBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
CacheRemoveBackupOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
 
CacheRemoveEntryListenerRequest - Class in com.hazelcast.cache.impl.client
Client request which unregisters the event listener on behalf of the client.
CacheRemoveEntryListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
 
CacheRemoveEntryListenerRequest(String, String) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
 
CacheRemoveOperation - Class in com.hazelcast.cache.impl.operation
Operation implementation for cache remove functionality.
CacheRemoveOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
CacheRemoveOperation(String, Data, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveOperation
 
CacheRemoveRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheRemoveOperation on the server side.
CacheRemoveRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
 
CacheRemoveRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
 
CacheRemoveRequest(String, Data, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
 
CacheReplaceOperation - Class in com.hazelcast.cache.impl.operation
Operator implementation for cache replace functionality.
CacheReplaceOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
CacheReplaceOperation(String, Data, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheReplaceOperation
 
CacheReplaceRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheReplaceOperation on the server side.
CacheReplaceRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
 
CacheReplaceRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
 
CacheReplaceRequest(String, Data, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
 
CacheReplicationOperation - Class in com.hazelcast.cache.impl.operation
Replication operation is the data migration operation of CacheRecordStore.
CacheReplicationOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
CacheReplicationOperation(CachePartitionSegment, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
caches - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
cacheService - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
CacheService - Class in com.hazelcast.cache.impl
Cache Service is the main access point of JCache implementation.
CacheService() - Constructor for class com.hazelcast.cache.impl.CacheService
 
CacheSimpleConfig - Class in com.hazelcast.config
Simple configuration to hold parsed xml configuration.
CacheSimpleConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig
 
CacheSimpleConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig
 
CacheSimpleConfigReadOnly - Class in com.hazelcast.config
Readonly version of CacheSimpleConfig
CacheSimpleConfigReadOnly(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfigReadOnly
 
CacheSimpleEntryListenerConfig - Class in com.hazelcast.config
Simple configuration to hold parsed listener config
CacheSimpleEntryListenerConfig(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
CacheSimpleEntryListenerConfig() - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
 
CacheSimpleEntryListenerConfigReadOnly - Class in com.hazelcast.config
Readonly version of CacheSimpleEntryListenerConfig
CacheSimpleEntryListenerConfigReadOnly(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
 
CacheSizeOperation - Class in com.hazelcast.cache.impl.operation
This operation implementation is for calculating the cluster size of a named cache.
CacheSizeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperation
 
CacheSizeOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperation
 
CacheSizeOperationFactory - Class in com.hazelcast.cache.impl.operation
Factory implementation of CacheSizeOperation.
CacheSizeOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
 
CacheSizeOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
 
CacheSizeRequest - Class in com.hazelcast.cache.impl.client
This client request specifically calls CacheSizeOperationFactory on the server side.
CacheSizeRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheSizeRequest
 
CacheSizeRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheSizeRequest
 
CacheStatistics - Interface in com.hazelcast.cache
Cache statistics
cacheStatisticsConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
CacheStatisticsImpl - Class in com.hazelcast.cache.impl
CacheStatistics implementation for ICache.
CacheStatisticsImpl() - Constructor for class com.hazelcast.cache.impl.CacheStatisticsImpl
 
CacheStatisticsMXBeanImpl - Class in com.hazelcast.cache.impl
Implementation of CacheStatisticsMXBean
CacheStatisticsMXBeanImpl(CacheStatisticsImpl) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
CacheSyncListenerCompleter - Interface in com.hazelcast.cache.impl
used to state that a sync event completed and any resources waiting for it should be released
cacheWriter - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
cachingProvider - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
calculateMaxPartitionSize(int, int) - Static method in class com.hazelcast.cache.impl.maxsize.impl.EntryCountCacheMaxSizeChecker
 
calculateObjectName(String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
Creates an object name using the scheme.
calculatePartitionHash(Object, PartitioningStrategy) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
calculateRFC2104HMAC(String, String) - Static method in class com.hazelcast.aws.security.RFC2104HMAC
 
call() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
 
call() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
 
call() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
 
call() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
 
call() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
 
call() - Method in class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
 
call() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
 
call() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
 
call() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
 
call() - Method in class com.hazelcast.cluster.client.ClientPingRequest
 
call() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
 
call() - Method in class com.hazelcast.collection.client.CollectionRemoveListenerRequest
 
call() - Method in class com.hazelcast.console.Echo
 
call() - Method in class com.hazelcast.console.SimulateLoadTask
 
call() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
 
call() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
 
call() - Method in class com.hazelcast.executor.impl.RunnableAdapter
 
call() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
 
call() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
 
call() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
 
call() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
 
call() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
 
call() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
 
call() - Method in class com.hazelcast.queue.impl.client.RemoveListenerRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
 
call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
 
call() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
 
call() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
 
call() - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
 
call() - Method in class com.hazelcast.transaction.client.RecoverTransactionRequest
 
CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
 
CallableClientRequest - Class in com.hazelcast.client.impl.client
 
CallableClientRequest() - Constructor for class com.hazelcast.client.impl.client.CallableClientRequest
 
CallableTaskOperation - Class in com.hazelcast.executor.impl.operations
 
CallableTaskOperation() - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
 
CallableTaskOperation(String, String, Data) - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
 
callAfterStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
 
Callback<T> - Interface in com.hazelcast.spi
A callback interface; make it possible to receive a callback.
callback - Variable in class com.hazelcast.spi.InvocationBuilder
 
callBeforeStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
 
CallerNotMemberException - Exception in com.hazelcast.spi.exception
A RetryableHazelcastException that indicates that a request was send to a machine which isn't member in the cluster.
CallerNotMemberException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
 
callId - Variable in class com.hazelcast.client.impl.client.ClientRequest
 
callId - Variable in class com.hazelcast.spi.impl.Response
 
callOnAddress(Address, Operation) - Method in class com.hazelcast.management.ManagementCenterService
 
callOnMember(Member, Operation) - Method in class com.hazelcast.management.ManagementCenterService
 
callOnThis(Operation) - Method in class com.hazelcast.management.ManagementCenterService
 
callTimeout - Variable in class com.hazelcast.spi.InvocationBuilder
 
CallTimeoutResponse - Class in com.hazelcast.spi.impl
An response that indicates that the execution of a single call ran into a timeout.
CallTimeoutResponse() - Constructor for class com.hazelcast.spi.impl.CallTimeoutResponse
 
CallTimeoutResponse(long, boolean) - Constructor for class com.hazelcast.spi.impl.CallTimeoutResponse
 
canAcquireLock(Data, String, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
 
canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
 
canAcquireLock(Data, String, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
 
canAcquireLock(Data, String, long) - Method in interface com.hazelcast.map.impl.RecordStore
 
canAcquireLock(Data, String, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
cancel(boolean) - Method in class com.hazelcast.client.spi.impl.ClientCallFuture
 
cancel(boolean) - Method in class com.hazelcast.client.util.ClientCancellableDelegatingFuture
 
cancel(String, boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
 
cancel() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
 
cancel() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
 
cancel() - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
 
cancel() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
 
cancel(boolean) - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
 
cancel(boolean) - Method in class com.hazelcast.util.executor.CompletedFuture
 
cancel(boolean) - Method in class com.hazelcast.util.executor.DelegatingFuture
 
cancel(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
 
CANCEL_JOB_SUPERVISOR_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
 
cancelAll() - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
 
cancelAndNotify(Exception) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
 
cancelEviction(ObjectNamespace, Data) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
cancelEviction(String) - Method in class com.hazelcast.queue.impl.QueueService
 
cancelEvictionIfExists() - Method in class com.hazelcast.queue.impl.QueueContainer
 
cancelExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
 
CancelJobSupervisorOperation - Class in com.hazelcast.mapreduce.impl.operation
This operation is fired by the jobs owner node to remotely cancel the defined jobId on all nodes.
CancelJobSupervisorOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
 
CancelJobSupervisorOperation(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
 
CANCELLATION_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
 
CancellationOperation - Class in com.hazelcast.executor.impl.operations
 
CancellationOperation() - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
 
CancellationOperation(String, boolean) - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
 
CancellationRequest - Class in com.hazelcast.executor.impl.client
 
CancellationRequest() - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
 
CancellationRequest(String, Address, boolean) - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
 
CancellationRequest(String, int, boolean) - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
 
cancelPartitionState() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
 
canTransformResource(String) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
 
capacity() - Method in class com.hazelcast.nio.DynamicByteBuffer
 
cd - Variable in class com.hazelcast.nio.serialization.DefaultPortableReader
 
CDL_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
CDL_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
changeSessionId() - Method in class com.hazelcast.web.WebFilter.RequestWrapper
 
CHAR_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
 
CHAR_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
 
CHAR_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
Char size in bytes
check(Node, String, boolean) - Method in class com.hazelcast.util.VersionCheck
 
CHECK_EVICT - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
 
CheckAndEvictOperation - Class in com.hazelcast.queue.impl.operations
Provides eviction functionality for Operations of Queue.
CheckAndEvictOperation() - Constructor for class com.hazelcast.queue.impl.operations.CheckAndEvictOperation
 
CheckAndEvictOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.CheckAndEvictOperation
 
checkAssignedMembersAvailable(Collection<Address>) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
 
checkAssignedMembersAvailable() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
 
checkAuthorization(String, String, Address) - Method in class com.hazelcast.wan.impl.WanNoDelayReplication
 
checkClassDefErrors - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
checkEvictable(MapContainer, int) - Method in class com.hazelcast.map.impl.eviction.MaxSizeChecker
 
checkFullyProcessed(JobProcessInformation) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
 
checkIfLoaded() - Method in class com.hazelcast.map.impl.DefaultRecordStore
 
checkIfLoaded() - Method in interface com.hazelcast.map.impl.RecordStore
 
checkIfManagerNotClosed() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
checkJoinInfo(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
 
checkNotNull(Object, String) - Static method in class com.hazelcast.util.ValidationUtil
 
checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
Checks whether current Subject has been granted specified permission or not.
CheckReplicaVersion - Class in com.hazelcast.partition.impl
 
CheckReplicaVersion() - Constructor for class com.hazelcast.partition.impl.CheckReplicaVersion
 
CheckReplicaVersion(long, boolean) - Constructor for class com.hazelcast.partition.impl.CheckReplicaVersion
 
checkTransactionState() - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
 
checkTransactionState() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
checkTransactionState() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
 
checkTransactionState() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
 
checkTrue(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
chunkSize - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
 
chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
 
chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
 
chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
 
chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
 
chunkSize - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
 
chunkSize(int) - Method in interface com.hazelcast.mapreduce.Job
Defines the number of elements per chunk.
chunkSize(int) - Method in interface com.hazelcast.mapreduce.MappingJob
Defines the number of elements per chunk.
chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingJob
Defines the number of elements per chunk.
chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Defines the number of elements per chunk.
CipherHelper - Class in com.hazelcast.nio
 
ClassDefinition - Interface in com.hazelcast.nio.serialization
ClassDefinition defines a class schema for Portable classes.
ClassDefinitionBuilder - Class in com.hazelcast.nio.serialization
ClassDefinitionBuilder is used to build and register ClassDefinitions manually.
ClassDefinitionBuilder(int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
ClassDefinitionBuilder(int, int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
classDefinitions - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
ClassDefinitionSerializer - Class in com.hazelcast.nio.serialization
Serializes/De-serializes ClassDefinitions to/from buffer and streams.
ClassDefinitionSerializer(Data, PortableContext) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionSerializer
 
classLoader - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
classLoader - Variable in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
 
classLoaderReference - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
ClassLoaderUtil - Class in com.hazelcast.nio
Utility class to deal with classloaders.
className - Variable in class com.hazelcast.config.ListenerConfig
 
className - Variable in class com.hazelcast.config.SecurityInterceptorConfig
 
ClasspathXmlConfig - Class in com.hazelcast.config
A Config which is initialized by loading an XML configuration file from the classpath.
ClasspathXmlConfig(String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread contextClassLoader.
ClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
Creates a config which is loaded from a classpath resource using the Thread.currentThread contextClassLoader.
ClasspathXmlConfig(ClassLoader, String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
Creates a config which is loaded from a classpath resource.
ClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
Creates a config which is loaded from a classpath resource.
CleanerRegistrator - Interface in com.hazelcast.replicatedmap.impl
This interface is used to give ReplicatedRecordStore implementations a chance to register themself to being cleaned up from expired entries
cleanNodeName(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
cleanNodeName(String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
cleanup() - Method in class com.hazelcast.jca.ManagedConnectionImpl
 
cleanup() - Method in class com.hazelcast.spi.impl.BasicBackPressureService
Cleans up all sync delay administration for dead connections.
cleanupService - Variable in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
CleanupService - Class in com.hazelcast.hibernate.local
An internal service to clean cache regions
CleanupService(String) - Constructor for class com.hazelcast.hibernate.local.CleanupService
 
clear() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
CLEAR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
clear() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
 
CLEAR - Static variable in class com.hazelcast.cache.impl.CachePortableHook
 
clear() - Method in class com.hazelcast.cache.impl.CacheProxy
 
clear() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
Implementation of CacheStatisticsMXBean.clear().
clear() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
 
clear() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
clears all internal data without publishing any events
clear() - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
clear() - Method in interface com.hazelcast.client.ClientEndpointManager
Removes all endpoints.
clear() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
clear() - Method in class com.hazelcast.client.nearcache.ClientHeapNearCache
 
clear() - Method in interface com.hazelcast.client.nearcache.ClientNearCache
 
clear() - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
 
clear() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
clear() - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
clear() - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
clear() - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
clear() - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
clear() - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
 
clear() - Method in class com.hazelcast.collection.CollectionContainer
 
clear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
clear() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
 
clear() - Method in class com.hazelcast.config.InterfacesConfig
clears all interfaces.
clear() - Method in class com.hazelcast.config.MemberGroupConfig
Removes all interfaces from the member group.
clear() - Method in class com.hazelcast.config.PartitionGroupConfig
Removes all the PartitionGroupConfig.MemberGroupType instances.
clear() - Method in class com.hazelcast.config.ServicesConfig
 
clear() - Method in class com.hazelcast.config.TcpIpConfig
Removes all members.
clear() - Method in interface com.hazelcast.core.IAtomicReference
Clears the current stored reference.
clear() - Method in interface com.hazelcast.core.IMap
This method clears the map and invokes MapStore.deleteAll(java.util.Collection)deleteAll on MapStore which, if connected to a database, will delete the records from that database.
clear() - Method in interface com.hazelcast.core.MultiMap
Clears the multimap.
clear() - Method in interface com.hazelcast.core.ReplicatedMap
The clear operation is used for wiping data out of the replicated maps.
clear() - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
 
clear() - Method in class com.hazelcast.hibernate.local.LocalRegionCache
 
clear() - Method in interface com.hazelcast.hibernate.RegionCache
 
clear() - Method in class com.hazelcast.jmx.ListMBean
 
clear() - Method in class com.hazelcast.jmx.LockMBean
 
clear() - Method in class com.hazelcast.jmx.MapMBean
 
clear() - Method in class com.hazelcast.jmx.MultiMapMBean
 
clear() - Method in class com.hazelcast.jmx.QueueMBean
 
clear() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
 
clear() - Method in class com.hazelcast.jmx.SetMBean
 
clear() - Method in class com.hazelcast.map.impl.DefaultRecordStore
 
CLEAR - Static variable in class com.hazelcast.map.impl.MapPortableHook
 
clear() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
Clears resources of this map-data-store.
clear() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
 
clear() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
 
clear() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
 
clear() - Method in class com.hazelcast.map.impl.NearCache
 
clear() - Method in class com.hazelcast.map.impl.NearCacheProvider
 
clear() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
This method clears the map and deletaAll on MapStore which if connected to a database, will delete the records from that database.
clear() - Method in interface com.hazelcast.map.impl.RecordStore
 
clear() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
 
clear() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
clear() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
 
clear() - Method in class com.hazelcast.nio.DynamicByteBuffer
 
clear() - Method in interface com.hazelcast.query.impl.Index
 
clear() - Method in class com.hazelcast.query.impl.IndexImpl
 
clear() - Method in interface com.hazelcast.query.impl.IndexStore
 
clear() - Method in class com.hazelcast.query.impl.SortedIndexStore
 
clear() - Method in class com.hazelcast.query.impl.UnsortedIndexStore
 
clear() - Method in class com.hazelcast.queue.impl.QueueContainer
 
CLEAR - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
 
CLEAR - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
 
CLEAR - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
clear(boolean, boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
clear(boolean, boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
clear() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
clear() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Removes all of the mappings from this map.
CLEAR_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CLEAR_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
CLEAR_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
 
CLEAR_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CLEAR_RESPONSE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
clearAllListeners() - Method in interface com.hazelcast.client.ClientEndpoint
 
clearAllListeners() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
 
clearBackup(Set<Long>) - Method in class com.hazelcast.collection.CollectionContainer
 
clearBackup(Set<Long>) - Method in class com.hazelcast.queue.impl.QueueContainer
 
ClearBackupOperation - Class in com.hazelcast.map.impl.operation
 
ClearBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearBackupOperation
 
ClearBackupOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearBackupOperation
 
ClearBackupOperation - Class in com.hazelcast.multimap.impl.operations
 
ClearBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearBackupOperation
 
ClearBackupOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearBackupOperation
 
ClearBackupOperation - Class in com.hazelcast.queue.impl.operations
Store items' id as set when ClearOperation run.
ClearBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.ClearBackupOperation
 
ClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.queue.impl.operations.ClearBackupOperation
 
clearBit(byte, int) - Static method in class com.hazelcast.nio.Bits
Clears n-th bit of the byte value
clearBit(int, int) - Static method in class com.hazelcast.nio.Bits
Clears n-th bit of the integer value
clearClients() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
ClearExpiredOperation - Class in com.hazelcast.map.impl.operation
Clear expired records.
ClearExpiredOperation(int) - Constructor for class com.hazelcast.map.impl.operation.ClearExpiredOperation
 
clearLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
 
clearLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
clearMapOnly() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
This method clears the map.It does not invoke deleteAll on any associated MapStore.
clearNearCache(String) - Method in class com.hazelcast.map.impl.NearCacheProvider
 
ClearOperation - Class in com.hazelcast.map.impl.operation
 
ClearOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
 
ClearOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
 
ClearOperation - Class in com.hazelcast.multimap.impl.operations
 
ClearOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
 
ClearOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
 
ClearOperation - Class in com.hazelcast.queue.impl.operations
Clears items stored by Queue.
ClearOperation() - Constructor for class com.hazelcast.queue.impl.operations.ClearOperation
 
ClearOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.ClearOperation
 
ClearOperationFactory - Class in com.hazelcast.map.impl.operation
 
ClearOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
 
ClearOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
 
clearPartition() - Method in class com.hazelcast.map.impl.DefaultRecordStore
 
clearPartition() - Method in interface com.hazelcast.map.impl.RecordStore
 
clearPartitionData(int) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
 
clearPartitionData(int) - Method in interface com.hazelcast.map.impl.MapServiceContext
 
clearPartitionReplica(int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
clearPartitionReplica(int) - Method in class com.hazelcast.collection.CollectionService
 
clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
clearPartitionReplica(int) - Method in class com.hazelcast.map.impl.MapService
 
clearPartitionReplica(int) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
clearPartitionReplica(int) - Method in class com.hazelcast.queue.impl.QueueService
 
clearPartitionReplica(int) - Method in interface com.hazelcast.spi.MigrationAwareService
 
clearPartitionReplicaVersions(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
 
clearPartitionReplicaVersions(int) - Method in interface com.hazelcast.partition.InternalPartitionService
 
clearPartitions() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
 
clearPartitions() - Method in interface com.hazelcast.map.impl.MapServiceContext
 
ClearRequest - Class in com.hazelcast.multimap.impl.client
 
ClearRequest() - Constructor for class com.hazelcast.multimap.impl.client.ClearRequest
 
ClearRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.ClearRequest
 
ClearRequest - Class in com.hazelcast.queue.impl.client
Provides the request service for ClearOperation
ClearRequest() - Constructor for class com.hazelcast.queue.impl.client.ClearRequest
 
ClearRequest(String) - Constructor for class com.hazelcast.queue.impl.client.ClearRequest
 
clearServers() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
 
client - Variable in class com.hazelcast.client.impl.DefaultClientExtension
 
client - Variable in class com.hazelcast.client.impl.HazelcastClientProxy
 
Client - Interface in com.hazelcast.core
The Client interface allows to get information about a connected client's socket address, type and uuid.
CLIENT_BINARY - Static variable in class com.hazelcast.nio.Protocols
Protocol that is used for clients(java, c++ , c# client)
CLIENT_CANCELLATION_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
 
CLIENT_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
CLIENT_ENGINE_THREAD_COUNT - Variable in class com.hazelcast.instance.GroupProperties
 
CLIENT_ERROR - Static variable in class com.hazelcast.ascii.TextCommandConstants
 
CLIENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
Name of the client executor.
CLIENT_HEARTBEAT_TIMEOUT_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
 
CLIENT_JOB_PROCESS_INFO_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
 
CLIENT_MAP_REDUCE_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
 
CLIENT_PING - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
 
CLIENT_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
CLIENT_RESPONSE - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
ClientResponse Class ID
CLIENT_TXN_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
ClientAtomicLongProxy - Class in com.hazelcast.client.proxy
 
ClientAtomicLongProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
ClientAtomicReferenceProxy<E> - Class in com.hazelcast.client.proxy
 
ClientAtomicReferenceProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
ClientAwareService - Interface in com.hazelcast.spi
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
ClientAwsConfig - Class in com.hazelcast.client.config
The AWSConfig contains the configuration for client to connect to nodes in aws environment.
ClientAwsConfig() - Constructor for class com.hazelcast.client.config.ClientAwsConfig
 
ClientCacheDistributedObject - Class in com.hazelcast.client.cache.impl
Basic client proxy object which serves as an accessor to ClientContext.
ClientCacheDistributedObject(String, String) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheDistributedObject
 
ClientCacheProxy<K,V> - Class in com.hazelcast.client.cache.impl
ICache implementation for client

This proxy is the implementation of ICache and javax.cache.Cache which is returned by HazelcastClientCacheManager.

ClientCacheProxy(CacheConfig<K, V>, ClientContext, HazelcastClientCacheManager) - Constructor for class com.hazelcast.client.cache.impl.ClientCacheProxy
 
ClientCallFuture<V> - Class in com.hazelcast.client.spi.impl
 
ClientCallFuture(HazelcastClientInstanceImpl, ClientRequest, EventHandler) - Constructor for class com.hazelcast.client.spi.impl.ClientCallFuture
 
ClientCancellableDelegatingFuture<V> - Class in com.hazelcast.client.util
A DelegatingFuture that can cancel a Runnable/Callable that is executed by an IExecutorService.
ClientCancellableDelegatingFuture(ICompletableFuture, ClientContext, String, Address, int) - Constructor for class com.hazelcast.client.util.ClientCancellableDelegatingFuture
 
ClientCancellableDelegatingFuture(ICompletableFuture, ClientContext, String, Address, int, V) - Constructor for class com.hazelcast.client.util.ClientCancellableDelegatingFuture
 
ClientCancellationRequest - Class in com.hazelcast.mapreduce.impl.client
This class is used to request a map reduce job cancellation on the job owning node from the emitting client.
ClientCancellationRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
 
ClientCancellationRequest(String, String) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
 
ClientClusterProxy - Class in com.hazelcast.client.proxy
Client implementation of the Cluster.
ClientClusterProxy(ClientClusterServiceImpl) - Constructor for class com.hazelcast.client.proxy.ClientClusterProxy
 
ClientClusterService - Interface in com.hazelcast.client.spi
 
ClientClusterServiceImpl - Class in com.hazelcast.client.spi.impl
The ClientClusterService implementation.
ClientClusterServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.ClientClusterServiceImpl
 
ClientClusterWideIterator<K,V> - Class in com.hazelcast.client.cache.impl
Client side cluster-wide iterator for ICache.
ClientClusterWideIterator(ClientCacheProxy<K, V>, ClientContext) - Constructor for class com.hazelcast.client.cache.impl.ClientClusterWideIterator
 
ClientConditionProxy - Class in com.hazelcast.client.proxy
 
ClientConditionProxy(ClientLockProxy, String, ClientContext) - Constructor for class com.hazelcast.client.proxy.ClientConditionProxy
 
ClientConfig - Class in com.hazelcast.client.config
Main configuration to setup a Hazelcast Client
ClientConfig() - Constructor for class com.hazelcast.client.config.ClientConfig
 
clientConnected(Client) - Method in interface com.hazelcast.core.ClientListener
Invoked when a new client is connected.
ClientConnection - Class in com.hazelcast.client.connection.nio
 
ClientConnection(ClientConnectionManager, IOSelector, IOSelector, int, SocketChannelWrapper, ClientExecutionService, ClientInvocationServiceImpl, SerializationService) - Constructor for class com.hazelcast.client.connection.nio.ClientConnection
 
ClientConnectionManager - Interface in com.hazelcast.client.connection
Responsible for managing ClientConnection objects.
ClientConnectionManagerImpl - Class in com.hazelcast.client.connection.nio
 
ClientConnectionManagerImpl(HazelcastClientInstanceImpl, LoadBalancer, AddressTranslator) - Constructor for class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
 
ClientConnectionManagerImpl.ManagerAuthenticator - Class in com.hazelcast.client.connection.nio
 
ClientConnectionManagerImpl.ManagerAuthenticator() - Constructor for class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl.ManagerAuthenticator
 
ClientConsoleApp - Class in com.hazelcast.client.console
A demo application to demonstrate a Hazelcast client.
ClientConsoleApp(HazelcastInstance) - Constructor for class com.hazelcast.client.console.ClientConsoleApp
 
ClientContext - Class in com.hazelcast.client.spi
 
ClientCountDownLatchProxy - Class in com.hazelcast.client.proxy
 
ClientCountDownLatchProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientCountDownLatchProxy
 
ClientCreateRequest - Class in com.hazelcast.client.impl.client
 
ClientCreateRequest() - Constructor for class com.hazelcast.client.impl.client.ClientCreateRequest
 
ClientCreateRequest(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientCreateRequest
 
ClientDataSerializerHook - Class in com.hazelcast.client.impl
Client DataSerializable Factory ID
ClientDataSerializerHook() - Constructor for class com.hazelcast.client.impl.ClientDataSerializerHook
 
ClientDestroyRequest - Class in com.hazelcast.client.impl.client
 
ClientDestroyRequest() - Constructor for class com.hazelcast.client.impl.client.ClientDestroyRequest
 
ClientDestroyRequest(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientDestroyRequest
 
clientDisconnected(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
clientDisconnected(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
clientDisconnected(Client) - Method in interface com.hazelcast.core.ClientListener
Invoked when a new client is disconnected.
clientDisconnected(String) - Method in interface com.hazelcast.spi.ClientAwareService
Invoked when a client disconnected from a member.
clientDisconnected(String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
 
ClientDisconnectionOperation - Class in com.hazelcast.client.impl.operations
 
ClientDisconnectionOperation() - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
 
ClientDisconnectionOperation(String) - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
 
ClientEndpoint - Interface in com.hazelcast.client
Represents an endpoint to a client.
ClientEndpointImpl - Class in com.hazelcast.client.impl
The ClientEndpoint and Client implementation.
ClientEndpointManager - Interface in com.hazelcast.client
A manager for ClientEndpoints.
ClientEndpointManagerImpl - Class in com.hazelcast.client.impl
Manages and stores ClientEndpointImpls.
ClientEndpointManagerImpl(ClientEngineImpl, NodeEngine) - Constructor for class com.hazelcast.client.impl.ClientEndpointManagerImpl
 
ClientEngine - Interface in com.hazelcast.client
The client Engine.
clientEngine - Variable in class com.hazelcast.client.impl.client.ClientRequest
 
clientEngine - Variable in class com.hazelcast.instance.Node
 
ClientEngineImpl - Class in com.hazelcast.client.impl
Class that requests, listeners from client handled in node side.
ClientEngineImpl(Node) - Constructor for class com.hazelcast.client.impl.ClientEngineImpl
 
ClientEngineMBean - Class in com.hazelcast.jmx
Management bean for ClientEngine
ClientEngineMBean(HazelcastInstance, ClientEngine, ManagementService) - Constructor for class com.hazelcast.jmx.ClientEngineMBean
 
ClientExceptionConverter - Interface in com.hazelcast.client.impl.exceptionconverters
The ClientExceptionConverter is responsible for converting a Java Throwable to something a client can understand.
ClientExceptionConverters - Class in com.hazelcast.client.impl.exceptionconverters
A utility class for getting the correct converter based on the client type.
ClientExecutionService - Interface in com.hazelcast.client.spi
 
ClientExecutionServiceImpl - Class in com.hazelcast.client.spi.impl
 
ClientExecutionServiceImpl(String, ThreadGroup, ClassLoader, int) - Constructor for class com.hazelcast.client.spi.impl.ClientExecutionServiceImpl
 
ClientExecutorServiceProxy - Class in com.hazelcast.client.proxy
 
ClientExecutorServiceProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientExecutorServiceProxy
 
ClientExtension - Interface in com.hazelcast.client
ClientExtension is a client extension mechanism to be able to plug different implementations of some modules, like; SerializationService, SocketChannelWrapperFactory etc.
ClientHeapNearCache<K> - Class in com.hazelcast.client.nearcache
Implementation of the ClientNearCache.
ClientHeapNearCache(String, ClientContext, NearCacheConfig) - Constructor for class com.hazelcast.client.nearcache.ClientHeapNearCache
 
ClientHeartbeatMonitor - Class in com.hazelcast.client.impl
Monitors client heartbeats..
ClientHeartbeatMonitor(ClientEndpointManagerImpl, ClientEngine, ExecutionService, GroupProperties) - Constructor for class com.hazelcast.client.impl.ClientHeartbeatMonitor
 
ClientIdGeneratorProxy - Class in com.hazelcast.client.proxy
 
ClientIdGeneratorProxy(String, String, IAtomicLong) - Constructor for class com.hazelcast.client.proxy.ClientIdGeneratorProxy
 
ClientImpl - Class in com.hazelcast.client.impl
Default Client implementation.
ClientImpl(String, InetSocketAddress) - Constructor for class com.hazelcast.client.impl.ClientImpl
 
ClientInvocationService - Interface in com.hazelcast.client.spi
 
ClientInvocationServiceImpl - Class in com.hazelcast.client.spi.impl
 
ClientInvocationServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.ClientInvocationServiceImpl
 
ClientJobProcessInformationRequest - Class in com.hazelcast.mapreduce.impl.client
This class is used to retrieve current processed records and other statistics from emitting client to the job owning node.
ClientJobProcessInformationRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
 
ClientJobProcessInformationRequest(String, String) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
 
ClientListener - Interface in com.hazelcast.core
The ClientListener provides the ability to listen to clients connecting and disconnecting from the cluster.
ClientListenerService - Interface in com.hazelcast.client.spi
Client service to add/remove remote listeners.
ClientListenerServiceImpl - Class in com.hazelcast.client.spi.impl
 
ClientListenerServiceImpl(HazelcastClientInstanceImpl, int, int) - Constructor for class com.hazelcast.client.spi.impl.ClientListenerServiceImpl
 
ClientListProxy<E> - Class in com.hazelcast.client.proxy
 
ClientListProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientListProxy
 
ClientLockProxy - Class in com.hazelcast.client.proxy
 
ClientLockProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientLockProxy
 
ClientMapProxy<K,V> - Class in com.hazelcast.client.proxy
 
ClientMapProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientMapProxy
 
ClientMapReduceProxy - Class in com.hazelcast.client.proxy
 
ClientMapReduceProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientMapReduceProxy
 
ClientMapReduceRequest<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl.client
This class is used to prepare and start a map reduce job emitted by a client on a random node in the cluster (making it the job owner).
ClientMapReduceRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
 
ClientMapReduceRequest(String, String, Collection, KeyPredicate, Mapper, CombinerFactory, ReducerFactory, KeyValueSource, int, TopologyChangedStrategy) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
 
ClientMembershipEvent - Class in com.hazelcast.cluster.client
 
ClientMembershipEvent() - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
 
ClientMembershipEvent(Member, int) - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
 
ClientMembershipEvent(Member, MemberAttributeChange) - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
 
ClientMultiMapProxy<K,V> - Class in com.hazelcast.client.proxy
 
ClientMultiMapProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientMultiMapProxy
 
ClientNearCache<K,V> - Interface in com.hazelcast.client.nearcache
ClientNearCache
ClientNearCacheType - Enum in com.hazelcast.client.nearcache
Legal near cache types
ClientNetworkConfig - Class in com.hazelcast.client.config
Contains configuration parameters for client network related behaviour
ClientNetworkConfig() - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
 
ClientOutOfMemoryHandler - Class in com.hazelcast.client
To clear resources of the client upon OutOfMemory
ClientOutOfMemoryHandler() - Constructor for class com.hazelcast.client.ClientOutOfMemoryHandler
 
ClientPartitionService - Interface in com.hazelcast.client.spi
 
ClientPartitionServiceImpl - Class in com.hazelcast.client.spi.impl
The ClientPartitionService implementation.
ClientPartitionServiceImpl(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.spi.impl.ClientPartitionServiceImpl
 
ClientPingRequest - Class in com.hazelcast.cluster.client
 
ClientPingRequest() - Constructor for class com.hazelcast.cluster.client.ClientPingRequest
 
ClientPortableFactory - Class in com.hazelcast.client.impl.client
Factory class for central client request
ClientPortableFactory() - Constructor for class com.hazelcast.client.impl.client.ClientPortableFactory
 
ClientPortableHook - Class in com.hazelcast.client.impl.client
Portable that creates a lot of the client related Portable instances.
ClientPortableHook() - Constructor for class com.hazelcast.client.impl.client.ClientPortableHook
 
ClientPrincipal - Class in com.hazelcast.client.impl.client
 
ClientPrincipal() - Constructor for class com.hazelcast.client.impl.client.ClientPrincipal
 
ClientPrincipal(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientPrincipal
 
ClientProperties - Class in com.hazelcast.client.config
Client Properties
ClientProperties(ClientConfig) - Constructor for class com.hazelcast.client.config.ClientProperties
 
ClientProperties.ClientProperty - Class in com.hazelcast.client.config
A single client property.
ClientProxy - Class in com.hazelcast.client.spi
 
ClientProxy(String, String) - Constructor for class com.hazelcast.client.spi.ClientProxy
 
ClientProxyFactory - Interface in com.hazelcast.client.spi
 
ClientQueueProxy<E> - Class in com.hazelcast.client.proxy
 
ClientQueueProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientQueueProxy
 
ClientReadHandler - Class in com.hazelcast.client.connection.nio
 
ClientReadHandler(ClientConnection, IOSelector, int) - Constructor for class com.hazelcast.client.connection.nio.ClientReadHandler
 
ClientReAuthOperation - Class in com.hazelcast.client.impl.operations
 
ClientReAuthOperation() - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation
 
ClientReAuthOperation(String) - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation
 
ClientReplicatedMapAddEntryListenerRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for ReplicatedMap.addEntryListener(com.hazelcast.core.EntryListener) implementation
ClientReplicatedMapAddEntryListenerRequest(String, Predicate, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
 
ClientReplicatedMapClearRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.clear() implementation
ClientReplicatedMapClearRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
 
ClientReplicatedMapContainsKeyRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.containsKey(Object) implementation
ClientReplicatedMapContainsKeyRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
 
ClientReplicatedMapContainsValueRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.containsValue(Object) implementation
ClientReplicatedMapContainsValueRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
 
ClientReplicatedMapEntrySetRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.entrySet() implementation
ClientReplicatedMapEntrySetRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
 
ClientReplicatedMapGetRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.get(Object) implementation
ClientReplicatedMapGetRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
 
ClientReplicatedMapIsEmptyRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.isEmpty() implementation
ClientReplicatedMapIsEmptyRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
 
ClientReplicatedMapKeySetRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.keySet() implementation
ClientReplicatedMapKeySetRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
 
ClientReplicatedMapProxy<K,V> - Class in com.hazelcast.client.proxy
The replicated map client side proxy implementation proxying all requests to a member node
ClientReplicatedMapProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
ClientReplicatedMapPutAllRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.putAll(java.util.Map) implementation
ClientReplicatedMapPutAllRequest(String, ReplicatedMapEntrySet) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
 
ClientReplicatedMapPutTtlRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for ReplicatedMap.put(Object, Object, long, java.util.concurrent.TimeUnit) implementation
ClientReplicatedMapPutTtlRequest(String, Object, Object, long) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
 
ClientReplicatedMapRemoveEntryListenerRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for ReplicatedMap.removeEntryListener(String) implementation
ClientReplicatedMapRemoveEntryListenerRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
 
ClientReplicatedMapRemoveEntryListenerRequest(String, String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
 
ClientReplicatedMapRemoveRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.remove(Object) implementation
ClientReplicatedMapRemoveRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
 
ClientReplicatedMapSizeRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.size() implementation
ClientReplicatedMapSizeRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
 
ClientReplicatedMapValuesRequest - Class in com.hazelcast.replicatedmap.impl.client
Client request class for Map.values() implementation
ClientReplicatedMapValuesRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
 
ClientRequest - Class in com.hazelcast.client.impl.client
 
ClientRequest() - Constructor for class com.hazelcast.client.impl.client.ClientRequest
 
ClientResponse - Class in com.hazelcast.client.impl.client
 
ClientResponse() - Constructor for class com.hazelcast.client.impl.client.ClientResponse
 
ClientResponse(Data, int, boolean) - Constructor for class com.hazelcast.client.impl.client.ClientResponse
 
ClientSecurityConfig - Class in com.hazelcast.client.config
Contains the security configuration for a client.
ClientSecurityConfig() - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
 
ClientSemaphoreProxy - Class in com.hazelcast.client.proxy
 
ClientSemaphoreProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientSemaphoreProxy
 
ClientService - Interface in com.hazelcast.core
ClientService allows you to query connected Clients and attach/detach ClientListeners to listen to connection events.
ClientServiceProxy - Class in com.hazelcast.client.impl
The default implementation of the ClientService.
ClientServiceProxy(Node) - Constructor for class com.hazelcast.client.impl.ClientServiceProxy
 
ClientSetProxy<E> - Class in com.hazelcast.client.proxy
 
ClientSetProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientSetProxy
 
clientThreadId - Variable in class com.hazelcast.transaction.client.BaseTransactionRequest
 
ClientTopicProxy<E> - Class in com.hazelcast.client.proxy
 
ClientTopicProxy(String, String) - Constructor for class com.hazelcast.client.proxy.ClientTopicProxy
 
ClientTransactionManager - Class in com.hazelcast.client.txn
 
ClientTransactionManager(HazelcastClientInstanceImpl) - Constructor for class com.hazelcast.client.txn.ClientTransactionManager
 
ClientTxnListProxy<E> - Class in com.hazelcast.client.txn.proxy
 
ClientTxnListProxy(String, TransactionContextProxy) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnListProxy
 
ClientTxnMapProxy<K,V> - Class in com.hazelcast.client.txn.proxy
 
ClientTxnMapProxy(String, TransactionContextProxy) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
 
ClientTxnMultiMapProxy<K,V> - Class in com.hazelcast.client.txn.proxy
 
ClientTxnMultiMapProxy(String, TransactionContextProxy) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnMultiMapProxy
 
ClientTxnPortableHook - Class in com.hazelcast.transaction.client
Factory class for client transaction related classes
ClientTxnPortableHook() - Constructor for class com.hazelcast.transaction.client.ClientTxnPortableHook
 
ClientTxnQueueProxy<E> - Class in com.hazelcast.client.txn.proxy
 
ClientTxnQueueProxy(String, TransactionContextProxy) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnQueueProxy
 
ClientTxnSetProxy<E> - Class in com.hazelcast.client.txn.proxy
 
ClientTxnSetProxy(String, TransactionContextProxy) - Constructor for class com.hazelcast.client.txn.proxy.ClientTxnSetProxy
 
ClientType - Enum in com.hazelcast.core
Type of a client.
ClientTypes - Class in com.hazelcast.client
Constants class that contains the different types of clients.
ClientWriteHandler - Class in com.hazelcast.client.connection.nio
 
ClientWriteHandler(ClientConnection, IOSelector, int) - Constructor for class com.hazelcast.client.connection.nio.ClientWriteHandler
 
Clock - Class in com.hazelcast.util
Utility class to be able to simulate different time zones.
clone() - Method in class com.hazelcast.monitor.TimedMemberState
 
cloneWithoutValues() - Method in class com.hazelcast.map.impl.EntryEventData
 
close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
 
close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
 
close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
close(ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
close(URI, ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
 
close() - Method in class com.hazelcast.client.connection.nio.ClientConnection
 
close(Throwable) - Method in class com.hazelcast.client.connection.nio.ClientConnection
 
close() - Method in class com.hazelcast.jca.HazelcastConnectionImpl
 
close() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
 
close() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
 
close() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
 
close() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
 
close() - Method in interface com.hazelcast.nio.Connection
Closes this connection.
close() - Method in class com.hazelcast.nio.DynamicByteBuffer
 
close() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
close() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
close() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
 
close() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
Closes socket channel.
close() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
close(Throwable) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
 
closeConnection() - Method in class com.hazelcast.nio.ascii.SocketTextReader
 
closeInbound() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
 
closeInbound() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
Closes inbound.
closeListeners() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
closeOutbound() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
 
closeOutbound() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
Closes outbound.
closeResource(Closeable) - Static method in class com.hazelcast.nio.IOUtil
Closes the Closable quietly.
closeResources() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
CloudyUtility - Class in com.hazelcast.aws.utility
 
Cluster - Interface in com.hazelcast.core
Hazelcast cluster interface.
CLUSTER - Static variable in class com.hazelcast.nio.Protocols
Protocol that is used among nodes
ClusterDataSerializerHook - Class in com.hazelcast.cluster.impl
 
ClusterDataSerializerHook() - Constructor for class com.hazelcast.cluster.impl.ClusterDataSerializerHook
 
ClusterPermission - Class in com.hazelcast.security.permission
 
ClusterPermission(String) - Constructor for class com.hazelcast.security.permission.ClusterPermission
 
ClusterPermissionCollection - Class in com.hazelcast.security.permission
 
ClusterPermissionCollection() - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
 
ClusterPermissionCollection(Class<? extends Permission>) - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
 
ClusterPropsRequest - Class in com.hazelcast.management.request
Request for cluster properties.
ClusterPropsRequest() - Constructor for class com.hazelcast.management.request.ClusterPropsRequest
 
ClusterProxy - Class in com.hazelcast.cluster.impl
 
ClusterProxy(ClusterServiceImpl) - Constructor for class com.hazelcast.cluster.impl.ClusterProxy
 
ClusterService - Interface in com.hazelcast.cluster
A service responsible for member related functionality.
clusterService - Variable in class com.hazelcast.instance.Node
 
ClusterServiceImpl - Class in com.hazelcast.cluster.impl
 
ClusterServiceImpl(Node) - Constructor for class com.hazelcast.cluster.impl.ClusterServiceImpl
 
ClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
Cluster-wide iterator for ICache.
ClusterWideIterator(CacheProxy<K, V>) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
 
clusterWideUpdateManagementCenterUrl(String, String, String) - Method in class com.hazelcast.management.ManagementCenterService
 
CoalescingDelayedTrigger - Class in com.hazelcast.util.scheduler
Coalescing trigger can be used when you want coalesce multiple execution of Runnable.
CoalescingDelayedTrigger(ExecutionService, long, long, Runnable) - Constructor for class com.hazelcast.util.scheduler.CoalescingDelayedTrigger
 
collate(Iterable<ValueIn>) - Method in interface com.hazelcast.mapreduce.Collator
This method is called with the mapped and possibly reduced values from the MapReduce algorithm.
Collator<ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
This interface can be implemented to define a Collator which is executed after calculation of the MapReduce algorithm on remote cluster nodes but before returning the final result.
Collator can for example be used to sum up a final value.
COLLECTION - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
 
COLLECTION_ADD - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_ADD - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_ADD_ALL - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_ADD_ALL - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_ADD_ALL_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_ADD_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_ADD_LISTENER - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_CLEAR - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_CLEAR - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_CLEAR_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_CONTAINS - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_CONTAINS - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
COLLECTION_EVENT - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_EVENT_FILTER - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_GET_ALL - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_GET_ALL - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_IS_EMPTY - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_IS_EMPTY - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_ITEM - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
COLLECTION_PREPARE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_PREPARE_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_REMOVE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_REMOVE - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_REMOVE_LISTENER - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_RESERVE_ADD - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_RESERVE_REMOVE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_ROLLBACK - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_ROLLBACK_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_SIZE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_SIZE - Static variable in class com.hazelcast.collection.CollectionPortableHook
 
COLLECTION_TXN_ADD - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_TXN_ADD_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_TXN_REMOVE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
COLLECTION_TXN_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
 
CollectionAddAllBackupOperation - Class in com.hazelcast.collection
 
CollectionAddAllBackupOperation() - Constructor for class com.hazelcast.collection.CollectionAddAllBackupOperation
 
CollectionAddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.collection.CollectionAddAllBackupOperation
 
CollectionAddAllOperation - Class in com.hazelcast.collection
 
CollectionAddAllOperation() - Constructor for class com.hazelcast.collection.CollectionAddAllOperation
 
CollectionAddAllOperation(String, List<Data>) - Constructor for class com.hazelcast.collection.CollectionAddAllOperation
 
CollectionAddAllRequest - Class in com.hazelcast.collection.client
 
CollectionAddAllRequest() - Constructor for class com.hazelcast.collection.client.CollectionAddAllRequest
 
CollectionAddAllRequest(String, List<Data>) - Constructor for class com.hazelcast.collection.client.CollectionAddAllRequest
 
CollectionAddBackupOperation - Class in com.hazelcast.collection
 
CollectionAddBackupOperation() - Constructor for class com.hazelcast.collection.CollectionAddBackupOperation
 
CollectionAddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.CollectionAddBackupOperation
 
CollectionAddListenerRequest - Class in com.hazelcast.collection.client
this class is used to attach a listener to node for collections
CollectionAddListenerRequest() - Constructor for class com.hazelcast.collection.client.CollectionAddListenerRequest
 
CollectionAddListenerRequest(String, boolean) - Constructor for class com.hazelcast.collection.client.CollectionAddListenerRequest
 
CollectionAddOperation - Class in com.hazelcast.collection
 
CollectionAddOperation() - Constructor for class com.hazelcast.collection.CollectionAddOperation
 
CollectionAddOperation(String, Data) - Constructor for class com.hazelcast.collection.CollectionAddOperation
 
CollectionAddRequest - Class in com.hazelcast.collection.client
 
CollectionAddRequest() - Constructor for class com.hazelcast.collection.client.CollectionAddRequest
 
CollectionAddRequest(String, Data) - Constructor for class com.hazelcast.collection.client.CollectionAddRequest
 
CollectionBackupAwareOperation - Class in com.hazelcast.collection
 
CollectionBackupAwareOperation() - Constructor for class com.hazelcast.collection.CollectionBackupAwareOperation
 
CollectionBackupAwareOperation(String) - Constructor for class com.hazelcast.collection.CollectionBackupAwareOperation
 
CollectionClearBackupOperation - Class in com.hazelcast.collection
 
CollectionClearBackupOperation() - Constructor for class com.hazelcast.collection.CollectionClearBackupOperation
 
CollectionClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.CollectionClearBackupOperation
 
CollectionClearOperation - Class in com.hazelcast.collection
 
CollectionClearOperation() - Constructor for class com.hazelcast.collection.CollectionClearOperation
 
CollectionClearOperation(String) - Constructor for class com.hazelcast.collection.CollectionClearOperation
 
CollectionClearRequest - Class in com.hazelcast.collection.client
 
CollectionClearRequest() - Constructor for class com.hazelcast.collection.client.CollectionClearRequest
 
CollectionClearRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionClearRequest
 
CollectionCompareAndRemoveOperation - Class in com.hazelcast.collection
 
CollectionCompareAndRemoveOperation() - Constructor for class com.hazelcast.collection.CollectionCompareAndRemoveOperation
 
CollectionCompareAndRemoveOperation(String, boolean, Set<Data>) - Constructor for class com.hazelcast.collection.CollectionCompareAndRemoveOperation
 
CollectionCompareAndRemoveRequest - Class in com.hazelcast.collection.client
 
CollectionCompareAndRemoveRequest() - Constructor for class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
 
CollectionCompareAndRemoveRequest(String, Set<Data>, boolean) - Constructor for class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
 
CollectionConfig<T extends CollectionConfig> - Class in com.hazelcast.config
 
CollectionConfig() - Constructor for class com.hazelcast.config.CollectionConfig
 
CollectionConfig(CollectionConfig) - Constructor for class com.hazelcast.config.CollectionConfig
 
CollectionContainer - Class in com.hazelcast.collection
 
CollectionContainer() - Constructor for class com.hazelcast.collection.CollectionContainer
 
CollectionContainer(String, NodeEngine) - Constructor for class com.hazelcast.collection.CollectionContainer
 
CollectionContainsOperation - Class in com.hazelcast.collection
 
CollectionContainsOperation() - Constructor for class com.hazelcast.collection.CollectionContainsOperation
 
CollectionContainsOperation(String, Set<Data>) - Constructor for class com.hazelcast.collection.CollectionContainsOperation
 
CollectionContainsRequest - Class in com.hazelcast.collection.client
 
CollectionContainsRequest() - Constructor for class com.hazelcast.collection.client.CollectionContainsRequest
 
CollectionContainsRequest(String, Set<Data>) - Constructor for class com.hazelcast.collection.client.CollectionContainsRequest
 
CollectionContainsRequest(String, Data) - Constructor for class com.hazelcast.collection.client.CollectionContainsRequest
 
CollectionDataSerializerHook - Class in com.hazelcast.collection
 
CollectionDataSerializerHook() - Constructor for class com.hazelcast.collection.CollectionDataSerializerHook
 
CollectionEvent - Class in com.hazelcast.collection
 
CollectionEvent() - Constructor for class com.hazelcast.collection.CollectionEvent
 
CollectionEvent(String, Data, ItemEventType, Address) - Constructor for class com.hazelcast.collection.CollectionEvent
 
CollectionEventFilter - Class in com.hazelcast.collection
 
CollectionEventFilter() - Constructor for class com.hazelcast.collection.CollectionEventFilter
 
CollectionEventFilter(boolean) - Constructor for class com.hazelcast.collection.CollectionEventFilter
 
CollectionGetAllOperation - Class in com.hazelcast.collection
 
CollectionGetAllOperation() - Constructor for class com.hazelcast.collection.CollectionGetAllOperation
 
CollectionGetAllOperation(String) - Constructor for class com.hazelcast.collection.CollectionGetAllOperation
 
CollectionGetAllRequest - Class in com.hazelcast.collection.client
 
CollectionGetAllRequest() - Constructor for class com.hazelcast.collection.client.CollectionGetAllRequest
 
CollectionGetAllRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionGetAllRequest
 
CollectionIsEmptyOperation - Class in com.hazelcast.collection
 
CollectionIsEmptyOperation() - Constructor for class com.hazelcast.collection.CollectionIsEmptyOperation
 
CollectionIsEmptyOperation(String) - Constructor for class com.hazelcast.collection.CollectionIsEmptyOperation
 
CollectionIsEmptyRequest - Class in com.hazelcast.collection.client
 
CollectionIsEmptyRequest() - Constructor for class com.hazelcast.collection.client.CollectionIsEmptyRequest
 
CollectionIsEmptyRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionIsEmptyRequest
 
CollectionItem - Class in com.hazelcast.collection
 
CollectionItem() - Constructor for class com.hazelcast.collection.CollectionItem
 
CollectionItem(long, Data) - Constructor for class com.hazelcast.collection.CollectionItem
 
CollectionOperation - Class in com.hazelcast.collection
 
CollectionOperation() - Constructor for class com.hazelcast.collection.CollectionOperation
 
CollectionOperation(String) - Constructor for class com.hazelcast.collection.CollectionOperation
 
CollectionPortableHook - Class in com.hazelcast.collection
 
CollectionPortableHook() - Constructor for class com.hazelcast.collection.CollectionPortableHook
 
CollectionPrepareBackupOperation - Class in com.hazelcast.collection.txn
 
CollectionPrepareBackupOperation() - Constructor for class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
 
CollectionPrepareBackupOperation(String, long, String, boolean) - Constructor for class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
 
CollectionPrepareOperation - Class in com.hazelcast.collection.txn
 
CollectionPrepareOperation() - Constructor for class com.hazelcast.collection.txn.CollectionPrepareOperation
 
CollectionPrepareOperation(String, long, String, boolean) - Constructor for class com.hazelcast.collection.txn.CollectionPrepareOperation
 
CollectionRegionAccessStrategyAdapter - Class in com.hazelcast.hibernate.region
Simple adapter implementation for transactional / concurrent access control on collections
CollectionRegionAccessStrategyAdapter(AccessDelegate<? extends HazelcastCollectionRegion>) - Constructor for class com.hazelcast.hibernate.region.CollectionRegionAccessStrategyAdapter
 
CollectionRemoveBackupOperation - Class in com.hazelcast.collection
 
CollectionRemoveBackupOperation() - Constructor for class com.hazelcast.collection.CollectionRemoveBackupOperation
 
CollectionRemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.CollectionRemoveBackupOperation
 
CollectionRemoveListenerRequest - Class in com.hazelcast.collection.client
 
CollectionRemoveListenerRequest() - Constructor for class com.hazelcast.collection.client.CollectionRemoveListenerRequest
 
CollectionRemoveListenerRequest(String, String, String) - Constructor for class com.hazelcast.collection.client.CollectionRemoveListenerRequest
 
CollectionRemoveOperation - Class in com.hazelcast.collection
 
CollectionRemoveOperation() - Constructor for class com.hazelcast.collection.CollectionRemoveOperation
 
CollectionRemoveOperation(String, Data) - Constructor for class com.hazelcast.collection.CollectionRemoveOperation
 
CollectionRemoveRequest - Class in com.hazelcast.collection.client
 
CollectionRemoveRequest() - Constructor for class com.hazelcast.collection.client.CollectionRemoveRequest
 
CollectionRemoveRequest(String, Data) - Constructor for class com.hazelcast.collection.client.CollectionRemoveRequest
 
CollectionReplicationOperation - Class in com.hazelcast.collection
 
CollectionReplicationOperation() - Constructor for class com.hazelcast.collection.CollectionReplicationOperation
 
CollectionReplicationOperation(Map<String, CollectionContainer>, int, int) - Constructor for class com.hazelcast.collection.CollectionReplicationOperation
 
CollectionRequest - Class in com.hazelcast.collection.client
 
CollectionRequest() - Constructor for class com.hazelcast.collection.client.CollectionRequest
 
CollectionRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionRequest
 
CollectionReserveAddOperation - Class in com.hazelcast.collection.txn
 
CollectionReserveAddOperation() - Constructor for class com.hazelcast.collection.txn.CollectionReserveAddOperation
 
CollectionReserveAddOperation(String, String, Data) - Constructor for class com.hazelcast.collection.txn.CollectionReserveAddOperation
 
CollectionReserveRemoveOperation - Class in com.hazelcast.collection.txn
 
CollectionReserveRemoveOperation() - Constructor for class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
 
CollectionReserveRemoveOperation(String, long, Data, String) - Constructor for class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
 
CollectionRollbackBackupOperation - Class in com.hazelcast.collection.txn
 
CollectionRollbackBackupOperation() - Constructor for class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
 
CollectionRollbackBackupOperation(String, long, boolean) - Constructor for class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
 
CollectionRollbackOperation - Class in com.hazelcast.collection.txn
 
CollectionRollbackOperation() - Constructor for class com.hazelcast.collection.txn.CollectionRollbackOperation
 
CollectionRollbackOperation(String, long, boolean) - Constructor for class com.hazelcast.collection.txn.CollectionRollbackOperation
 
CollectionService - Class in com.hazelcast.collection
 
CollectionService(NodeEngine) - Constructor for class com.hazelcast.collection.CollectionService
 
CollectionSizeOperation - Class in com.hazelcast.collection
 
CollectionSizeOperation() - Constructor for class com.hazelcast.collection.CollectionSizeOperation
 
CollectionSizeOperation(String) - Constructor for class com.hazelcast.collection.CollectionSizeOperation
 
CollectionSizeRequest - Class in com.hazelcast.collection.client
 
CollectionSizeRequest() - Constructor for class com.hazelcast.collection.client.CollectionSizeRequest
 
CollectionSizeRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionSizeRequest
 
CollectionTransactionLog - Class in com.hazelcast.collection.txn
 
CollectionTransactionLog() - Constructor for class com.hazelcast.collection.txn.CollectionTransactionLog
 
CollectionTransactionLog(long, String, int, String, String, Operation) - Constructor for class com.hazelcast.collection.txn.CollectionTransactionLog
 
CollectionTransactionRollbackOperation - Class in com.hazelcast.collection
 
CollectionTransactionRollbackOperation() - Constructor for class com.hazelcast.collection.CollectionTransactionRollbackOperation
 
CollectionTransactionRollbackOperation(String, String) - Constructor for class com.hazelcast.collection.CollectionTransactionRollbackOperation
 
CollectionTxnAddBackupOperation - Class in com.hazelcast.collection.txn
 
CollectionTxnAddBackupOperation() - Constructor for class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
 
CollectionTxnAddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
 
CollectionTxnAddOperation - Class in com.hazelcast.collection.txn
 
CollectionTxnAddOperation() - Constructor for class com.hazelcast.collection.txn.CollectionTxnAddOperation
 
CollectionTxnAddOperation(String, long, Data) - Constructor for class com.hazelcast.collection.txn.CollectionTxnAddOperation
 
CollectionTxnRemoveBackupOperation - Class in com.hazelcast.collection.txn
 
CollectionTxnRemoveBackupOperation() - Constructor for class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
 
CollectionTxnRemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
 
CollectionTxnRemoveOperation - Class in com.hazelcast.collection.txn
 
CollectionTxnRemoveOperation() - Constructor for class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
 
CollectionTxnRemoveOperation(String, long) - Constructor for class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
 
CollectionUtil - Class in com.hazelcast.util
Various collection utility methods, mainly targeted to use internally.
com.hazelcast - package com.hazelcast
 
com.hazelcast.ascii - package com.hazelcast.ascii
This package contains Ascii functionality for Hazelcast.
com.hazelcast.ascii.memcache - package com.hazelcast.ascii.memcache
This package contains MemoryCache functionality for Hazelcast.
com.hazelcast.ascii.rest - package com.hazelcast.ascii.rest
This package contains Reset functionality for Hazelcast.
com.hazelcast.aws - package com.hazelcast.aws
Provides interfaces/classes for Hazelcast AWS.
com.hazelcast.aws.impl - package com.hazelcast.aws.impl
Provides implementation classes for Hazelcast AWS.
com.hazelcast.aws.security - package com.hazelcast.aws.security
Provides security classes for Hazelcast AWS.
com.hazelcast.aws.utility - package com.hazelcast.aws.utility
Provides utility classes for Hazelcast AWS.
com.hazelcast.buildutils - package com.hazelcast.buildutils
This module contains Maven and other build additions that are used by Hazelcast to build bundle modules
com.hazelcast.cache - package com.hazelcast.cache
This package contains the public API extension for Hazelcast JCache, the Hazelcast implementation of the JSR-107 commonly referred to as JCache.
com.hazelcast.cache.impl - package com.hazelcast.cache.impl
Hazelcast JSR-107 aka JCache implementation
com.hazelcast.cache.impl.client - package com.hazelcast.cache.impl.client
Hazelcast JSR-107 aka JCache implementation Client Requests
com.hazelcast.cache.impl.eviction - package com.hazelcast.cache.impl.eviction
Eviction policy implementations for cache.
com.hazelcast.cache.impl.eviction.impl - package com.hazelcast.cache.impl.eviction.impl
Eviction implementations for cache.
com.hazelcast.cache.impl.eviction.impl.evaluator - package com.hazelcast.cache.impl.eviction.impl.evaluator
EvictionPolicyEvaluator implementations for cache.
com.hazelcast.cache.impl.eviction.impl.strategy - package com.hazelcast.cache.impl.eviction.impl.strategy
EvictionStrategy implementations for cache.
com.hazelcast.cache.impl.eviction.impl.strategy.sampling - package com.hazelcast.cache.impl.eviction.impl.strategy.sampling
Sampling based EvictionStrategy implementations for cache.
com.hazelcast.cache.impl.maxsize - package com.hazelcast.cache.impl.maxsize
Max-Size policy interfaces for cache.
com.hazelcast.cache.impl.maxsize.impl - package com.hazelcast.cache.impl.maxsize.impl
Max-Size policy implementations for cache.
com.hazelcast.cache.impl.operation - package com.hazelcast.cache.impl.operation
Hazelcast JSR-107 aka JCache implementation
com.hazelcast.cache.impl.record - package com.hazelcast.cache.impl.record
Hazelcast JSR-107 aka JCache implementation Internal record store
com.hazelcast.client - package com.hazelcast.client
Contains classes/interfaces related to Client
com.hazelcast.client.cache.impl - package com.hazelcast.client.cache.impl
Hazelcast JSR-107 aka JCache implementation client side
com.hazelcast.client.config - package com.hazelcast.client.config
Contains classes related to config for com.hazelcast.client
com.hazelcast.client.connection - package com.hazelcast.client.connection
Provides connection interfaces/classes for com.hazelcast.client
com.hazelcast.client.connection.nio - package com.hazelcast.client.connection.nio
Contains classes related to New IO for com.hazelcast.client.connection
com.hazelcast.client.console - package com.hazelcast.client.console
This package contains ClientConsoleApp
com.hazelcast.client.impl - package com.hazelcast.client.impl
Contains most of the client side HazelcastInstance implementation functionality.
com.hazelcast.client.impl.client - package com.hazelcast.client.impl.client
This contains the Requests and other DTO's exchanged between client/server
com.hazelcast.client.impl.exceptionconverters - package com.hazelcast.client.impl.exceptionconverters
Contains logic to convert client exceptions.
com.hazelcast.client.impl.operations - package com.hazelcast.client.impl.operations
Contains client operations
com.hazelcast.client.nearcache - package com.hazelcast.client.nearcache
Contains classes/interfaces related to com.hazelcast.client.nearcache
com.hazelcast.client.proxy - package com.hazelcast.client.proxy
This package contains client side proxy implementations of the different Hazelcast data structures and operation types
com.hazelcast.client.spi - package com.hazelcast.client.spi
Contains classes/interfaces related to Service Provider Interface such as ClientProxy , ClientClusterService
com.hazelcast.client.spi.impl - package com.hazelcast.client.spi.impl
Provides util classes for com.hazelcast.client
com.hazelcast.client.txn - package com.hazelcast.client.txn
Contains classes related to Txn such as TransactionProxy
com.hazelcast.client.txn.proxy - package com.hazelcast.client.txn.proxy
Contains classes related to proxy for com.hazelcast.client.client.txn
com.hazelcast.client.util - package com.hazelcast.client.util
This package contains some utility classes and the base implementations of the loadbalancer implementations
com.hazelcast.cluster - package com.hazelcast.cluster
This package contains the cluster functionality.
com.hazelcast.cluster.client - package com.hazelcast.cluster.client
This package contains the client cluster functionality.
com.hazelcast.cluster.impl - package com.hazelcast.cluster.impl
This package contains the implementation of the cluster functionality.
com.hazelcast.cluster.impl.operations - package com.hazelcast.cluster.impl.operations
This package contains operations for the com.hazelcast.cluster.impl package.
com.hazelcast.collection - package com.hazelcast.collection
This package contains classes related to Collections (IList,ISet etc..)
com.hazelcast.collection.client - package com.hazelcast.collection.client
This package contains client functionality for Collections in Hazelcast.
com.hazelcast.collection.common - package com.hazelcast.collection.common
This package contains common classes related to all collections
com.hazelcast.collection.list - package com.hazelcast.collection.list
This package contains IList functionality for Hazelcast.
com.hazelcast.collection.set - package com.hazelcast.collection.set
This package contains ISet functionality for Hazelcast.
com.hazelcast.collection.txn - package com.hazelcast.collection.txn
This package contains the Transaction behavior for the Collections.
com.hazelcast.concurrent.atomiclong - package com.hazelcast.concurrent.atomiclong
This package contains IAtomicLong functionality for Hazelcast.
The IAtomicLong is the distributed version of the AtomicLong.
com.hazelcast.concurrent.atomiclong.client - package com.hazelcast.concurrent.atomiclong.client
This package contains client requests for the IAtomicLong.
This package contains all the client request object to operate on the IAtomicLong that are send by the client.
com.hazelcast.concurrent.atomiclong.operations - package com.hazelcast.concurrent.atomiclong.operations
This package contains the operations on the IAtomicLong.
com.hazelcast.concurrent.atomicreference - package com.hazelcast.concurrent.atomicreference
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the AtomicReference.
com.hazelcast.concurrent.atomicreference.client - package com.hazelcast.concurrent.atomicreference.client
This package contains client requests for the IAtomicLong.
This package contains all the client request object to operate on the IAtomicLong that are send by the client.
com.hazelcast.concurrent.atomicreference.operations - package com.hazelcast.concurrent.atomicreference.operations
This package contains the operations on the IAtomicReference.
com.hazelcast.concurrent.countdownlatch - package com.hazelcast.concurrent.countdownlatch
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the CountDownLatch.
com.hazelcast.concurrent.countdownlatch.client - package com.hazelcast.concurrent.countdownlatch.client
This package contains client requests for the ICountDownLatch.
This package contains all the client requests object to operate on the ICountDownLatch that are send by the client.
com.hazelcast.concurrent.countdownlatch.operations - package com.hazelcast.concurrent.countdownlatch.operations
This package contains the operations on the ICountDownLatch.
com.hazelcast.concurrent.idgen - package com.hazelcast.concurrent.idgen
This package contains IdGenerator functionality for Hazelcast.
With the IdGenerator it is very simple to create cluster wide id's.
com.hazelcast.concurrent.lock - package com.hazelcast.concurrent.lock
This package contains Lock for Hazelcast.
The ILock is the distributed version of the Lock.
com.hazelcast.concurrent.lock.client - package com.hazelcast.concurrent.lock.client
This package contains client requests for the ILock.
This package contains all the client requests object to operate on the ILock that are send by the client.
com.hazelcast.concurrent.lock.operations - package com.hazelcast.concurrent.lock.operations
This package contains the operations on the ILock.
com.hazelcast.concurrent.semaphore - package com.hazelcast.concurrent.semaphore
This package contains ISemaphore functionality for Hazelcast.
The ISemaphore is the distributed version of the Semaphore.
com.hazelcast.concurrent.semaphore.client - package com.hazelcast.concurrent.semaphore.client
This package contains client requests for the ISemaphore.
com.hazelcast.concurrent.semaphore.operations - package com.hazelcast.concurrent.semaphore.operations
This package contains the operations on the ISemaphore.
com.hazelcast.config - package com.hazelcast.config
Provides classes for configuring HazelcastInstance.
com.hazelcast.console - package com.hazelcast.console
This package contains classes related to ConsoleApp
com.hazelcast.core - package com.hazelcast.core
Provides core API interfaces/classes.
com.hazelcast.core.server - package com.hazelcast.core.server
This package contains classes to launch standalone Hazelcast Instance
com.hazelcast.executor.impl - package com.hazelcast.executor.impl
This package contains IExecutorService functionality for Hazelcast.
The IExecutorService extends the ExecutorService and provides all kinds of additional methods related to distributed systems.
com.hazelcast.executor.impl.client - package com.hazelcast.executor.impl.client
This package contains client requests for the IExecutorService.
com.hazelcast.executor.impl.operations - package com.hazelcast.executor.impl.operations
This package contains operations for the IExecutorService.
com.hazelcast.hibernate - package com.hazelcast.hibernate
Contains interfaces/classes related to Hibernate.
com.hazelcast.hibernate.access - package com.hazelcast.hibernate.access
Provides access interfaces/classes for Hibernate.
com.hazelcast.hibernate.distributed - package com.hazelcast.hibernate.distributed
Provides distributed class for Hibernate.
com.hazelcast.hibernate.instance - package com.hazelcast.hibernate.instance
Provides instance interfaces/classes for Hibernate.
com.hazelcast.hibernate.local - package com.hazelcast.hibernate.local
Provides local classes for Hibernate.
com.hazelcast.hibernate.region - package com.hazelcast.hibernate.region
Provides region interfaces/classes for Hibernate.
com.hazelcast.hibernate.serialization - package com.hazelcast.hibernate.serialization
This class contains the Hibernate4 serializer hooks so what we don't loose handling on serialization while working on hibernate
com.hazelcast.instance - package com.hazelcast.instance
This package contains Hazelcast Instance functionality.
com.hazelcast.jca - package com.hazelcast.jca
This package contains jca functionality
com.hazelcast.jmx - package com.hazelcast.jmx
Contains Hazelcast management bean classes.
com.hazelcast.logging - package com.hazelcast.logging
This package contains logging functionality for Hazelcast.
Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commongs logging, so that different logging frameworks like log4j, can be hooked in.
com.hazelcast.management - package com.hazelcast.management
Contains classes to provide data/operation interface for Management Center.
com.hazelcast.management.operation - package com.hazelcast.management.operation
Contains operations that are called from Management Center.
com.hazelcast.management.request - package com.hazelcast.management.request
Contains requests that made from Management Center.
com.hazelcast.map - package com.hazelcast.map
Contains Hazelcast map module classes.
com.hazelcast.map.impl - package com.hazelcast.map.impl
Contains implementation specific classes of com.hazelcast.map package.
com.hazelcast.map.impl.client - package com.hazelcast.map.impl.client
Contains client requests for the IMap
com.hazelcast.map.impl.eviction - package com.hazelcast.map.impl.eviction
This package contains eviction classes.
com.hazelcast.map.impl.mapstore - package com.hazelcast.map.impl.mapstore
Contains map store operations.
com.hazelcast.map.impl.mapstore.writebehind - package com.hazelcast.map.impl.mapstore.writebehind
Package for processing write behind store operations.
com.hazelcast.map.impl.mapstore.writethrough - package com.hazelcast.map.impl.mapstore.writethrough
Package for processing write through store operations.
com.hazelcast.map.impl.operation - package com.hazelcast.map.impl.operation
Package for map operations.
com.hazelcast.map.impl.proxy - package com.hazelcast.map.impl.proxy
Contains map proxy implementation and support classes.
com.hazelcast.map.impl.record - package com.hazelcast.map.impl.record
Contains record specific classes.
com.hazelcast.map.impl.tx - package com.hazelcast.map.impl.tx
Contains implementation classes for TransactionalMap
com.hazelcast.map.impl.wan - package com.hazelcast.map.impl.wan
Contains wan replication event classes
com.hazelcast.map.merge - package com.hazelcast.map.merge
Contains merge policies for IMap
com.hazelcast.mapreduce - package com.hazelcast.mapreduce
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the active Hazelcast cluster.
com.hazelcast.mapreduce.aggregation - package com.hazelcast.mapreduce.aggregation
This package contains the aggregation API and the convenience helper classes to retrieve predefined aggregation implementations.
com.hazelcast.mapreduce.aggregation.impl - package com.hazelcast.mapreduce.aggregation.impl
This package contains a set of predefined aggregation implementations
com.hazelcast.mapreduce.impl - package com.hazelcast.mapreduce.impl
This package contains the default implementation for the map reduce framework internals.
com.hazelcast.mapreduce.impl.client - package com.hazelcast.mapreduce.impl.client
This package contains request and response classes for communication between cluster members and Hazelcast native clients
com.hazelcast.mapreduce.impl.notification - package com.hazelcast.mapreduce.impl.notification
This package contains all remote node notifications
com.hazelcast.mapreduce.impl.operation - package com.hazelcast.mapreduce.impl.operation
This package contains all remote operations that are needed to control work on supervising or worker nodes.
com.hazelcast.mapreduce.impl.task - package com.hazelcast.mapreduce.impl.task
This package contains the base implementation for a standard map reduce job.
com.hazelcast.memory - package com.hazelcast.memory
Provides classes/interfaces for memory utilities, heap/native memory storage support.
com.hazelcast.monitor - package com.hazelcast.monitor
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
com.hazelcast.monitor.impl - package com.hazelcast.monitor.impl
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc.
com.hazelcast.multimap.impl - package com.hazelcast.multimap.impl
Contains classes for Hazelcast MultiMap module.
com.hazelcast.multimap.impl.client - package com.hazelcast.multimap.impl.client
Contains client requests for Hazelcast MultiMap module.
com.hazelcast.multimap.impl.operations - package com.hazelcast.multimap.impl.operations
Contains operations for Hazelcast MultiMap module.
com.hazelcast.multimap.impl.txn - package com.hazelcast.multimap.impl.txn
This package contains the Transaction behavior for the Multimap.
com.hazelcast.nio - package com.hazelcast.nio
This package contains classes related to New IO
com.hazelcast.nio.ascii - package com.hazelcast.nio.ascii
Contains SocketTextReader and SocketTextWriter classes;
com.hazelcast.nio.serialization - package com.hazelcast.nio.serialization
Contains interfaces/classes related to serialization; such as serializer interfaces, input/output streams.
com.hazelcast.nio.serialization.serializers - package com.hazelcast.nio.serialization.serializers
Contains interfaces/classes related to SerializerHook for ArrayList and LinkedList
com.hazelcast.nio.ssl - package com.hazelcast.nio.ssl
Contains interfaces/classes related to SSL for New IO
com.hazelcast.nio.tcp - package com.hazelcast.nio.tcp
Contains functionality for the TCP/IP Networking between cluster members
com.hazelcast.osgi - package com.hazelcast.osgi
This package contains the OSGI functionality for Hazelcast.
com.hazelcast.partition - package com.hazelcast.partition
Contains the partition logic for Hazelcast.
com.hazelcast.partition.client - package com.hazelcast.partition.client
Contains client functionality for partition related information.
com.hazelcast.partition.impl - package com.hazelcast.partition.impl
Contains the actual implementation of the InternalPartitionService.
com.hazelcast.partition.membergroup - package com.hazelcast.partition.membergroup
todo
com.hazelcast.partition.strategy - package com.hazelcast.partition.strategy
Packages contains different partitioning strategies.
com.hazelcast.query - package com.hazelcast.query
Contains interfaces/classes related to Hazelcast query and indexing support.
com.hazelcast.query.impl - package com.hazelcast.query.impl
Contains the implementation classes of the query functionality.
com.hazelcast.queue.impl - package com.hazelcast.queue.impl
This package contains the IQueue functionality.
The IQueue is the distributed version of the BlockingQueue.
com.hazelcast.queue.impl.client - package com.hazelcast.queue.impl.client
This package contains client requests for the IQueue.
com.hazelcast.queue.impl.operations - package com.hazelcast.queue.impl.operations
This package contains the IQueue operations
com.hazelcast.queue.impl.proxy - package com.hazelcast.queue.impl.proxy
This package contains the IQueue proxies.
com.hazelcast.queue.impl.tx - package com.hazelcast.queue.impl.tx
This package contains the Transaction behavior for the IQueue.
com.hazelcast.replicatedmap.impl - package com.hazelcast.replicatedmap.impl
This package contains the implementation of the replicated map service itself and some connection interfaces only used internally - No public API!
com.hazelcast.replicatedmap.impl.client - package com.hazelcast.replicatedmap.impl.client
This package contains classes for client communication on replicated map implementation
com.hazelcast.replicatedmap.impl.messages - package com.hazelcast.replicatedmap.impl.messages
This package contains replication event classes to communicate replications to other nodes
com.hazelcast.replicatedmap.impl.operation - package com.hazelcast.replicatedmap.impl.operation
This package contains some remote operations to execute on remote nodes
com.hazelcast.replicatedmap.impl.record - package com.hazelcast.replicatedmap.impl.record
This package contains the implementation of the backing data storage for the replicated map implementation
com.hazelcast.security - package com.hazelcast.security
Provides interfaces/classes for Hazelcast security implementation.
com.hazelcast.security.permission - package com.hazelcast.security.permission
Contains all the security permissions
com.hazelcast.spi - package com.hazelcast.spi
Provides interfaces/classes for Hazelcast SPI.
com.hazelcast.spi.annotation - package com.hazelcast.spi.annotation
Contains annotations for Hazelcast SPI.
com.hazelcast.spi.exception - package com.hazelcast.spi.exception
Contains exceptions for Hazelcast SPI.
com.hazelcast.spi.impl - package com.hazelcast.spi.impl
Contains implementations for Hazelcast SPI.
com.hazelcast.spring - package com.hazelcast.spring
Provides Spring interfaces/classes for Hazelcast.
com.hazelcast.spring.cache - package com.hazelcast.spring.cache
Contains Hazelcast cache classes related to Spring.
com.hazelcast.spring.context - package com.hazelcast.spring.context
Contains context classes for Spring.
com.hazelcast.spring.hibernate - package com.hazelcast.spring.hibernate
Contains class related to Hibernate.
com.hazelcast.storage - package com.hazelcast.storage
This package contains storage functionality for Hazelcast.
com.hazelcast.topic.impl - package 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.client - package com.hazelcast.topic.impl.client
This package contains client requests for the ITopic.
com.hazelcast.transaction - package com.hazelcast.transaction
Provides interfaces/classes for Hazelcast transaction support.
com.hazelcast.transaction.client - package com.hazelcast.transaction.client
This package contains client transaction code
com.hazelcast.transaction.impl - package com.hazelcast.transaction.impl
Provides implementation for Hazelcast transaction support.
com.hazelcast.util - package 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.
com.hazelcast.util.executor - package com.hazelcast.util.executor
This package contains classes related to Util.Executor
com.hazelcast.util.scheduler - package com.hazelcast.util.scheduler
This package contains scheduler classes for Util
com.hazelcast.wan - package com.hazelcast.wan
This package contains the WAN replication API
com.hazelcast.wan.impl - package com.hazelcast.wan.impl
This package contains the opensource implementation of WAN replication
com.hazelcast.web - package com.hazelcast.web
Provides Hazelcast-based session replication.
com.hazelcast.web.spring - package com.hazelcast.web.spring
Provides Spring aware Hazelcast based session replication.
combine(ValueIn) - Method in class com.hazelcast.mapreduce.Combiner
This method is called to supply values to be combined into an intermediate result chunk.
The combine method might be called multiple times so the combined chunk needs to be hold internally in a member state of the Combiner.
After this method is called you need to reset the internal state to prepare combining of the next chunk.
Combiner<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
The abstract Combiner class is used to build combiners for the Job.
Those Combiners are distributed inside of the cluster and are running alongside the Mapper implementations in the same node.
Combiners are called in a threadsafe way so internal locking is not required.
Combiner() - Constructor for class com.hazelcast.mapreduce.Combiner
 
combiner(CombinerFactory<Key, Value, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
 
combiner(CombinerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Defines the CombinerFactory for this task.
COMBINER_RESULT_LIST - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
 
CombinerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
A CombinerFactory implementation is used to build Combiner instances per key.
An implementation needs to be serializable by Hazelcast since it is distributed together with the Mapper implementation to run alongside.
combinerFactory - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
 
combinerFactory - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
 
CombinerResultList<E> - Class in com.hazelcast.mapreduce.impl
This ArrayList subclass exists to prevent DefaultContext.CollectingCombinerFactory created collections to be mixed up with user provided List results from Combiners.
CombinerResultList() - Constructor for class com.hazelcast.mapreduce.impl.CombinerResultList
 
CombinerResultList(Collection<? extends E>) - Constructor for class com.hazelcast.mapreduce.impl.CombinerResultList
 
combineToInt(short, short) - Static method in class com.hazelcast.nio.Bits
Combines two short integer values into an integer.
combineToLong(int, int) - Static method in class com.hazelcast.nio.Bits
Combines two integer values into a long integer.
CommandParser - Interface in com.hazelcast.ascii
 
commit(Xid, boolean) - Method in class com.hazelcast.client.txn.XAResourceProxy
 
commit(NodeEngine) - Method in class com.hazelcast.collection.txn.CollectionTransactionLog
 
commit() - Method in class com.hazelcast.jca.HazelcastTransactionImpl
 
commit(Xid, boolean) - Method in class com.hazelcast.jca.XAResourceWrapper
 
commit(NodeEngine) - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
 
commit(NodeEngine) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
 
commit(NodeEngine) - Method in class com.hazelcast.queue.impl.tx.QueueTransactionLog
 
COMMIT - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
 
commit() - Method in interface com.hazelcast.transaction.impl.Transaction
 
commit(NodeEngine) - Method in interface com.hazelcast.transaction.impl.TransactionLog
 
commit(Xid, boolean) - Method in class com.hazelcast.transaction.impl.XAResourceImpl
 
commitAdd(long, Data) - Method in class com.hazelcast.collection.CollectionContainer
 
commitAddBackup(long, Data) - Method in class com.hazelcast.collection.CollectionContainer
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.CollectionService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
 
commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.queue.impl.QueueService
 
commitMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
 
commitRemove(long) - Method in class com.hazelcast.collection.CollectionContainer
 
commitRemoveBackup(long) - Method in class com.hazelcast.collection.CollectionContainer
 
commitTransaction() - Method in class com.hazelcast.client.txn.TransactionContextProxy
 
commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Commits a transaction.
CommitTransactionRequest - Class in com.hazelcast.transaction.client
 
CommitTransactionRequest() - Constructor for class com.hazelcast.transaction.client.CommitTransactionRequest
 
CommitTransactionRequest(boolean) - Constructor for class com.hazelcast.transaction.client.CommitTransactionRequest
 
compact() - Method in class com.hazelcast.nio.DynamicByteBuffer
 
compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
 
COMPARABLE_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
COMPARABLE_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
COMPARABLE_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
COMPARABLE_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
 
comparableMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to find the maximum value of all supplied Comparable implementing values.
This aggregation is similar to
ComparableMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined maximum aggregation for values of type Comparable.
ComparableMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
 
comparableMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
Returns an aggregation to find the minimum value of all supplied Comparable implementing values.
This aggregation is similar to
ComparableMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
The predefined minimum aggregation for values of type Comparable.
ComparableMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
 
compare(Object, Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
compare(Comparator<Map.Entry>, IterationType, Map.Entry, Map.Entry) - Static method in class com.hazelcast.util.SortingUtil
 
COMPARE_AND_REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
COMPARE_AND_REMOVE - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
 
COMPARE_AND_REMOVE - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
 
COMPARE_AND_REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
COMPARE_AND_REMOVE_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
 
COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
 
COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
compareAndRemove(boolean, Set<Data>) - Method in class com.hazelcast.collection.CollectionContainer
 
compareAndRemove(Collection<Data>, boolean) - Method in class com.hazelcast.queue.impl.QueueContainer
This method triggers store load
compareAndRemoveBackup(Set<Long>) - Method in class com.hazelcast.queue.impl.QueueContainer
 
CompareAndRemoveBackupOperation - Class in com.hazelcast.queue.impl.operations
This class triggers backup method for items' id.
CompareAndRemoveBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.CompareAndRemoveBackupOperation
 
CompareAndRemoveBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.queue.impl.operations.CompareAndRemoveBackupOperation
 
CompareAndRemoveOperation - Class in com.hazelcast.queue.impl.operations
This class triggers iterator and if find same item in the Queue, remove this item.
CompareAndRemoveOperation() - Constructor for class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
 
CompareAndRemoveOperation(String, Collection<Data>, boolean) - Constructor for class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
 
CompareAndRemoveRequest - Class in com.hazelcast.queue.impl.client
Provides the request service for CompareAndRemoveOperation
CompareAndRemoveRequest() - Constructor for class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
 
CompareAndRemoveRequest(String, Collection<Data>, boolean) - Constructor for class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
 
compareAndSet(long, long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
 
compareAndSet(E, E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
 
compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.LongWrapper
 
compareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
compareAndSet(Data, Data) - Method in class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
 
compareAndSet(long, long) - Method in interface com.hazelcast.core.IAtomicLong
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(E, E) - Method in interface com.hazelcast.core.IAtomicReference
Atomically sets the value to the given updated value only if the current value == the expected value.
compareAndSet(long, long) - Method in class com.hazelcast.jmx.AtomicLongMBean
 
CompareAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
 
CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
CompareAndSetOperation(String, long, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
 
CompareAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
CompareAndSetOperation(String, Data, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
 
CompareAndSetRequest - Class in com.hazelcast.concurrent.atomiclong.client
 
CompareAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
 
CompareAndSetRequest(String, long, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
 
CompareAndSetRequest - Class in com.hazelcast.concurrent.atomicreference.client
 
CompareAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
 
CompareAndSetRequest(String, Data, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
 
compareIntegers(int, int) - Static method in class com.hazelcast.util.QuickMath
Compares two integers
compareLongs(long, long) - Static method in class com.hazelcast.util.QuickMath
Compares two longs
compareTo(CollectionItem) - Method in class com.hazelcast.collection.CollectionItem
 
compareTo(MonitoredThread) - Method in class com.hazelcast.management.MonitoredThread
 
compareTo(Object) - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
 
compareTo(Object) - Method in class com.hazelcast.query.impl.IndexImpl.NullObject
 
compareTo(QueueItem) - Method in class com.hazelcast.queue.impl.QueueItem
 
ComparisonType - Enum in com.hazelcast.query.impl
Type of Comparison
CompletableFutureTask<V> - Class in com.hazelcast.util.executor
 
CompletableFutureTask(Callable<V>, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
 
CompletableFutureTask(Runnable, V, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
 
CompletedFuture<V> - Class in com.hazelcast.util.executor
 
CompletedFuture(SerializationService, Object, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletedFuture
 
completionId - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
 
completionId - Variable in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
 
compress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
 
concatenate(byte[], byte[]) - Static method in class com.hazelcast.ascii.memcache.MemcacheCommandProcessor
 
ConcurrencyUtil - Class in com.hazelcast.util
Utility methods to getOrPutSynchronized and getOrPutIfAbsent in thread safe way from ConcurrentMap with a ConstructorFunction .
ConcurrentReferenceHashMap<K,V> - Class in com.hazelcast.util
An advanced hash table supporting configurable garbage collection semantics of keys and values, optional referential-equality, full concurrency of retrievals, and adjustable expected concurrency for updates.
ConcurrentReferenceHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity, reference types, load factor and concurrency level.
ConcurrentReferenceHashMap(int, float, int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity, load factor and concurrency level.
ConcurrentReferenceHashMap(int, float) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity and load factor and with the default reference types (weak keys, strong values), and concurrencyLevel (16).
ConcurrentReferenceHashMap(int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity, reference types and with default load factor (0.75) and concurrencyLevel (16).
ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty reference map with the specified key and value reference types.
ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty reference map with the specified reference types and behavioral options.
ConcurrentReferenceHashMap(int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with the specified initial capacity, and with default reference types (weak keys, strong values), load factor (0.75) and concurrencyLevel (16).
ConcurrentReferenceHashMap() - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new, empty map with a default initial capacity (16), reference types (weak keys, strong values), default load factor (0.75) and concurrencyLevel (16).
ConcurrentReferenceHashMap(Map<? extends K, ? extends V>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
Creates a new map with the same mappings as the given map.
ConcurrentReferenceHashMap.Option - Enum in com.hazelcast.util
 
ConcurrentReferenceHashMap.ReferenceType - Enum in com.hazelcast.util
An option specifying which Java reference type should be used to refer to a key and/or value.
ConcurrentReferenceHashMap.SimpleEntry<K,V> - Class in com.hazelcast.util
 
ConcurrentReferenceHashMap.SimpleEntry(K, V) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
ConcurrentReferenceHashMap.SimpleEntry(Map.Entry<? extends K, ? extends V>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.SimpleEntry
 
ConcurrentReferenceHashMap.WriteThroughEntry - Class in com.hazelcast.util
Custom Entry class used by EntryIterator.next(), that relays setValue changes to the underlying map.
ConcurrentReferenceHashMap.WriteThroughEntry(K, V) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap.WriteThroughEntry
 
CONDITION_AWAIT - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
 
CONDITION_BEFORE_AWAIT - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
 
CONDITION_SIGNAL - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
 
ConditionKey - Class in com.hazelcast.concurrent.lock
 
ConditionKey(String, Data, String) - Constructor for class com.hazelcast.concurrent.lock.ConditionKey
 
config - Variable in class com.hazelcast.cluster.impl.AbstractJoiner
 
Config - Class in com.hazelcast.config
Contains all the configuration to start a HazelcastInstance.
Config() - Constructor for class com.hazelcast.config.Config
 
Config(String) - Constructor for class com.hazelcast.config.Config
 
config - Variable in class com.hazelcast.hibernate.local.LocalRegionCache
 
config - Variable in class com.hazelcast.instance.Node
 
config - Variable in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
config - Variable in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
 
config - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
 
config - Variable in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
 
CONFIG_CHECK - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
 
CONFIG_FILE_PATH - Static variable in class com.hazelcast.hibernate.CacheEnvironment
Property to configure the path of the hazelcast.xml or hazelcast-client.xml configuration files
CONFIG_FILE_PATH_LEGACY - Static variable in class com.hazelcast.hibernate.CacheEnvironment
Deprecated. 
ConfigBuilder - Interface in com.hazelcast.config
Interface for all config builders.
configBuilder - Variable in class com.hazelcast.spring.AbstractHazelcastBeanDefinitionParser.SpringXmlBuilderHelper
 
ConfigCheck - Class in com.hazelcast.cluster.impl
Contains enough information about Hazelcast Config, to do a validation check so that clusters with different configurations don't join.
ConfigCheck() - Constructor for class com.hazelcast.cluster.impl.ConfigCheck
 
ConfigCheck(Config, String) - Constructor for class com.hazelcast.cluster.impl.ConfigCheck
 
configCheck - Variable in class com.hazelcast.cluster.impl.JoinMessage
 
ConfigLoader - Class in com.hazelcast.config
Provides loading service for a configuration.
ConfigMemberGroupFactory - Class in com.hazelcast.partition.membergroup
 
ConfigMemberGroupFactory(Collection<MemberGroupConfig>) - Constructor for class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
 
ConfigMismatchException - Exception in com.hazelcast.cluster.impl
Exception thrown when 2 nodes want to join, but there configuration doesn't match
ConfigMismatchException(String) - Constructor for exception com.hazelcast.cluster.impl.ConfigMismatchException
 
ConfigMismatchOperation - Class in com.hazelcast.cluster.impl.operations
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated.
ConfigMismatchOperation() - Constructor for class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
 
ConfigMismatchOperation(String) - Constructor for class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
 
configs - Variable in class com.hazelcast.cache.impl.AbstractCacheService
 
configs - Variable in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
 
ConfigurableService<T> - Interface in com.hazelcast.spi
A capability for SPI services.
configure(Properties) - Method in interface com.hazelcast.hibernate.instance.IHazelcastInstanceLoader
Applies a set of properties to the factory
configure(GroupConfig, Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
Configures ICredentialsFactory.
configure(SecurityConfig, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
Configures IPermissionPolicy.
configure(T) - Method in interface com.hazelcast.spi.ConfigurableService
 
configureBlocking(boolean) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
 
configureBlocking(boolean) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
 
ConfigXmlGenerator - Class in com.hazelcast.config
The ConfigXmlGenerator is responsible for transforming a Config to a Hazelcast XML string.
ConfigXmlGenerator() - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator that will format the code.
ConfigXmlGenerator(boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
Creates a ConfigXmlGenerator.
connect(SocketAddress) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
 
connect(SocketAddress) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
 
CONNECT_ALL_WAIT_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
 
connection - Variable in class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
 
Connection - Interface in com.hazelcast.nio
Represents a 'connection' between two machines.
connection - Variable in class com.hazelcast.nio.tcp.DefaultPacketReader
 
CONNECTION_MONITOR_INTERVAL - Variable in class com.hazelcast.instance.GroupProperties
 
CONNECTION_MONITOR_MAX_FAULTS - Variable in class com.hazelcast.instance.GroupProperties
 
connectionAdded(Connection) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
 
connectionAdded(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
 
ConnectionFactoryImpl - Class in com.hazelcast.jca
Small facade to bring together container's pooling mechanism and other vendor-specific calls with the real implementation classes of this resource adapter
ConnectionFactoryImpl() - Constructor for class com.hazelcast.jca.ConnectionFactoryImpl
 
ConnectionFactoryImpl(ManagedConnectionFactoryImpl, ConnectionManager) - Constructor for class com.hazelcast.jca.ConnectionFactoryImpl
 
ConnectionListener - Interface in com.hazelcast.nio
A listener for the ConnectionManager to listen to connections being added or removed.
connectionManager - Variable in class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
 
connectionManager - Variable in class com.hazelcast.instance.Node
 
ConnectionManager - Interface in com.hazelcast.nio
Responsible for managing Connection objects.
ConnectionManagerMBean - Class in com.hazelcast.jmx
Management bean for ConnectionManager
ConnectionManagerMBean(HazelcastInstance, ConnectionManager, ManagementService) - Constructor for class com.hazelcast.jmx.ConnectionManagerMBean
 
connectionRemoved(Connection) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
 
connectionRemoved(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
 
ConnectionType - Enum in com.hazelcast.nio
An enumeration of all possible Connection types.
connectToAddress(Address) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
 
connectToAddress(Address) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
 
ConsoleApp - Class in com.hazelcast.console
Special thanks to Alexandre Vasseur for providing this very nice test application.
ConsoleApp(HazelcastInstance) - Constructor for class com.hazelcast.console.ConsoleApp
 
ConsoleCommandHandler - Class in com.hazelcast.management
Handler class for console commands that sent from Console application which located in Management Center.
ConsoleCommandHandler(HazelcastInstance) - Constructor for class com.hazelcast.management.ConsoleCommandHandler
 
ConsoleCommandRequest - Class in com.hazelcast.management.request
Request for sending console commands.
ConsoleCommandRequest() - Constructor for class com.hazelcast.management.request.ConsoleCommandRequest
 
ConsoleCommandRequest(String) - Constructor for class com.hazelcast.management.request.ConsoleCommandRequest
 
ConsoleRequest - Interface in com.hazelcast.management.request
Represents request sent from Management Center.
ConsoleRequestConstants - Class in com.hazelcast.management.request
Constants to identify serialized requests.
CONSTANT_SERIALIZERS_LENGTH - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_BOOLEAN - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_BYTE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_BYTE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_CHAR - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_CHAR_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_DATA_SERIALIZABLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_DOUBLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_DOUBLE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_FLOAT - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_FLOAT_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_INTEGER - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_INTEGER_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_LONG - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_LONG_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_NULL - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_PORTABLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_SHORT - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_SHORT_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
CONSTANT_TYPE_STRING - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
Constants - Class in com.hazelcast.aws.impl
 
Constants() - Constructor for class com.hazelcast.aws.impl.Constants
 
ConstantSerializers - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.BooleanSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.BooleanSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.BooleanSerializer
 
ConstantSerializers.ByteSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.ByteSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ByteSerializer
 
ConstantSerializers.CharArraySerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.CharArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.CharArraySerializer
 
ConstantSerializers.CharSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.CharSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.CharSerializer
 
ConstantSerializers.DoubleArraySerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.DoubleArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.DoubleArraySerializer
 
ConstantSerializers.DoubleSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.DoubleSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.DoubleSerializer
 
ConstantSerializers.FloatArraySerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.FloatArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.FloatArraySerializer
 
ConstantSerializers.FloatSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.FloatSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.FloatSerializer
 
ConstantSerializers.IntegerArraySerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.IntegerArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.IntegerArraySerializer
 
ConstantSerializers.IntegerSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.IntegerSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.IntegerSerializer
 
ConstantSerializers.LongArraySerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.LongArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.LongArraySerializer
 
ConstantSerializers.LongSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.LongSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.LongSerializer
 
ConstantSerializers.ShortArraySerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.ShortArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ShortArraySerializer
 
ConstantSerializers.ShortSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.ShortSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ShortSerializer
 
ConstantSerializers.StringSerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.StringSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.StringSerializer
 
ConstantSerializers.TheByteArraySerializer - Class in com.hazelcast.nio.serialization
 
ConstantSerializers.TheByteArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
 
ConstructorFunction<K,V> - Interface in com.hazelcast.util
See ConcurrencyUtil
container - Variable in class com.hazelcast.queue.impl.QueueItem
 
contains(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
 
contains(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
Determines if this store contains an entry for the specified key.
contains(Object) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
 
contains(E) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
 
contains(Object) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
contains(Object) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
 
contains(Set<Data>) - Method in class com.hazelcast.collection.CollectionContainer
 
CONTAINS - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
 
contains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
 
contains(Data) - Method in class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
 
contains(E) - Method in interface com.hazelcast.core.IAtomicReference
Checks if the reference contains the value.
contains(Object) - Method in class com.hazelcast.hibernate.distributed.IMapRegionCache
 
contains(Object) - Method in class com.hazelcast.hibernate.local.LocalRegionCache
 
contains(Object) - Method in interface com.hazelcast.hibernate.RegionCache
 
CONTAINS - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
contains(Object) - Method in class com.hazelcast.query.impl.AndResultSet
 
contains(Object) - Method in class com.hazelcast.query.impl.MultiResultSet
 
contains(Object) - Method in class com.hazelcast.query.impl.OrResultSet
 
contains(Object) - Method in class com.hazelcast.query.impl.SingleResultSet
 
contains(Object) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
 
contains(Collection<Data>) - Method in class com.hazelcast.queue.impl.QueueContainer
This method does not trigger store load.
CONTAINS - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
 
CONTAINS - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
 
contains(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Legacy method testing if some key maps into the specified value in this table.
CONTAINS_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
CONTAINS_ENTRY - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
 
CONTAINS_ENTRY - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
 
CONTAINS_KEY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
 
CONTAINS_KEY - Static variable in class com.hazelcast.cache.impl.CachePortableHook
 
CONTAINS_KEY - Static variable in class com.hazelcast.map.impl.MapPortableHook
 
CONTAINS_KEY - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
CONTAINS_VALUE - Static variable in class com.hazelcast.map.impl.MapPortableHook
 
CONTAINS_VALUE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
 
containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.AbstractClientCollectionProxy
 
containsAll(Collection<?>) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
 
containsAll(Collection<?>) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
 
containsAll(Collection<?>) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
 
containsAtomicLong(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
 
containsAtomicReference(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
 
containsCollection(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
 
containsEntry(K, V) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
containsEntry(K, V) - Method in interface com.hazelcast.core.MultiMap
Returns whether the multimap contains the given key-value pair.
containsEntry(boolean, Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
containsEntry(K, V) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
ContainsEntryOperation - Class in com.hazelcast.multimap.impl.operations
 
ContainsEntryOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
ContainsEntryOperation(String, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
ContainsEntryOperation(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
 
containsInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
 
containsKey(K) - Method in class com.hazelcast.cache.impl.CacheProxy
 
containsKey(K) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
 
containsKey(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
containsKey(K) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
containsKey(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
containsKey(Object) - Method in class com.hazelcast.client.txn.proxy.ClientTxnMapProxy
 
containsKey(Object) - Method in interface com.hazelcast.core.BaseMap
Returns true if this map contains an entry for the specified key.
containsKey(Object) - Method in interface com.hazelcast.core.IMap
Returns true if this map contains an entry for the specified key.
containsKey(K) - Method in interface com.hazelcast.core.MultiMap
Returns whether the multimap contains an entry with the key.
containsKey(Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.containsKey(Object).
containsKey(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
 
containsKey(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
containsKey(Data) - Method in interface com.hazelcast.map.impl.RecordStore
 
containsKey(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
 
containsKey(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
containsKey(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
containsKey(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
containsKey(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Tests if the specified object is a key in this table.
containsKeyInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
 
ContainsKeyOperation - Class in com.hazelcast.map.impl.operation
 
ContainsKeyOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
ContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
 
containsLatch(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
 
ContainsOperation - Class in com.hazelcast.concurrent.atomicreference.operations
 
ContainsOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
ContainsOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
 
ContainsOperation - Class in com.hazelcast.queue.impl.operations
Checks whether contain or not item in the Queue.
ContainsOperation() - Constructor for class com.hazelcast.queue.impl.operations.ContainsOperation
 
ContainsOperation(String, Collection<Data>) - Constructor for class com.hazelcast.queue.impl.operations.ContainsOperation
 
containsQueue(String) - Method in class com.hazelcast.queue.impl.QueueService
 
containsRecordId(long) - Method in class com.hazelcast.multimap.impl.MultiMapWrapper
 
ContainsRequest - Class in com.hazelcast.concurrent.atomicreference.client
 
ContainsRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
 
ContainsRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
 
ContainsRequest - Class in com.hazelcast.multimap.impl.client
The contains requests checks if a value is stored in the multimap.
ContainsRequest() - Constructor for class com.hazelcast.multimap.impl.client.ContainsRequest
 
ContainsRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.ContainsRequest
 
ContainsRequest - Class in com.hazelcast.queue.impl.client
Provides the request service for ContainsOperation
ContainsRequest() - Constructor for class com.hazelcast.queue.impl.client.ContainsRequest
 
ContainsRequest(String, Collection<Data>) - Constructor for class com.hazelcast.queue.impl.client.ContainsRequest
 
containsSemaphore(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
 
containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientMapProxy
 
containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientMultiMapProxy
 
containsValue(Object) - Method in class com.hazelcast.client.proxy.ClientReplicatedMapProxy
 
containsValue(Object) - Method in interface com.hazelcast.core.IMap
containsValue(Object) - Method in interface com.hazelcast.core.MultiMap
Returns whether the multimap contains an entry with the value.
containsValue(Object) - Method in class com.hazelcast.map.impl.DefaultRecordStore
 
containsValue(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
 
containsValue(Object) - Method in interface com.hazelcast.map.impl.RecordStore
 
containsValue(boolean, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
 
containsValue(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
 
containsValue(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
 
containsValue(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
 
containsValue(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
 
containsValue(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
Returns true if this map maps one or more keys to the specified value.
ContainsValueOperation - Class in com.hazelcast.map.impl.operation
 
ContainsValueOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
 
ContainsValueOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
 
ContainsValueOperationFactory - Class in com.hazelcast.map.impl.operation
 
ContainsValueOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
 
ContainsValueOperationFactory(String, Data) - Constructor for class com.hazelcast.map.impl.operation.