- AbstractAllPartitionsMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
- AbstractAllPartitionsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractAllPartitionsMessageTask
-
- 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
-
- AbstractAtomicLongOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AbstractAtomicLongOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
-
- AbstractAtomicLongOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAtomicLongOperation
-
- AbstractAtomicReferenceOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- AbstractAtomicReferenceOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
-
- AbstractAtomicReferenceOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAtomicReferenceOperation
-
- AbstractBaseReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
-
Internal base class to encapsulate the internals from the interface methods of ReplicatedRecordStore
- AbstractBaseReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-
- AbstractCacheMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.cache
-
Abstract Cache request to handle InMemoryFormat which needed for operation provider
- AbstractCacheMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.AbstractCacheMessageTask
-
- 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
-
- AbstractCacheService - Class in com.hazelcast.cache.impl
-
- AbstractCacheService() - Constructor for class com.hazelcast.cache.impl.AbstractCacheService
-
- AbstractCallableMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
Base callable Message task.
- AbstractCallableMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractCallableMessageTask
-
- AbstractClientSelectionHandler - Class in com.hazelcast.client.connection.nio
-
The AbstractClientSelectionHandler gets called by an IO-thread when there is data available to read,
or space available to write.
- AbstractClientSelectionHandler(ClientConnection, NonBlockingIOThread, LoggingService) - Constructor for class com.hazelcast.client.connection.nio.AbstractClientSelectionHandler
-
- AbstractClientTxnCollectionProxy<E> - Class in com.hazelcast.client.proxy.txn
-
- AbstractClientTxnCollectionProxy(String, ClientTransactionContext) - Constructor for class com.hazelcast.client.proxy.txn.AbstractClientTxnCollectionProxy
-
- AbstractClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
-
- AbstractClusterWideIterator(ICache<K, V>, int, int, boolean) - Constructor for class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- AbstractCollectionProxyImpl<S extends RemoteService,E> - Class in com.hazelcast.collection.impl.collection
-
- AbstractCollectionProxyImpl(String, NodeEngine, S) - Constructor for class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- AbstractCompletableFuture<V> - Class in com.hazelcast.spi.impl
-
A base
ICompletableFuture
implementation that may be explicitly completed by setting its
value through setResult.
- AbstractCompletableFuture(NodeEngine, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- AbstractCompletableFuture(Executor, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- AbstractConfigBuilder - Class in com.hazelcast.config
-
Contains logic for replacing system variables in the XML file and importing XML files from different locations.
- AbstractConfigBuilder() - Constructor for class com.hazelcast.config.AbstractConfigBuilder
-
- AbstractConfigBuilder.ConfigType - Enum in com.hazelcast.config
-
- AbstractCredentials - Class in com.hazelcast.security
-
- AbstractCredentials() - Constructor for class com.hazelcast.security.AbstractCredentials
-
- AbstractCredentials(String) - Constructor for class com.hazelcast.security.AbstractCredentials
-
- AbstractDiscoveryStrategy - Class in com.hazelcast.spi.discovery
-
An common abstract superclass for
DiscoveryStrategy
implementations,
offering convenient access to configuration properties (which may be overridden
on the system's environment or JVM properties), as well as a
ILogger
instance.
- AbstractDiscoveryStrategy(ILogger, Map<String, Comparable>) - Constructor for class com.hazelcast.spi.discovery.AbstractDiscoveryStrategy
-
- 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
-
- AbstractEntryProcessor() - Constructor for class com.hazelcast.map.AbstractEntryProcessor
-
- AbstractEntryProcessor(boolean) - Constructor for class com.hazelcast.map.AbstractEntryProcessor
-
Creates an AbstractEntryProcessor.
- AbstractEvictionStrategy<A,E extends Evictable,S extends EvictableStore<A,E>> - Class in com.hazelcast.internal.eviction.impl.strategy
-
- AbstractEvictionStrategy() - Constructor for class com.hazelcast.internal.eviction.impl.strategy.AbstractEvictionStrategy
-
- AbstractExecutorServiceCancelMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.executorservice
-
- AbstractExecutorServiceCancelMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-
- AbstractExecutorThreadFactory - Class in com.hazelcast.util.executor
-
- AbstractExecutorThreadFactory(ThreadGroup, ClassLoader) - Constructor for class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-
- AbstractFilteringStrategy - Class in com.hazelcast.map.impl.event
-
A common abstract class to support implementations of filtering strategies.
- AbstractFilteringStrategy(SerializationService, MapServiceContext) - Constructor for class com.hazelcast.map.impl.event.AbstractFilteringStrategy
-
- AbstractHandler - Class in com.hazelcast.nio.tcp.nonblocking
-
- AbstractHandler(TcpIpConnection, NonBlockingIOThread, int) - Constructor for class com.hazelcast.nio.tcp.nonblocking.AbstractHandler
-
- AbstractHandler - Class in com.hazelcast.nio.tcp.spinning
-
- AbstractHandler(TcpIpConnection, ILogger) - Constructor for class com.hazelcast.nio.tcp.spinning.AbstractHandler
-
- 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
-
- 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
-
- AbstractICacheEvent - Class in com.hazelcast.cache.impl.event
-
- AbstractICacheEvent(Object, Member, int) - Constructor for class com.hazelcast.cache.impl.event.AbstractICacheEvent
-
Constructs a prototypical Cache Event.
- 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.
- AbstractIndexAwarePredicate<K,V> - Class in com.hazelcast.query.impl.predicates
-
- AbstractIndexAwarePredicate() - Constructor for class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
-
- AbstractIndexAwarePredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.AbstractIndexAwarePredicate
-
- AbstractInvocationFuture<V> - Class in com.hazelcast.spi.impl
-
- AbstractInvocationFuture(Executor, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractInvocationFuture
-
- AbstractInvocationMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
- AbstractInvocationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractInvocationMessageTask
-
- 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.internal.cluster.impl
-
- AbstractJoiner(Node) - Constructor for class com.hazelcast.internal.cluster.impl.AbstractJoiner
-
- AbstractLoadBalancer - Class in com.hazelcast.client.util
-
- AbstractLoadBalancer() - Constructor for class com.hazelcast.client.util.AbstractLoadBalancer
-
- AbstractLockOperation - Class in com.hazelcast.concurrent.lock.operations
-
- AbstractLockOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
-
- AbstractLockOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
-
- AbstractLockOperation(ObjectNamespace, Data, long, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
-
- AbstractLockOperation(ObjectNamespace, Data, long, long, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
-
- 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
-
- AbstractMapAddEntryListenerMessageTask<Parameter> - Class in com.hazelcast.client.impl.protocol.task.map
-
- AbstractMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-
- 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
-
- AbstractMapPartitionIterator<K,V> - Class in com.hazelcast.map.impl.iterator
-
- AbstractMapPartitionIterator(IMap<K, V>, int, int, boolean) - Constructor for class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
-
- AbstractMapPutMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
-
- AbstractMapPutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
-
- AbstractMapQueryMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.map
-
- AbstractMapQueryMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-
- AbstractMapReduceTask<Parameters> - Class in com.hazelcast.client.impl.protocol.task.mapreduce
-
- AbstractMapReduceTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.mapreduce.AbstractMapReduceTask
-
- AbstractMember - Class in com.hazelcast.instance
-
- AbstractMember() - Constructor for class com.hazelcast.instance.AbstractMember
-
- AbstractMember(Address) - Constructor for class com.hazelcast.instance.AbstractMember
-
- AbstractMember(Address, String) - Constructor for class com.hazelcast.instance.AbstractMember
-
- AbstractMember(Address, String, Map<String, Object>) - Constructor for class com.hazelcast.instance.AbstractMember
-
- AbstractMember(Address, String, Map<String, Object>, boolean) - Constructor for class com.hazelcast.instance.AbstractMember
-
- AbstractMember(AbstractMember) - Constructor for class com.hazelcast.instance.AbstractMember
-
- AbstractMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
Base Message task
- AbstractMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractMessageTask
-
- AbstractMultiMapAddEntryListenerMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task.multimap
-
- AbstractMultiMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-
- AbstractMultiPartitionMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
- AbstractMultiPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-
- AbstractMultiTargetMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
- AbstractMultiTargetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractMultiTargetMessageTask
-
- AbstractMultiValueGetter - Class in com.hazelcast.query.impl.getters
-
- AbstractMultiValueGetter(Getter, String, Class<?>, Class) - Constructor for class com.hazelcast.query.impl.getters.AbstractMultiValueGetter
-
- 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
-
- AbstractNearCacheInvalidator - Class in com.hazelcast.map.impl.nearcache
-
Contains common functionality of a NearCacheInvalidator
- AbstractNearCacheInvalidator(MapServiceContext, NearCacheProvider) - Constructor for class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-
- AbstractNearCacheRecord<V> - Class in com.hazelcast.cache.impl.nearcache.impl.record
-
Abstract implementation of
NearCacheRecord
with value and
expiration time as internal state.
- AbstractNearCacheRecord(V, long, long) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-
- AbstractNearCacheRecordStore<K,V,KS,R extends NearCacheRecord,NCRM extends NearCacheRecordMap<KS,R>> - Class in com.hazelcast.cache.impl.nearcache.impl.store
-
- AbstractNearCacheRecordStore(NearCacheConfig, NearCacheContext) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-
- AbstractNearCacheRecordStore(NearCacheConfig, NearCacheContext, NearCacheStatsImpl) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-
- AbstractNearCacheRecordStore.MaxSizeEvictionChecker - Class in com.hazelcast.cache.impl.nearcache.impl.store
-
- AbstractNearCacheRecordStore.MaxSizeEvictionChecker() - Constructor for class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore.MaxSizeEvictionChecker
-
- AbstractOperation - Class in com.hazelcast.spi
-
- AbstractOperation() - Constructor for class com.hazelcast.spi.AbstractOperation
-
Deprecated.
- AbstractPartitionMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
AbstractPartitionMessageTask
- AbstractPartitionMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
-
- AbstractPredicate<K,V> - Class in com.hazelcast.query.impl.predicates
-
Provides base features for predicates, such as extraction and convertion of the attribute's value.
- AbstractPredicate() - Constructor for class com.hazelcast.query.impl.predicates.AbstractPredicate
-
- AbstractPredicate(String) - Constructor for class com.hazelcast.query.impl.predicates.AbstractPredicate
-
- AbstractRecord<V> - Class in com.hazelcast.map.impl.record
-
- AbstractRemoveListenerMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
Base class for remove listener message tasks that removes a client listener registration
from a node
- AbstractRemoveListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-
- AbstractReplicatedMapAddEntryListenerMessageTask<Parameter> - Class in com.hazelcast.client.impl.protocol.task.replicatedmap
-
- AbstractReplicatedMapAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- AbstractReplicatedMapOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
- AbstractReplicatedMapOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-
- AbstractReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
-
- AbstractReplicatedRecordStore(String, ReplicatedMapService, int) - Constructor for class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- AbstractRingBufferOperation - Class in com.hazelcast.ringbuffer.impl.operations
-
- AbstractRingBufferOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
-
- AbstractRingBufferOperation(String) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AbstractRingBufferOperation
-
- AbstractSerializationService - Class in com.hazelcast.internal.serialization.impl
-
- AbstractTextCommand - Class in com.hazelcast.internal.ascii
-
- AbstractTextCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.internal.ascii.AbstractTextCommand
-
- AbstractTextCommandProcessor<T> - Class in com.hazelcast.internal.ascii
-
- AbstractTextCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.internal.ascii.AbstractTextCommandProcessor
-
- AbstractTransactionalCollectionProxy<S extends RemoteService,E> - Class in com.hazelcast.collection.impl.txncollection
-
- AbstractTransactionalCollectionProxy(String, Transaction, NodeEngine, S) - Constructor for class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-
- AbstractTransactionalMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
- AbstractTransactionalMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
-
- AbstractTxOperation - Class in com.hazelcast.transaction.impl.operations
-
- AbstractTxOperation() - Constructor for class com.hazelcast.transaction.impl.operations.AbstractTxOperation
-
- AbstractVisitor - Class in com.hazelcast.query.impl.predicates
-
Base class for all visitors.
- AbstractVisitor() - Constructor for class com.hazelcast.query.impl.predicates.AbstractVisitor
-
- AbstractWaitNotifyKey - Class in com.hazelcast.spi
-
Abstract implementation of the WaitNotifyKey.
- AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.AbstractWaitNotifyKey
-
- AbstractXAOperation - Class in com.hazelcast.transaction.impl.xa.operations
-
- AbstractXAOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.AbstractXAOperation
-
- AbstractXmlConfigHelper - Class in com.hazelcast.config
-
Contains Hazelcast Xml Configuration helper methods and variables.
- AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
-
- accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-
- accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
-
- accept(Visitor, Indexes) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-
- accept(Visitor, Indexes) - Method in class com.hazelcast.query.SqlPredicate
-
- accept(Visitor, Indexes) - Method in interface com.hazelcast.query.VisitablePredicate
-
Accept visitor.
- accept(int, int, V) - Method in interface com.hazelcast.util.collection.BiInt2ObjectMap.EntryConsumer
-
A map entry
- accept(T, U) - Method in interface com.hazelcast.util.function.BiConsumer
-
Performs this operation on the given arguments.
- accept(T) - Method in interface com.hazelcast.util.function.Consumer
-
Performs this operation on the given argument.
- accept(long, long) - Method in interface com.hazelcast.util.function.LongLongConsumer
-
Accept a key and value that comes as a tuple of longs.
- 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, long) - Method in class com.hazelcast.internal.cluster.impl.ClusterHeartbeatManager
-
- acceptVisitor(Predicate[], Visitor, Indexes) - Static method in class com.hazelcast.query.impl.predicates.VisitorUtils
-
Accept visitor by all predicates.
- access() - Method in class com.hazelcast.map.impl.nearcache.NearCacheRecord
-
- access() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- ACCESS_CONTROL - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- accessHit - Variable in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-
- accessHit - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- accessRecord(Data, R, ExpiryPolicy, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- accessTime - Variable in class com.hazelcast.cache.impl.nearcache.impl.record.AbstractNearCacheRecord
-
- accessTime - Variable in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- accumulateOrInvalidate(String, Data, List<Data>, String) - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-
- 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.SemaphoreContainer
-
- 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
-
- 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
-
- activate() - Method in interface com.hazelcast.osgi.impl.HazelcastInternalOSGiService
-
Activates the service.
- Activator - Class in com.hazelcast.osgi.impl
-
Hazelcast OSGi bundle activator.
- Activator() - Constructor for class com.hazelcast.osgi.impl.Activator
-
- activeConnectionCount - Variable in class com.hazelcast.internal.management.dto.ConnectionManagerDTO
-
- add(int, E) - Method in class com.hazelcast.client.proxy.ClientListProxy
-
- add(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.proxy.ClientRingbufferProxy
-
- add(E) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-
- add(E) - Method in class com.hazelcast.client.proxy.txn.ClientTxnListProxy
-
- add(E) - Method in class com.hazelcast.client.proxy.txn.ClientTxnSetProxy
-
- add(E) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- add(Data) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- add(int, Data) - Method in class com.hazelcast.collection.impl.list.ListContainer
-
- add(int, E) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-
- add(E) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-
- add(E) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-
- add(E) - Method in class com.hazelcast.collection.impl.txnset.TransactionalSetProxy
-
- add(CountDownLatchContainer) - 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(Callable) - Method in class com.hazelcast.durableexecutor.impl.TaskRingBuffer
-
Adds the task to next available spot and returns the sequence corresponding to that spot.
- add(M) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
-
- add(long) - Method in interface com.hazelcast.internal.util.collection.LongSet
-
- add(long) - Method in class com.hazelcast.internal.util.collection.LongSetHsa
-
- add(Data, Data) - Method in class com.hazelcast.map.impl.MapEntries
-
- 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(DelayedEntry<Data, Object>) - 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(SingleNearCacheInvalidation) - Method in class com.hazelcast.map.impl.nearcache.BatchNearCacheInvalidation
-
- add(long) - Method in class com.hazelcast.map.impl.nearcache.NearCacheSizeEstimator
-
- add(long) - Method in interface com.hazelcast.map.impl.SizeEstimator
-
- add(QueryableEntry) - Method in class com.hazelcast.query.impl.FastMultiResultSet
-
- add(T) - Method in class com.hazelcast.query.impl.getters.MultiResult
-
- add(Data, Data) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntries
-
- add(Object) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-
- add(Data) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
- add(E) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-
- add(E) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Adds an item to the tail of the Ringbuffer.
- 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(Object, boolean) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.DefaultOperationQueue
-
- add(Object, boolean) - Method in interface com.hazelcast.spi.impl.operationexecutor.impl.OperationQueue
-
Adds an task to this queue.
- add(Address, long) - Method in class com.hazelcast.spi.LiveOperations
-
- add(TransactionLogRecord) - Method in interface com.hazelcast.transaction.impl.Transaction
-
- add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.TransactionLog
-
- add(TransactionLogRecord) - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-
- add(T) - Method in class com.hazelcast.util.collection.InflatableSet
-
- add(T) - Method in class com.hazelcast.util.collection.InflatableSet.Builder
-
- add(Integer) - Method in class com.hazelcast.util.collection.IntHashSet
- add(int) - Method in class com.hazelcast.util.collection.IntHashSet
-
Primitive specialised overload of {this#add(Integer)}
- add(Long) - Method in class com.hazelcast.util.collection.LongHashSet
- add(long) - Method in class com.hazelcast.util.collection.LongHashSet
-
Primitive specialised overload of {this#add(Long)}
- add(T, long) - Method in class com.hazelcast.util.ItemCounter
-
Add delta to the item
- add(E) - Method in class com.hazelcast.util.UnmodifiableListIterator
-
- ADD_ALL - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- ADD_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- ADD_ALL_BACKUP - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- ADD_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- ADD_ALL_BACKUP_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-
- ADD_ALL_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-
- ADD_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- ADD_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- ADD_BACKUP_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-
- ADD_OPERATION - Static variable in class com.hazelcast.ringbuffer.impl.RingbufferDataSerializerHook
-
- addAction(String) - Method in class com.hazelcast.config.PermissionConfig
-
- addActiveMigration(MigrationInfo) - Method in class com.hazelcast.internal.partition.impl.MigrationManager
-
- 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(int, Collection<? extends E>) - Method in class com.hazelcast.client.proxy.ClientListProxy
-
- addAll(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.client.proxy.ClientSetProxy
-
- addAll(Collection<? extends E>) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- addAll(List<Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- addAll(int, List<Data>) - Method in class com.hazelcast.collection.impl.list.ListContainer
-
- addAll(int, Collection<? extends E>) - Method in class com.hazelcast.collection.impl.list.ListProxyImpl
-
- addAll(Collection<Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- addAll(Collection<? extends E>) - Method in class com.hazelcast.collection.impl.queue.QueueProxyImpl
-
- addAll(List<Data>) - Method in class com.hazelcast.collection.impl.set.SetContainer
-
- addAll(Collection<? extends M>) - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
-
- addAll(Collection<QueryableEntry>) - Method in class com.hazelcast.map.impl.query.QueryResult
-
- addAll(Data[]) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
- addAll(Collection<? extends Integer>) - Method in class com.hazelcast.util.collection.IntHashSet
- addAll(Collection<? extends Long>) - Method in class com.hazelcast.util.collection.LongHashSet
- addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-
- addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-
- addAllAsync(Collection<? extends E>, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Adds all the items of a collection to the tail of the Ringbuffer.
- addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- AddAllBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
-
- AddAllBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-
- AddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllBackupOperation
-
- AddAllBackupOperation - Class in com.hazelcast.ringbuffer.impl.operations
-
- AddAllBackupOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
-
- AddAllBackupOperation(String, Data[]) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllBackupOperation
-
- AddAllOperation - Class in com.hazelcast.collection.impl.queue.operations
-
Add collection items to the Queue.
- AddAllOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-
- AddAllOperation(String, Collection<Data>) - Constructor for class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-
- AddAllOperation - Class in com.hazelcast.ringbuffer.impl.operations
-
- AddAllOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-
- AddAllOperation(String, Data[], OverflowPolicy) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddAllOperation
-
- addAllRows(Collection<QueryResultRow>) - Method in class com.hazelcast.map.impl.query.QueryResult
-
- addAllRows(Collection<QueryResultRow>) - Method in class com.hazelcast.map.impl.query.QueryResultCollection
-
- addAndGet(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-
- addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- 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.internal.jmx.AtomicLongMBean
-
- addAndGetAsync(long) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- addAndGetAsync(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- addAndGetAsync(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically adds the given value to the current value.
- 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
-
- addAsync(E, OverflowPolicy) - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-
- addAsync(E, OverflowPolicy) - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-
- addAsync(E, OverflowPolicy) - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
- addAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- addBackup(long, Data) - Method in class com.hazelcast.collection.impl.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
-
- AddBackupOperation - Class in com.hazelcast.ringbuffer.impl.operations
-
- AddBackupOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
-
- AddBackupOperation(String, Data) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddBackupOperation
-
- addBooleanArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- 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(CacheConfig) - Method in class com.hazelcast.cache.impl.operation.PostJoinCacheOperation
-
- 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
-
Deprecated.
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Add a configuration for a CacheEntryListener
.
- addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
Adds the CachePartitionLostListenerConfig to partitionLostListenerConfigs.
- addCachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
Deprecated.
- addCacheResource(String, Closeable) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- 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.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- addClassDefinition(ClassDefinition) - Method in interface com.hazelcast.internal.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
-
- addConnection(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.spinning.SpinningInputThread
-
- addConnection(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.spinning.SpinningOutputThread
-
- addConnectionHeartbeatListener(ConnectionHeartbeatListener) - Method in interface com.hazelcast.client.connection.ClientConnectionManager
-
- addConnectionHeartbeatListener(ConnectionHeartbeatListener) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- addConnectionListener(ConnectionListener) - Method in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.nio.ConnectionListenable
-
Registers a ConnectionListener.
- addConnectionListener(ConnectionListener) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- addContainer(String, CollectionContainer) - Method in class com.hazelcast.collection.impl.collection.CollectionService
-
- addContainer(String, QueueContainer) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
-
- addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- addDataSerializableFactory(int, DataSerializableFactory) - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-
- addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
-
- addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- addDestroyAction(String, Callable<Boolean>) - Method in interface com.hazelcast.client.ClientEndpoint
-
Adds a remove callable to be called when endpoint is destroyed
Note: removeDestroyAction should be called when there is no need to destroy action anymore.
- addDestroyAction(String, Callable<Boolean>) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfig
-
- addDiscoveryStrategyConfig(DiscoveryStrategyConfig) - Method in class com.hazelcast.config.DiscoveryConfigReadOnly
-
Deprecated.
- 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
-
- AddDistributedObjectListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- AddDistributedObjectListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- addDoubleArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addDurableExecutorConfig(DurableExecutorConfig) - Method in class com.hazelcast.config.Config
-
Adds a new DurableExecutorConfig by name
- addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
-
- addEntryListener(MapListener, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addEntryListener(MapListener, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addEntryListener(EntryListener, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addEntryListener(EntryListener, 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(MapListener, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(EntryListener, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(EntryListener, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- 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(MapListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(MapListener, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(MapListener, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- addEntryListener(MapListener, K, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- addEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- addEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- 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<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
-
Deprecated.
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-
Deprecated.
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfig
-
Adds an entry listener to this MultiMap (listens for when entries are added or removed).
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
Deprecated.
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.QueryCacheConfig
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- addEventData(CacheEventData) - Method in class com.hazelcast.cache.impl.CacheEventSet
-
Helper method for adding multiple CacheEventData into this Set
- addEventHandler(long, EventHandler) - Method in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-
- addEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addEventListener(EventListener, EventFilter, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEventPublishingService
-
- addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
-
Adds a new ExecutorConfig by name
- addField(FieldDefinitionImpl) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addFieldDef(FieldDefinitionImpl) - Method in class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- addFilter(String) - Method in class com.hazelcast.config.WanReplicationRef
-
- addFirst(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Inserts collection of elements to the front of this queue.
- addFlag(short) - Method in class com.hazelcast.client.impl.protocol.ClientMessage
-
Sets the flags field value.
- addFloatArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- 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.
- addIndex(String, boolean) - Method in interface com.hazelcast.map.QueryCache
-
- addIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.QueryCacheConfig
-
- AddIndexOperation - Class in com.hazelcast.map.impl.operation
-
- AddIndexOperation() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
-
- AddIndexOperation(String, String, boolean) - 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(String, 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() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- AddInterceptorOperation(String, MapInterceptor, String) - 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
-
- addInvalidationListener(String, CacheEventListener, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- addInvalidationListener(String, CacheEventListener, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- addInvalidationMessage(CacheSingleInvalidationMessage) - Method in class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-
- addItem(Object) - Method in class com.hazelcast.ringbuffer.impl.ReadResultSetImpl
-
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientListProxy
-
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientQueueProxy
-
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.client.proxy.ClientSetProxy
-
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- addItemListener(String, ItemListener, boolean, boolean) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- addItemListener(ItemListener<E>, boolean) - Method in interface com.hazelcast.core.ICollection
-
Adds an item listener for this collection.
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.CollectionConfig
-
Adds an item listener to this collection (listens for when items are added or removed).
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.ListConfigReadOnly
-
Deprecated.
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfig
-
Add an item listener configuration to this queue.
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
Deprecated.
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
-
Deprecated.
- addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.config.Config
-
- addLast(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Inserts to the end of this queue.
- 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
-
- addListenerConfig(QuorumListenerConfig) - Method in class com.hazelcast.config.QuorumConfig
-
- addListenerDestroyAction(String, String, String) - Method in interface com.hazelcast.client.ClientEndpoint
-
Adds a remove callable to be called when endpoint is destroyed to clean related listener
Following line will be called when endpoint destroyed :
eventService.deregisterListener(service, topic, id);
Note: removeDestroyAction should be called when there is no need to destroy action anymore.
- addListenerDestroyAction(String, String, String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- addLocalEntryListener(MapListener) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addLocalEntryListener(EntryListener) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addLocalEntryListener(EntryListener, 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(MapListener) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(EntryListener) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds a local entry listener for this map.
- addLocalEntryListener(EntryListener, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
- addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.MultiMap
-
Adds a local entry listener for this multimap.
- addLocalEntryListener(MapListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(MapListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(MapListener, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener, 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(Object, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addLocalEventListener(Object, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addLocalPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
-
- addLocalPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
-
- addLocalPartitionLostListener(MapPartitionLostListener, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addLocalPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
-
- addLogListener(Level, LogListener) - Method in class com.hazelcast.client.impl.ClientLoggingService
-
- 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
-
- addMapAttributeConfig(MapAttributeConfig) - Method in class com.hazelcast.config.MapConfig
-
- addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
-
- addMapEntrySet(Object, Object, MapEntries) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- addMapEntrySet(Map<Object, Object>, MapEntries) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- 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
-
Deprecated.
- addMapInterceptors(MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-
- addMapPartitionLostListenerConfig(MapPartitionLostListenerConfig) - Method in class com.hazelcast.config.MapConfig
-
- 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
-
- 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 interface com.hazelcast.core.Cluster
-
Adds MembershipListener to listen for membership updates.
- addMembershipListener(MembershipListener) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- AddMembershipListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- AddMembershipListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-
- addMessageListener(MessageListener<E>) - Method in class com.hazelcast.client.proxy.ClientReliableTopicProxy
-
- 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.reliable.ReliableTopicProxy
-
- addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.TopicProxy
-
- addMessageListener(String, MessageListener, boolean) - Method in class com.hazelcast.topic.impl.TopicService
-
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.ReliableTopicConfig
-
Adds a message listener (listens for when messages are added or removed) to this reliable topic.
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
-
Adds a message listener to this topic (listens for when messages are added or removed).
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfigReadOnly
-
Deprecated.
- addMessageListenerInternal(MessageListener) - Method in class com.hazelcast.topic.impl.TopicProxySupport
-
- 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.internal.partition.impl.InternalPartitionServiceImpl
-
- addMigrationListener(MigrationListener) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
-
- addMigrationListener(MigrationListener) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
-
- addMigrationListener(MigrationListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
-
- addMulticastListener(MulticastListener) - Method in class com.hazelcast.internal.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
- addNearCacheInvalidateListener() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- addNearCacheInvalidateListener(EventHandler) - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- addNearCacheStats(LocalMapStatsImpl, LocalMapStatsProvider.LocalMapOnDemandCalculatedStats, MapContainer) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-
Adds near cache stats.
- addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- addObject(T) - Method in class com.hazelcast.query.extractor.ValueCollector
-
Collects a value passed as an argument
- addObject(Object) - Method in class com.hazelcast.query.impl.DefaultValueCollector
-
- addOperation(CollectionTxnOperation) - Method in class com.hazelcast.collection.impl.txncollection.CollectionTransactionLogRecord
-
- addOperation(Operation) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLogRecord
-
- AddOperation - Class in com.hazelcast.ringbuffer.impl.operations
-
- AddOperation() - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddOperation
-
- AddOperation(String, Data, OverflowPolicy) - Constructor for class com.hazelcast.ringbuffer.impl.operations.AddOperation
-
- addOrGetIndex(String, boolean) - Method in class com.hazelcast.query.impl.Indexes
-
- addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
-
- addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
-
- addOwnerPartitionStats(LocalMapStatsImpl, LocalMapStatsProvider.LocalMapOnDemandCalculatedStats, String, int) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-
Calculates and adds owner partition stats.
- addOwnershipMapping(String, String) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- addPartitionListener(PartitionListener) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
-
- addPartitionLostListener(CachePartitionLostListener) - Method in interface com.hazelcast.cache.ICache
-
Adds a CachePartitionLostListener.
- addPartitionLostListener(CachePartitionLostListener) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- addPartitionLostListener(CachePartitionLostListener) - Method in class com.hazelcast.client.cache.impl.ClientCacheProxy
-
- addPartitionLostListener(MapPartitionLostListener) - Method in class com.hazelcast.client.proxy.ClientMapProxy
-
- addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.client.proxy.PartitionServiceProxy
-
- addPartitionLostListener(MapPartitionLostListener) - Method in interface com.hazelcast.core.IMap
-
Adds a MapPartitionLostListener.
- addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.core.PartitionService
-
Adds a PartitionLostListener.
- addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
-
- addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.impl.PartitionEventManager
-
- addPartitionLostListener(PartitionLostListener) - Method in class com.hazelcast.internal.partition.PartitionServiceProxy
-
- addPartitionLostListener(MapPartitionLostListener, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addPartitionLostListener(MapPartitionLostListener) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addPartitionLostListener(PartitionLostListener) - Method in interface com.hazelcast.spi.partition.IPartitionService
-
- AddPartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
- AddPartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-
- 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.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- addPortableFactory(int, PortableFactory) - Method in interface com.hazelcast.internal.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, Comparable) - Method in class com.hazelcast.config.DiscoveryStrategyConfig
-
- addProperty(String, String) - Method in class com.hazelcast.config.ServiceConfig
-
- addProxyFactoryConfig(ProxyFactoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
- addProxyListener(DistributedObjectListener) - Method in class com.hazelcast.spi.impl.proxyservice.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.
- addQueryCacheConfig(String, QueryCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
- addQueryCacheConfig(QueryCacheConfig) - Method in class com.hazelcast.config.MapConfig
-
Adds a new queryCacheConfig
to this MapConfig
.
- addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
-
- addQuorumConfig(QuorumConfig) - Method in class com.hazelcast.config.Config
-
- addQuorumListener(String, QuorumListener) - Method in class com.hazelcast.quorum.impl.QuorumServiceImpl
-
- addRegistration(String, Registration) - Method in class com.hazelcast.spi.impl.eventservice.impl.EventServiceSegment
-
- addReliableTopicConfig(ClientReliableTopicConfig) - Method in class com.hazelcast.client.config.ClientConfig
-
Adds a ClientReliableTopicConfig.
- addReliableTopicConfig(ReliableTopicConfig) - Method in class com.hazelcast.config.Config
-
- addRemoveTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increments the remove time accumulator.
- addReplicaPartitionStats(LocalMapStatsProvider.LocalMapOnDemandCalculatedStats, String, int, IPartition, IPartitionService, int, Address) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-
Calculates and adds replica partition stats.
- addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.config.Config
-
- address - Variable in class com.hazelcast.instance.AbstractMember
-
- address - Variable in class com.hazelcast.instance.Node
-
- ADDRESS - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- address - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- address - Variable in class com.hazelcast.internal.management.dto.ClientEndPointDTO
-
- address() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
-
- address() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- 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
-
- addresses() - Method in class com.hazelcast.spi.LiveOperations
-
- 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
-
Strategy to select an
Address
that a Hazelcast cluster member binds its server socket to
and a (potentially different) address that Hazelcast will advertise to other cluster members and clients.
- 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
-
- addResults(Map<Integer, Object>) - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation.PartitionResponse
-
- addResultSet(ConcurrentMap<Data, QueryableEntry>) - Method in class com.hazelcast.query.impl.DuplicateDetectingMultiResult
-
- addResultSet(ConcurrentMap<Data, QueryableEntry>) - Method in class com.hazelcast.query.impl.FastMultiResultSet
-
- addResultSet(ConcurrentMap<Data, QueryableEntry>) - Method in interface com.hazelcast.query.impl.MultiResultSet
-
TODO
- addResultsOfPagingPredicate(List<Future<QueryResult>>, Collection, Collection<Integer>) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-
Adds results of paging predicates to result set and removes queried partition ids.
- addResultsOfPredicate(List<Future<QueryResult>>, QueryResult, Collection<Integer>) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-
Adds results of non-paging predicates to result set and removes queried partition ids.
- addRingbuffer(String, RingbufferContainer) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- addRingBufferConfig(RingbufferConfig) - Method in class com.hazelcast.config.Config
-
- addrOfKey1At(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
-
- addrOfKey2At(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
-
- addrOfValueAt(long) - Static method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArray16byteKeyImpl
-
- addRow(QueryResultRow) - Method in class com.hazelcast.map.impl.query.QueryResult
-
- 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
-
- 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
-
- addTask(Runnable) - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThread
-
Adds a task to this NonBlockingIOThread without notifying the thread.
- addTaskAndWakeup(Runnable) - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingIOThread
-
Adds a task to be executed by the NonBlockingIOThread and wakes up the selector so that it will
eventually pick up the task.
- addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
-
- addToValueList(Map<K, List<V>>, K, V) - Static method in class com.hazelcast.util.CollectionUtil
-
Adds a value to a list of values in the map.
- 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.
- addUTFArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addWanPublisherConfig(WanPublisherConfig) - Method in class com.hazelcast.config.WanReplicationConfig
-
- addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
-
- advance() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- advance() - Method in class com.hazelcast.cache.impl.CachePartitionIterator
-
- advance() - Method in class com.hazelcast.client.cache.impl.ClientCachePartitionIterator
-
- advance() - Method in interface com.hazelcast.internal.util.collection.LongCursor
-
Advances to the next long
element.
- advance() - Method in interface com.hazelcast.internal.util.collection.LongLongCursor
-
Advances to the next map entry.
- advance() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotCursor
-
Advances to the next assigned slot.
- advance() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase.Cursor
-
- advance() - Method in class com.hazelcast.map.impl.iterator.AbstractMapPartitionIterator
-
- advance() - Method in class com.hazelcast.util.collection.Long2LongHashMap.LongLongCursor
-
- after(List<Operation>) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
-
- after(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
-
- afterGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Called after the get(..) operation is completed.
- afterPut(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Called after the put(..) operation is completed.
- afterRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Called after the remove(..) operation is completed.
- afterResponse() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
-
Called on node side, after sending the response to the client.
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- afterRun() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddAllOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionAddOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionClearOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionCompareAndRemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionRemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.list.operations.ListSetOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.AddAllOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.ClearOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.CompareAndRemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.ContainsOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.DrainOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.IsEmptyOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.IteratorOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.OfferOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.PeekOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.PollOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.RemainingCapacityOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.RemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.queue.operations.SizeOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnAddOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionTxnRemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnOfferOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPeekOperation
-
- afterRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnPollOperation
-
- 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.internal.cluster.impl.operations.JoinCheckOperation
-
- afterRun() - Method in class com.hazelcast.internal.management.operation.GetMapConfigOperation
-
- afterRun() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-
- afterRun() - Method in class com.hazelcast.internal.management.operation.ThreadDumpOperation
-
- afterRun() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
-
- afterRun() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
-
- afterRun() - Method in class com.hazelcast.internal.partition.operation.CheckReplicaVersion
-
- afterRun() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
-
- afterRun() - Method in class com.hazelcast.internal.partition.operation.ReplicaSyncRequest
-
- afterRun() - Method in class com.hazelcast.internal.partition.operation.ReplicaSyncResponse
-
- afterRun() - Method in class com.hazelcast.internal.partition.operation.ReplicaSyncRetryResponse
-
- 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.ClearOperation
-
- 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.EvictAllOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.EvictBackupOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.GetOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.MapOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.MutatingKeyBasedMapOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
-
- 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.TryRemoveOperation
-
- 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.replicatedmap.impl.operation.PutOperation
-
- afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.RemoveOperation
-
- afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicateUpdateToCallerOperation
-
- afterRun() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-
- afterRun() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.PartitionIteratingOperation
-
- afterRun() - Method in class com.hazelcast.spi.Operation
-
- 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() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- afterStart() - Method in interface com.hazelcast.instance.NodeExtension
-
Called after node is started
- 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.internal.serialization.impl.FactoryIdHelper
-
- AGGREGATIONS_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.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.
- AlignmentAwareMemoryAccessor - Class in com.hazelcast.internal.memory.impl
-
Aligned
MemoryAccessor
which checks for and handles unaligned memory access
by splitting a larger-size memory operation into several smaller-size ones
(which have finer-grained alignment requirements).
- AlignmentUtil - Class in com.hazelcast.internal.memory.impl
-
- alive - Variable in class com.hazelcast.client.connection.nio.ClientConnectionManagerImpl
-
- 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
PropertyExtractor
s transformation to the
input data.
- allDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
-
Check if all futures are done
- allocate(long) - Method in interface com.hazelcast.internal.memory.MemoryAllocator
-
Allocates a block of addresses with the requested size and returns the base address of the
block.
- allocateArrayAndAdjustFields(long, long) - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- AllowedDuringPassiveState - Interface in com.hazelcast.spi.impl
-
Marker interface for operations those are allowed to be executed or invoked during
Node
's
NodeState.PASSIVE
state.
- AllowedDuringPassiveStateTransactionImpl - Class in com.hazelcast.transaction.impl
-
- AllowedDuringPassiveStateTransactionImpl(TransactionManagerServiceImpl, NodeEngine, TransactionOptions, String) - Constructor for class com.hazelcast.transaction.impl.AllowedDuringPassiveStateTransactionImpl
-
- allowUnsafe - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- 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.
- alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- alterAndGetAsync(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- alterAndGetAsync(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- alterAndGetAsync(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- alterAndGetAsync(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.
- alterAndGetAsync(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
-
- alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- alterAsync(IFunction<E, E>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- alterAsync(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- alterAsync(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- alterAsync(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
-
Alters the currently stored value by applying a function on it.
- alterAsync(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
-
Alters the currently stored reference by applying a function on it.
- 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
-
- AMEM - Static variable in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
-
- AMEM_AVAILABLE - Static variable in class com.hazelcast.internal.memory.GlobalMemoryAccessorRegistry
-
- and(MemberSelector...) - Static method in class com.hazelcast.cluster.memberselector.MemberSelectors
-
Selects a member when all of the selectors succeed
- and(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
-
- and(Predicate...) - Static method in class com.hazelcast.query.Predicates
-
- AND_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-
- AndPredicate - Class in com.hazelcast.query.impl.predicates
-
And Predicate
- AndPredicate() - Constructor for class com.hazelcast.query.impl.predicates.AndPredicate
-
- AndPredicate(Predicate...) - Constructor for class com.hazelcast.query.impl.predicates.AndPredicate
-
- 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.util.ClientDelegatingFuture
-
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- andThen(ExecutionCallback<V>) - Method in interface com.hazelcast.core.ICompletableFuture
-
Registers a callback that will run after the future is completed.
- andThen(ExecutionCallback<V>, Executor) - Method in interface com.hazelcast.core.ICompletableFuture
-
Registers a callback that will run with the provided executor after the future is completed.
- 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.spi.impl.AbstractInvocationFuture
-
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
-
- 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<R>) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- answerMasterQuestion(JoinMessage, Connection) - Method in class com.hazelcast.internal.cluster.impl.ClusterJoinManager
-
- ANY_THREAD - Static variable in class com.hazelcast.concurrent.lock.operations.AbstractLockOperation
-
- append(ClientProtocolBuffer, int, int) - Method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
-
Append a source buffer to the end of the internal buffer, resizing the internal buffer as required.
- appendDateTime() - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
-
- appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- APPLICATION_VALIDATION_TOKEN - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Use this property to verify that Hazelcast nodes only join the cluster when their 'application' level configuration is the
same.
- 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<K, V>) - Method in class com.hazelcast.query.impl.FalsePredicate
-
- apply(Map.Entry<K, V>) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.AndPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.InstanceOfPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.NotEqualPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.NotPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.impl.predicates.OrPredicate
-
- 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.SqlPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.TruePredicate
-
- apply(Collection<Member>) - Method in interface com.hazelcast.quorum.QuorumFunction
-
Determines if quorum is present based on the member-list.
- apply(int) - Method in interface com.hazelcast.util.function.IntFunction
-
Applies this function to the given argument.
- apply(long) - Method in interface com.hazelcast.util.function.LongFunction
-
Applies this function to the given argument.
- applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicLongProxy
-
- applyAsync(IFunction<E, R>) - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- applyAsync(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- applyAsync(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- applyAsync(IFunction<Long, R>) - Method in interface com.hazelcast.core.IAtomicLong
-
Applies a function on the value, the actual stored value will not change.
- applyAsync(IFunction<E, R>) - Method in interface com.hazelcast.core.IAtomicReference
-
Applies a function on the value, the actual stored value will not change.
- applyChanges() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
Provides a similar functionality as committing a transaction.
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.AbstractPredicate
-
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.BetweenPredicate
-
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.EqualPredicate
-
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.GreaterLessPredicate
-
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.InPredicate
-
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.LikePredicate
-
- applyForSingleAttributeValue(Map.Entry, Comparable) - Method in class com.hazelcast.query.impl.predicates.RegexPredicate
-
- applyIfAbsent(K, IFunction<? super K, ? extends V>) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- applyIfAbsent(K, IFunction<? super K, ? extends V>) - Method in interface com.hazelcast.util.IConcurrentMap
- 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
-
- ArgumentParser<I,O> - Class in com.hazelcast.query.extractor
-
Common superclass for all argument parsers.
- ArgumentParser() - Constructor for class com.hazelcast.query.extractor.ArgumentParser
-
- arrange(Collection<MemberGroup>, InternalPartition[]) - Method in interface com.hazelcast.internal.partition.PartitionStateGenerator
-
Arranges the partition layout.
- ARRAY_BOOLEAN_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of boolean[]
- ARRAY_BOOLEAN_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of boolean[]
- ARRAY_BYTE_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of byte[]
- ARRAY_BYTE_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of byte[]
- ARRAY_CHAR_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of char[]
- ARRAY_CHAR_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of char[]
- ARRAY_DOUBLE_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of double[]
- ARRAY_DOUBLE_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of double[]
- ARRAY_FLOAT_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of float[]
- ARRAY_FLOAT_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of float[]
- ARRAY_INDEX_OUT_OF_BOUNDS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- ARRAY_INT_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of int[]
- ARRAY_INT_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of int[]
- ARRAY_LONG_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of long[]
- ARRAY_LONG_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of long[]
- ARRAY_OBJECT_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of any type of Object[]
- ARRAY_OBJECT_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of any type of Object[]
- ARRAY_SHORT_BASE_OFFSET - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Base offset of short[]
- ARRAY_SHORT_INDEX_SCALE - Static variable in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Index scale of short[]
- ARRAY_STORE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- arrayBaseOffset(Class<?>) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Gets the base offset of the array typed with given class.
- arrayBaseOffset(Class<?>) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- arrayBaseOffset(Class<?>) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- ArrayDataSerializableFactory - Class in com.hazelcast.internal.serialization.impl
-
- ArrayDataSerializableFactory(ConstructorFunction<Integer, IdentifiedDataSerializable>[]) - Constructor for class com.hazelcast.internal.serialization.impl.ArrayDataSerializableFactory
-
- arrayIndexScale(Class<?>) - Method in interface com.hazelcast.internal.memory.HeapMemoryAccessor
-
Gets the index scale of the array typed with given class.
- arrayIndexScale(Class<?>) - Method in class com.hazelcast.internal.memory.impl.AlignmentAwareMemoryAccessor
-
- arrayIndexScale(Class<?>) - Method in class com.hazelcast.internal.memory.impl.StandardMemoryAccessor
-
- ArrayListStreamSerializer - Class in com.hazelcast.internal.serialization.impl
-
- ArrayListStreamSerializer() - Constructor for class com.hazelcast.internal.serialization.impl.ArrayListStreamSerializer
-
- ArrayUtils - Class in com.hazelcast.util.collection
-
Convenient method for array manipulations.
- asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.ExecutionService
-
- asCompletableFuture(Future<V>) - Method in class com.hazelcast.spi.impl.executionservice.impl.ExecutionServiceImpl
-
- asElementIterable(NodeList) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- asList() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Returns a read-only list representation of this queue.
- asReadOnly() - Method in class com.hazelcast.config.MemberAttributeConfig
-
- ASSERTION_ERROR - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- assertValid() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- 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.internal.partition.operation
-
- AssignPartitions() - Constructor for class com.hazelcast.internal.partition.operation.AssignPartitions
-
- 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
-
Deprecated.
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
-
Deprecated.
Alters the currently stored value by applying a function on it.
- asyncAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
Deprecated.
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
-
Deprecated.
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
-
Deprecated.
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
-
Deprecated.
Applies a function on the value, the actual stored value will not change.
- asyncApply(IFunction<E, R>) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
Deprecated.
Applies a function on the value, the actual stored value will not change.
- AsyncAtomicLong - Interface in com.hazelcast.core
-
Deprecated.
- AsyncAtomicReference<E> - Interface in com.hazelcast.core
-
Deprecated.
- asyncClear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- asyncClear() - Method in interface com.hazelcast.core.AsyncAtomicReference
-
Deprecated.
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
-
Deprecated.
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
-
Deprecated.
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- AsyncConsoleRequest - Interface in com.hazelcast.internal.management.request
-
Represents async requests sent from Management Center.
- asyncContains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- asyncContains(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
Deprecated.
Checks if the reference contains the value.
- asyncDecrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- asyncDecrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
-
Deprecated.
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
-
Deprecated.
Gets the current value.
- asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicReference
-
Deprecated.
Gets the current value.
- asyncGetAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- asyncGetAndAdd(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
-
Deprecated.
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
-
Deprecated.
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
-
Deprecated.
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
-
Deprecated.
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
-
Deprecated.
Atomically sets the given value and returns the old value.
- asyncGetAndSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
Deprecated.
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
-
Deprecated.
Atomically increments the current value by one.
- asyncInvokeOnPartition(String, Operation, int, ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.operationservice.impl.OperationServiceImpl
-
- asyncInvokeOnPartition(String, Operation, int, ExecutionCallback<V>) - Method in interface com.hazelcast.spi.impl.operationservice.InternalOperationService
-
- asyncIsNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- asyncIsNull() - Method in interface com.hazelcast.core.AsyncAtomicReference
-
Deprecated.
Checks if the stored reference is null.
- AsyncResponseHandler - Class in com.hazelcast.spi.impl.operationservice.impl
-
The AsyncResponsePacketHandler is a PacketHandler that asynchronously process operation-response packets.
- 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
-
Deprecated.
Atomically sets the given value.
- asyncSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
Deprecated.
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.internal.serialization.impl.FactoryIdHelper
-
- ATOMIC_LONG_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ATOMIC_LONG_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- ATOMIC_LONG_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ATOMIC_LONG_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ATOMIC_REFERENCE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ATOMIC_REFERENCE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ATOMIC_REFERENCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ATOMIC_REFERENCE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- AtomicLongAddAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongAddAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAddAndGetMessageTask
-
- AtomicLongAlterAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongAlterAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterAndGetMessageTask
-
- AtomicLongAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongAlterMessageTask
-
- AtomicLongApplyMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongApplyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongApplyMessageTask
-
- 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
-
- AtomicLongCompareAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongCompareAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongCompareAndSetMessageTask
-
- AtomicLongContainer - Class in com.hazelcast.concurrent.atomiclong
-
- AtomicLongContainer() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongContainer
-
- AtomicLongDataSerializerHook - Class in com.hazelcast.concurrent.atomiclong
-
- AtomicLongDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- AtomicLongDecrementAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongDecrementAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongDecrementAndGetMessageTask
-
- AtomicLongGetAndAddMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongGetAndAddMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAddMessageTask
-
- AtomicLongGetAndAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongGetAndAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndAlterMessageTask
-
- AtomicLongGetAndIncrementMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongGetAndIncrementMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndIncrementMessageTask
-
- AtomicLongGetAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongGetAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetAndSetMessageTask
-
- AtomicLongGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongGetMessageTask
-
- AtomicLongIncrementAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongIncrementAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongIncrementAndGetMessageTask
-
- AtomicLongMBean - Class in com.hazelcast.internal.jmx
-
- AtomicLongMBean(IAtomicLong, ManagementService) - Constructor for class com.hazelcast.internal.jmx.AtomicLongMBean
-
- AtomicLongPermission - Class in com.hazelcast.security.permission
-
- AtomicLongPermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicLongPermission
-
- 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
-
- AtomicLongService - Class in com.hazelcast.concurrent.atomiclong
-
- AtomicLongService() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- AtomicLongSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomiclong
-
- AtomicLongSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomiclong.AtomicLongSetMessageTask
-
- AtomicReferenceAlterAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceAlterAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterAndGetMessageTask
-
- AtomicReferenceAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceAlterMessageTask
-
- AtomicReferenceApplyMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceApplyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceApplyMessageTask
-
- 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
-
- AtomicReferenceClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceClearMessageTask
-
- AtomicReferenceCompareAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceCompareAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceCompareAndSetMessageTask
-
- AtomicReferenceContainer - Class in com.hazelcast.concurrent.atomicreference
-
- AtomicReferenceContainer() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceContainer
-
- AtomicReferenceContainsMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceContainsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceContainsMessageTask
-
- AtomicReferenceDataSerializerHook - Class in com.hazelcast.concurrent.atomicreference
-
- AtomicReferenceDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- AtomicReferenceGetAndAlterMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceGetAndAlterMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndAlterMessageTask
-
- AtomicReferenceGetAndSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceGetAndSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetAndSetMessageTask
-
- AtomicReferenceGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceGetMessageTask
-
- AtomicReferenceIsNullMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceIsNullMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceIsNullMessageTask
-
- AtomicReferenceMBean - Class in com.hazelcast.internal.jmx
-
- AtomicReferenceMBean(IAtomicReference, ManagementService) - Constructor for class com.hazelcast.internal.jmx.AtomicReferenceMBean
-
- AtomicReferencePermission - Class in com.hazelcast.security.permission
-
- AtomicReferencePermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicReferencePermission
-
- 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
-
- AtomicReferenceSetAndGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceSetAndGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetAndGetMessageTask
-
- AtomicReferenceSetMessageTask - Class in com.hazelcast.client.impl.protocol.task.atomicreference
-
- AtomicReferenceSetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.atomicreference.AtomicReferenceSetMessageTask
-
- attributeMap - Variable in class com.hazelcast.internal.jmx.HazelcastMBean
-
- attributes - Variable in class com.hazelcast.instance.AbstractMember
-
- AttributeType - Enum in com.hazelcast.query.impl
-
Type of Attribute
- 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
-
- AUTHENTICATION - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- AUTHENTICATION - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-
- AuthenticationBaseMessageTask<P> - Class in com.hazelcast.client.impl.protocol.task
-
Base authentication task
- AuthenticationBaseMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-
- AuthenticationCustomCredentialsMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
Custom Authentication with custom credential impl
- AuthenticationCustomCredentialsMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationCustomCredentialsMessageTask
-
- AuthenticationException - Exception in com.hazelcast.client
-
- 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.internal.cluster.impl.operations
-
- AuthenticationFailureOperation() - Constructor for class com.hazelcast.internal.cluster.impl.operations.AuthenticationFailureOperation
-
- AuthenticationMessageTask - Class in com.hazelcast.client.impl.protocol.task
-
Default Authentication with username password handling task
- AuthenticationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.AuthenticationMessageTask
-
- AuthenticationStatus - Enum in com.hazelcast.client.impl.protocol
-
Status codes of authentication results
- AuthorizationOperation - Class in com.hazelcast.internal.cluster.impl.operations
-
- AuthorizationOperation() - Constructor for class com.hazelcast.internal.cluster.impl.operations.AuthorizationOperation
-
- AuthorizationOperation(String, String) - Constructor for class com.hazelcast.internal.cluster.impl.operations.AuthorizationOperation
-
- available() - Method in class com.hazelcast.internal.serialization.impl.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.
- 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(BlockingOperation) - Method in class com.hazelcast.spi.impl.waitnotifyservice.impl.WaitNotifyServiceImpl
-
- await(BlockingOperation) - Method in interface com.hazelcast.spi.impl.waitnotifyservice.WaitNotifyService
-
- 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
-
- AwaitMapFlushOperation - Class in com.hazelcast.map.impl.operation
-
IMap.flush()
call waits the end of flush by using this operation.
- AwaitMapFlushOperation() - Constructor for class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
-
- AwaitMapFlushOperation(String, long) - Constructor for class com.hazelcast.map.impl.operation.AwaitMapFlushOperation
-
- 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
-
- AwaitOperation(ObjectNamespace, Data, long, long, String, long) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientDurableExecutorServiceProxy
-
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.client.proxy.ClientExecutorServiceProxy
-
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorServiceProxy
-
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.spi.impl.executionservice.impl.DelegatingTaskScheduler
-
- awaitTermination(int, TimeUnit) - Method in class com.hazelcast.spi.impl.operationexecutor.impl.OperationThread
-
- 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.
- AwsAddressProvider(ClientAwsConfig, LoggingService) - Constructor for class com.hazelcast.client.spi.impl.AwsAddressProvider
-
- AwsAddressTranslator - Class in com.hazelcast.client.spi.impl
-
AwsLookupTable loads ec2 ip addresses with given aws credentials.
- AwsAddressTranslator(ClientAwsConfig, LoggingService) - Constructor for class com.hazelcast.client.spi.impl.AwsAddressTranslator
-
- AwsConfig - Class in com.hazelcast.config
-
The AWSConfig contains the configuration for AWS join mechanism.
- AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
-
- BackoffIdleStrategy - Class in com.hazelcast.util.concurrent
-
Idling strategy for threads when they have no work to do.
- BackoffIdleStrategy(long, long, long, long) - Constructor for class com.hazelcast.util.concurrent.BackoffIdleStrategy
-
Create a set of state tracking idle behavior
- BACKPRESSURE_BACKOFF_TIMEOUT_MILLIS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Control the maximum timeout in millis to wait for an invocation space to be available.
- BACKPRESSURE_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Using back pressure, you can prevent an overload of pending asynchronous backups.
- BACKPRESSURE_MAX_CONCURRENT_INVOCATIONS_PER_PARTITION - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
The maximum number of concurrent invocations per partition.
- BACKPRESSURE_SYNCWINDOW - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Controls the frequency of a BackupAwareOperation getting its async backups converted to a sync backups.
- backup - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-
- backup - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- Backup - Class in com.hazelcast.spi.impl.operationservice.impl.operations
-
- Backup() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-
- Backup(Operation, Address, long[], boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-
- Backup(Data, Address, long[], boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-
- BACKUP - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- BACKUP_ACK_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- BACKUP_ENTRY_PROCESSOR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- BackupAckResponse - Class in com.hazelcast.spi.impl.operationservice.impl.responses
-
- BackupAckResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.BackupAckResponse
-
- BackupAckResponse(long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.BackupAckResponse
-
- 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 to 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.
- backupCount - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-
- backupEntryCount - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-
- backupEntryMemoryCost - Variable in class com.hazelcast.map.impl.LocalMapStatsProvider.LocalMapOnDemandCalculatedStats
-
- 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.collection.impl.queue.QueueContainer
-
- Base64 - Class in com.hazelcast.util
-
This class provides encode/decode for RFC 2045 Base64 as
defined by RFC 2045, N.
- baseAddress - Variable in class com.hazelcast.internal.util.sort.MemArrayQuickSorter
-
- BaseHeapNearCacheRecordStore<K,V,R extends NearCacheRecord> - Class in com.hazelcast.cache.impl.nearcache.impl.store
-
- BaseHeapNearCacheRecordStore(NearCacheConfig, NearCacheContext) - Constructor for class com.hazelcast.cache.impl.nearcache.impl.store.BaseHeapNearCacheRecordStore
-
- 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.
- 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, boolean) - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- BaseRemoveOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- BaseRemoveOperation() - Constructor for class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- BaseTxnQueueOperation - Class in com.hazelcast.collection.impl.txnqueue.operations
-
- BaseTxnQueueOperation() - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.BaseTxnQueueOperation
-
- BaseTxnQueueOperation(String, long) - Constructor for class com.hazelcast.collection.impl.txnqueue.operations.BaseTxnQueueOperation
-
- BasicSSLContextFactory - Class in com.hazelcast.nio.ssl
-
- BasicSSLContextFactory() - Constructor for class com.hazelcast.nio.ssl.BasicSSLContextFactory
-
- BATCH_INVALIDATION_MESSAGE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- batchEvent - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- BatchInvalidator - Class in com.hazelcast.map.impl.nearcache
-
Sends invalidations to near-caches in batches.
- BatchNearCacheInvalidation - Class in com.hazelcast.map.impl.nearcache
-
- BatchNearCacheInvalidation() - Constructor for class com.hazelcast.map.impl.nearcache.BatchNearCacheInvalidation
-
- BatchNearCacheInvalidation(String, int) - Constructor for class com.hazelcast.map.impl.nearcache.BatchNearCacheInvalidation
-
- BatchNearCacheInvalidation(String, List<SingleNearCacheInvalidation>) - Constructor for class com.hazelcast.map.impl.nearcache.BatchNearCacheInvalidation
-
- before(List<Operation>, Operation) - Static method in class com.hazelcast.collection.impl.CollectionTxnUtil
-
- 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
-
- BeforeAwaitOperation(ObjectNamespace, Data, long, String, long) - Constructor for class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- beforeJoin() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- beforeJoin() - Method in interface com.hazelcast.instance.NodeExtension
-
Called before node attempts to join to the cluster
- BeforeJoinCheckFailureOperation - Class in com.hazelcast.internal.cluster.impl.operations
-
- BeforeJoinCheckFailureOperation() - Constructor for class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOperation
-
- BeforeJoinCheckFailureOperation(String) - Constructor for class com.hazelcast.internal.cluster.impl.operations.BeforeJoinCheckFailureOperation
-
- beforeListenerRegister() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy.ClientMapAddNearCacheEventHandler
-
- 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.impl.collection.CollectionService
-
- beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- 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.durableexecutor.impl.DistributedDurableExecutorService
-
- 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.replicatedmap.impl.ReplicatedMapService
-
- beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.ringbuffer.impl.RingbufferService
-
- beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.spi.impl.DelegatingMigrationAwareService
-
- beforeMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
-
Called before migration process starts, on both source and destination members.
- beforeMigration(PartitionMigrationEvent) - Method in class com.hazelcast.transaction.impl.xa.XAService
-
- beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
-
Called on node side, before starting any operation.
- beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
-
- beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-
- beforeProcess() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-
- beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.AbstractPartitionMessageTask
-
Called on node side, after process is run and right before sending the response to the client.
- beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapPutMessageTask
-
- beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapGetMessageTask
-
- beforeResponse() - Method in class com.hazelcast.client.impl.protocol.task.map.MapRemoveMessageTask
-
- 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.collection.impl.collection.operations.CollectionAddBackupOperation
-
- beforeRun() - Method in class com.hazelcast.collection.impl.collection.operations.CollectionOperation
-
- beforeRun() - Method in class com.hazelcast.collection.impl.list.operations.ListRemoveOperation
-
- beforeRun() - Method in class com.hazelcast.collection.impl.queue.operations.QueueOperation
-
- beforeRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitBackupOperation
-
- beforeRun() - Method in class com.hazelcast.collection.impl.txncollection.operations.CollectionCommitOperation
-
- beforeRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitBackupOperation
-
- beforeRun() - Method in class com.hazelcast.collection.impl.txnqueue.operations.TxnCommitOperation
-
- 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.internal.cluster.impl.operations.ChangeClusterStateOperation
-
- beforeRun() - Method in class com.hazelcast.internal.cluster.impl.operations.LockClusterStateOperation
-
- beforeRun() - Method in class com.hazelcast.internal.cluster.impl.operations.PostJoinOperation
-
- beforeRun() - Method in class com.hazelcast.internal.management.operation.GetMapConfigOperation
-
- beforeRun() - Method in class com.hazelcast.internal.management.operation.ScriptExecutorOperation
-
- beforeRun() - Method in class com.hazelcast.internal.management.operation.ThreadDumpOperation
-
- beforeRun() - Method in class com.hazelcast.internal.management.operation.UpdateManagementCenterUrlOperation
-
- beforeRun() - Method in class com.hazelcast.internal.management.operation.UpdateMapConfigOperation
-
- beforeRun() - Method in class com.hazelcast.internal.partition.operation.CheckReplicaVersion
-
- beforeRun() - Method in class com.hazelcast.internal.partition.operation.PromotionCommitOperation
-
- beforeRun() - Method in class com.hazelcast.internal.partition.operation.ReplicaSyncRequest
-
- beforeRun() - Method in class com.hazelcast.internal.partition.operation.ReplicaSyncResponse
-
- beforeRun() - Method in class com.hazelcast.internal.partition.operation.ReplicaSyncRetryResponse
-
- beforeRun() - Method in class com.hazelcast.map.impl.operation.MapOperation
-
- 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.ringbuffer.impl.operations.ReadManyOperation
-
- beforeRun() - Method in class com.hazelcast.ringbuffer.impl.operations.ReadOneOperation
-
- beforeRun() - Method in class com.hazelcast.spi.impl.operationservice.impl.operations.Backup
-
- 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.xa.operations.ClearRemoteTransactionBackupOperation
-
- beforeRun() - Method in class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-
- beforeRun() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionBackupOperation
-
- beforeRun() - Method in class com.hazelcast.transaction.impl.xa.operations.FinalizeRemoteTransactionOperation
-
- beforeRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
-
Called before inner run method and can be overridden to customize.
- beforeShutdown() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- beforeShutdown() - Method in interface com.hazelcast.instance.NodeExtension
-
Called before Node.shutdown()
- 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() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- beforeStart() - Method in interface com.hazelcast.instance.NodeExtension
-
Called before node is started
- begin() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- begin() - Method in class com.hazelcast.transaction.impl.TransactionImpl
-
- begin() - Method in class com.hazelcast.transaction.impl.xa.XATransaction
-
- BEGIN_AND_END_FLAGS - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
-
Begin and End Flags
- BEGIN_FLAG - Static variable in class com.hazelcast.client.impl.protocol.ClientMessage
-
Begin Flag
- 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.proxy.txn.TransactionContextProxy
-
- beginTransaction() - Method in class com.hazelcast.client.proxy.txn.xa.XATransactionContextProxy
-
- beginTransaction() - Method in class com.hazelcast.transaction.impl.xa.XATransactionContextImpl
-
- beginTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
-
Begins a transaction.
- 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
-
- BETWEEN_PREDICATE - Static variable in class com.hazelcast.query.impl.predicates.PredicateDataSerializerHook
-
- BetweenPredicate - Class in com.hazelcast.query.impl.predicates
-
Between Predicate
- BetweenPredicate() - Constructor for class com.hazelcast.query.impl.predicates.BetweenPredicate
-
- BetweenPredicate(String, Comparable, Comparable) - Constructor for class com.hazelcast.query.impl.predicates.BetweenPredicate
-
- BetweenVisitor - Class in com.hazelcast.query.impl.predicates
-
Replaces expression from (age >= X and age <= Y) into (age between X Y)
It detects some predicates which are trivally false.
- BetweenVisitor() - Constructor for class com.hazelcast.query.impl.predicates.BetweenVisitor
-
- BiConsumer<T,U> - Interface in com.hazelcast.util.function
-
Represents an operation that accepts two input arguments and returns no
result.
- 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_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- 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_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- 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
-
- BiInt2ObjectMap<V> - Class in com.hazelcast.util.collection
-
Map that takes two part int key and associates with an object.
- BiInt2ObjectMap() - Constructor for class com.hazelcast.util.collection.BiInt2ObjectMap
-
Construct an empty map
- BiInt2ObjectMap(int, double) - Constructor for class com.hazelcast.util.collection.BiInt2ObjectMap
-
- BiInt2ObjectMap.EntryConsumer<V> - Interface in com.hazelcast.util.collection
-
Handler for a map entry
- 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_MESSAGE - Static variable in class com.hazelcast.internal.cluster.impl.ClusterDataSerializerHook
-
- BindMessage - Class in com.hazelcast.internal.cluster.impl
-
- BindMessage() - Constructor for class com.hazelcast.internal.cluster.impl.BindMessage
-
- BindMessage(Address, Address, boolean) - Constructor for class com.hazelcast.internal.cluster.impl.BindMessage
-
- Bits - Class in com.hazelcast.nio
-
Access and manipulate bits, bytes, primitives ...
- BitSetUtils - Class in com.hazelcast.util
-
Convenient method for BitSet manipulations
- blacklist(Address, boolean) - Method in interface com.hazelcast.cluster.Joiner
-
Deprecated.
Adds an address to the blacklist.
- blacklist(Address, boolean) - Method in class com.hazelcast.internal.cluster.impl.AbstractJoiner
-
- blacklistedAddresses - Variable in class com.hazelcast.internal.cluster.impl.AbstractJoiner
-
- BLOCK_SIZE - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorImpl
-
- BlockingOperation - Interface in com.hazelcast.spi
-
An interface that can be implemented by an operation that can block.
- BOOLEAN - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-
- BOOLEAN_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- BOOLEAN_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- BOOLEAN_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- BOOLEAN_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
-
Boolean size in bytes
- BOTH_OF_ENTRIES_HAVE_SAME_PRIORITY_TO_BE_EVICTED - Static variable in class com.hazelcast.internal.eviction.EvictionPolicyComparator
-
Integer constant for representing behaviour for giving same priority to both of entry to be evicted.
- BROADCAST_TX_ROLLBACK - Static variable in class com.hazelcast.transaction.impl.TransactionDataSerializerHook
-
- BroadcastTxRollbackOperation - Class in com.hazelcast.transaction.impl.operations
-
- BroadcastTxRollbackOperation() - Constructor for class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
-
- BroadcastTxRollbackOperation(String) - Constructor for class com.hazelcast.transaction.impl.operations.BroadcastTxRollbackOperation
-
- buffer() - Method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
-
- buffer - Variable in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- buffer() - Method in class com.hazelcast.client.impl.protocol.util.MessageFlyweight
-
- BufferBuilder - Class in com.hazelcast.client.impl.protocol.util
-
Builder for appending buffers that grows capacity as necessary.
- BufferBuilder() - Constructor for class com.hazelcast.client.impl.protocol.util.BufferBuilder
-
- BufferObjectDataInput - Interface in com.hazelcast.nio
-
- BufferObjectDataOutput - Interface in com.hazelcast.nio
-
- BufferPool - Interface in com.hazelcast.internal.serialization.impl.bufferpool
-
- BufferPoolFactory - Interface in com.hazelcast.internal.serialization.impl.bufferpool
-
- BufferPoolFactoryImpl - Class in com.hazelcast.internal.serialization.impl.bufferpool
-
- BufferPoolFactoryImpl() - Constructor for class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolFactoryImpl
-
- BufferPoolImpl - Class in com.hazelcast.internal.serialization.impl.bufferpool
-
Default {BufferPool} implementation.
- BufferPoolImpl(InternalSerializationService) - Constructor for class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolImpl
-
- bufferPoolThreadLocal - Variable in class com.hazelcast.internal.serialization.impl.AbstractSerializationService
-
- BufferPoolThreadLocal - Class in com.hazelcast.internal.serialization.impl.bufferpool
-
- BufferPoolThreadLocal(InternalSerializationService, BufferPoolFactory) - Constructor for class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
-
- 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.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- build() - Method in interface com.hazelcast.internal.serialization.SerializationServiceBuilder
-
- build() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- build() - Method in class com.hazelcast.util.collection.InflatableSet.Builder
-
- buildExecutorName(String) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- BuildInfo - Class in com.hazelcast.instance
-
- BuildInfo(String, String, String, int, boolean, byte) - Constructor for class com.hazelcast.instance.BuildInfo
-
- BuildInfoPlugin - Class in com.hazelcast.internal.diagnostics
-
- BuildInfoPlugin(NodeEngineImpl) - Constructor for class com.hazelcast.internal.diagnostics.BuildInfoPlugin
-
- BuildInfoProvider - Class in com.hazelcast.instance
-
Provides information about current Hazelcast build.
- buildNumber - Variable in class com.hazelcast.internal.cluster.impl.JoinMessage
-
- buildRecordInfo(Record) - Static method in class com.hazelcast.map.impl.record.Records
-
- BuiltInCacheMergePolicies - Enum in com.hazelcast.cache
-
- BusySpinIdleStrategy - Class in com.hazelcast.util.concurrent
-
Busy spin strategy targeted at lowest possible latency.
- BusySpinIdleStrategy() - Constructor for class com.hazelcast.util.concurrent.BusySpinIdleStrategy
-
- 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_ACCESS - Static variable in class com.hazelcast.internal.memory.impl.EndiannessUtil
-
Accesses bytes in a Java byte array
- BYTE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- BYTE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- BYTE_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- BYTE_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
-
Byte size in bytes
- ByteAccessStrategy<R> - Interface in com.hazelcast.internal.memory
-
Access strategy for single memory bytes.
- byteArray() - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
-
Get the underlying byte[] if one exists.
- byteArray() - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-
- byteArray() - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-
- ByteArrayAccessStrategy - Class in com.hazelcast.internal.memory.impl
-
- 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.internal.ascii.memcache.MemcacheCommandProcessor
-
- byteOrder - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- bytes() - Method in class com.hazelcast.memory.MemorySize
-
Returns value of memory size in bytes.
- bytesPending() - Method in class com.hazelcast.nio.tcp.nonblocking.NonBlockingSocketWriter
-
- bytesPending() - Method in class com.hazelcast.nio.tcp.spinning.SpinningSocketWriter
-
- bytesToHex(byte[]) - Static method in class com.hazelcast.util.QuickMath
-
- bytesToString(byte[], int, int) - Static method in class com.hazelcast.util.StringUtil
-
Creates a UTF8_CHARSET string from a byte array.
- bytesToString(byte[]) - Static method in class com.hazelcast.util.StringUtil
-
Creates a UTF8_CHARSET string from a byte array.
- cache - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- CACHE - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CACHE_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CACHE_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.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_INVALIDATION_MESSAGE_BATCH_ENABLED - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Defines cache invalidation event batch sending is enabled or not.
- CACHE_INVALIDATION_MESSAGE_BATCH_FREQUENCY_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Defines the cache invalidation event batch sending frequency in seconds.
- CACHE_INVALIDATION_MESSAGE_BATCH_SIZE - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
Defines the maximum number of cache invalidation events to be drained and sent to the event listeners in a batch.
- CACHE_KEY_ITERATOR_RESULT - Static variable in class com.hazelcast.client.impl.protocol.ResponseMessageConst
-
- CACHE_LINE_LENGTH - Static variable in class com.hazelcast.nio.Bits
-
Length of the data blocks used by the CPU cache sub-system in bytes.
- CACHE_LOADER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CACHE_MANAGER_PREFIX - Static variable in interface com.hazelcast.cache.HazelcastCacheManager
-
Hazelcast's CacheManager
's prefix to be appended to the head of the cache name.
- CACHE_NOT_EXISTS - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CACHE_PARTITION_LOST_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-
- CACHE_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CACHE_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CACHE_SUPPORT_NOT_AVAILABLE_ERROR_MESSAGE - Static variable in interface com.hazelcast.cache.impl.ICacheService
-
- CACHE_WRITER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CacheAddEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
Client request which registers an event listener on behalf of the client and delegates the received events
back to client.
- CacheAddEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-
- CacheAddInvalidationListenerTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheAddInvalidationListenerTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-
- CacheAddPartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheAddPartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-
- 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
-
- CacheBatchInvalidationMessage - Class in com.hazelcast.cache.impl.client
-
- CacheBatchInvalidationMessage() - Constructor for class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-
- CacheBatchInvalidationMessage(String) - Constructor for class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-
- CacheBatchInvalidationMessage(String, int) - Constructor for class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-
- CacheBatchInvalidationMessage(String, List<CacheSingleInvalidationMessage>) - Constructor for class com.hazelcast.cache.impl.client.CacheBatchInvalidationMessage
-
- CacheClearBackupOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheClearBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- CacheClearBackupOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- CacheClearMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheClearMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheClearMessageTask
-
- 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
-
- CacheClearOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- CacheClearOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- CacheClearResponse - Class in com.hazelcast.cache.impl
-
- CacheClearResponse() - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
-
- CacheClearResponse(Object) - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
-
- 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(String) - 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
-
Deprecated.
this class will be removed in 3.8; it is meant for internal usage only.git ch
- CacheConfiguration<K,V> - Interface in com.hazelcast.config
-
Mutable extension to CompleteConfiguration
- CacheContainsKeyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheContainsKeyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheContainsKeyMessageTask
-
- 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
-
- cacheContexesConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- cacheContext - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- CacheContext - Class in com.hazelcast.cache.impl
-
Holds some specific informations for per cache in the node and shared by all partitions of that cache on the node.
- CacheContext() - Constructor for class com.hazelcast.cache.impl.CacheContext
-
- cacheContexts - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- CacheCreateConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheCreateConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheCreateConfigMessageTask
-
- 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
-
- CacheCreateConfigOperation(CacheConfig, boolean, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- 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() - Constructor for class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CacheDeserializedValues - Enum in com.hazelcast.config
-
Control caching of de-serialized values.
- CacheDestroyMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheDestroyMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheDestroyMessageTask
-
- CacheDestroyOperation - Class in com.hazelcast.cache.impl.operation
-
- 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
-
- CachedExecutorServiceDelegate - Class in com.hazelcast.util.executor
-
- CachedExecutorServiceDelegate(NodeEngine, String, ExecutorService, int, int) - Constructor for class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- CachedQueryEntry - Class in com.hazelcast.query.impl
-
Entry of the Query.
- CachedQueryEntry() - Constructor for class com.hazelcast.query.impl.CachedQueryEntry
-
- CachedQueryEntry(InternalSerializationService, Data, Object, Extractors) - Constructor for class com.hazelcast.query.impl.CachedQueryEntry
-
- 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
-
- CacheEntryCountResolver - Class in com.hazelcast.cache.impl
-
Contract point for tracking count of stored cache entries.
- CacheEntryCountResolver() - Constructor for class com.hazelcast.cache.impl.CacheEntryCountResolver
-
- cacheEntryCountResolver - Variable in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- 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
-
- CacheEntryIterationResult - Class in com.hazelcast.cache.impl
-
- CacheEntryIterationResult() - Constructor for class com.hazelcast.cache.impl.CacheEntryIterationResult
-
- CacheEntryIterationResult(List<Map.Entry<Data, Data>>, int) - Constructor for class com.hazelcast.cache.impl.CacheEntryIterationResult
-
- CacheEntryIteratorOperation - Class in com.hazelcast.cache.impl.operation
-
Provides iterator functionality for ICache.
- CacheEntryIteratorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
-
- CacheEntryIteratorOperation(String, int, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryIteratorOperation
-
- cacheEntryListenerDeregistered(String, CacheEntryListenerConfiguration) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- CacheEntryListenerProvider<K,V> - Interface in com.hazelcast.cache.impl
-
Provides underlying (wrapped) CacheEntryListener
instance.
- cacheEntryListenerRegistered(String, CacheEntryListenerConfiguration) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- 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
-
- CacheEntryProcessorMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheEntryProcessorMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheEntryProcessorMessageTask
-
- 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
-
- 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
-
- CacheEntryView<K,V> - Interface in com.hazelcast.cache
-
Entry info for cache record.
- CacheEntryViews - Class in com.hazelcast.cache.impl
-
A class providing static factory methods that create various entry view objects.
- CacheEntryViews.CacheEntryViewType - Enum in com.hazelcast.cache.impl
-
- CacheEventContext - Class in com.hazelcast.cache.impl
-
- CacheEventContext() - Constructor for class com.hazelcast.cache.impl.CacheEventContext
-
- CacheEventContextUtil - Class in com.hazelcast.cache.impl
-
- CacheEventData - Interface in com.hazelcast.cache.impl
-
Internal event data wrapper used during publishing and dispatching events.
- CacheEventDataImpl - Class in com.hazelcast.cache.impl
-
- CacheEventDataImpl() - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
-
- CacheEventDataImpl(String, CacheEventType, Data, Data, Data, boolean) - Constructor for class com.hazelcast.cache.impl.CacheEventDataImpl
-
- cacheEventHandler - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- 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, HazelcastInstance) - 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, Set<CacheEventData>, int) - 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
-
- CacheEvictionConfig() - Constructor for class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicy) - Constructor for class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, String) - Constructor for class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, String) - Constructor for class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- CacheEvictionConfig(int, EvictionConfig.MaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- CacheEvictionConfig(int, CacheEvictionConfig.CacheMaxSizePolicy, EvictionPolicyComparator) - Constructor for class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- CacheEvictionConfig(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfig
-
Deprecated.
- CacheEvictionConfig.CacheMaxSizePolicy - Enum in com.hazelcast.config
-
Deprecated.
Cache Maximum Size Policy
- CacheEvictionConfigReadOnly - Class in com.hazelcast.config
-
- CacheEvictionConfigReadOnly(EvictionConfig) - Constructor for class com.hazelcast.config.CacheEvictionConfigReadOnly
-
Deprecated.
- CacheEvictionPolicyComparator<K,V> - Class in com.hazelcast.cache
-
- CacheEvictionPolicyComparator() - Constructor for class com.hazelcast.cache.CacheEvictionPolicyComparator
-
- CacheGetAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheGetAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAllMessageTask
-
- 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
-
- CacheGetAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- CacheGetAllOperationFactory(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- CacheGetAndRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheGetAndRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndRemoveMessageTask
-
- 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
-
- CacheGetAndReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheGetAndReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetAndReplaceMessageTask
-
- 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
-
- CacheGetConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheGetConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetConfigMessageTask
-
- 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
-
- CacheGetMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheGetMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheGetMessageTask
-
- 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
-
- CacheInvalidationMessage - Class in com.hazelcast.cache.impl.client
-
- CacheInvalidationMessage() - Constructor for class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-
- CacheInvalidationMessage(String) - Constructor for class com.hazelcast.cache.impl.client.CacheInvalidationMessage
-
- CacheIterateEntriesMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheIterateEntriesMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheIterateEntriesMessageTask
-
- CacheIterateMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheIterateMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheIterateMessageTask
-
- CacheKeyIterationResult - Class in com.hazelcast.cache.impl
-
- CacheKeyIterationResult() - Constructor for class com.hazelcast.cache.impl.CacheKeyIterationResult
-
- CacheKeyIterationResult(List<Data>, int) - Constructor for class com.hazelcast.cache.impl.CacheKeyIterationResult
-
- 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
-
- CacheListenerRegistrationMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheListenerRegistrationMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheListenerRegistrationMessageTask
-
- 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
-
- CacheLoadAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheLoadAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheLoadAllMessageTask
-
- CacheLoadAllOperation - Class in com.hazelcast.cache.impl.operation
-
- 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
-
- CacheLoadAllOperationFactory(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- CacheLoadAllOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- cacheLoader - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- cacheLocalEntries - Variable in class com.hazelcast.map.impl.proxy.NearCachedMapProxyImpl
-
- CacheManagementConfigMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheManagementConfigMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheManagementConfigMessageTask
-
- 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
-
- CacheManagerBeanDefinitionParser - Class in com.hazelcast.spring
-
Bean definition parser for JCache
CacheManager
Sample bean
- CacheManagerBeanDefinitionParser() - Constructor for class com.hazelcast.spring.CacheManagerBeanDefinitionParser
-
- CacheMergeOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheMergeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperation
-
- CacheMergeOperation(String, Data, CacheEntryView<Data, Data>, CacheMergePolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheMergeOperation
-
- CacheMergePolicy - Interface in com.hazelcast.cache
-
Policy for merging cache entries.
- CacheMergePolicyProvider - Class in com.hazelcast.cache.impl.merge.policy
-
- CacheMergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.cache.impl.merge.policy.CacheMergePolicyProvider
-
- 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 does not exist 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
- CachePartitionEventData - Class in com.hazelcast.cache.impl
-
- CachePartitionEventData(String, int, Member) - Constructor for class com.hazelcast.cache.impl.CachePartitionEventData
-
- CachePartitionIterator<K,V> - Class in com.hazelcast.cache.impl
-
- CachePartitionIterator(CacheProxy<K, V>, int, int, boolean) - Constructor for class com.hazelcast.cache.impl.CachePartitionIterator
-
- CachePartitionLostEvent - Class in com.hazelcast.cache.impl.event
-
Used to provide information about the lost partition of a cache.
- CachePartitionLostEvent(Object, Member, int, int) - Constructor for class com.hazelcast.cache.impl.event.CachePartitionLostEvent
-
- CachePartitionLostEventFilter - Class in com.hazelcast.cache.impl.event
-
Used to filter partition lost listener events
- CachePartitionLostEventFilter() - Constructor for class com.hazelcast.cache.impl.event.CachePartitionLostEventFilter
-
- CachePartitionLostListener - Interface in com.hazelcast.cache.impl.event
-
Invoked when owner and all backups of a partition are lost for a specific cache.
- CachePartitionLostListenerConfig - Class in com.hazelcast.config
-
Configuration for CachePartitionLostListener
- CachePartitionLostListenerConfig() - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(String) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(CachePartitionLostListener) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfig(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfig
-
- CachePartitionLostListenerConfigReadOnly - Class in com.hazelcast.config
-
Deprecated.
this class will be removed in 3.8; it is meant for internal usage only.
- CachePartitionLostListenerConfigReadOnly(CachePartitionLostListenerConfig) - Constructor for class com.hazelcast.config.CachePartitionLostListenerConfigReadOnly
-
Deprecated.
- CachePartitionSegment - Class in com.hazelcast.cache.impl
-
Responsible for all cache data of a partition.
- CachePartitionSegment(AbstractCacheService, int) - Constructor for class com.hazelcast.cache.impl.CachePartitionSegment
-
- CachePermission - Class in com.hazelcast.security.permission
-
- CachePermission(String, String...) - Constructor for class com.hazelcast.security.permission.CachePermission
-
- CacheProxy<K,V> - Class in com.hazelcast.cache.impl
-
ICache implementation
- 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
-
- CachePutAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CachePutAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutAllMessageTask
-
- CachePutAllOperation - Class in com.hazelcast.cache.impl.operation
-
- CachePutAllOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- CachePutAllOperation(String, List<Map.Entry<Data, Data>>, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllOperation
-
- 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
-
- CachePutBackupOperation(String, Data, CacheRecord, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- CachePutIfAbsentMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CachePutIfAbsentMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutIfAbsentMessageTask
-
- CachePutIfAbsentOperation - Class in com.hazelcast.cache.impl.operation
-
- 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
-
- CachePutMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CachePutMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CachePutMessageTask
-
- CachePutOperation - Class in com.hazelcast.cache.impl.operation
-
- 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
-
- 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
-
- CacheRecordFactory(InMemoryFormat, SerializationService) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordFactory
-
- CacheRecordHashMap - Class in com.hazelcast.cache.impl.record
-
- CacheRecordHashMap(SerializationService, int, CacheContext) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- 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
-
- CacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.CacheRecordStore
-
- CacheRemoveAllBackupOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheRemoveAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- CacheRemoveAllBackupOperation(String, Set<Data>) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- CacheRemoveAllKeysMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheRemoveAllKeysMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllKeysMessageTask
-
- CacheRemoveAllMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheRemoveAllMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveAllMessageTask
-
- 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
-
- 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
-
- CacheRemoveBackupOperation(String, Data, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-
- CacheRemoveEntryListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
Client request which unregisters the event listener on behalf of the client.
- CacheRemoveEntryListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveEntryListenerMessageTask
-
- CacheRemoveInvalidationListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
Client request which unregisters the invalidation listener on behalf of the client.
- CacheRemoveInvalidationListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveInvalidationListenerMessageTask
-
- CacheRemoveMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheRemoveMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemoveMessageTask
-
- 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
-
- CacheRemovePartitionLostListenerMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheRemovePartitionLostListenerMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheRemovePartitionLostListenerMessageTask
-
- CacheReplaceMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheReplaceMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheReplaceMessageTask
-
- 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
-
- CacheReplicationOperation - Class in com.hazelcast.cache.impl.operation
-
- 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 - Variable in class com.hazelcast.cache.impl.CachePartitionSegment
-
- 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
-
- CacheSimpleConfig.ExpiryPolicyFactoryConfig - Class in com.hazelcast.config
-
Represents configuration for "ExpiryPolicyFactory".
- CacheSimpleConfig.ExpiryPolicyFactoryConfig(String) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- CacheSimpleConfig.ExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig
-
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig - Class in com.hazelcast.config
-
Represents duration configuration with duration amount and time unit
for the "TimedExpiryPolicyFactoryConfig".
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig(long, TimeUnit) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
-
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig - Class in com.hazelcast.config
-
Represents configuration for time based "ExpiryPolicyFactory" with duration and time unit.
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig(CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType, CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
-
- CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType - Enum in com.hazelcast.config
-
Represents type of the "TimedExpiryPolicyFactoryConfig".
- CacheSimpleConfigReadOnly - Class in com.hazelcast.config
-
Deprecated.
this class will be removed in 3.8; it is meant for internal usage only.
- CacheSimpleConfigReadOnly(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfigReadOnly
-
Deprecated.
- 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
-
Deprecated.
this class will be removed in 3.8; it is meant for internal usage only.
- CacheSimpleEntryListenerConfigReadOnly(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-
Deprecated.
- CacheSingleInvalidationMessage - Class in com.hazelcast.cache.impl.client
-
- CacheSingleInvalidationMessage() - Constructor for class com.hazelcast.cache.impl.client.CacheSingleInvalidationMessage
-
- CacheSingleInvalidationMessage(String, Data, String) - Constructor for class com.hazelcast.cache.impl.client.CacheSingleInvalidationMessage
-
- CacheSizeMessageTask - Class in com.hazelcast.client.impl.protocol.task.cache
-
- CacheSizeMessageTask(ClientMessage, Node, Connection) - Constructor for class com.hazelcast.client.impl.protocol.task.cache.CacheSizeMessageTask
-
- 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
-
- CacheSizeOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- CacheSizeOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- cacheSplitBrainHandler - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- CacheStatistics - Interface in com.hazelcast.cache
-
Cache statistics
- cacheStatisticsConstructorFunction - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- CacheStatisticsImpl - Class in com.hazelcast.cache.impl
-
- CacheStatisticsImpl(long) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- CacheStatisticsImpl(long, CacheEntryCountResolver) - 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
- CacheUtil - Class in com.hazelcast.cache
-
Utility class for various cache related operations to be used by our internal structure and end user.
- CacheWanEventPublisher - Interface in com.hazelcast.cache.impl.event
-
This interface provides methods to publish wan replication events
from cache operations.
- cacheWriter - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- cachingProvider - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- calculateDataSize(String) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Data) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Map.Entry<Data, Data>) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(byte[]) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Integer) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateDataSize(Boolean) - Static method in class com.hazelcast.client.impl.protocol.util.ParameterUtil
-
- calculateExpirationWithDelay(long, long, boolean) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
-
On backup partitions, this method delays key`s expiration.
- calculateHeapCost(Object) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
-
- calculateMaxIdleMillis(MapConfig) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
-
- 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.internal.serialization.impl.AbstractSerializationService
-
- calculatePerNodeMaxRecordStoreSize(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
Calculates and returns the expected maximum size of an evicted record-store
when
PER_NODE
max-size-policy is used.
- calculateSize(NearCacheRecord) - Method in class com.hazelcast.map.impl.nearcache.NearCacheSizeEstimator
-
- calculateSize(T) - Method in interface com.hazelcast.map.impl.SizeEstimator
-
- calculateTTLMillis(MapConfig) - Static method in class com.hazelcast.map.impl.ExpirationTimeSetter
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractCallableMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractMultiPartitionMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractRemoveListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AbstractTransactionalMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddDistributedObjectListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddMembershipListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AddPartitionLostListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.AuthenticationBaseMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddInvalidationListenerTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.cache.CacheAddPartitionLostListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.DestroyProxyMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.AbstractExecutorServiceCancelMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorIsShutdownMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.durable.DurableExecutorShutdownMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceIsShutdownMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.executorservice.ExecutorServiceShutdownMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.GetDistributedObjectsMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.GetPartitionsMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.list.ListAddListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.AbstractMapQueryMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapAddPartitionLostListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapFlushMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.map.MapLoadAllMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceCancelMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.mapreduce.MapReduceJobProcessInformationMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.multimap.AbstractMultiMapAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.PingMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.queue.QueueAddListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.RemoveAllListenersMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.replicatedmap.AbstractReplicatedMapAddEntryListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.set.SetAddListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.topic.TopicAddMessageListenerMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XAClearRemoteTransactionMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCommitMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionCreateMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionPrepareMessageTask
-
- call() - Method in class com.hazelcast.client.impl.protocol.task.transaction.XATransactionRollbackMessageTask
-
- call() - Method in class com.hazelcast.console.Echo
-
- call() - Method in class com.hazelcast.console.SimulateLoadTask
-
- call() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- call() - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl.QueryPartitionCallable
-
- CALL_TIMEOUT_RESPONSE - Static variable in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- 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
-
- callBeforeStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-
- CALLER_NOT_MEMBER - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CallerNotMemberException - Exception in com.hazelcast.spi.exception
-
A
RetryableHazelcastException
that indicates that an operation was send by a machine which isn't member
in the cluster when the operation is executed.
- CallerNotMemberException(Address, Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-
- CallerNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-
- callId - Variable in class com.hazelcast.spi.impl.operationservice.impl.responses.Response
-
- callIds(Address) - Method in class com.hazelcast.spi.LiveOperations
-
- CallIdSequence - Class in com.hazelcast.client.spi.impl
-
- CallIdSequence() - Constructor for class com.hazelcast.client.spi.impl.CallIdSequence
-
- CallIdSequence - Class in com.hazelcast.spi.impl.operationservice.impl
-
Responsible for generating callIds.
- CallIdSequence() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.CallIdSequence
-
- CallIdSequence.CallIdSequenceFailFast - Class in com.hazelcast.client.spi.impl
-
A
CallIdSequence
that provided backpressure by taking
the number in flight operations into account when a call-id needs to be determined.
- CallIdSequence.CallIdSequenceFailFast(int) - Constructor for class com.hazelcast.client.spi.impl.CallIdSequence.CallIdSequenceFailFast
-
- callOnAddress(Address, Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- callOnMember(Member, Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- callOnThis(Operation) - Method in class com.hazelcast.internal.management.ManagementCenterService
-
- callTimeout - Variable in class com.hazelcast.spi.InvocationBuilder
-
- CallTimeoutResponse - Class in com.hazelcast.spi.impl.operationservice.impl.responses
-
An response that indicates that the execution of a single call ran into a timeout.
- CallTimeoutResponse() - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.CallTimeoutResponse
-
- CallTimeoutResponse(long, boolean) - Constructor for class com.hazelcast.spi.impl.operationservice.impl.responses.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.recordstore.DefaultRecordStore
-
- canAcquireLock(Data, String, long) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientAddressCancellableDelegatingFuture
-
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientCancellableDelegatingFuture
-
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientDelegatingFuture
-
- cancel(boolean) - Method in class com.hazelcast.client.util.ClientPartitionCancellableDelegatingFuture
-
- 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.spi.impl.AbstractCompletableFuture
-
- cancel(boolean) - Method in class com.hazelcast.spi.impl.AbstractInvocationFuture
-
- 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(String) - Method in class com.hazelcast.collection.impl.queue.QueueService
-
- cancelEvictionIfExists() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- cancelExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- cancelIfExists(K, V) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
- 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 - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- 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
-
- cancelled - Variable in class com.hazelcast.client.util.ClientCancellableDelegatingFuture
-
- cancelled(boolean) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
Protected method invoked when this task transitions to state
isCancelled
.
- cancelled(boolean) - Method in class com.hazelcast.util.executor.CompletableFutureTask
-
- cancelPartitionState() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- cancelReplicaSync(int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
-
- cancelReplicaSyncRequestsTo(Address) - Method in class com.hazelcast.internal.partition.impl.InternalPartitionServiceImpl
-
- cancelTtlEntry(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractBaseReplicatedRecordStore
-
- cancelTtlEntry(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- cancelWaitingOps(String, Object, Throwable) - Method in class com.hazelcast.spi.impl.waitnotifyservice.impl.WaitNotifyServiceImpl
-
- cancelWaitingOps(String, Object, Throwable) - Method in interface com.hazelcast.spi.impl.waitnotifyservice.WaitNotifyService
-
- canTransformResource(String) - Method in class com.hazelcast.buildutils.HazelcastManifestTransformer
-
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.BufferBuilder
-
The current capacity of the buffer.
- capacity() - Method in interface com.hazelcast.client.impl.protocol.util.ClientProtocolBuffer
-
Get the capacity of the underlying buffer.
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.SafeBuffer
-
- capacity() - Method in class com.hazelcast.client.impl.protocol.util.UnsafeBuffer
-
- capacity() - Method in class com.hazelcast.client.proxy.ClientRingbufferProxy
-
- capacity() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
-
- capacity() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- capacity() - Method in class com.hazelcast.ringbuffer.impl.RingbufferProxy
-
- capacity() - Method in interface com.hazelcast.ringbuffer.Ringbuffer
-
Returns the capacity of this Ringbuffer.
- capacity() - Method in class com.hazelcast.util.collection.BiInt2ObjectMap
-
Get the total capacity for the map to which the load factor with be a fraction of.
- capacity() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
-
Get the total capacity for the map to which the load factor with be a fraction of.
- capacity() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
-
Get the total capacity for the map to which the load factor with be a fraction of.
- CAPACITY_OFFSET - Static variable in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- CapacityUtil - Class in com.hazelcast.internal.util.hashslot.impl
-
Utility functions related to data structure capacity calculation.
- casCachedValue(Object, Object) - Method in class com.hazelcast.map.impl.record.AbstractRecord
-
- casCachedValue(Object, Object) - Method in interface com.hazelcast.map.impl.record.Record
-
Atomically sets the cached value to the given new value
if the current cached value ==
the expected value.
- cd - Variable in class com.hazelcast.internal.serialization.impl.DefaultPortableReader
-
- CDL_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CDL_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CDL_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CDL_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- changeClusterState(ClusterState) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- changeClusterState(ClusterState, TransactionOptions) - Method in class com.hazelcast.client.proxy.ClientClusterProxy
-
- changeClusterState(ClusterState) - Method in interface com.hazelcast.core.Cluster
-
Changes state of the cluster to the given state transactionally.
- changeClusterState(ClusterState, TransactionOptions) - Method in interface com.hazelcast.core.Cluster
-
Changes state of the cluster to the given state transactionally.
- changeClusterState(ClusterState) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- changeClusterState(ClusterState, TransactionOptions) - Method in class com.hazelcast.internal.cluster.impl.ClusterServiceImpl
-
- ChangeClusterStateOperation - Class in com.hazelcast.internal.cluster.impl.operations
-
- ChangeClusterStateOperation() - Constructor for class com.hazelcast.internal.cluster.impl.operations.ChangeClusterStateOperation
-
- ChangeClusterStateOperation(ClusterState, Address, String) - Constructor for class com.hazelcast.internal.cluster.impl.operations.ChangeClusterStateOperation
-
- ChangeClusterStateRequest - Class in com.hazelcast.internal.management.request
-
Request coming from Management Center for changing the
ClusterState
- ChangeClusterStateRequest() - Constructor for class com.hazelcast.internal.management.request.ChangeClusterStateRequest
-
- ChangeClusterStateRequest(String) - Constructor for class com.hazelcast.internal.management.request.ChangeClusterStateRequest
-
- changeNodeStateToActive() - Method in class com.hazelcast.instance.Node
-
- changeNodeStateToPassive() - Method in class com.hazelcast.instance.Node
-
- ChangeWanStateOperation - Class in com.hazelcast.internal.management.operation
-
- ChangeWanStateOperation() - Constructor for class com.hazelcast.internal.management.operation.ChangeWanStateOperation
-
- ChangeWanStateOperation(String, String, boolean) - Constructor for class com.hazelcast.internal.management.operation.ChangeWanStateOperation
-
- ChangeWanStateRequest - Class in com.hazelcast.internal.management.request
-
- ChangeWanStateRequest() - Constructor for class com.hazelcast.internal.management.request.ChangeWanStateRequest
-
- ChangeWanStateRequest(String, String, boolean) - Constructor for class com.hazelcast.internal.management.request.ChangeWanStateRequest
-
- CHAR_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- CHAR_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
Deprecated.
- CHAR_CONVERTER - Static variable in class com.hazelcast.query.impl.TypeConverters
-
- 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.PhoneHome
-
- check2BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
-
- check4BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
-
- check8BytesAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
-
- CHECK_EVICT - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- checkAllDone(Collection<Future>) - Static method in class com.hazelcast.util.FutureUtil
-
Rethrow exeception of the fist future that completed with an exception
- CheckAndEvictOperation - Class in com.hazelcast.collection.impl.queue.operations
-
Provides eviction functionality for Operations of Queue.
- CheckAndEvictOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-
- CheckAndEvictOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.CheckAndEvictOperation
-
- checkAssignedMembersAvailable(Collection<Address>) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- checkAssignedMembersAvailable() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- checkAsyncBackupCount(int, int) - Static method in class com.hazelcast.util.Preconditions
-
Tests if the newAsyncBackupCount count is valid.
- checkAvailable() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-
- checkBackupCount(int, int) - Static method in class com.hazelcast.util.Preconditions
-
Tests if the newBackupCount count is valid.
- checkBlockableReadSequence(long) - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
- checkCacheConfig(String, CacheConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- checkCacheSimpleConfig(String, CacheSimpleConfig) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- checkClassDefErrors - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- checkEvictable(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkEvictable(RecordStore) - Method in interface com.hazelcast.map.impl.eviction.Evictor
-
Check whether the supplied record-store needs eviction.
- checkEvictable(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictorImpl
-
- checkEvictionConfig(EvictionConfig) - Static method in class com.hazelcast.internal.eviction.impl.EvictionConfigHelper
-
- checkEvictionConfig(EvictionPolicy, String, Object) - Static method in class com.hazelcast.internal.eviction.impl.EvictionConfigHelper
-
- checkFalse(boolean, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests whether the supplied expression is false
.
- checkFreeHeapPercentageEviction(MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkFreeHeapSizeEviction(MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkFullyProcessed(JobProcessInformation) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- checkHasNext(Iterator<T>, String) - Static method in class com.hazelcast.util.Preconditions
-
Check if iterator has next element.
- checkHasText(String, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a string contains text.
- checkHeapPercentageEviction(String, MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkHeapSizeEviction(String, MaxSizeConfig) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkIfLoaded() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- checkIfLoaded() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- checkIfManagerNotClosed() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- checkIndexNotNegative(int) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- checkInstanceOf(Class, E, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests whether the supplied object is an instance of the supplied class type.
- checkMapConfig(MapConfig) - Static method in class com.hazelcast.map.impl.MapConfigValidator
-
Checks preconditions to create a map proxy.
- checkNegative(long, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a long value is not negative.
- checkNotInstanceOf(Class, E, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests the supplied object to see if it is not a type of the supplied class.
- checkNotNative(InMemoryFormat) - Static method in class com.hazelcast.map.impl.MapConfigValidator
-
- checkNotNegative(long, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a value is not negative.
- checkNotNegative(int, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a value is not negative.
- checkNotNull(T, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if an argument is not null.
- checkNotNull(T) - Static method in class com.hazelcast.util.Preconditions
-
Tests if an argument is not null.
- checkNotPagingPredicate(Predicate) - Method in class com.hazelcast.map.impl.query.MapQueryEngineImpl
-
- checkObjectNotNull(Object) - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- checkObjectNotNull(Object) - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-
- checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
-
Checks whether current
Subject
has been granted specified permission or not.
- checkPerNodeEviction(RecordStore) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkPerPartitionEviction(String, MaxSizeConfig, int) - Method in class com.hazelcast.map.impl.eviction.EvictionChecker
-
- checkPositive(long, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a value is positive; so larger than 0.
- checkPositive(int, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests if a value is positive; larger than 0.
- checkReferenceAligned(long) - Static method in class com.hazelcast.internal.memory.impl.AlignmentUtil
-
- CheckReplicaVersion - Class in com.hazelcast.internal.partition.operation
-
- CheckReplicaVersion() - Constructor for class com.hazelcast.internal.partition.operation.CheckReplicaVersion
-
- CheckReplicaVersion(long, boolean) - Constructor for class com.hazelcast.internal.partition.operation.CheckReplicaVersion
-
- CheckReplicaVersion - Class in com.hazelcast.replicatedmap.impl.operation
-
Checks whether replica version is in sync with the primary.
- CheckReplicaVersion() - Constructor for class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersion
-
- CheckReplicaVersion(PartitionContainer) - Constructor for class com.hazelcast.replicatedmap.impl.operation.CheckReplicaVersion
-
- checkState(boolean, String) - Static method in class com.hazelcast.util.Preconditions
-
Check the state of a condition
- checkTransactionActive() - Method in class com.hazelcast.collection.impl.txncollection.AbstractTransactionalCollectionProxy
-
- checkTransactionActive() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- checkTransactionState() - Method in class com.hazelcast.collection.impl.txnqueue.TransactionalQueueProxySupport
-
- checkTransactionState() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- checkTrue(boolean, String) - Static method in class com.hazelcast.util.Preconditions
-
Tests whether the supplied expression is true
.
- checkWanReplicationQueues() - Method in class com.hazelcast.map.impl.MapContainer
-
- checkWanReplicationQueues(String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-
- checkWanReplicationQueues() - Method in interface com.hazelcast.wan.WanReplicationPublisher
-
- checkWanReplicationQueues(String) - Method in interface com.hazelcast.wan.WanReplicationService
-
- childElements(Node) - Static 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(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.
- CLASS_CAST - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- CLASS_NOT_FOUND - Static variable in class com.hazelcast.client.impl.protocol.ClientProtocolErrorCodes
-
- 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
-
- ClassDefinitionImpl - Class in com.hazelcast.internal.serialization.impl
-
- ClassDefinitionImpl(int, int, int) - Constructor for class com.hazelcast.internal.serialization.impl.ClassDefinitionImpl
-
- classDefinitions - Variable in class com.hazelcast.internal.serialization.impl.DefaultSerializationServiceBuilder
-
- classIterator(String, ClassLoader) - Static method in class com.hazelcast.util.ServiceLoader
-
- classLoader - Variable in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-
- classLoader - Variable in class com.hazelcast.internal.serialization.impl.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.
- ClassLoadingMetricSet - Class in com.hazelcast.internal.metrics.metricsets
-
- className - Variable in class com.hazelcast.config.ListenerConfig
-
- className - Variable in class com.hazelcast.config.PredicateConfig
-
- 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.
- clean() - Method in class com.hazelcast.internal.diagnostics.DiagnosticsLogWriter
-
- CleaningNearCacheInvalidation - Class in com.hazelcast.map.impl.nearcache
-
Used when invalidating client near-caches.
- CleaningNearCacheInvalidation() - Constructor for class com.hazelcast.map.impl.nearcache.CleaningNearCacheInvalidation
-
- CleaningNearCacheInvalidation(String, String) - Constructor for class com.hazelcast.map.impl.nearcache.CleaningNearCacheInvalidation
-
- cleanNodeName(Node) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- cleanup() - Method in class com.hazelcast.ringbuffer.impl.RingbufferContainer
-
Cleans up the ringbuffer by deleting all expired items.
- 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() - 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.cache.impl.nearcache.impl.DefaultNearCache
-
- clear() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-
- clear() - Method in interface com.hazelcast.cache.impl.nearcache.NearCache
-
Removes all stored values.
- clear() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheRecordStore
-
Removes all stored values.
- clear() - Method in class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- 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.map.impl.nearcache.ClientHeapNearCache
-
- clear() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- clear() - Method in class com.hazelcast.client.proxy.ClientListProxy
-
- 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.client.proxy.ClientSetProxy
-
- clear() - Method in class com.hazelcast.client.proxy.NearCachedClientMapProxy
-
- clear() - Method in class com.hazelcast.collection.impl.collection.AbstractCollectionProxyImpl
-
- clear() - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- clear() - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- CLEAR - Static variable in class com.hazelcast.collection.impl.queue.QueueDataSerializerHook
-
- 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
-
- 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
-
- clear() - Method in interface com.hazelcast.core.MultiMap
-
Clears the multimap.
- clear() - Method in interface com.hazelcast.core.ReplicatedMap
-
The clear operation wipes data out of the replicated maps.
- clear() - Method in class com.hazelcast.internal.cluster.impl.MemberSelectingCollection
-
- clear() - Method in class com.hazelcast.internal.jmx.ListMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.LockMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.MapMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.MultiMapMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.QueueMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.ReplicatedMapMBean
-
- clear() - Method in class com.hazelcast.internal.jmx.SetMBean
-
- clear() - Method in class com.hazelcast.internal.serialization.impl.bufferpool.BufferPoolThreadLocal
-
- clear() - Method in interface com.hazelcast.internal.util.collection.Long2LongMap
-
- clear() - Method in class com.hazelcast.internal.util.collection.Long2LongMapHsa
-
- clear() - Method in interface com.hazelcast.internal.util.collection.LongSet
-
- clear() - Method in class com.hazelcast.internal.util.collection.LongSetHsa
-
- clear() - Method in class com.hazelcast.internal.util.collection.MPSCQueue
-
.
- clear() - Method in interface com.hazelcast.internal.util.hashslot.HashSlotArray
-
After this method returns, all slots in the current hash slot array are unassigned.
- clear() - Method in class com.hazelcast.internal.util.hashslot.impl.HashSlotArrayBase
-
- clear() - Method in class com.hazelcast.map.impl.MapEntries
-
- clear() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Removes all of the elements in this
WriteBehindQueue
Queue will be empty after this method returns.
- clear(String, boolean, String) - Method in class com.hazelcast.map.impl.nearcache.BatchInvalidator
-
- clear() - Method in class com.hazelcast.map.impl.nearcache.NearCacheImpl
-
- clear(String, boolean, String) - Method in interface com.hazelcast.map.impl.nearcache.NearCacheInvalidator
-
Clears local and remote near-caches.
- clear(String, boolean, String) - Method in class com.hazelcast.map.impl.nearcache.NonStopInvalidator
-
- clear() - Method in class com.hazelcast.map.impl.nearcache.StaleReadPreventerNearCacheWrapper
-
- clear(boolean) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- clear() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
This method clears the map and calls deleteAll on MapStore which if connected to a database,
will delete the records from that database.
- clear() - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- clear() - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
- clear(boolean) - Method in interface com.hazelcast.map.impl.recordstore.Storage
-
- clear(boolean) - Method in class com.hazelcast.map.impl.recordstore.StorageImpl
-
- clear() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- clear() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- clear() - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- clear() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
-
- 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.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- clear() - Method in class com.hazelcast.replicatedmap.impl.record.InternalReplicatedMapStorage
-
- clear() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- clear() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- clear() - Method in class com.hazelcast.spi.impl.UnmodifiableLazyList
-
- clear() - Method in class com.hazelcast.spi.LiveOperations
-
- clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
-
- clear() - Method in class com.hazelcast.util.collection.InflatableSet
-
- clear() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap
- clear() - Method in class com.hazelcast.util.collection.Int2ObjectHashMap.KeySet
-
- clear() - Method in class com.hazelcast.util.collection.IntHashSet
- clear() - Method in class com.hazelcast.util.collection.Long2LongHashMap
- clear() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap
- clear() - Method in class com.hazelcast.util.collection.Long2ObjectHashMap.KeySet
-
- clear() - Method in class com.hazelcast.util.collection.LongHashSet
- clear() - Method in class com.hazelcast.util.collection.MapDelegatingSet
- 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.collection.impl.queue.QueueDataSerializerHook
-
- CLEAR_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- 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
-
- clearAllNearCaches() - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-
- clearAllNearCaches() - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheManager
-
- clearAsync() - Method in class com.hazelcast.client.proxy.ClientAtomicReferenceProxy
-
- clearAsync() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- clearAsync() - Method in interface com.hazelcast.core.IAtomicReference
-
Clears the current stored reference.
- clearBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.collection.CollectionContainer
-
- clearBackup(Set<Long>) - Method in class com.hazelcast.collection.impl.queue.QueueContainer
-
- ClearBackupOperation - Class in com.hazelcast.collection.impl.queue.operations
-
Store items' id as set when ClearOperation run.
- ClearBackupOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-
- ClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearBackupOperation
-
- 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
-
- 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
-
- clearIndexes() - Method in class com.hazelcast.query.impl.Indexes
-
- clearLocal(String) - Method in class com.hazelcast.map.impl.nearcache.AbstractNearCacheInvalidator
-
- 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.
- clearMapsHavingLesserBackupCountThan(int, int) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
Clears all map partitions which are expected to have lesser backups
than given.
- clearNearCache(String) - Method in class com.hazelcast.cache.impl.nearcache.impl.DefaultNearCacheManager
-
- clearNearCache(String) - Method in interface com.hazelcast.cache.impl.nearcache.NearCacheManager
-
Clears
NearCache
instance associated with given
name
but not removes it.
- clearNearCache(boolean) - Method in class com.hazelcast.map.impl.operation.MapOperation
-
- ClearNearCacheOperation - Class in com.hazelcast.map.impl.operation
-
- ClearNearCacheOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearNearCacheOperation
-
- ClearNearCacheOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearNearCacheOperation
-
- ClearOperation - Class in com.hazelcast.collection.impl.queue.operations
-
Clears items stored by Queue.
- ClearOperation() - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearOperation
-
- ClearOperation(String) - Constructor for class com.hazelcast.collection.impl.queue.operations.ClearOperation
-
- 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.replicatedmap.impl.operation
-
- ClearOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-
- ClearOperation(String, boolean) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperation
-
- ClearOperation(String, boolean, long) - Constructor for class com.hazelcast.replicatedmap.impl.operation.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
-
- ClearOperationFactory - Class in com.hazelcast.replicatedmap.impl.operation
-
- ClearOperationFactory() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-
- ClearOperationFactory(String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ClearOperationFactory
-
- clearPartition(boolean) - Method in class com.hazelcast.map.impl.recordstore.DefaultRecordStore
-
- clearPartition(boolean) - Method in interface com.hazelcast.map.impl.recordstore.RecordStore
-
Clears internal partition data.
- clearPartitionData(int) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- clearPartitionReplicaVersions(int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
-
- clearPartitions(boolean) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
Clears all partition based data allocated by MapService.
- clearRecords() - Method in class com.hazelcast.cache.impl.nearcache.impl.store.AbstractNearCacheRecordStore
-
- ClearRemoteTransactionBackupOperation - Class in com.hazelcast.transaction.impl.xa.operations
-
- ClearRemoteTransactionBackupOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-
- ClearRemoteTransactionBackupOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionBackupOperation
-
- ClearRemoteTransactionOperation - Class in com.hazelcast.transaction.impl.xa.operations
-
- ClearRemoteTransactionOperation() - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-
- ClearRemoteTransactionOperation(Data) - Constructor for class com.hazelcast.transaction.impl.xa.operations.ClearRemoteTransactionOperation
-
- clearReplicaSyncRequest(int, int) - Method in class com.hazelcast.internal.partition.impl.PartitionReplicaManager
-
- clearRingBuffersHavingLesserBackupCountThan(int) - Method in class com.hazelcast.durableexecutor.impl.DurableExecutorPartitionContainer
-
- clearServers() - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- clearSystemProperty() - Method in enum com.hazelcast.instance.GroupProperty
-
Deprecated.
- clearSystemProperty() - Method in interface com.hazelcast.instance.HazelcastProperty
-
Deprecated.
Clears the environmental value of the property.
- clearWithVersion(long) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- clearWithVersion(long) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- client - Variable in class com.hazelcast.client.impl.DefaultClientExtension
-
- client - Variable in class com.hazelcast.client.impl.HazelcastClientProxy
-
- client - Variable in class com.hazelcast.client.spi.impl.ClusterListenerSupport
-
- client - Variable in class com.hazelcast.client.spi.impl.listener.ClientListenerServiceImpl
-
- 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_NEW - Static variable in class com.hazelcast.nio.Protocols
-
New Client Protocol that is used for clients(java, c++ , c# client)
- CLIENT_DS_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_DS_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_ENGINE_THREAD_COUNT - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
The number of threads that the client engine has available for processing requests that are not partition specific.
- CLIENT_ERROR - Static variable in class com.hazelcast.internal.ascii.TextCommandConstants
-
- CLIENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the client executor.
- CLIENT_HEARTBEAT_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.properties.GroupProperty
-
- CLIENT_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_TXN_PORTABLE_FACTORY - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- CLIENT_TXN_PORTABLE_FACTORY_ID - Static variable in class com.hazelcast.internal.serialization.impl.FactoryIdHelper
-
- ClientAddressCancellableDelegatingFuture<V> - Class in com.hazelcast.client.util
-
A DelegatingFuture that can cancel a Runnable/Callable that is executed by an
IExecutorService
.
- ClientAddressCancellableDelegatingFuture(ClientInvocationFuture, ClientContext, String, Address, V, ClientMessageDecoder) - Constructor for class com.hazelcast.client.util.ClientAddressCancellableDelegatingFuture
-
- 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
-