- AbstractAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-
- AbstractAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-
- AbstractAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- AbstractAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- AbstractAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- AbstractAlterRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- AbstractAlterRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- AbstractAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- AbstractAlterRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- AbstractAlterRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- AbstractAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- AbstractCacheRecord<V> - Class in com.hazelcast.cache.impl.record
-
Abstract implementation of
CacheRecord
with key, value and
expiration time as internal state.
- AbstractCacheRecord() - Constructor for class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- AbstractCacheRecord(long) - Constructor for class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- AbstractCacheRecordStore<R extends CacheRecord,CRM extends CacheRecordMap<Data,R>> - Class in com.hazelcast.cache.impl
-
- AbstractCacheRecordStore(String, int, NodeEngine, AbstractCacheService) - Constructor for class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- AbstractCacheRequest - Class in com.hazelcast.cache.impl.client
-
Abstract cache request to handle a completion id registration.
- AbstractCacheRequest() - Constructor for class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- AbstractCacheRequest(String, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- AbstractCacheService - Class in com.hazelcast.cache.impl
-
- AbstractCacheService() - Constructor for class com.hazelcast.cache.impl.AbstractCacheService
-
- AbstractClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
-
- AbstractClusterWideIterator(ICache<K, V>, int) - Constructor for class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- AbstractCollectionProxyImpl<S extends RemoteService,E> - Class in com.hazelcast.collection
-
- AbstractCollectionProxyImpl(String, NodeEngine, S) - Constructor for class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- AbstractCompletableFuture<V> - Class in com.hazelcast.spi.impl
-
- AbstractCompletableFuture(NodeEngine, ILogger) - Constructor for class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- AbstractCredentials - Class in com.hazelcast.security
-
- AbstractCredentials() - Constructor for class com.hazelcast.security.AbstractCredentials
-
- AbstractCredentials(String) - Constructor for class com.hazelcast.security.AbstractCredentials
-
- AbstractDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi
-
Abstract DistributedObject implementation.
- AbstractDistributedObject(NodeEngine, S) - Constructor for class com.hazelcast.spi.AbstractDistributedObject
-
- AbstractEntryProcessor<K,V> - Class in com.hazelcast.map
-
- AbstractEntryProcessor() - Constructor for class com.hazelcast.map.AbstractEntryProcessor
-
- AbstractEntryProcessor(boolean) - Constructor for class com.hazelcast.map.AbstractEntryProcessor
-
Creates an AbstractEntryProcessor.
- AbstractExecutorThreadFactory - Class in com.hazelcast.util.executor
-
- AbstractExecutorThreadFactory(ThreadGroup, ClassLoader) - Constructor for class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-
- AbstractHazelcastCacheManager - Class in com.hazelcast.cache.impl
-
Abstract CacheManager
implementation provides shared functionality to server and client cache managers.
- AbstractHazelcastCacheManager(CachingProvider, 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
-
- AbstractIMapEvent - Class in com.hazelcast.core
-
- AbstractIMapEvent(Object, Member, int) - Constructor for class com.hazelcast.core.AbstractIMapEvent
-
Constructs a prototypical Event.
- AbstractIOSelector - Class in com.hazelcast.nio.tcp
-
- AbstractIOSelector(ThreadGroup, String, ILogger, IOSelectorOutOfMemoryHandler) - Constructor for class com.hazelcast.nio.tcp.AbstractIOSelector
-
- AbstractIsLockedRequest - Class in com.hazelcast.concurrent.lock.client
-
- AbstractIsLockedRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- AbstractIsLockedRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- AbstractIsLockedRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- AbstractJob<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl
-
Base class for all map reduce job implementations
- AbstractJob(String, JobTracker, KeyValueSource<KeyIn, ValueIn>) - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob
-
- AbstractJob.MappingJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
-
This class is just used to comply to the public DSL style API
- AbstractJob.MappingJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- AbstractJob.ReducingJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
-
This class is just used to comply to the public DSL style API
- AbstractJob.ReducingJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-
- AbstractJob.ReducingSubmittableJobImpl<EntryKey,Key,Value> - Class in com.hazelcast.mapreduce.impl
-
This class is just used to comply to the public DSL style API
- AbstractJob.ReducingSubmittableJobImpl() - Constructor for class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-
- AbstractJobTracker - Class in com.hazelcast.mapreduce.impl
-
This is the base class for all
JobTracker
implementations on node and client side.
It combines a lot of the base functionality to handle remote operations.
- AbstractJoiner - Class in com.hazelcast.cluster.impl
-
- AbstractJoiner(Node) - Constructor for class com.hazelcast.cluster.impl.AbstractJoiner
-
- AbstractLockRequest - Class in com.hazelcast.concurrent.lock.client
-
- AbstractLockRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- AbstractLockRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- AbstractLockRequest(Data, long, long, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- AbstractLogger - Class in com.hazelcast.logging
-
Abstract
ILogger
implementation that provides implementations for the convenience methods like
finest,info,warning and severe.
- AbstractLogger() - Constructor for class com.hazelcast.logging.AbstractLogger
-
- AbstractMapAddEntryListenerRequest - Class in com.hazelcast.map.impl.client
-
Base class for adding entry listener to map
- AbstractMapAddEntryListenerRequest() - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- AbstractMapAddEntryListenerRequest(String, boolean) - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- AbstractMapAddEntryListenerRequest(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- AbstractMapDataStore<K,V> - Class in com.hazelcast.map.impl.mapstore
-
Abstract map data store contains common functionality of map data stores.
- AbstractMapDataStore(MapStoreWrapper, SerializationService) - Constructor for class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-
- AbstractMapOperation - Class in com.hazelcast.map.impl.operation
-
- AbstractMapOperation() - Constructor for class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- AbstractMapOperation(String) - Constructor for class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- AbstractMutatingCacheOperation - Class in com.hazelcast.cache.impl.operation
-
Base class for all mutable cache operations.
- AbstractMutatingCacheOperation() - Constructor for class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- AbstractMutatingCacheOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- AbstractNamedOperation - Class in com.hazelcast.spi.impl
-
- AbstractNamedOperation(String) - Constructor for class com.hazelcast.spi.impl.AbstractNamedOperation
-
- AbstractNamedOperation() - Constructor for class com.hazelcast.spi.impl.AbstractNamedOperation
-
- AbstractOperation - Class in com.hazelcast.spi
-
Abstract
Operation
implementation with some basic methods
implemented.
- AbstractOperation() - Constructor for class com.hazelcast.spi.AbstractOperation
-
- AbstractReplicatedMapClientRequest - Class in com.hazelcast.replicatedmap.impl.client
-
Base class for all ReplicatedMap client request.
- AbstractReplicatedMapClientRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- AbstractReplicatedMapClientRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- AbstractReplicatedMapOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
Base class for replicated map remote operations
- AbstractReplicatedMapOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-
- AbstractReplicatedRecordStore<K,V> - Class in com.hazelcast.replicatedmap.impl.record
-
- AbstractReplicatedRecordStore(String, NodeEngine, ReplicatedMapService) - Constructor for class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- AbstractTextCommand - Class in com.hazelcast.ascii
-
- AbstractTextCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.AbstractTextCommand
-
- AbstractTextCommandProcessor<T> - Class in com.hazelcast.ascii
-
- AbstractTextCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.ascii.AbstractTextCommandProcessor
-
- AbstractTransactionalCollectionProxy<S extends RemoteService,E> - Class in com.hazelcast.collection.txn
-
- AbstractTransactionalCollectionProxy(String, TransactionSupport, NodeEngine, S) - Constructor for class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- AbstractTxnMapRequest - Class in com.hazelcast.map.impl.client
-
- AbstractTxnMapRequest() - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data, Data) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- AbstractTxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data, long, TimeUnit) - Constructor for class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- AbstractTxnMapRequest.TxnMapRequestType - Enum in com.hazelcast.map.impl.client
-
- AbstractUnlockRequest - Class in com.hazelcast.concurrent.lock.client
-
- AbstractUnlockRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- AbstractUnlockRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- AbstractUnlockRequest(Data, long, boolean) - Constructor for class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- AbstractWaitNotifyKey - Class in com.hazelcast.spi
-
Abstract implementation of the WaitNotifyKey.
- AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.AbstractWaitNotifyKey
-
- AbstractXmlConfigHelper - Class in com.hazelcast.config
-
Contains Hazelcast Xml Configuration helper methods and variables.
- AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
-
- AbstractXmlConfigHelper.IterableNodeList - Class in com.hazelcast.config
-
Iterator for NodeList
- AbstractXmlConfigHelper.IterableNodeList(Node) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- AbstractXmlConfigHelper.IterableNodeList(NodeList) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- AbstractXmlConfigHelper.IterableNodeList(Node, short) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- AbstractXmlConfigHelper.IterableNodeList(NodeList, short) - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- ACCEPT_ALL_SUPPLIER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- AcceptAllSupplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation.impl
-
A standard implementation of the
Supplier
interface which accepts all input values and may apply a given
PropertyExtractor
on those.
- AcceptAllSupplier(PropertyExtractor<ValueIn, ValueOut>) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-
- acceptMasterConfirmation(MemberImpl) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- access() - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- access() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- access() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- accessRecord(R, ExpiryPolicy, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- accumulate(CacheStatisticsImpl) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Simple CacheStatistics adder.
- acquire(int, String) - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- acquire() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- acquire(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- acquire() - Method in interface com.hazelcast.core.ISemaphore
-
Acquires a permit, if one is available and returns immediately,
reducing the number of available permits by one.
- acquire(int) - Method in interface com.hazelcast.core.ISemaphore
-
Acquires the given number of permits, if they are available,
and returns immediately, reducing the number of available permits
by the given amount.
- ACQUIRE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- ACQUIRE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- AcquireBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- AcquireBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-
- AcquireBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-
- AcquireOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- AcquireOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- AcquireOperation(String, int, long) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- AcquireRequest - Class in com.hazelcast.concurrent.semaphore.client
-
- AcquireRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- AcquireRequest(String, int, long) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- AcquireRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- AcquireRequest(String) - Constructor for class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- ACTION_ACQUIRE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_ADD - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_ALL - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_CREATE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_DESTROY - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_INDEX - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_INTERCEPT - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_LISTEN - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_LOCK - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_MODIFY - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_PUBLISH - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_PUT - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_READ - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_RELEASE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ACTION_REMOVE - Static variable in class com.hazelcast.security.permission.ActionConstants
-
- ActionConstants - Class in com.hazelcast.security.permission
-
- actions - Variable in class com.hazelcast.security.permission.InstancePermission
-
- Activator - Class in com.hazelcast.osgi
-
Hazelcast OSGi bundle activator
initializes script Engines
- Activator() - Constructor for class com.hazelcast.osgi.Activator
-
- add(E) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- add(Data) - Method in class com.hazelcast.collection.CollectionContainer
-
- add(int, Data) - Method in class com.hazelcast.collection.list.ListContainer
-
- add(int, E) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- add(E) - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- add(E) - Method in class com.hazelcast.collection.txn.TransactionalSetProxy
-
- add(CountDownLatchInfo) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- add(E) - Method in interface com.hazelcast.core.TransactionalList
-
Add new item to transactional list
- add(E) - Method in interface com.hazelcast.core.TransactionalSet
-
Add new item to transactional set
- add(Map.Entry<Data, Data>) - Method in class com.hazelcast.map.impl.MapEntrySet
-
- add(Data, Data) - Method in class com.hazelcast.map.impl.MapEntrySet
-
- add(K, V, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-
- add(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- add(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-
- add(QueryResultEntry) - Method in class com.hazelcast.map.impl.QueryResult
-
- add(long) - Method in interface com.hazelcast.map.impl.SizeEstimator
-
- add(QueryableEntry) - Method in class com.hazelcast.query.impl.MultiResultSet
-
- add(E) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- add(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- add(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- add(PermissionCollection) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- add(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- add(QueryResultEntry) - Method in class com.hazelcast.util.QueryResultSet
-
- add(Object) - Method in class com.hazelcast.util.QueryResultSet
-
- add(Map.Entry) - Method in class com.hazelcast.util.SortedQueryResultSet
-
- ADD_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- ADD_ALL - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- ADD_ALL - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- ADD_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- ADD_ALL_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- ADD_AND_GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- ADD_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- ADD_ENTRY_LISTENER - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- ADD_ENTRY_LISTENER_SQL - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- ADD_INDEX - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- ADD_INTERCEPTOR - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- ADD_INVALIDATION_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- ADD_LISTENER - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- ADD_LISTENER - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- ADD_LISTENER - Static variable in class com.hazelcast.topic.impl.TopicPortableHook
-
- addAction(String) - Method in class com.hazelcast.config.PermissionConfig
-
- addAll(Collection<? extends E>) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- addAll(List<Data>) - Method in class com.hazelcast.collection.CollectionContainer
-
- addAll(int, List<Data>) - Method in class com.hazelcast.collection.list.ListContainer
-
- addAll(int, Collection<? extends E>) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- addAll(List<Data>) - Method in class com.hazelcast.collection.set.SetContainer
-
- addAll(Collection<? extends E>) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- addAll(Collection<Data>) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.collection.CollectionContainer
-
- addAllBackup(Map<Long, Data>) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- AddAllBackupOperation - Class in com.hazelcast.queue.impl.operations
-
- AddAllBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.AddAllBackupOperation
-
- AddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.queue.impl.operations.AddAllBackupOperation
-
- AddAllOperation - Class in com.hazelcast.queue.impl.operations
-
Add collection items to the Queue.
- AddAllOperation() - Constructor for class com.hazelcast.queue.impl.operations.AddAllOperation
-
- AddAllOperation(String, Collection<Data>) - Constructor for class com.hazelcast.queue.impl.operations.AddAllOperation
-
- AddAllRequest - Class in com.hazelcast.queue.impl.client
-
- AddAllRequest() - Constructor for class com.hazelcast.queue.impl.client.AddAllRequest
-
- AddAllRequest(String, Collection<Data>) - Constructor for class com.hazelcast.queue.impl.client.AddAllRequest
-
- addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- addAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.LongWrapper
-
- addAndGet(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically adds the given value to the current value.
- addAndGet(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- AddAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AddAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- AddAndGetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- AddAndGetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- AddAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-
- AddAndGetRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-
- addAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- addBackup(long, Data) - Method in class com.hazelcast.collection.CollectionContainer
-
- addBackup(K, V, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-
- addBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- addBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-
- AddBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AddBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-
- AddBackupOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-
- addBooleanField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addByteArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addByteField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addCacheConfig(CacheSimpleConfig) - Method in class com.hazelcast.config.Config
-
- addCacheConfigIfAbsentToLocal(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- addCacheConfigIfAbsentToLocal(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- addCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Add a configuration for a CacheEntryListener
.
- addCharArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addCharField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addClassDefinition(ClassDefinition) - Method in class com.hazelcast.config.SerializationConfig
-
- addClassDefinition(ClassDefinition) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- addClassDefinition(ClassDefinition) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- addClientListener(ClientListener) - Method in class com.hazelcast.client.impl.ClientServiceProxy
-
- addClientListener(ClientListener) - Method in interface com.hazelcast.core.ClientService
-
Adds a ClientListener
When a ClientListener is added more than once, it will receive duplicate events.
- addClientLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- addClientRecoveredTransaction(RecoveredTransaction) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- addConnectionListener(ConnectionListener) - Method in interface com.hazelcast.nio.ConnectionManager
-
- addConnectionListener(ConnectionListener) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- addContainer(String, CollectionContainer) - Method in class com.hazelcast.collection.CollectionService
-
- addContainer(String, QueueContainer) - Method in class com.hazelcast.queue.impl.QueueService
-
- addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
-
- addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- addDataSerializableFactory(int, DataSerializableFactory) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
-
- addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- addDistributedObjectListener(DistributedObjectListener) - Method in 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
-
- addDoubleArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addEnd(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Add this collection to the end of the queue.
- addEndpoint(String) - Method in class com.hazelcast.config.PermissionConfig
-
- addEndpoint(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds an entry listener for this map.
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds the specified entry listener for the specified key.
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds an continuous entry listener for this map.
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds an continuous entry listener for this map.
- addEntryListener(EntryListener<K, V>, boolean) - Method in interface com.hazelcast.core.MultiMap
-
Adds an entry listener for this multimap.
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in interface com.hazelcast.core.MultiMap
-
Adds the specified entry listener for the specified key.
- addEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
-
Adds an entry listener for this map.
- addEntryListener(EntryListener<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
-
Adds the specified entry listener for the specified key.
- addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in interface com.hazelcast.core.ReplicatedMap
-
Adds an continuous entry listener for this map.
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in interface com.hazelcast.core.ReplicatedMap
-
Adds an continuous entry listener for this map.
- addEntryListener(EntryListener, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addEntryListener(EntryListener<K, V>, boolean) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- addEntryListener(EntryListener<K, V>, K, boolean) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- addEntryListener(EntryListener, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- addEntryListener(EntryListener, Predicate, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- addEntryListener(EntryListener, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- addEntryListener(EntryListener, Predicate, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- addEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- addEntryListener(EntryListener<K, V>, K) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- addEntryListener(EntryListener<K, V>, Predicate<K, V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- addEntryListener(EntryListener<K, V>, Predicate<K, V>, K) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- addEntryListenerConfig(CacheSimpleEntryListenerConfig) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfig
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfig
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- addEntryListenerConfig(EntryListenerConfig) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- AddEntryListenerRequest - Class in com.hazelcast.multimap.impl.client
-
- AddEntryListenerRequest() - Constructor for class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- AddEntryListenerRequest(String, Data, boolean) - Constructor for class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- addEventData(CacheEventData) - Method in class com.hazelcast.cache.impl.CacheEventSet
-
Helper method for adding multiple CacheEventData into this Set
- addEventListener(EntryListener, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addEventListener(EventListener, EventFilter, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
-
Adds a new ExecutorConfig by name
- addFloatArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addFront(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Add this collection to the front of the queue.
- addGetTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increments the getCache time accumulator.
- addIndex(String, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds an index to this map for the specified entries so
that queries can run faster.
- AddIndexOperation - Class in com.hazelcast.map.impl.operation
-
- AddIndexOperation(String, String, boolean) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
-
- AddIndexOperation() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperation
-
- AddIndexOperationFactory - Class in com.hazelcast.map.impl.operation
-
- AddIndexOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-
- AddIndexOperationFactory(String, String, boolean) - Constructor for class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-
- addIntArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addInterceptor(MapInterceptor) - Method in interface com.hazelcast.core.IMap
-
Adds an interceptor for this map.
- addInterceptor(MapInterceptor) - Method in class com.hazelcast.map.impl.MapContainer
-
- addInterceptor(String, MapInterceptor) - Method in class com.hazelcast.map.impl.MapContainer
-
- addInterceptor(String, MapInterceptor) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- addInterceptor(MapInterceptor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- AddInterceptorOperation - Class in com.hazelcast.map.impl.operation
-
- AddInterceptorOperation(String, MapInterceptor, String) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- AddInterceptorOperation() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- AddInterceptorOperationFactory - Class in com.hazelcast.map.impl.operation
-
- AddInterceptorOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
-
- AddInterceptorOperationFactory(String, String, MapInterceptor) - Constructor for class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
-
- addInterface(String) - Method in class com.hazelcast.config.InterfacesConfig
-
Adds a new interface
- addInterface(String) - Method in class com.hazelcast.config.MemberGroupConfig
-
Adds an interface to the member group.
- addIntField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addItemListener(ItemListener<E>, boolean) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- addItemListener(ItemListener<E>, boolean) - Method in interface com.hazelcast.core.ICollection
-
Adds an item listener for this collection.
- addItemListener(String, ItemListener, boolean) - Method in class com.hazelcast.queue.impl.QueueService
-
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.CollectionConfig
-
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.ListConfigReadOnly
-
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfig
-
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
-
- addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.config.Config
-
- addLifecycleListener(LifecycleListener) - Method in interface com.hazelcast.core.LifecycleService
-
Add listener object to listen 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.config.Config
-
- AddListenerRequest - Class in com.hazelcast.queue.impl.client
-
this class is used to attach a listener to targeted node which sends back the events to client for a queue
- AddListenerRequest() - Constructor for class com.hazelcast.queue.impl.client.AddListenerRequest
-
- AddListenerRequest(String, boolean) - Constructor for class com.hazelcast.queue.impl.client.AddListenerRequest
-
- addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.IMap
-
Adds a local entry listener for this map.
- addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds a local entry listener for this map.
- addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in interface com.hazelcast.core.IMap
-
Adds a local entry listener for this map.
- addLocalEntryListener(EntryListener<K, V>) - Method in interface com.hazelcast.core.MultiMap
-
Adds a local entry listener for this multimap.
- addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener<K, V>, Predicate<K, V>, K, boolean) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- addLocalEntryListener(EntryListener<K, V>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- addLocalEventListener(EntryListener, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addLocalEventListener(EntryListener, EventFilter, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- addLogListener(Level, LogListener) - Method in interface com.hazelcast.logging.LoggingService
-
- addLogListener(Level, LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
-
- addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addManagedTransaction(Xid, Transaction) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
-
- addMapIndex(MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-
- addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfig
-
- addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- addMapInterceptors(MapContainer) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-
- addMember(String) - Method in class com.hazelcast.config.TcpIpConfig
-
Adds a 'well known' member.
- addMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- addMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-
- addMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
-
- addMemberInfo(MemberInfo, Map<Address, Integer>, int) - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- addMemberLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- addMembers(Collection<Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-
- addMembers(Collection<Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- addMembershipListener(MembershipListener) - Method in class com.hazelcast.cluster.impl.ClusterProxy
-
- addMembershipListener(MembershipListener) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- addMembershipListener(MembershipListener) - Method in interface com.hazelcast.core.Cluster
-
Adds MembershipListener to listen for membership updates.
- AddMembershipListenerRequest - Class in com.hazelcast.cluster.client
-
- AddMembershipListenerRequest() - Constructor for class com.hazelcast.cluster.client.AddMembershipListenerRequest
-
- addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.core.ITopic
-
Subscribes to this topic.
- addMessageListener(MessageListener<E>) - Method in class com.hazelcast.topic.impl.TopicProxy
-
- addMessageListener(String, MessageListener) - Method in class com.hazelcast.topic.impl.TopicService
-
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
-
- addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfigReadOnly
-
- AddMessageListenerRequest - Class in com.hazelcast.topic.impl.client
-
- AddMessageListenerRequest() - Constructor for class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- AddMessageListenerRequest(String) - Constructor for class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- addMigrationListener(MigrationListener) - Method in interface com.hazelcast.core.PartitionService
-
Adds a MigrationListener.
- addMigrationListener(MigrationListener) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- addMigrationListener(MigrationListener) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- addMigrationListener(MigrationListener) - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- addMulticastListener(MulticastListener) - Method in class com.hazelcast.cluster.impl.MulticastService
-
- addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.config.Config
-
- addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- addOperation(Operation) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- addOrGetIndex(String, boolean) - Method in class com.hazelcast.query.impl.IndexService
-
- addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
-
- addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
-
- addOwnershipMapping(String, String) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- addPartition(int) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- addPortableArrayField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.config.SerializationConfig
-
- addPortableFactory(int, PortableFactory) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- addPortableFactory(int, PortableFactory) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- addPortableFactoryClass(int, Class<? extends PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- addPortableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
-
- addPortableField(String, ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addProcessedRecords(int) - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- addProxyListener(DistributedObjectListener) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- addProxyListener(DistributedObjectListener) - Method in interface com.hazelcast.spi.ProxyService
-
- addPutTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increments the put time accumulator.
- addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
-
- addRemoveTimeNanos(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increments the remove time accumulator.
- addReplicatedMapConfig(ReplicatedMapConfig) - Method in class com.hazelcast.config.Config
-
- ADDRESS - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-
- address - Variable in class com.hazelcast.cluster.impl.JoinMessage
-
- address - Variable in class com.hazelcast.instance.Node
-
- Address - Class in com.hazelcast.nio
-
Represents an address of a member in the cluster.
- Address() - Constructor for class com.hazelcast.nio.Address
-
- Address(String, int) - Constructor for class com.hazelcast.nio.Address
-
- Address(InetAddress, int) - Constructor for class com.hazelcast.nio.Address
-
- Address(InetSocketAddress) - Constructor for class com.hazelcast.nio.Address
-
Creates a new Address
- Address(String, InetAddress, int) - Constructor for class com.hazelcast.nio.Address
-
- Address(Address) - Constructor for class com.hazelcast.nio.Address
-
- address - Variable in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- AddressPicker - Interface in com.hazelcast.instance
-
- AddressUtil - Class in com.hazelcast.util
-
AddressUtil contains Address helper methods
- AddressUtil.AddressHolder - Class in com.hazelcast.util
-
Holds address
- AddressUtil.AddressHolder(String, int, String) - Constructor for class com.hazelcast.util.AddressUtil.AddressHolder
-
- AddressUtil.AddressMatcher - Class in com.hazelcast.util
-
http://docs.oracle.com/javase/1.5.0/docs/guide/net/ipv6_guide/index.html
- AddressUtil.AddressMatcher(String[]) - Constructor for class com.hazelcast.util.AddressUtil.AddressMatcher
-
- AddressUtil.InvalidAddressException - Exception in com.hazelcast.util
-
Thrown when given address is not valid.
- AddressUtil.InvalidAddressException(String) - Constructor for exception com.hazelcast.util.AddressUtil.InvalidAddressException
-
- addResultSet(ConcurrentMap<Data, QueryableEntry>) - Method in class com.hazelcast.query.impl.MultiResultSet
-
- addSecurityInterceptorConfig(SecurityInterceptorConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- addSemaphoreConfig(SemaphoreConfig) - Method in class com.hazelcast.config.Config
-
Adds a new SemaphoreConfig by name
- addSerializerConfig(SerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
-
- addServiceConfig(ServiceConfig) - Method in class com.hazelcast.config.ServicesConfig
-
- addSetConfig(SetConfig) - Method in class com.hazelcast.config.Config
-
- addShortArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addShortField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addStoreListener(StoreListener) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-
- addTargetClusterConfig(WanTargetClusterConfig) - Method in class com.hazelcast.config.WanReplicationConfig
-
- addTask(Runnable) - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- addTask(Runnable) - Method in interface com.hazelcast.nio.tcp.IOSelector
-
- addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
-
- addTransactionLog(TransactionLog) - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- addTransient(K, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-
- addTransient(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- addTransient(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-
- addTrustedInterface(String) - Method in class com.hazelcast.config.MulticastConfig
-
Adds a trusted interface.
- addTxBackupLogForClientRecovery(Transaction) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
-
- advance() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- after(Credentials, String, String, String, Parameters) - Method in interface com.hazelcast.security.SecurityInterceptor
-
- afterGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Called after get(..) operation is completed.
- afterPut(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Called after put(..) operation is completed.
- afterRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Called after remove(..) operation is completed.
- afterResponse() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
-
Called on node side, after sending the response to the client.
- afterRun() - Method in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionAddAllBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionAddAllOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionAddBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionAddOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionClearBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionClearOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionCompareAndRemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionContainsOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionGetAllOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionIsEmptyOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionRemoveBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionRemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionSizeOperation
-
- afterRun() - Method in class com.hazelcast.collection.CollectionTransactionRollbackOperation
-
- afterRun() - Method in class com.hazelcast.collection.list.ListGetOperation
-
- afterRun() - Method in class com.hazelcast.collection.list.ListIndexOfOperation
-
- afterRun() - Method in class com.hazelcast.collection.list.ListRemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.list.ListSetBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.list.ListSetOperation
-
- afterRun() - Method in class com.hazelcast.collection.list.ListSubOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionPrepareOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionReserveAddOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionRollbackOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionTxnAddOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
-
- afterRun() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
-
- afterRun() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-
- afterRun() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-
- afterRun() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- afterRun() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-
- afterRun() - Method in class com.hazelcast.management.operation.GetMapConfigOperation
-
- afterRun() - Method in class com.hazelcast.management.operation.ScriptExecutorOperation
-
- afterRun() - Method in class com.hazelcast.management.operation.ThreadDumpOperation
-
- afterRun() - Method in class com.hazelcast.management.operation.UpdateManagementCenterUrlOperation
-
- afterRun() - Method in class com.hazelcast.management.operation.UpdateMapConfigOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- 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.KeyBasedMapOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- 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.RemoveIfSameOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.SetOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.operation.WanOriginatedDeleteOperation
-
- afterRun() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-
- afterRun() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- afterRun() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- afterRun() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-
- afterRun() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-
- afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- afterRun() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.ClearOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.ContainsOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.DrainOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.IsEmptyOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.IteratorOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.PeekOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.RemainingCapacityOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.operations.SizeOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.tx.TxnPeekOperation
-
- afterRun() - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- afterRun() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-
- afterRun() - Method in class com.hazelcast.spi.AbstractOperation
-
- afterRun() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- afterRun() - Method in class com.hazelcast.spi.Operation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.BeginTxBackupOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.RecoverTxnOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- afterRun() - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- afterRun() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
-
Called after inner run method and can be overridden to customize.
- afterStart(Node) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- afterStart(Node) - Method in interface com.hazelcast.instance.NodeExtension
-
Called after node is started
- afterStore(StoreEvent<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.StoreListener
-
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.IMap
-
Executes a predefined aggregation on the maps data set.
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.IMap
-
Executes a predefined aggregation on the maps data set.
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in interface com.hazelcast.core.MultiMap
-
Executes a predefined aggregation on the multimaps data set.
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in interface com.hazelcast.core.MultiMap
-
Executes a predefined aggregation on the multimaps data set.
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- aggregate(Supplier<K, V, SuppliedValue>, Aggregation<K, SuppliedValue, Result>, JobTracker) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- Aggregation<Key,Supplied,Result> - Interface in com.hazelcast.mapreduce.aggregation
-
The Aggregation interface combines multiple map-reduce operations steps to a
single operation definition.
- Aggregations - Class in com.hazelcast.mapreduce.aggregation
-
This class is used to access the Hazelcast predefined set of aggregations in a type-safe
way.
- AGGREGATIONS_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- AGGREGATIONS_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- AggregationsDataSerializerHook - Class in com.hazelcast.mapreduce.aggregation.impl
-
This class contains all the ID hooks for IdentifiedDataSerializable classes used for aggregations.
- AggregationsDataSerializerHook() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- AggType<KeyIn,ValueIn,KeyOut,SuppliedValue,CombinerValue,ReducerValue,Result> - Interface in com.hazelcast.mapreduce.aggregation.impl
-
The internal interface for Aggregation definitions to make those implementations more type-safe.
- all() - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
-
The predefined Supplier selects all values and does not perform any kind of data
transformation.
- all(PropertyExtractor<ValueIn, ValueOut>) - Static method in class com.hazelcast.mapreduce.aggregation.Supplier
-
The predefined Supplier selects all values and performs the given
PropertyExtractor
s transformation to the
input data.
- allowUnsafe - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- AllPartitionsClientRequest - Class in com.hazelcast.client.impl.client
-
Base class for client request that will run on all partitions.
- AllPartitionsClientRequest() - Constructor for class com.hazelcast.client.impl.client.AllPartitionsClientRequest
-
- AllPermissions - Class in com.hazelcast.security.permission
-
- AllPermissions() - Constructor for class com.hazelcast.security.permission.AllPermissions
-
- AllPermissions.AllPermissionsCollection - Class in com.hazelcast.security.permission
-
- AllPermissions.AllPermissionsCollection() - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- AllPermissions.AllPermissionsCollection(boolean) - Constructor for class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- ALTER - 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.concurrent.atomiclong.AtomicLongProxy
-
- alterAndGet(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- alterAndGet(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
-
Alters the currently stored value by applying a function on it and gets the result.
- alterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
-
Alters the currently stored reference by applying a function on it and gets the result.
- AlterAndGetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-
- AlterAndGetOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-
- AlterAndGetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- AlterAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-
- AlterAndGetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-
- AlterAndGetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- AlterAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-
- AlterAndGetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-
- AlterAndGetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- AlterAndGetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-
- AlterAndGetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-
- AlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-
- AlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-
- AlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- AlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-
- AlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-
- AlterRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- AlterRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-
- AlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-
- AlterRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- AlterRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-
- AlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-
- and(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
-
- and(Predicate...) - Static method in class com.hazelcast.query.Predicates
-
- AndResultSet - Class in com.hazelcast.query.impl
-
And Result set for Predicates.
- AndResultSet(Set<QueryableEntry>, List<Set<QueryableEntry>>, List<Predicate>) - Constructor for class com.hazelcast.query.impl.AndResultSet
-
- andThen(ExecutionCallback<V>) - Method in interface com.hazelcast.core.ICompletableFuture
-
- andThen(ExecutionCallback<V>, Executor) - Method in interface com.hazelcast.core.ICompletableFuture
-
- andThen(ExecutionCallback<V>) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.CompletableFutureTask
-
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.CompletableFutureTask
-
- andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.CompletedFuture
-
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.CompletedFuture
-
- andThen(ExecutionCallback<V>) - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- andThen(ExecutionCallback<V>, Executor) - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- answerMasterQuestion(JoinMessage) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- APPLY - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- apply(IFunction<Long, R>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- APPLY - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- apply(IFunction<E, R>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- apply(IFunction<Long, R>) - Method in interface com.hazelcast.core.IAtomicLong
-
Applies a function on the value, the actual stored value will not change.
- apply(IFunction<E, R>) - Method in interface com.hazelcast.core.IAtomicReference
-
Applies a function on the value, the actual stored value will not change.
- apply(T) - Method in interface com.hazelcast.core.IFunction
-
- apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-
- apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-
- apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-
- apply(Map.Entry<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.aggregation.Supplier
-
The apply method is used to apply the actual filtering or extraction / transformation
to the input entry.
If the input value should be ignored by the aggregation, the Supplier has to return
- apply(Map.Entry) - Method in class com.hazelcast.query.PagingPredicate
-
Used for delegating filtering to inner predicate
- apply(Map.Entry<K, V>) - Method in interface com.hazelcast.query.Predicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.PredicateBuilder
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.AndPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.BetweenPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.EqualPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.GreaterLessPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.InPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.LikePredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.NotEqualPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.NotPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.OrPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.Predicates.RegexPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.SqlPredicate
-
- apply(Map.Entry) - Method in class com.hazelcast.query.TruePredicate
-
- applyAndIncrementVectorClock(VectorClockTimestamp, Member) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- applyChanges() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
Provides a similar functionality as committing a transaction.
- ApplyOperation<R> - Class in com.hazelcast.concurrent.atomiclong.operations
-
- ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-
- ApplyOperation(String, IFunction<Long, R>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-
- ApplyOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- ApplyOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-
- ApplyOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-
- applyRecordInfo(Record, RecordInfo) - Static method in class com.hazelcast.map.impl.record.Records
-
- ApplyRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- ApplyRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-
- ApplyRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-
- ApplyRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- ApplyRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-
- ApplyRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-
- applyVectorClock(VectorClockTimestamp) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- array() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- ArrayDataSerializableFactory - Class in com.hazelcast.nio.serialization
-
- ArrayDataSerializableFactory(ConstructorFunction<Integer, IdentifiedDataSerializable>[]) - Constructor for class com.hazelcast.nio.serialization.ArrayDataSerializableFactory
-
- ArrayListSerializerHook - Class in com.hazelcast.nio.serialization.serializers
-
This class is the auto registered serializer hook for a
ArrayList
.
- ArrayListSerializerHook() - Constructor for class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook
-
- ArrayListSerializerHook.ArrayListStreamSerializer - Class in com.hazelcast.nio.serialization.serializers
-
- ArrayListSerializerHook.ArrayListStreamSerializer() - Constructor for class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook.ArrayListStreamSerializer
-
- ArrayPortableFactory - Class in com.hazelcast.nio.serialization
-
- ArrayPortableFactory(ConstructorFunction<Integer, Portable>[]) - Constructor for class com.hazelcast.nio.serialization.ArrayPortableFactory
-
- asCompletableFuture(Future<V>) - Method in interface com.hazelcast.spi.ExecutionService
-
- asCompletableFuture(Future<V>) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- asList() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Returns list representation of this queue.
- asMap() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation.PartitionResponse
-
- asReadOnly() - Method in class com.hazelcast.config.MemberAttributeConfig
-
- assignKeyReducerAddress(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- assignKeyReducerAddress(Object, Address) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- assignMemberId(Address, String, JobTaskConfiguration) - Method in class com.hazelcast.mapreduce.impl.task.MemberAssigningJobProcessInformationImpl
-
- AssignPartitions - Class in com.hazelcast.partition.impl
-
- AssignPartitions() - Constructor for class com.hazelcast.partition.impl.AssignPartitions
-
- async - Variable in class com.hazelcast.map.impl.client.MapPutRequest
-
- async - Variable in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- ASYNC_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the async executor.
- asyncAddAndGet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- asyncAddAndGet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
-
- 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
-
- asyncAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- 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
-
- asyncAlterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- 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
-
- asyncApply(IFunction<E, R>) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- AsyncAtomicLong - Interface in com.hazelcast.core
-
- AsyncAtomicReference<E> - Interface in com.hazelcast.core
-
- asyncClear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- asyncClear() - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- 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
-
- asyncCompareAndSet(E, E) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- asyncContains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- asyncContains(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- asyncDecrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- asyncDecrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
-
- 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
-
- asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- asyncGetAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- asyncGetAndAdd(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
-
- 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
-
- asyncGetAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- asyncGetAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- asyncGetAndIncrement() - Method in interface com.hazelcast.core.AsyncAtomicLong
-
- 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
-
- asyncGetAndSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- asyncIncrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- asyncIncrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
-
- asyncIsNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- asyncIsNull() - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- 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
-
- asyncSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- asyncSetAndGet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- asyncSetAndGet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
-
- ATOMIC_LONG_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- ATOMIC_LONG_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- ATOMIC_LONG_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- ATOMIC_REFERENCE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- ATOMIC_REFERENCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- AtomicLongBackupAwareOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AtomicLongBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-
- AtomicLongBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-
- AtomicLongBaseOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AtomicLongBaseOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-
- AtomicLongBaseOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-
- AtomicLongDataSerializerHook - Class in com.hazelcast.concurrent.atomiclong
-
- AtomicLongDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- AtomicLongMBean - Class in com.hazelcast.jmx
-
- AtomicLongMBean(IAtomicLong, ManagementService) - Constructor for class com.hazelcast.jmx.AtomicLongMBean
-
- AtomicLongPermission - Class in com.hazelcast.security.permission
-
- AtomicLongPermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicLongPermission
-
- AtomicLongPortableHook - Class in com.hazelcast.concurrent.atomiclong.client
-
- AtomicLongPortableHook() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
-
- AtomicLongProxy - Class in com.hazelcast.concurrent.atomiclong
-
- AtomicLongProxy(String, NodeEngine, AtomicLongService) - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- AtomicLongReplicationOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- AtomicLongReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- AtomicLongReplicationOperation(Map<String, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- AtomicLongRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- AtomicLongRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- AtomicLongRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- AtomicLongService - Class in com.hazelcast.concurrent.atomiclong
-
- AtomicLongService() - Constructor for class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- AtomicReferenceBackupAwareOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- AtomicReferenceBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-
- AtomicReferenceBackupAwareOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-
- AtomicReferenceBaseOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- AtomicReferenceBaseOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-
- AtomicReferenceBaseOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-
- AtomicReferenceDataSerializerHook - Class in com.hazelcast.concurrent.atomicreference
-
- AtomicReferenceDataSerializerHook() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- AtomicReferenceMBean - Class in com.hazelcast.jmx
-
- AtomicReferenceMBean(IAtomicReference, ManagementService) - Constructor for class com.hazelcast.jmx.AtomicReferenceMBean
-
- AtomicReferencePermission - Class in com.hazelcast.security.permission
-
- AtomicReferencePermission(String, String...) - Constructor for class com.hazelcast.security.permission.AtomicReferencePermission
-
- AtomicReferencePortableHook - Class in com.hazelcast.concurrent.atomicreference.client
-
- AtomicReferencePortableHook() - Constructor for class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
-
- AtomicReferenceProxy<E> - Class in com.hazelcast.concurrent.atomicreference
-
- AtomicReferenceProxy(String, NodeEngine, AtomicReferenceService) - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- AtomicReferenceReplicationOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- AtomicReferenceReplicationOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- AtomicReferenceReplicationOperation(Map<String, Data>) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- AtomicReferenceService - Class in com.hazelcast.concurrent.atomicreference
-
- AtomicReferenceService() - Constructor for class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- attribute - Variable in class com.hazelcast.query.Predicates.AbstractPredicate
-
- attribute - Variable in class com.hazelcast.query.Predicates.LikePredicate
-
- attributeMap - Variable in class com.hazelcast.jmx.HazelcastMBean
-
- AttributeType - Enum in com.hazelcast.query.impl
-
Type of Attribute
- AUTH - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- authenticated(ClientPrincipal, Credentials, boolean) - Method in interface com.hazelcast.client.ClientEndpoint
-
- authenticated(ClientPrincipal) - Method in interface com.hazelcast.client.ClientEndpoint
-
- authenticated(ClientPrincipal, Credentials, boolean) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- authenticated(ClientPrincipal) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- AuthenticationException - Exception in com.hazelcast.client
-
- AuthenticationException() - Constructor for exception com.hazelcast.client.AuthenticationException
-
Creates a AuthenticationException with a default message.
- AuthenticationException(String) - Constructor for exception com.hazelcast.client.AuthenticationException
-
Creates a AuthenticationException with the given message.
- AuthenticationFailureOperation - Class in com.hazelcast.cluster.impl.operations
-
- AuthenticationFailureOperation() - Constructor for class com.hazelcast.cluster.impl.operations.AuthenticationFailureOperation
-
- AuthenticationRequest - Class in com.hazelcast.client.impl.client
-
Client Authentication Request that holds credentials
- AuthenticationRequest() - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
-
- AuthenticationRequest(Credentials) - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
-
- AuthenticationRequest(Credentials, ClientPrincipal) - Constructor for class com.hazelcast.client.impl.client.AuthenticationRequest
-
- AuthorizationOperation - Class in com.hazelcast.cluster.impl.operations
-
- AuthorizationOperation() - Constructor for class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-
- AuthorizationOperation(String, String) - Constructor for class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-
- AUTO_TYPE_ARRAY_LIST - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- AUTO_TYPE_JOB_PARTITION_STATE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- AUTO_TYPE_JOB_PARTITION_STATE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- AUTO_TYPE_LINKED_LIST - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- available() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- AVAILABLE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- AvailableOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- AvailableOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-
- AvailableOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-
- availablePermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- availablePermits() - Method in interface com.hazelcast.core.ISemaphore
-
Returns the current number of permits currently available in this semaphore.
- AvailableRequest - Class in com.hazelcast.concurrent.semaphore.client
-
- AvailableRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-
- AvailableRequest(String) - Constructor for class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-
- AVG_TUPLE - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- AvgTuple<F,S> - Class in com.hazelcast.mapreduce.aggregation.impl
-
Internal tuple type for average calculations, used to transmit data between
Combiner and Reducer implementations.
- AvgTuple(F, S) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- await(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, an exception is thrown, or the specified waiting time elapses.
- await(WaitSupport) - Method in interface com.hazelcast.spi.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
-
- AwaitOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- AwaitOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- AwaitOperation(String, long) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- AwaitOperation - Class in com.hazelcast.concurrent.lock.operations
-
- AwaitOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- AwaitOperation(ObjectNamespace, Data, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- AwaitRequest - Class in com.hazelcast.concurrent.countdownlatch.client
-
- AwaitRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- AwaitRequest(String, long) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- AwaitRequest - Class in com.hazelcast.concurrent.lock.client
-
- AwaitRequest() - Constructor for class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- AwaitRequest(ObjectNamespace, String, long, long, String) - Constructor for class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- awaitShutdown() - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- awaitShutdown() - Method in interface com.hazelcast.nio.tcp.IOSelector
-
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- awaitTermination(long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- AwsConfig - Class in com.hazelcast.config
-
The AWSConfig contains the configuration for AWS join mechanism.
- AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
-
- cache - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- CACHE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- CACHE_EVENT_DATA - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CACHE_EVENT_DATA_SET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CACHE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- CacheAddEntryListenerRequest - Class in com.hazelcast.cache.impl.client
-
Client request which registers an event listener on behalf of the client and delegates the received events
back to client.
- CacheAddEntryListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-
- CacheAddEntryListenerRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-
- CacheBackupEntryProcessorOperation - Class in com.hazelcast.cache.impl.operation
-
Operation of the Cache Backup Entry Processor.
- CacheBackupEntryProcessorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-
- CacheBackupEntryProcessorOperation(String, Data, EntryProcessor, Object...) - Constructor for class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-
- CacheClearBackupOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheClearBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- CacheClearBackupOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- CacheClearOperation - Class in com.hazelcast.cache.impl.operation
-
Cache Clear will clear all internal cache data without sending any event
- CacheClearOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- CacheClearOperation(String, int) - 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, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- CacheClearRequest - Class in com.hazelcast.cache.impl.client
-
- CacheClearRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheClearRequest
-
- CacheClearRequest(String, Set<Data>, boolean, int) - Constructor for class com.hazelcast.cache.impl.client.CacheClearRequest
-
- CacheClearResponse - Class in com.hazelcast.cache.impl
-
- CacheClearResponse() - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
-
- CacheClearResponse(Object) - Constructor for class com.hazelcast.cache.impl.CacheClearResponse
-
- CacheConcurrentHashMap<K,V> - Class in com.hazelcast.util
-
ConcurrentHashMap to extend iterator capability
- CacheConcurrentHashMap(int) - Constructor for class com.hazelcast.util.CacheConcurrentHashMap
-
- CacheConcurrentHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.CacheConcurrentHashMap
-
- cacheConfig - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- CacheConfig<K,V> - Class in com.hazelcast.config
-
Contains all the configuration for the
ICache
- CacheConfig() - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfig(CompleteConfiguration<K, V>) - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheConfig
-
- CacheConfigReadOnly<K,V> - Class in com.hazelcast.config
-
Contains the configuration for an
ICache
(read-only).
- CacheConfiguration<K,V> - Interface in com.hazelcast.config
-
Mutable extension to CompleteConfiguration
- CacheContainsKeyOperation - Class in com.hazelcast.cache.impl.operation
-
Cache contains key operation, determines if the cache contains an entry for the specified key.
- CacheContainsKeyOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-
- CacheContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-
- CacheContainsKeyRequest - Class in com.hazelcast.cache.impl.client
-
- CacheContainsKeyRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-
- CacheContainsKeyRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-
- CacheCreateConfigOperation - Class in com.hazelcast.cache.impl.operation
-
Used to create cluster wide cache configuration.
- CacheCreateConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- CacheCreateConfigOperation(CacheConfig) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- CacheCreateConfigOperation(CacheConfig, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- CacheCreateConfigRequest - Class in com.hazelcast.cache.impl.client
-
- CacheCreateConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- CacheCreateConfigRequest(CacheConfig, boolean, int) - Constructor for class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- CacheDataSerializerHook - Class in com.hazelcast.cache.impl
-
- CacheDataSerializerHook() - Constructor for class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- 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
-
- CacheDestroyRequest - Class in com.hazelcast.cache.impl.client
-
- CacheDestroyRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- CacheDestroyRequest(String, int) - Constructor for class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- CachedExecutorServiceDelegate - Class in com.hazelcast.util.executor
-
- CachedExecutorServiceDelegate(NodeEngine, String, ExecutorService, int, int) - Constructor for class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- CacheDistributedObject - Class in com.hazelcast.cache.impl
-
- CacheDistributedObject(String, NodeEngine, ICacheService) - Constructor for class com.hazelcast.cache.impl.CacheDistributedObject
-
- CacheEntry<K,V> - Class in com.hazelcast.cache.impl
-
Simple Cache.Entry
implementation for wrapping a "key,value" pair.
- CacheEntry(K, V) - Constructor for class com.hazelcast.cache.impl.CacheEntry
-
- CacheEntryEventImpl<K,V> - Class in com.hazelcast.cache.impl
-
CacheEntryEvent implementation is the actual event object received by sub-interfaces of
CacheEntryListener
.
- CacheEntryEventImpl(ICache<K, V>, EventType, K, V, V) - Constructor for class com.hazelcast.cache.impl.CacheEntryEventImpl
-
- CacheEntryProcessorEntry<K,V,R extends CacheRecord> - Class in com.hazelcast.cache.impl
-
This class is an implementation of MutableEntry
which is provided into
EntryProcessor.process(javax.cache.processor.MutableEntry, Object...)
.
- CacheEntryProcessorEntry(Data, R, AbstractCacheRecordStore, long) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- CacheEntryProcessorEntry.State - Enum in com.hazelcast.cache.impl
-
- CacheEntryProcessorOperation - Class in com.hazelcast.cache.impl.operation
-
Operation of the Cache Entry Processor.
- CacheEntryProcessorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- CacheEntryProcessorOperation(String, Data, int, EntryProcessor, Object...) - Constructor for class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- CacheEntryProcessorRequest - Class in com.hazelcast.cache.impl.client
-
- CacheEntryProcessorRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-
- CacheEntryProcessorRequest(String, Data, EntryProcessor, InMemoryFormat, Object...) - Constructor for class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-
- CacheEntryProcessorResult<T> - Class in com.hazelcast.cache.impl
-
This simple implementation of EntryProcessorResult
wraps the result returned or exception thrown in a
single object so that multiple exceptions from multiple entry processes can be returned.
- CacheEntryProcessorResult(T) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorResult
-
- CacheEntryProcessorResult(Throwable) - Constructor for class com.hazelcast.cache.impl.CacheEntryProcessorResult
-
- 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
-
- CacheEventListener - Interface in com.hazelcast.cache.impl
-
Cache Event Listener interface is designated for handling cache events internally such as delegating events
to cache event listener.
- CacheEventListenerAdaptor<K,V> - Class in com.hazelcast.cache.impl
-
This implementation of
CacheEventListener
uses the adapter pattern for wrapping all cache event listener
types into a single listener.
- CacheEventListenerAdaptor(ICache<K, V>, CacheEntryListenerConfiguration<K, V>, SerializationService) - Constructor for class com.hazelcast.cache.impl.CacheEventListenerAdaptor
-
- CacheEventSet - Class in com.hazelcast.cache.impl
-
Internal Set wrapper of
CacheEventData
items used during publishing and dispatching events.
- CacheEventSet() - Constructor for class com.hazelcast.cache.impl.CacheEventSet
-
- CacheEventSet(CacheEventType, Set<CacheEventData>) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
-
- CacheEventSet(CacheEventType) - Constructor for class com.hazelcast.cache.impl.CacheEventSet
-
- CacheEventType - Enum in com.hazelcast.cache.impl
-
Hazelcast JCache implementation's internal event types.
- 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
-
- CacheGetAllRequest - Class in com.hazelcast.cache.impl.client
-
- CacheGetAllRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- CacheGetAllRequest(String, Set<Data>, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- CacheGetAndRemoveOperation - Class in com.hazelcast.cache.impl.operation
-
Cache GetAndRemove Operation.
- CacheGetAndRemoveOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- CacheGetAndRemoveOperation(String, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- CacheGetAndRemoveRequest - Class in com.hazelcast.cache.impl.client
-
- CacheGetAndRemoveRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-
- CacheGetAndRemoveRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-
- CacheGetAndReplaceOperation - Class in com.hazelcast.cache.impl.operation
-
Cache GetAndReplace Operation.
- CacheGetAndReplaceOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- CacheGetAndReplaceOperation(String, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- CacheGetAndReplaceRequest - Class in com.hazelcast.cache.impl.client
-
- CacheGetAndReplaceRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-
- CacheGetAndReplaceRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-
- CacheGetConfigOperation - Class in com.hazelcast.cache.impl.operation
-
Cache GetConfig Operation.
- CacheGetConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-
- CacheGetConfigOperation(String, String) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-
- CacheGetConfigRequest - Class in com.hazelcast.cache.impl.client
-
- CacheGetConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-
- CacheGetConfigRequest(String, String, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-
- CacheGetOperation - Class in com.hazelcast.cache.impl.operation
-
Cache Get Operation.
- CacheGetOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheGetOperation
-
- CacheGetOperation(String, Data, ExpiryPolicy) - Constructor for class com.hazelcast.cache.impl.operation.CacheGetOperation
-
- CacheGetRequest - Class in com.hazelcast.cache.impl.client
-
- CacheGetRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheGetRequest
-
- CacheGetRequest(String, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheGetRequest
-
- CacheIterateRequest - Class in com.hazelcast.cache.impl.client
-
- CacheIterateRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- CacheIterateRequest(String, int, int, int, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- cacheIterator() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- CacheKeyIteratorOperation - Class in com.hazelcast.cache.impl.operation
-
Provides iterator functionality for ICache.
- CacheKeyIteratorOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-
- CacheKeyIteratorOperation(String, int, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-
- CacheKeyIteratorResult - Class in com.hazelcast.cache.impl
-
- CacheKeyIteratorResult() - Constructor for class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- CacheKeyIteratorResult(List<Data>, int) - Constructor for class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- CacheListenerRegistrationOperation - Class in com.hazelcast.cache.impl.operation
-
Listener can be registered and unregistered by
CacheService
.
- CacheListenerRegistrationOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- CacheListenerRegistrationOperation(String, CacheEntryListenerConfiguration, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- CacheListenerRegistrationRequest - Class in com.hazelcast.cache.impl.client
-
- CacheListenerRegistrationRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- CacheListenerRegistrationRequest(String, CacheEntryListenerConfiguration, boolean, Address) - Constructor for class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- CacheLoadAllOperation - Class in com.hazelcast.cache.impl.operation
-
- 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
-
- CacheLoadAllRequest - Class in com.hazelcast.cache.impl.client
-
- CacheLoadAllRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- CacheLoadAllRequest(String, Set<Data>, boolean) - Constructor for class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- cacheLoader - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- CacheManagementConfigOperation - Class in com.hazelcast.cache.impl.operation
-
Cache ManagementConfig Operation provides enabling/disabling the functionality of management and
statistics mxbeans of the cache.
- CacheManagementConfigOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- CacheManagementConfigOperation(String, boolean, boolean) - Constructor for class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- CacheManagementConfigRequest - Class in com.hazelcast.cache.impl.client
-
- CacheManagementConfigRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- CacheManagementConfigRequest(String, boolean, boolean, Address) - Constructor for class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- CacheMXBeanImpl - Class in com.hazelcast.cache.impl
-
Implementation of CacheMXBean
.
- CacheMXBeanImpl(CacheConfig) - Constructor for class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- cacheNamePrefix - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- cacheNamePrefix() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
This method calculates a fixed string based on the URI and classloader using the formula:
- CacheNotExistsException - Exception in com.hazelcast.cache
-
This exception class is thrown while creating
CacheRecordStore
instances but the cache config is not existing on the node to create the instance on.
- CacheNotExistsException(String) - Constructor for exception com.hazelcast.cache.CacheNotExistsException
-
- CacheObjectRecord - Class in com.hazelcast.cache.impl.record
-
Implementation of
CacheRecord
which has an internal object format.
- CacheObjectRecord() - Constructor for class com.hazelcast.cache.impl.record.CacheObjectRecord
-
- CacheOperationProvider - Interface in com.hazelcast.cache.impl
-
Provide InMemoryFormat specific operations for cache
- CachePartitionSegment - Class in com.hazelcast.cache.impl
-
Cache Partition Segment
- CachePortableHook - Class in com.hazelcast.cache.impl
-
- CachePortableHook() - Constructor for class com.hazelcast.cache.impl.CachePortableHook
-
- CacheProxy<K,V> - Class in com.hazelcast.cache.impl
-
ICache implementation
- CacheProxy(CacheConfig, NodeEngine, ICacheService, HazelcastServerCacheManager) - Constructor for class com.hazelcast.cache.impl.CacheProxy
-
- CacheProxyUtil - Class in com.hazelcast.cache.impl
-
Static util methods for
ICache implementations.
- CachePutAllBackupOperation - Class in com.hazelcast.cache.impl.operation
-
Cache PutAllBackup Operation is the backup operation used by load all operation.
- CachePutAllBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- CachePutAllBackupOperation(String, Map<Data, CacheRecord>) - Constructor for class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- CachePutBackupOperation - Class in com.hazelcast.cache.impl.operation
-
Backup operation for the operation of adding cache entries into record stores.
- CachePutBackupOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- CachePutBackupOperation(String, Data, CacheRecord) - Constructor for class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- CachePutIfAbsentOperation - Class in com.hazelcast.cache.impl.operation
-
- CachePutIfAbsentOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- CachePutIfAbsentOperation(String, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- CachePutIfAbsentRequest - Class in com.hazelcast.cache.impl.client
-
- CachePutIfAbsentRequest() - Constructor for class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-
- CachePutIfAbsentRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-
- CachePutOperation - Class in com.hazelcast.cache.impl.operation
-
- CachePutOperation() - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
-
- CachePutOperation(String, Data, Data, ExpiryPolicy, boolean, int) - Constructor for class com.hazelcast.cache.impl.operation.CachePutOperation
-
- CachePutRequest - Class in com.hazelcast.cache.impl.client
-
- CachePutRequest() - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
-
- CachePutRequest(String, Data, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
-
- CachePutRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
-
- CachePutRequest(String, Data, Data, ExpiryPolicy, boolean, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CachePutRequest
-
- CacheRecord<V> - Interface in com.hazelcast.cache.impl.record
-
An expirable 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<K,V> - Class in com.hazelcast.cache.impl.record
-
- CacheRecordHashMap(int) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- CacheRecordHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- CacheRecordHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>, Callback<Data>) - Constructor for class com.hazelcast.cache.impl.record.CacheRecordHashMap
-
- CacheRecordMap<K,V> - 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
-
- 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
-
- CacheRemoveEntryListenerRequest - Class in com.hazelcast.cache.impl.client
-
Client request which unregisters the event listener on behalf of the client.
- CacheRemoveEntryListenerRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-
- CacheRemoveEntryListenerRequest(String, String) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-
- CacheRemoveOperation - Class in com.hazelcast.cache.impl.operation
-
Operation implementation for cache remove functionality.
- CacheRemoveOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- CacheRemoveOperation(String, Data, Data, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- CacheRemoveRequest - Class in com.hazelcast.cache.impl.client
-
- CacheRemoveRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- CacheRemoveRequest(String, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- CacheRemoveRequest(String, Data, Data, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- CacheReplaceOperation - Class in com.hazelcast.cache.impl.operation
-
Operator implementation for cache replace functionality.
- CacheReplaceOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- CacheReplaceOperation(String, Data, Data, Data, ExpiryPolicy, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- CacheReplaceRequest - Class in com.hazelcast.cache.impl.client
-
- CacheReplaceRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- CacheReplaceRequest(String, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- CacheReplaceRequest(String, Data, Data, Data, ExpiryPolicy, InMemoryFormat) - Constructor for class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- CacheReplicationOperation - Class in com.hazelcast.cache.impl.operation
-
- CacheReplicationOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- CacheReplicationOperation(CachePartitionSegment, int) - Constructor for class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- caches - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- cacheService - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- CacheService - Class in com.hazelcast.cache.impl
-
Cache Service is the main access point of JCache implementation.
- CacheService() - Constructor for class com.hazelcast.cache.impl.CacheService
-
- CacheSimpleConfig - Class in com.hazelcast.config
-
Simple configuration to hold parsed xml configuration.
- CacheSimpleConfig(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfig
-
- CacheSimpleConfig() - Constructor for class com.hazelcast.config.CacheSimpleConfig
-
- CacheSimpleConfigReadOnly - Class in com.hazelcast.config
-
Readonly version of CacheSimpleConfig
- CacheSimpleConfigReadOnly(CacheSimpleConfig) - Constructor for class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- CacheSimpleEntryListenerConfig - Class in com.hazelcast.config
-
Simple configuration to hold parsed listener config
- CacheSimpleEntryListenerConfig(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- CacheSimpleEntryListenerConfig() - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- CacheSimpleEntryListenerConfigReadOnly - Class in com.hazelcast.config
-
Readonly version of CacheSimpleEntryListenerConfig
- CacheSimpleEntryListenerConfigReadOnly(CacheSimpleEntryListenerConfig) - Constructor for class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-
- CacheSizeOperation - Class in com.hazelcast.cache.impl.operation
-
This operation implementation is for calculating the cluster size of a named cache.
- CacheSizeOperation() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperation
-
- CacheSizeOperation(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperation
-
- CacheSizeOperationFactory - Class in com.hazelcast.cache.impl.operation
-
- CacheSizeOperationFactory() - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- CacheSizeOperationFactory(String) - Constructor for class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- CacheSizeRequest - Class in com.hazelcast.cache.impl.client
-
- CacheSizeRequest() - Constructor for class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- CacheSizeRequest(String) - Constructor for class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- CacheStatistics - Interface in com.hazelcast.cache
-
Cache statistics
- CacheStatisticsImpl - Class in com.hazelcast.cache.impl
-
- CacheStatisticsImpl() - Constructor for class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- CacheStatisticsMXBeanImpl - Class in com.hazelcast.cache.impl
-
Implementation of CacheStatisticsMXBean
- CacheStatisticsMXBeanImpl(CacheStatisticsImpl) - Constructor for class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- cacheWriter - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- cachingProvider - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- calculateObjectName(String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
-
Creates an object name using the scheme.
- calculatePartitionHash(Object, PartitioningStrategy) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- call() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-
- call() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-
- call() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-
- call() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-
- call() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- call() - Method in class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
-
- call() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-
- call() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-
- call() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-
- call() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-
- call() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- call() - Method in class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- call() - Method in class com.hazelcast.console.ConsoleApp.Echo
-
- call() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-
- call() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-
- call() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- call() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- call() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-
- call() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- call() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- call() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-
- call() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- call() - Method in class com.hazelcast.queue.impl.client.RemoveListenerRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-
- call() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-
- call() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- call() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- call() - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-
- call() - Method in class com.hazelcast.transaction.client.RecoverTransactionRequest
-
- CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- CallableClientRequest - Class in com.hazelcast.client.impl.client
-
- CallableClientRequest() - Constructor for class com.hazelcast.client.impl.client.CallableClientRequest
-
- CallableTaskOperation - Class in com.hazelcast.executor.impl.operations
-
- CallableTaskOperation() - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
-
- CallableTaskOperation(String, String, Data) - Constructor for class com.hazelcast.executor.impl.operations.CallableTaskOperation
-
- callAfterStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-
- Callback<T> - Interface in com.hazelcast.spi
-
A callback interface; make it possible to receive a callback.
- callback - Variable in class com.hazelcast.spi.InvocationBuilder
-
- callBeforeStoreListeners(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-
- CallerNotMemberException - Exception in com.hazelcast.spi.exception
-
A RetryableHazelcastException that indicates that a request was send to a machine which isn't member
in the cluster.
- CallerNotMemberException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.CallerNotMemberException
-
- callId - Variable in class com.hazelcast.client.impl.client.ClientRequest
-
- callId - Variable in class com.hazelcast.spi.impl.Response
-
- callOnAddress(Address, Operation) - Method in class com.hazelcast.management.ManagementCenterService
-
- callOnMember(Member, Operation) - Method in class com.hazelcast.management.ManagementCenterService
-
- callOnThis(Operation) - Method in class com.hazelcast.management.ManagementCenterService
-
- callTimeout - Variable in class com.hazelcast.spi.InvocationBuilder
-
- CallTimeoutException - Exception in com.hazelcast.spi.exception
-
A RetryableHazelcastException that indicates that the execution of an operation ran into a timeout.
- CallTimeoutException() - Constructor for exception com.hazelcast.spi.exception.CallTimeoutException
-
- CallTimeoutException(String) - Constructor for exception com.hazelcast.spi.exception.CallTimeoutException
-
- CallTimeoutException(String, long, long) - Constructor for exception com.hazelcast.spi.exception.CallTimeoutException
-
- canAcquireLock(Data, String, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- canAcquireLock(Data, String, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- canAcquireLock(Data, String, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- cancel(String, boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
-
- cancel() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-
- cancel(boolean) - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- cancel(boolean) - Method in class com.hazelcast.util.executor.CompletedFuture
-
- cancel(boolean) - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- cancel(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
- CANCEL_JOB_SUPERVISOR_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- cancelAll() - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
- cancelAndNotify(Exception) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- cancelEviction(ObjectNamespace, Data) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- cancelEviction(String) - Method in class com.hazelcast.queue.impl.QueueService
-
- cancelEvictionIfExists() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- cancelExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- CancelJobSupervisorOperation - Class in com.hazelcast.mapreduce.impl.operation
-
This operation is fired by the jobs owner node to remotely cancel the defined jobId on all nodes.
- CancelJobSupervisorOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- CancelJobSupervisorOperation(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- CANCELLATION_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-
- CancellationOperation - Class in com.hazelcast.executor.impl.operations
-
- CancellationOperation() - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
-
- CancellationOperation(String, boolean) - Constructor for class com.hazelcast.executor.impl.operations.CancellationOperation
-
- CancellationRequest - Class in com.hazelcast.executor.impl.client
-
- CancellationRequest() - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
-
- CancellationRequest(String, Address, boolean) - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
-
- CancellationRequest(String, int, boolean) - Constructor for class com.hazelcast.executor.impl.client.CancellationRequest
-
- cancelNotifyAndRestart() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- cancelPartitionState() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- capacity() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- cd - Variable in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- CDL_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- CDL_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- CHAR_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- CHAR_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- CHAR_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
-
Char size in bytes
- check(Node, String, boolean) - Method in class com.hazelcast.util.VersionCheck
-
- CHECK_EVICT - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- CheckAndEvictOperation - Class in com.hazelcast.queue.impl.operations
-
Provides eviction functionality for Operations of Queue.
- CheckAndEvictOperation() - Constructor for class com.hazelcast.queue.impl.operations.CheckAndEvictOperation
-
- CheckAndEvictOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.CheckAndEvictOperation
-
- checkAssignedMembersAvailable(Collection<Address>) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- checkAssignedMembersAvailable() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- checkAuthorization(String, String, Address) - Method in class com.hazelcast.wan.impl.WanNoDelayReplication
-
- checkClassDefErrors - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- checkEvictable(MapContainer, int) - Method in class com.hazelcast.map.impl.eviction.MaxSizeChecker
-
- checkFullyProcessed(JobProcessInformation) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- checkIfLoaded() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- checkIfLoaded() - Method in interface com.hazelcast.map.impl.RecordStore
-
- checkJoinInfo(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- checkNotNull(Object, String) - Static method in class com.hazelcast.util.ValidationUtil
-
- checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
-
Checks whether current
Subject
has been granted specified permission or not.
- CheckReplicaVersion - Class in com.hazelcast.partition.impl
-
- CheckReplicaVersion() - Constructor for class com.hazelcast.partition.impl.CheckReplicaVersion
-
- CheckReplicaVersion(long, boolean) - Constructor for class com.hazelcast.partition.impl.CheckReplicaVersion
-
- checkTransactionState() - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- checkTransactionState() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- checkTransactionState() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- checkTransactionState() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- checkTrue(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- chunkSize - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-
- chunkSize(int) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-
- chunkSize - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.Job
-
Defines the number of elements per chunk.
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.MappingJob
-
Defines the number of elements per chunk.
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingJob
-
Defines the number of elements per chunk.
- chunkSize(int) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
-
Defines the number of elements per chunk.
- CipherHelper - Class in com.hazelcast.nio
-
- ClassDefinition - Interface in com.hazelcast.nio.serialization
-
ClassDefinition defines a class schema for Portable classes.
- ClassDefinitionBuilder - Class in com.hazelcast.nio.serialization
-
ClassDefinitionBuilder is used to build and register ClassDefinitions manually.
- ClassDefinitionBuilder(int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- ClassDefinitionBuilder(int, int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
-
- classDefinitions - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- ClassDefinitionSerializer - Class in com.hazelcast.nio.serialization
-
Serializes/De-serializes ClassDefinitions to/from buffer and streams.
- ClassDefinitionSerializer(Data, PortableContext) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionSerializer
-
- classLoader - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- classLoader - Variable in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-
- classLoaderReference - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- ClassLoaderUtil - Class in com.hazelcast.nio
-
Utility class to deal with classloaders.
- className - Variable in class com.hazelcast.config.ListenerConfig
-
- className - Variable in class com.hazelcast.config.SecurityInterceptorConfig
-
- ClasspathXmlConfig - Class in com.hazelcast.config
-
A
Config
which is initialized by loading an XML configuration file from the classpath.
- ClasspathXmlConfig(String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread contextClassLoader.
- ClasspathXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource using the
Thread.currentThread contextClassLoader.
- ClasspathXmlConfig(ClassLoader, String) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- ClasspathXmlConfig(ClassLoader, String, Properties) - Constructor for class com.hazelcast.config.ClasspathXmlConfig
-
Creates a config which is loaded from a classpath resource.
- CleanerRegistrator - Interface in com.hazelcast.replicatedmap.impl
-
This interface is used to give
ReplicatedRecordStore
implementations
a chance to register themself to being cleaned up from expired entries
- cleanNodeName(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- cleanNodeName(String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- cleanupStagingArea(long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- clear() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- CLEAR - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- clear() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- CLEAR - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- clear() - Method in class com.hazelcast.cache.impl.CacheProxy
-
- clear() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Implementation of CacheStatisticsMXBean.clear()
.
- clear() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- clear() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
clears all internal data without publishing any events
- clear() - Method in interface com.hazelcast.client.ClientEndpointManager
-
Removes all endpoints.
- clear() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- clear() - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- clear() - Method in class com.hazelcast.collection.CollectionContainer
-
- clear() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- clear() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- clear() - Method in class com.hazelcast.config.InterfacesConfig
-
clears all interfaces.
- clear() - Method in class com.hazelcast.config.MemberGroupConfig
-
Removes all interfaces from the member group.
- clear() - Method in class com.hazelcast.config.PartitionGroupConfig
-
- 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 is thought for wiping data out of the replicated maps.
- clear() - Method in class com.hazelcast.jmx.ListMBean
-
- clear() - Method in class com.hazelcast.jmx.LockMBean
-
- clear() - Method in class com.hazelcast.jmx.MapMBean
-
- clear() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- clear() - Method in class com.hazelcast.jmx.QueueMBean
-
- clear() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- clear() - Method in class com.hazelcast.jmx.SetMBean
-
- clear() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- CLEAR - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- clear() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
- clear() - Method in class com.hazelcast.map.impl.NearCache
-
- clear() - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- clear() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
This method clears the map and deletaAll on MapStore which if connected to a database,
will delete the records from that database.
- clear() - Method in interface com.hazelcast.map.impl.RecordStore
-
- clear() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- CLEAR - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- clear() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- clear() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
-
- clear() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- clear() - Method in interface com.hazelcast.query.impl.Index
-
- clear() - Method in class com.hazelcast.query.impl.IndexImpl
-
- clear() - Method in interface com.hazelcast.query.impl.IndexStore
-
- clear() - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- clear() - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- clear() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- CLEAR - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- CLEAR - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- CLEAR - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- clear(boolean, boolean) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- clear(boolean, boolean) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- clear() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- clear() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Removes all of the mappings from this map.
- CLEAR_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CLEAR_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- CLEAR_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- CLEAR_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CLEAR_RESPONSE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- clearAllListeners() - Method in interface com.hazelcast.client.ClientEndpoint
-
- clearAllListeners() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- clearBackup(Set<Long>) - Method in class com.hazelcast.collection.CollectionContainer
-
- clearBackup(Set<Long>) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- ClearBackupOperation - Class in com.hazelcast.map.impl.operation
-
- ClearBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearBackupOperation
-
- ClearBackupOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearBackupOperation
-
- ClearBackupOperation - Class in com.hazelcast.multimap.impl.operations
-
- ClearBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-
- ClearBackupOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-
- ClearBackupOperation - Class in com.hazelcast.queue.impl.operations
-
Store items' id as set when ClearOperation run.
- ClearBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.ClearBackupOperation
-
- ClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.queue.impl.operations.ClearBackupOperation
-
- clearBit(byte, int) - Static method in class com.hazelcast.nio.Bits
-
Clears n-th bit of the byte value
- clearBit(int, int) - Static method in class com.hazelcast.nio.Bits
-
Clears n-th bit of the integer value
- ClearExpiredOperation - Class in com.hazelcast.map.impl.operation
-
Clear expired records.
- ClearExpiredOperation(int) - Constructor for class com.hazelcast.map.impl.operation.ClearExpiredOperation
-
- clearLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
-
- clearLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- clearMapOnly() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
This method clears the map.It does not invoke deleteAll on any associated MapStore.
- clearNearCache(String) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- ClearOperation - Class in com.hazelcast.map.impl.operation
-
- ClearOperation() - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
-
- ClearOperation(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperation
-
- ClearOperation - Class in com.hazelcast.multimap.impl.operations
-
- ClearOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
-
- ClearOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ClearOperation
-
- ClearOperation - Class in com.hazelcast.queue.impl.operations
-
Clears items stored by Queue.
- ClearOperation() - Constructor for class com.hazelcast.queue.impl.operations.ClearOperation
-
- ClearOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.ClearOperation
-
- ClearOperationFactory - Class in com.hazelcast.map.impl.operation
-
- ClearOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
-
- ClearOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.ClearOperationFactory
-
- clearPartition() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- clearPartition() - Method in interface com.hazelcast.map.impl.RecordStore
-
- clearPartitionData(int) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- clearPartitionData(int) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- clearPartitionReplica(int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- clearPartitionReplica(int) - Method in class com.hazelcast.collection.CollectionService
-
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- clearPartitionReplica(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- clearPartitionReplica(int) - Method in class com.hazelcast.map.impl.MapService
-
- clearPartitionReplica(int) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- clearPartitionReplica(int) - Method in class com.hazelcast.queue.impl.QueueService
-
- clearPartitionReplica(int) - Method in interface com.hazelcast.spi.MigrationAwareService
-
- clearPartitionReplicaVersions(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- clearPartitionReplicaVersions(int) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- clearPartitions() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- clearPartitions() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- clearPartitions() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- ClearRequest - Class in com.hazelcast.multimap.impl.client
-
- ClearRequest() - Constructor for class com.hazelcast.multimap.impl.client.ClearRequest
-
- ClearRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.ClearRequest
-
- ClearRequest - Class in com.hazelcast.queue.impl.client
-
- ClearRequest() - Constructor for class com.hazelcast.queue.impl.client.ClearRequest
-
- ClearRequest(String) - Constructor for class com.hazelcast.queue.impl.client.ClearRequest
-
- Client - Interface in com.hazelcast.core
-
Client interface allows to get information about
a connected clients socket address, type and uuid.
- CLIENT_BINARY - Static variable in class com.hazelcast.nio.Protocols
-
Protocol that is used for clients(java, c++ , c# client)
- CLIENT_CANCELLATION_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- CLIENT_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- CLIENT_ENGINE_THREAD_COUNT - Variable in class com.hazelcast.instance.GroupProperties
-
- CLIENT_ERROR - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- CLIENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the client executor.
- CLIENT_HEARTBEAT_TIMEOUT_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- CLIENT_JOB_PROCESS_INFO_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- CLIENT_MAP_REDUCE_REQUEST - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- CLIENT_PING - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- CLIENT_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- CLIENT_RESPONSE - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
-
ClientResponse Class ID
- CLIENT_TXN_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- ClientAwareService - Interface in com.hazelcast.spi
-
A interface that can be implemented by a SPI Service so that it can be notified about client disconnects.
- ClientCancellationRequest - Class in com.hazelcast.mapreduce.impl.client
-
This class is used to request a map reduce job cancellation on the job owning
node from the emitting client.
- ClientCancellationRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-
- ClientCancellationRequest(String, String) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-
- clientConnected(Client) - Method in interface com.hazelcast.core.ClientListener
-
Invoked when a new client is connected.
- ClientCreateRequest - Class in com.hazelcast.client.impl.client
-
- ClientCreateRequest() - Constructor for class com.hazelcast.client.impl.client.ClientCreateRequest
-
- ClientCreateRequest(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientCreateRequest
-
- ClientDataSerializerHook - Class in com.hazelcast.client.impl
-
Client DataSerializable Factory ID
- ClientDataSerializerHook() - Constructor for class com.hazelcast.client.impl.ClientDataSerializerHook
-
- ClientDestroyRequest - Class in com.hazelcast.client.impl.client
-
- ClientDestroyRequest() - Constructor for class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- ClientDestroyRequest(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- clientDisconnected(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- clientDisconnected(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- clientDisconnected(Client) - Method in interface com.hazelcast.core.ClientListener
-
Invoked when a new client is disconnected.
- clientDisconnected(String) - Method in interface com.hazelcast.spi.ClientAwareService
-
Invoked when a client disconnected from a member.
- clientDisconnected(String) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- ClientDisconnectionOperation - Class in com.hazelcast.client.impl.operations
-
- ClientDisconnectionOperation() - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-
- ClientDisconnectionOperation(String) - Constructor for class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-
- ClientEndpoint - Interface in com.hazelcast.client
-
Represents an endpoint to a client.
- ClientEndpointImpl - Class in com.hazelcast.client.impl
-
- ClientEndpointManager - Interface in com.hazelcast.client
-
- ClientEndpointManagerImpl - Class in com.hazelcast.client.impl
-
- ClientEndpointManagerImpl(ClientEngineImpl, NodeEngine) - Constructor for class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- ClientEngine - Interface in com.hazelcast.client
-
The client Engine.
- clientEngine - Variable in class com.hazelcast.client.impl.client.ClientRequest
-
- clientEngine - Variable in class com.hazelcast.instance.Node
-
- ClientEngineImpl - Class in com.hazelcast.client.impl
-
Class that requests, listeners from client handled in node side.
- ClientEngineImpl(Node) - Constructor for class com.hazelcast.client.impl.ClientEngineImpl
-
- ClientEngineMBean - Class in com.hazelcast.jmx
-
- ClientEngineMBean(HazelcastInstance, ClientEngine, ManagementService) - Constructor for class com.hazelcast.jmx.ClientEngineMBean
-
- ClientExceptionConverter - Interface in com.hazelcast.client.impl.exceptionconverters
-
The ClientExceptionConverter is responsible for converting a Java Throwable to something a client can understand.
- ClientExceptionConverters - Class in com.hazelcast.client.impl.exceptionconverters
-
A utility class for getting the correct converter based on the client type.
- ClientHeartbeatMonitor - Class in com.hazelcast.client.impl
-
Monitors client heartbeats..
- ClientHeartbeatMonitor(ClientEndpointManagerImpl, ClientEngine, ExecutionService, GroupProperties) - Constructor for class com.hazelcast.client.impl.ClientHeartbeatMonitor
-
- ClientJobProcessInformationRequest - Class in com.hazelcast.mapreduce.impl.client
-
This class is used to retrieve current processed records and other statistics from
emitting client to the job owning node.
- ClientJobProcessInformationRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-
- ClientJobProcessInformationRequest(String, String) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-
- ClientListener - Interface in com.hazelcast.core
-
The ClientListener provides the ability to listen to clients connecting and disconnecting from the cluster.
- ClientMapReduceRequest<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl.client
-
This class is used to prepare and start a map reduce job emitted by a client
on a random node in the cluster (making it the job owner).
- ClientMapReduceRequest() - Constructor for class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- ClientMapReduceRequest(String, String, Collection, KeyPredicate, Mapper, CombinerFactory, ReducerFactory, KeyValueSource, int, TopologyChangedStrategy) - Constructor for class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- ClientMembershipEvent - Class in com.hazelcast.cluster.client
-
- ClientMembershipEvent() - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
-
- ClientMembershipEvent(Member, int) - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
-
- ClientMembershipEvent(Member, MemberAttributeChange) - Constructor for class com.hazelcast.cluster.client.ClientMembershipEvent
-
- ClientPingRequest - Class in com.hazelcast.cluster.client
-
- ClientPingRequest() - Constructor for class com.hazelcast.cluster.client.ClientPingRequest
-
- ClientPortableFactory - Class in com.hazelcast.client.impl.client
-
Factory class for central client request
- ClientPortableFactory() - Constructor for class com.hazelcast.client.impl.client.ClientPortableFactory
-
- ClientPortableHook - Class in com.hazelcast.client.impl.client
-
Portable that creates a lot of the client related Portable instances.
- ClientPortableHook() - Constructor for class com.hazelcast.client.impl.client.ClientPortableHook
-
- ClientPrincipal - Class in com.hazelcast.client.impl.client
-
- ClientPrincipal() - Constructor for class com.hazelcast.client.impl.client.ClientPrincipal
-
- ClientPrincipal(String, String) - Constructor for class com.hazelcast.client.impl.client.ClientPrincipal
-
- ClientReAuthOperation - Class in com.hazelcast.client.impl.operations
-
- ClientReAuthOperation() - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- ClientReAuthOperation(String) - Constructor for class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- ClientReplicatedMapAddEntryListenerRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapAddEntryListenerRequest(String, Predicate, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- ClientReplicatedMapClearRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapClearRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-
- ClientReplicatedMapContainsKeyRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapContainsKeyRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- ClientReplicatedMapContainsValueRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapContainsValueRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- ClientReplicatedMapEntrySetRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapEntrySetRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-
- ClientReplicatedMapGetRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapGetRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- ClientReplicatedMapIsEmptyRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapIsEmptyRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-
- ClientReplicatedMapKeySetRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapKeySetRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-
- ClientReplicatedMapPutAllRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapPutAllRequest(String, ReplicatedMapEntrySet) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- ClientReplicatedMapPutTtlRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapPutTtlRequest(String, Object, Object, long) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-
- ClientReplicatedMapRemoveEntryListenerRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapRemoveEntryListenerRequest() - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- ClientReplicatedMapRemoveEntryListenerRequest(String, String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- ClientReplicatedMapRemoveRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapRemoveRequest(String, Object) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- ClientReplicatedMapSizeRequest - Class in com.hazelcast.replicatedmap.impl.client
-
Client request class for
Map.size()
implementation
- ClientReplicatedMapSizeRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-
- ClientReplicatedMapValuesRequest - Class in com.hazelcast.replicatedmap.impl.client
-
- ClientReplicatedMapValuesRequest(String) - Constructor for class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-
- ClientRequest - Class in com.hazelcast.client.impl.client
-
- ClientRequest() - Constructor for class com.hazelcast.client.impl.client.ClientRequest
-
- ClientResponse - Class in com.hazelcast.client.impl.client
-
- ClientResponse() - Constructor for class com.hazelcast.client.impl.client.ClientResponse
-
- ClientResponse(Data, int, boolean) - Constructor for class com.hazelcast.client.impl.client.ClientResponse
-
- ClientService - Interface in com.hazelcast.core
-
ClientService allows to query connected
Client
s and
attach/detach
ClientListener
s to listen connection events.
- ClientServiceProxy - Class in com.hazelcast.client.impl
-
- ClientServiceProxy(Node) - Constructor for class com.hazelcast.client.impl.ClientServiceProxy
-
- clientThreadId - Variable in class com.hazelcast.transaction.client.BaseTransactionRequest
-
- ClientTxnPortableHook - Class in com.hazelcast.transaction.client
-
Factory class for client transaction related classes
- ClientTxnPortableHook() - Constructor for class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- ClientType - Enum in com.hazelcast.core
-
Type of a client.
- ClientTypes - Class in com.hazelcast.client
-
Constants class that contains the different types of clients.
- Clock - Class in com.hazelcast.util
-
Utility class to be able to simulate different time zones.
- clone() - Method in class com.hazelcast.monitor.TimedMemberState
-
- cloneWithoutValues() - Method in class com.hazelcast.map.impl.EntryEventData
-
- close() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close(ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- close() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- close(ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- close(URI, ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- close() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-
- close() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- close() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- close() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- close() - Method in interface com.hazelcast.nio.Connection
-
Closes this connection.
- close() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- close() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- close() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
-
- close() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- close() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
Closes socket channel.
- close() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- close(Throwable) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- closeConnection() - Method in class com.hazelcast.nio.ascii.SocketTextReader
-
- closeInbound() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- closeInbound() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
Closes inbound.
- closeOutbound() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- closeOutbound() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
Closes outbound.
- closeResource(Closeable) - Static method in class com.hazelcast.nio.IOUtil
-
Closes the Closable quietly.
- closeResources() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- Cluster - Interface in com.hazelcast.core
-
Hazelcast cluster interface.
- CLUSTER - Static variable in class com.hazelcast.nio.Protocols
-
Protocol that is used among nodes
- ClusterDataSerializerHook - Class in com.hazelcast.cluster.impl
-
- ClusterDataSerializerHook() - Constructor for class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-
- ClusterPermission - Class in com.hazelcast.security.permission
-
- ClusterPermission(String) - Constructor for class com.hazelcast.security.permission.ClusterPermission
-
- ClusterPermissionCollection - Class in com.hazelcast.security.permission
-
- ClusterPermissionCollection() - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
-
- ClusterPermissionCollection(Class<? extends Permission>) - Constructor for class com.hazelcast.security.permission.ClusterPermissionCollection
-
- ClusterPropsRequest - Class in com.hazelcast.management.request
-
Request for cluster properties.
- ClusterPropsRequest() - Constructor for class com.hazelcast.management.request.ClusterPropsRequest
-
- ClusterProxy - Class in com.hazelcast.cluster.impl
-
- ClusterProxy(ClusterServiceImpl) - Constructor for class com.hazelcast.cluster.impl.ClusterProxy
-
- ClusterService - Interface in com.hazelcast.cluster
-
A service responsible for member related functionality.
- clusterService - Variable in class com.hazelcast.instance.Node
-
- ClusterServiceImpl - Class in com.hazelcast.cluster.impl
-
- ClusterServiceImpl(Node) - Constructor for class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- ClusterWideIterator<K,V> - Class in com.hazelcast.cache.impl
-
Cluster-wide iterator for
ICache
.
- ClusterWideIterator(CacheProxy<K, V>) - Constructor for class com.hazelcast.cache.impl.ClusterWideIterator
-
- clusterWideUpdateManagementCenterUrl(String, String, String) - Method in class com.hazelcast.management.ManagementCenterService
-
- CoalescingDelayedTrigger - Class in com.hazelcast.util.scheduler
-
Coalescing trigger can be used when you want coalesce multiple execution of
Runnable
.
- CoalescingDelayedTrigger(ExecutionService, long, long, Runnable) - Constructor for class com.hazelcast.util.scheduler.CoalescingDelayedTrigger
-
- collate(Iterable<ValueIn>) - Method in interface com.hazelcast.mapreduce.Collator
-
This method is called with the mapped and possibly reduced values from the MapReduce algorithm.
- Collator<ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
-
This interface can be implemented to define a Collator which is executed after calculation
of the MapReduce algorithm on remote cluster nodes but before returning the final result.
Collator can for example be used to sum up a final value.
- COLLECTION - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-
- COLLECTION_ADD - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_ADD - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_ADD_ALL - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_ADD_ALL - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_ADD_ALL_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_ADD_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_ADD_LISTENER - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_CLEAR - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_CLEAR - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_CLEAR_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_COMPARE_AND_REMOVE - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_CONTAINS - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_CONTAINS - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- COLLECTION_EVENT - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_EVENT_FILTER - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_GET_ALL - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_GET_ALL - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_IS_EMPTY - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_IS_EMPTY - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_ITEM - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- COLLECTION_PREPARE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_PREPARE_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_REMOVE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_REMOVE - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_REMOVE_LISTENER - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_RESERVE_ADD - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_RESERVE_REMOVE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_ROLLBACK - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_ROLLBACK_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_SIZE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_SIZE - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- COLLECTION_TXN_ADD - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_TXN_ADD_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_TXN_REMOVE - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- COLLECTION_TXN_REMOVE_BACKUP - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- CollectionAddAllBackupOperation - Class in com.hazelcast.collection
-
- CollectionAddAllBackupOperation() - Constructor for class com.hazelcast.collection.CollectionAddAllBackupOperation
-
- CollectionAddAllBackupOperation(String, Map<Long, Data>) - Constructor for class com.hazelcast.collection.CollectionAddAllBackupOperation
-
- CollectionAddAllOperation - Class in com.hazelcast.collection
-
- CollectionAddAllOperation() - Constructor for class com.hazelcast.collection.CollectionAddAllOperation
-
- CollectionAddAllOperation(String, List<Data>) - Constructor for class com.hazelcast.collection.CollectionAddAllOperation
-
- CollectionAddAllRequest - Class in com.hazelcast.collection.client
-
- CollectionAddAllRequest() - Constructor for class com.hazelcast.collection.client.CollectionAddAllRequest
-
- CollectionAddAllRequest(String, List<Data>) - Constructor for class com.hazelcast.collection.client.CollectionAddAllRequest
-
- CollectionAddBackupOperation - Class in com.hazelcast.collection
-
- CollectionAddBackupOperation() - Constructor for class com.hazelcast.collection.CollectionAddBackupOperation
-
- CollectionAddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.CollectionAddBackupOperation
-
- CollectionAddListenerRequest - Class in com.hazelcast.collection.client
-
this class is used to attach a listener to node for collections
- CollectionAddListenerRequest() - Constructor for class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- CollectionAddListenerRequest(String, boolean) - Constructor for class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- CollectionAddOperation - Class in com.hazelcast.collection
-
- CollectionAddOperation() - Constructor for class com.hazelcast.collection.CollectionAddOperation
-
- CollectionAddOperation(String, Data) - Constructor for class com.hazelcast.collection.CollectionAddOperation
-
- CollectionAddRequest - Class in com.hazelcast.collection.client
-
- CollectionAddRequest() - Constructor for class com.hazelcast.collection.client.CollectionAddRequest
-
- CollectionAddRequest(String, Data) - Constructor for class com.hazelcast.collection.client.CollectionAddRequest
-
- CollectionBackupAwareOperation - Class in com.hazelcast.collection
-
- CollectionBackupAwareOperation() - Constructor for class com.hazelcast.collection.CollectionBackupAwareOperation
-
- CollectionBackupAwareOperation(String) - Constructor for class com.hazelcast.collection.CollectionBackupAwareOperation
-
- CollectionClearBackupOperation - Class in com.hazelcast.collection
-
- CollectionClearBackupOperation() - Constructor for class com.hazelcast.collection.CollectionClearBackupOperation
-
- CollectionClearBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.collection.CollectionClearBackupOperation
-
- CollectionClearOperation - Class in com.hazelcast.collection
-
- CollectionClearOperation() - Constructor for class com.hazelcast.collection.CollectionClearOperation
-
- CollectionClearOperation(String) - Constructor for class com.hazelcast.collection.CollectionClearOperation
-
- CollectionClearRequest - Class in com.hazelcast.collection.client
-
- CollectionClearRequest() - Constructor for class com.hazelcast.collection.client.CollectionClearRequest
-
- CollectionClearRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionClearRequest
-
- CollectionCompareAndRemoveOperation - Class in com.hazelcast.collection
-
- CollectionCompareAndRemoveOperation() - Constructor for class com.hazelcast.collection.CollectionCompareAndRemoveOperation
-
- CollectionCompareAndRemoveOperation(String, boolean, Set<Data>) - Constructor for class com.hazelcast.collection.CollectionCompareAndRemoveOperation
-
- CollectionCompareAndRemoveRequest - Class in com.hazelcast.collection.client
-
- CollectionCompareAndRemoveRequest() - Constructor for class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
-
- CollectionCompareAndRemoveRequest(String, Set<Data>, boolean) - Constructor for class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
-
- CollectionConfig<T extends CollectionConfig> - Class in com.hazelcast.config
-
- CollectionConfig() - Constructor for class com.hazelcast.config.CollectionConfig
-
- CollectionConfig(CollectionConfig) - Constructor for class com.hazelcast.config.CollectionConfig
-
- CollectionContainer - Class in com.hazelcast.collection
-
- CollectionContainer() - Constructor for class com.hazelcast.collection.CollectionContainer
-
- CollectionContainer(String, NodeEngine) - Constructor for class com.hazelcast.collection.CollectionContainer
-
- CollectionContainsOperation - Class in com.hazelcast.collection
-
- CollectionContainsOperation() - Constructor for class com.hazelcast.collection.CollectionContainsOperation
-
- CollectionContainsOperation(String, Set<Data>) - Constructor for class com.hazelcast.collection.CollectionContainsOperation
-
- CollectionContainsRequest - Class in com.hazelcast.collection.client
-
- CollectionContainsRequest() - Constructor for class com.hazelcast.collection.client.CollectionContainsRequest
-
- CollectionContainsRequest(String, Set<Data>) - Constructor for class com.hazelcast.collection.client.CollectionContainsRequest
-
- CollectionContainsRequest(String, Data) - Constructor for class com.hazelcast.collection.client.CollectionContainsRequest
-
- CollectionDataSerializerHook - Class in com.hazelcast.collection
-
- CollectionDataSerializerHook() - Constructor for class com.hazelcast.collection.CollectionDataSerializerHook
-
- CollectionEvent - Class in com.hazelcast.collection
-
- CollectionEvent() - Constructor for class com.hazelcast.collection.CollectionEvent
-
- CollectionEvent(String, Data, ItemEventType, Address) - Constructor for class com.hazelcast.collection.CollectionEvent
-
- CollectionEventFilter - Class in com.hazelcast.collection
-
- CollectionEventFilter() - Constructor for class com.hazelcast.collection.CollectionEventFilter
-
- CollectionEventFilter(boolean) - Constructor for class com.hazelcast.collection.CollectionEventFilter
-
- CollectionGetAllOperation - Class in com.hazelcast.collection
-
- CollectionGetAllOperation() - Constructor for class com.hazelcast.collection.CollectionGetAllOperation
-
- CollectionGetAllOperation(String) - Constructor for class com.hazelcast.collection.CollectionGetAllOperation
-
- CollectionGetAllRequest - Class in com.hazelcast.collection.client
-
- CollectionGetAllRequest() - Constructor for class com.hazelcast.collection.client.CollectionGetAllRequest
-
- CollectionGetAllRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionGetAllRequest
-
- CollectionIsEmptyOperation - Class in com.hazelcast.collection
-
- CollectionIsEmptyOperation() - Constructor for class com.hazelcast.collection.CollectionIsEmptyOperation
-
- CollectionIsEmptyOperation(String) - Constructor for class com.hazelcast.collection.CollectionIsEmptyOperation
-
- CollectionIsEmptyRequest - Class in com.hazelcast.collection.client
-
- CollectionIsEmptyRequest() - Constructor for class com.hazelcast.collection.client.CollectionIsEmptyRequest
-
- CollectionIsEmptyRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionIsEmptyRequest
-
- CollectionItem - Class in com.hazelcast.collection
-
- CollectionItem() - Constructor for class com.hazelcast.collection.CollectionItem
-
- CollectionItem(long, Data) - Constructor for class com.hazelcast.collection.CollectionItem
-
- CollectionOperation - Class in com.hazelcast.collection
-
- CollectionOperation() - Constructor for class com.hazelcast.collection.CollectionOperation
-
- CollectionOperation(String) - Constructor for class com.hazelcast.collection.CollectionOperation
-
- CollectionPortableHook - Class in com.hazelcast.collection
-
- CollectionPortableHook() - Constructor for class com.hazelcast.collection.CollectionPortableHook
-
- CollectionPrepareBackupOperation - Class in com.hazelcast.collection.txn
-
- CollectionPrepareBackupOperation() - Constructor for class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
-
- CollectionPrepareBackupOperation(String, long, String, boolean) - Constructor for class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
-
- CollectionPrepareOperation - Class in com.hazelcast.collection.txn
-
- CollectionPrepareOperation() - Constructor for class com.hazelcast.collection.txn.CollectionPrepareOperation
-
- CollectionPrepareOperation(String, long, String, boolean) - Constructor for class com.hazelcast.collection.txn.CollectionPrepareOperation
-
- CollectionRemoveBackupOperation - Class in com.hazelcast.collection
-
- CollectionRemoveBackupOperation() - Constructor for class com.hazelcast.collection.CollectionRemoveBackupOperation
-
- CollectionRemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.CollectionRemoveBackupOperation
-
- CollectionRemoveListenerRequest - Class in com.hazelcast.collection.client
-
- CollectionRemoveListenerRequest() - Constructor for class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- CollectionRemoveListenerRequest(String, String, String) - Constructor for class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- CollectionRemoveOperation - Class in com.hazelcast.collection
-
- CollectionRemoveOperation() - Constructor for class com.hazelcast.collection.CollectionRemoveOperation
-
- CollectionRemoveOperation(String, Data) - Constructor for class com.hazelcast.collection.CollectionRemoveOperation
-
- CollectionRemoveRequest - Class in com.hazelcast.collection.client
-
- CollectionRemoveRequest() - Constructor for class com.hazelcast.collection.client.CollectionRemoveRequest
-
- CollectionRemoveRequest(String, Data) - Constructor for class com.hazelcast.collection.client.CollectionRemoveRequest
-
- CollectionReplicationOperation - Class in com.hazelcast.collection
-
- CollectionReplicationOperation() - Constructor for class com.hazelcast.collection.CollectionReplicationOperation
-
- CollectionReplicationOperation(Map<String, CollectionContainer>, int, int) - Constructor for class com.hazelcast.collection.CollectionReplicationOperation
-
- CollectionRequest - Class in com.hazelcast.collection.client
-
- CollectionRequest() - Constructor for class com.hazelcast.collection.client.CollectionRequest
-
- CollectionRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionRequest
-
- CollectionReserveAddOperation - Class in com.hazelcast.collection.txn
-
- CollectionReserveAddOperation() - Constructor for class com.hazelcast.collection.txn.CollectionReserveAddOperation
-
- CollectionReserveAddOperation(String, String, Data) - Constructor for class com.hazelcast.collection.txn.CollectionReserveAddOperation
-
- CollectionReserveRemoveOperation - Class in com.hazelcast.collection.txn
-
- CollectionReserveRemoveOperation() - Constructor for class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
-
- CollectionReserveRemoveOperation(String, long, Data, String) - Constructor for class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
-
- CollectionRollbackBackupOperation - Class in com.hazelcast.collection.txn
-
- CollectionRollbackBackupOperation() - Constructor for class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
-
- CollectionRollbackBackupOperation(String, long, boolean) - Constructor for class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
-
- CollectionRollbackOperation - Class in com.hazelcast.collection.txn
-
- CollectionRollbackOperation() - Constructor for class com.hazelcast.collection.txn.CollectionRollbackOperation
-
- CollectionRollbackOperation(String, long, boolean) - Constructor for class com.hazelcast.collection.txn.CollectionRollbackOperation
-
- CollectionService - Class in com.hazelcast.collection
-
- CollectionService(NodeEngine) - Constructor for class com.hazelcast.collection.CollectionService
-
- CollectionSizeOperation - Class in com.hazelcast.collection
-
- CollectionSizeOperation() - Constructor for class com.hazelcast.collection.CollectionSizeOperation
-
- CollectionSizeOperation(String) - Constructor for class com.hazelcast.collection.CollectionSizeOperation
-
- CollectionSizeRequest - Class in com.hazelcast.collection.client
-
- CollectionSizeRequest() - Constructor for class com.hazelcast.collection.client.CollectionSizeRequest
-
- CollectionSizeRequest(String) - Constructor for class com.hazelcast.collection.client.CollectionSizeRequest
-
- CollectionTransactionLog - Class in com.hazelcast.collection.txn
-
- CollectionTransactionLog() - Constructor for class com.hazelcast.collection.txn.CollectionTransactionLog
-
- CollectionTransactionLog(long, String, int, String, String, Operation) - Constructor for class com.hazelcast.collection.txn.CollectionTransactionLog
-
- CollectionTransactionRollbackOperation - Class in com.hazelcast.collection
-
- CollectionTransactionRollbackOperation() - Constructor for class com.hazelcast.collection.CollectionTransactionRollbackOperation
-
- CollectionTransactionRollbackOperation(String, String) - Constructor for class com.hazelcast.collection.CollectionTransactionRollbackOperation
-
- CollectionTxnAddBackupOperation - Class in com.hazelcast.collection.txn
-
- CollectionTxnAddBackupOperation() - Constructor for class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
-
- CollectionTxnAddBackupOperation(String, long, Data) - Constructor for class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
-
- CollectionTxnAddOperation - Class in com.hazelcast.collection.txn
-
- CollectionTxnAddOperation() - Constructor for class com.hazelcast.collection.txn.CollectionTxnAddOperation
-
- CollectionTxnAddOperation(String, long, Data) - Constructor for class com.hazelcast.collection.txn.CollectionTxnAddOperation
-
- CollectionTxnRemoveBackupOperation - Class in com.hazelcast.collection.txn
-
- CollectionTxnRemoveBackupOperation() - Constructor for class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
-
- CollectionTxnRemoveBackupOperation(String, long) - Constructor for class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
-
- CollectionTxnRemoveOperation - Class in com.hazelcast.collection.txn
-
- CollectionTxnRemoveOperation() - Constructor for class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
-
- CollectionTxnRemoveOperation(String, long) - Constructor for class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
-
- com.hazelcast.ascii - package com.hazelcast.ascii
-
This package contains Ascii functionality for Hazelcast.
- com.hazelcast.ascii.memcache - package com.hazelcast.ascii.memcache
-
This package contains MemoryCache functionality for Hazelcast.
- com.hazelcast.ascii.rest - package com.hazelcast.ascii.rest
-
This package contains Reset functionality for Hazelcast.
- com.hazelcast.cache - package com.hazelcast.cache
-
Hazelcast JSR-107 aka JCache implementation
- com.hazelcast.cache.impl - package com.hazelcast.cache.impl
-
Hazelcast JSR-107 aka JCache implementation
- com.hazelcast.cache.impl.client - package com.hazelcast.cache.impl.client
-
Hazelcast JSR-107 aka JCache implementation
Client Requests
- com.hazelcast.cache.impl.operation - package com.hazelcast.cache.impl.operation
-
Hazelcast JSR-107 aka JCache implementation
- com.hazelcast.cache.impl.record - package com.hazelcast.cache.impl.record
-
Hazelcast JSR-107 aka JCache implementation
Internal record store
- com.hazelcast.client - package com.hazelcast.client
-
This package contains the serverside client functionality
- com.hazelcast.client.impl - package com.hazelcast.client.impl
-
Implementation classes of the com.hazelcast.client interfaces
- com.hazelcast.client.impl.client - package com.hazelcast.client.impl.client
-
This contains the Requests and other DTO's exchanged between client/server
- com.hazelcast.client.impl.exceptionconverters - package com.hazelcast.client.impl.exceptionconverters
-
Contains logic to convert client exceptions.
- com.hazelcast.client.impl.operations - package com.hazelcast.client.impl.operations
-
Contains client operations
- com.hazelcast.cluster - package com.hazelcast.cluster
-
This package contains the cluster functionality.
- com.hazelcast.cluster.client - package com.hazelcast.cluster.client
-
This package contains the client cluster functionality.
- com.hazelcast.cluster.impl - package com.hazelcast.cluster.impl
-
This package contains the implementation of the cluster functionality.
- com.hazelcast.cluster.impl.operations - package com.hazelcast.cluster.impl.operations
-
This package contains operations for the com.hazelcast.cluster.impl package.
- com.hazelcast.collection - package com.hazelcast.collection
-
This package contains classes related to Collections (IList,ISet etc..)
- com.hazelcast.collection.client - package com.hazelcast.collection.client
-
This package contains client functionality for Collections in Hazelcast.
- com.hazelcast.collection.common - package com.hazelcast.collection.common
-
This package contains common classes related to all collections
- com.hazelcast.collection.list - package com.hazelcast.collection.list
-
This package contains IList functionality for Hazelcast.
- com.hazelcast.collection.set - package com.hazelcast.collection.set
-
This package contains ISet functionality for Hazelcast.
- com.hazelcast.collection.txn - package com.hazelcast.collection.txn
-
This package contains the Transaction behavior for the Collections.
- com.hazelcast.concurrent.atomiclong - package com.hazelcast.concurrent.atomiclong
-
This package contains IAtomicLong functionality for Hazelcast.
The IAtomicLong is the distributed version of the
AtomicLong
.
- com.hazelcast.concurrent.atomiclong.client - package com.hazelcast.concurrent.atomiclong.client
-
This package contains client requests for the IAtomicLong.
This package contains all the client request object to operate on the
IAtomicLong that are send by the client.
- com.hazelcast.concurrent.atomiclong.operations - package com.hazelcast.concurrent.atomiclong.operations
-
This package contains the operations on the IAtomicLong.
- com.hazelcast.concurrent.atomicreference - package com.hazelcast.concurrent.atomicreference
-
This package contains IAtomicReferece functionality for Hazelcast.
The IAtomicReference is the distributed version of the
AtomicReference
.
- com.hazelcast.concurrent.atomicreference.client - package com.hazelcast.concurrent.atomicreference.client
-
This package contains client requests for the IAtomicLong.
This package contains all the client request object to operate on the
IAtomicLong that are send by the client.
- com.hazelcast.concurrent.atomicreference.operations - package com.hazelcast.concurrent.atomicreference.operations
-
This package contains the operations on the IAtomicReference.
- com.hazelcast.concurrent.countdownlatch - package com.hazelcast.concurrent.countdownlatch
-
This package contains ICountDownLatch functionality for Hazelcast.
The ICountDownLatch is the distributed version of the
CountDownLatch
.
- com.hazelcast.concurrent.countdownlatch.client - package com.hazelcast.concurrent.countdownlatch.client
-
This package contains client requests for the ICountDownLatch.
This package contains all the client requests object to operate on the
ICountDownLatch that are send by the client.
- com.hazelcast.concurrent.countdownlatch.operations - package com.hazelcast.concurrent.countdownlatch.operations
-
This package contains the operations on the ICountDownLatch.
- com.hazelcast.concurrent.idgen - package com.hazelcast.concurrent.idgen
-
This package contains IdGenerator functionality for Hazelcast.
With the
IdGenerator
it is very simple to create cluster wide id's.
- com.hazelcast.concurrent.lock - package com.hazelcast.concurrent.lock
-
This package contains Lock for Hazelcast.
The
ILock
is the distributed version of the
Lock
.
- com.hazelcast.concurrent.lock.client - package com.hazelcast.concurrent.lock.client
-
This package contains client requests for the ILock.
This package contains all the client requests object to operate on the
ILock that are send by the client.
- com.hazelcast.concurrent.lock.operations - package com.hazelcast.concurrent.lock.operations
-
This package contains the operations on the ILock.
- com.hazelcast.concurrent.semaphore - package com.hazelcast.concurrent.semaphore
-
This package contains ISemaphore functionality for Hazelcast.
The ISemaphore is the distributed version of the
Semaphore
.
- com.hazelcast.concurrent.semaphore.client - package com.hazelcast.concurrent.semaphore.client
-
This package contains client requests for the ISemaphore.
- com.hazelcast.concurrent.semaphore.operations - package com.hazelcast.concurrent.semaphore.operations
-
This package contains the operations on the ISemaphore.
- com.hazelcast.config - package com.hazelcast.config
-
Provides classes for configuring HazelcastInstance.
- com.hazelcast.console - package com.hazelcast.console
-
This package contains classes related to ConsoleApp
- com.hazelcast.core - package com.hazelcast.core
-
Provides core API interfaces/classes.
- com.hazelcast.core.server - package com.hazelcast.core.server
-
This package contains classes to launch standalone Hazelcast Instance
- com.hazelcast.executor.impl - package com.hazelcast.executor.impl
-
This package contains IExecutorService functionality for Hazelcast.
The IExecutorService extends the
ExecutorService
and provides all kinds
of additional methods related to distributed systems.
- com.hazelcast.executor.impl.client - package com.hazelcast.executor.impl.client
-
This package contains client requests for the IExecutorService.
- com.hazelcast.executor.impl.operations - package com.hazelcast.executor.impl.operations
-
This package contains operations for the IExecutorService.
- com.hazelcast.instance - package com.hazelcast.instance
-
This package contains Hazelcast Instance functionality.
- com.hazelcast.jmx - package com.hazelcast.jmx
-
Contains Hazelcast management bean classes.
- com.hazelcast.logging - package com.hazelcast.logging
-
This package contains logging functionality for Hazelcast.
Since Hazelcast has a zero dependency policy, Hazelcast provides a logging abstraction like commongs logging,
so that different logging frameworks like log4j, can be hooked in.
- com.hazelcast.management - package com.hazelcast.management
-
Contains classes to provide data/operation interface for Management Center.
- com.hazelcast.management.operation - package com.hazelcast.management.operation
-
Contains operations that are called from Management Center.
- com.hazelcast.management.request - package com.hazelcast.management.request
-
Contains requests that made from Management Center.
- com.hazelcast.map - package com.hazelcast.map
-
Contains Hazelcast map module classes.
- com.hazelcast.map.impl - package com.hazelcast.map.impl
-
- com.hazelcast.map.impl.client - package com.hazelcast.map.impl.client
-
Contains client requests for the
IMap
- com.hazelcast.map.impl.eviction - package com.hazelcast.map.impl.eviction
-
This package contains eviction classes.
- com.hazelcast.map.impl.mapstore - package com.hazelcast.map.impl.mapstore
-
Contains map store operations.
- com.hazelcast.map.impl.mapstore.writebehind - package com.hazelcast.map.impl.mapstore.writebehind
-
Package for processing write behind store operations.
- com.hazelcast.map.impl.mapstore.writethrough - package com.hazelcast.map.impl.mapstore.writethrough
-
Package for processing write through store operations.
- com.hazelcast.map.impl.operation - package com.hazelcast.map.impl.operation
-
Package for map operations.
- com.hazelcast.map.impl.proxy - package com.hazelcast.map.impl.proxy
-
Contains map proxy implementation and support classes.
- com.hazelcast.map.impl.record - package com.hazelcast.map.impl.record
-
Contains record specific classes.
- com.hazelcast.map.impl.tx - package com.hazelcast.map.impl.tx
-
- com.hazelcast.map.impl.wan - package com.hazelcast.map.impl.wan
-
Contains wan replication event classes
- com.hazelcast.map.merge - package com.hazelcast.map.merge
-
Contains merge policies for
IMap
- com.hazelcast.mapreduce - package com.hazelcast.mapreduce
-
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the
active Hazelcast cluster.
- com.hazelcast.mapreduce.aggregation - package com.hazelcast.mapreduce.aggregation
-
This package contains the aggregation API and the convenience helper classes
to retrieve predefined aggregation implementations.
- com.hazelcast.mapreduce.aggregation.impl - package com.hazelcast.mapreduce.aggregation.impl
-
This package contains a set of predefined aggregation implementations
- com.hazelcast.mapreduce.impl - package com.hazelcast.mapreduce.impl
-
This package contains the default implementation for the map reduce framework
internals.
- com.hazelcast.mapreduce.impl.client - package com.hazelcast.mapreduce.impl.client
-
This package contains request and response classes for communication between cluster
members and Hazelcast native clients
- com.hazelcast.mapreduce.impl.notification - package com.hazelcast.mapreduce.impl.notification
-
This package contains all remote node notifications
- com.hazelcast.mapreduce.impl.operation - package com.hazelcast.mapreduce.impl.operation
-
This package contains all remote operations that are needed to control work on
supervising or worker nodes.
- com.hazelcast.mapreduce.impl.task - package com.hazelcast.mapreduce.impl.task
-
This package contains the base implementation for a standard map reduce job.
- com.hazelcast.memory - package com.hazelcast.memory
-
Provides classes/interfaces for memory utilities, heap/native memory storage support.
- com.hazelcast.monitor - package com.hazelcast.monitor
-
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
- com.hazelcast.monitor.impl - package com.hazelcast.monitor.impl
-
Contains Hazelcast statistics implementations related to map, queue, topic, multimap, executor service etc.
- com.hazelcast.multimap.impl - package com.hazelcast.multimap.impl
-
Contains classes for Hazelcast MultiMap module.
- com.hazelcast.multimap.impl.client - package com.hazelcast.multimap.impl.client
-
Contains client requests for Hazelcast MultiMap module.
- com.hazelcast.multimap.impl.operations - package com.hazelcast.multimap.impl.operations
-
Contains operations for Hazelcast MultiMap module.
- com.hazelcast.multimap.impl.txn - package com.hazelcast.multimap.impl.txn
-
This package contains the Transaction behavior for the Multimap.
- com.hazelcast.nio - package com.hazelcast.nio
-
This package contains classes related to New IO
- com.hazelcast.nio.ascii - package com.hazelcast.nio.ascii
-
Contains SocketTextReader and SocketTextWriter classes;
- com.hazelcast.nio.serialization - package com.hazelcast.nio.serialization
-
Contains interfaces/classes related to serialization;
such as serializer interfaces, input/output streams.
- com.hazelcast.nio.serialization.serializers - package com.hazelcast.nio.serialization.serializers
-
Contains interfaces/classes related to SerializerHook for ArrayList and LinkedList
- com.hazelcast.nio.ssl - package com.hazelcast.nio.ssl
-
Contains interfaces/classes related to SSL for New IO
- com.hazelcast.nio.tcp - package com.hazelcast.nio.tcp
-
Contains functionality for the TCP/IP Networking between cluster members
- com.hazelcast.osgi - package com.hazelcast.osgi
-
This package contains the OSGI functionality for Hazelcast.
- com.hazelcast.partition - package com.hazelcast.partition
-
Contains the partition logic for Hazelcast.
- com.hazelcast.partition.client - package com.hazelcast.partition.client
-
Contains client functionality for partition related information.
- com.hazelcast.partition.impl - package com.hazelcast.partition.impl
-
- com.hazelcast.partition.membergroup - package com.hazelcast.partition.membergroup
-
todo
- com.hazelcast.partition.strategy - package com.hazelcast.partition.strategy
-
Packages contains different partitioning strategies.
- com.hazelcast.query - package com.hazelcast.query
-
Contains interfaces/classes related to Hazelcast query and indexing support.
- com.hazelcast.query.impl - package com.hazelcast.query.impl
-
Contains the implementation classes of the query functionality.
- com.hazelcast.queue.impl - package com.hazelcast.queue.impl
-
This package contains the IQueue functionality.
The
IQueue
is the distributed version of the
BlockingQueue
.
- com.hazelcast.queue.impl.client - package com.hazelcast.queue.impl.client
-
This package contains client requests for the IQueue.
- com.hazelcast.queue.impl.operations - package com.hazelcast.queue.impl.operations
-
This package contains the IQueue operations
- com.hazelcast.queue.impl.proxy - package com.hazelcast.queue.impl.proxy
-
This package contains the IQueue proxies.
- com.hazelcast.queue.impl.tx - package com.hazelcast.queue.impl.tx
-
This package contains the Transaction behavior for the IQueue.
- com.hazelcast.replicatedmap.impl - package com.hazelcast.replicatedmap.impl
-
This package contains the implementation of the replicated map service itself and some connection interfaces only used
internally - No public API!
- com.hazelcast.replicatedmap.impl.client - package com.hazelcast.replicatedmap.impl.client
-
This package contains classes for client communication on replicated map implementation
- com.hazelcast.replicatedmap.impl.messages - package com.hazelcast.replicatedmap.impl.messages
-
This package contains replication event classes to communicate replications to other nodes
- com.hazelcast.replicatedmap.impl.operation - package com.hazelcast.replicatedmap.impl.operation
-
This package contains some remote operations to execute on remote nodes
- com.hazelcast.replicatedmap.impl.record - package com.hazelcast.replicatedmap.impl.record
-
This package contains the implementation of the backing data storage for the replicated map implementation
- com.hazelcast.security - package com.hazelcast.security
-
Provides interfaces/classes for Hazelcast security implementation.
- com.hazelcast.security.permission - package com.hazelcast.security.permission
-
Contains all the security permissions
- com.hazelcast.spi - package com.hazelcast.spi
-
Provides interfaces/classes for Hazelcast SPI.
- com.hazelcast.spi.annotation - package com.hazelcast.spi.annotation
-
Contains annotations for Hazelcast SPI.
- com.hazelcast.spi.exception - package com.hazelcast.spi.exception
-
Contains exceptions for Hazelcast SPI.
- com.hazelcast.spi.impl - package com.hazelcast.spi.impl
-
Contains implementations for Hazelcast SPI.
- com.hazelcast.storage - package com.hazelcast.storage
-
This package contains storage functionality for Hazelcast.
- com.hazelcast.topic.impl - package com.hazelcast.topic.impl
-
This package contains ITopic functionality for Hazelcast.
With the ITopic it is possible to create publish subscribe solutions similar to JMS Topics.
- com.hazelcast.topic.impl.client - package com.hazelcast.topic.impl.client
-
This package contains client requests for the ITopic.
- com.hazelcast.transaction - package com.hazelcast.transaction
-
Provides interfaces/classes for Hazelcast transaction support.
- com.hazelcast.transaction.client - package com.hazelcast.transaction.client
-
This package contains client transaction code
- com.hazelcast.transaction.impl - package com.hazelcast.transaction.impl
-
Provides implementation for Hazelcast transaction support.
- com.hazelcast.util - package com.hazelcast.util
-
This package contains classes to support the inner workings of Hazelcast
as well as some backports of newer Java features / data structures to
support older Java versions in a clean and nice way.
- com.hazelcast.util.executor - package com.hazelcast.util.executor
-
This package contains classes related to Util.Executor
- com.hazelcast.util.scheduler - package com.hazelcast.util.scheduler
-
This package contains scheduler classes for Util
- com.hazelcast.wan - package com.hazelcast.wan
-
This package contains the WAN replication API
- com.hazelcast.wan.impl - package com.hazelcast.wan.impl
-
This package contains the opensource implementation of WAN replication
- combine(ValueIn) - Method in class com.hazelcast.mapreduce.Combiner
-
This method is called to supply values to be combined into an intermediate result chunk.
The combine method might be called multiple times so the combined chunk needs to be hold
internally in a member state of the Combiner.
After this method is called you need to reset the internal state to prepare combining of
the next chunk.
- Combiner<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
-
The abstract Combiner class is used to build combiners for the
Job
.
Those Combiners are distributed inside of the cluster and are running alongside
the
Mapper
implementations in the same node.
Combiners are called in a threadsafe way so internal locking is not required.
- Combiner() - Constructor for class com.hazelcast.mapreduce.Combiner
-
- combiner(CombinerFactory<Key, Value, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- combiner(CombinerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
-
- COMBINER_RESULT_LIST - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- CombinerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
-
A CombinerFactory implementation is used to build
Combiner
instances per key.
An implementation needs to be serializable by Hazelcast since it is distributed together with
the
Mapper
implementation to run alongside.
- combinerFactory - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-
- combinerFactory - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- CombinerResultList<E> - Class in com.hazelcast.mapreduce.impl
-
This
ArrayList
subclass exists to prevent
DefaultContext.CollectingCombinerFactory
created collections to be mixed up with user provided List results from
Combiner
s.
- CombinerResultList() - Constructor for class com.hazelcast.mapreduce.impl.CombinerResultList
-
- CombinerResultList(Collection<? extends E>) - Constructor for class com.hazelcast.mapreduce.impl.CombinerResultList
-
- combineToInt(short, short) - Static method in class com.hazelcast.nio.Bits
-
Combines two short integer values into an integer.
- combineToLong(int, int) - Static method in class com.hazelcast.nio.Bits
-
Combines two integer values into a long integer.
- CommandParser - Interface in com.hazelcast.ascii
-
- commit(NodeEngine) - Method in class com.hazelcast.collection.txn.CollectionTransactionLog
-
- commit(NodeEngine) - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
-
- commit(NodeEngine) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- commit(NodeEngine) - Method in class com.hazelcast.queue.impl.tx.QueueTransactionLog
-
- COMMIT - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- commit() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- commit(NodeEngine) - Method in interface com.hazelcast.transaction.impl.TransactionLog
-
- commit(Xid, boolean) - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- commitAdd(long, Data) - Method in class com.hazelcast.collection.CollectionContainer
-
- commitAddBackup(long, Data) - Method in class com.hazelcast.collection.CollectionContainer
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.CollectionService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- commitMigration(PartitionMigrationEvent) - Method in class com.hazelcast.queue.impl.QueueService
-
- commitMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
-
- commitRemove(long) - Method in class com.hazelcast.collection.CollectionContainer
-
- commitRemoveBackup(long) - Method in class com.hazelcast.collection.CollectionContainer
-
- commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
-
Commits a transaction.
- CommitTransactionRequest - Class in com.hazelcast.transaction.client
-
- CommitTransactionRequest() - Constructor for class com.hazelcast.transaction.client.CommitTransactionRequest
-
- CommitTransactionRequest(boolean) - Constructor for class com.hazelcast.transaction.client.CommitTransactionRequest
-
- compact() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- compact() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- COMPARABLE_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- COMPARABLE_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- COMPARABLE_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- COMPARABLE_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- comparableMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to find the maximum value of all supplied
Comparable
implementing values.
This aggregation is similar to
- ComparableMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined maximum aggregation for values of type
Comparable
.
- ComparableMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-
- comparableMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to find the minimum value of all supplied
Comparable
implementing values.
This aggregation is similar to
- ComparableMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined minimum aggregation for values of type
Comparable
.
- ComparableMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-
- compare(Object, Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- compare(Comparator<Map.Entry>, IterationType, Map.Entry, Map.Entry) - Static method in class com.hazelcast.util.SortingUtil
-
- COMPARE_AND_REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- COMPARE_AND_REMOVE - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- COMPARE_AND_REMOVE - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- COMPARE_AND_REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- COMPARE_AND_REMOVE_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- COMPARE_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- compareAndRemove(boolean, Set<Data>) - Method in class com.hazelcast.collection.CollectionContainer
-
- compareAndRemove(Collection<Data>, boolean) - Method in class com.hazelcast.queue.impl.QueueContainer
-
This method triggers store load
- compareAndRemoveBackup(Set<Long>) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- CompareAndRemoveBackupOperation - Class in com.hazelcast.queue.impl.operations
-
This class triggers backup method for items' id.
- CompareAndRemoveBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.CompareAndRemoveBackupOperation
-
- CompareAndRemoveBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.queue.impl.operations.CompareAndRemoveBackupOperation
-
- CompareAndRemoveOperation - Class in com.hazelcast.queue.impl.operations
-
This class triggers iterator and if find same item in the Queue, remove this item.
- CompareAndRemoveOperation() - Constructor for class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- CompareAndRemoveOperation(String, Collection<Data>, boolean) - Constructor for class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- CompareAndRemoveRequest - Class in com.hazelcast.queue.impl.client
-
- CompareAndRemoveRequest() - Constructor for class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
-
- CompareAndRemoveRequest(String, Collection<Data>, boolean) - Constructor for class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
-
- compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- compareAndSet(long, long) - Method in class com.hazelcast.concurrent.atomiclong.LongWrapper
-
- compareAndSet(E, E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- compareAndSet(Data, Data) - Method in class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
-
- compareAndSet(long, long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- compareAndSet(E, E) - Method in interface com.hazelcast.core.IAtomicReference
-
Atomically sets the value to the given updated value
only if the current value ==
the expected value.
- compareAndSet(long, long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- CompareAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- CompareAndSetOperation(String, long, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- CompareAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- CompareAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- CompareAndSetOperation(String, Data, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- CompareAndSetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- CompareAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-
- CompareAndSetRequest(String, long, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-
- CompareAndSetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- CompareAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-
- CompareAndSetRequest(String, Data, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-
- compareTo(CollectionItem) - Method in class com.hazelcast.collection.CollectionItem
-
- compareTo(MonitoredThread) - Method in class com.hazelcast.management.MonitoredThread
-
- compareTo(NearCache.CacheRecord) - Method in class com.hazelcast.map.impl.NearCache.CacheRecord
-
- compareTo(Object) - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
-
- compareTo(Object) - Method in class com.hazelcast.query.impl.IndexImpl.NullObject
-
- compareTo(QueueItem) - Method in class com.hazelcast.queue.impl.QueueItem
-
- ComparisonType - Enum in com.hazelcast.query.impl
-
Type of Comparison
- CompletableFutureTask<V> - Class in com.hazelcast.util.executor
-
- CompletableFutureTask(Callable<V>, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
-
- CompletableFutureTask(Runnable, V, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletableFutureTask
-
- CompletedFuture<V> - Class in com.hazelcast.util.executor
-
- CompletedFuture(SerializationService, Object, ExecutorService) - Constructor for class com.hazelcast.util.executor.CompletedFuture
-
- completionId - Variable in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- compress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
-
- concatenate(byte[], byte[]) - Static method in class com.hazelcast.ascii.memcache.MemcacheCommandProcessor
-
- ConcurrencyUtil - Class in com.hazelcast.util
-
Utility methods to getOrPutSynchronized and getOrPutIfAbsent in thread safe way
from ConcurrentMap with a ConstructorFunction .
- ConcurrentReferenceHashMap<K,V> - Class in com.hazelcast.util
-
An advanced hash table supporting configurable garbage collection semantics
of keys and values, optional referential-equality, full concurrency of
retrievals, and adjustable expected concurrency for updates.
- ConcurrentReferenceHashMap(int, float, int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial
capacity, reference types, load factor and concurrency level.
- ConcurrentReferenceHashMap(int, float, int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial
capacity, load factor and concurrency level.
- ConcurrentReferenceHashMap(int, float) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial capacity
and load factor and with the default reference types (weak keys,
strong values), and concurrencyLevel (16).
- ConcurrentReferenceHashMap(int, ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial capacity,
reference types and with default load factor (0.75) and concurrencyLevel (16).
- ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty reference map with the specified key
and value reference types.
- ConcurrentReferenceHashMap(ConcurrentReferenceHashMap.ReferenceType, ConcurrentReferenceHashMap.ReferenceType, EnumSet<ConcurrentReferenceHashMap.Option>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty reference map with the specified reference types
and behavioral options.
- ConcurrentReferenceHashMap(int) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with the specified initial capacity,
and with default reference types (weak keys, strong values),
load factor (0.75) and concurrencyLevel (16).
- ConcurrentReferenceHashMap() - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new, empty map with a default initial capacity (16),
reference types (weak keys, strong values), default
load factor (0.75) and concurrencyLevel (16).
- ConcurrentReferenceHashMap(Map<? extends K, ? extends V>) - Constructor for class com.hazelcast.util.ConcurrentReferenceHashMap
-
Creates a new map with the same mappings as the given map.
- ConcurrentReferenceHashMap.Option - Enum in com.hazelcast.util
-
- ConcurrentReferenceHashMap.ReferenceType - Enum in com.hazelcast.util
-
An option specifying which Java reference type should be used to refer
to a key and/or value.
- CONDITION_AWAIT - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- CONDITION_BEFORE_AWAIT - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- CONDITION_SIGNAL - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- ConditionKey - Class in com.hazelcast.concurrent.lock
-
- ConditionKey(String, Data, String) - Constructor for class com.hazelcast.concurrent.lock.ConditionKey
-
- config - Variable in class com.hazelcast.cluster.impl.AbstractJoiner
-
- Config - Class in com.hazelcast.config
-
- Config() - Constructor for class com.hazelcast.config.Config
-
- Config(String) - Constructor for class com.hazelcast.config.Config
-
- config - Variable in class com.hazelcast.instance.Node
-
- config - Variable in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- config - Variable in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- config - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- config - Variable in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- CONFIG_CHECK - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-
- ConfigBuilder - Interface in com.hazelcast.config
-
Interface for all config builders.
- ConfigCheck - Class in com.hazelcast.cluster.impl
-
Contains enough information about Hazelcast Config, to do a validation check so that clusters with different configurations
don't join.
- ConfigCheck() - Constructor for class com.hazelcast.cluster.impl.ConfigCheck
-
- ConfigCheck(Config, String) - Constructor for class com.hazelcast.cluster.impl.ConfigCheck
-
- configCheck - Variable in class com.hazelcast.cluster.impl.JoinMessage
-
- ConfigLoader - Class in com.hazelcast.config
-
Provides loading service for a configuration.
- ConfigMemberGroupFactory - Class in com.hazelcast.partition.membergroup
-
- ConfigMemberGroupFactory(Collection<MemberGroupConfig>) - Constructor for class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
-
- ConfigMismatchException - Exception in com.hazelcast.cluster.impl
-
Exception thrown when 2 nodes want to join, but there configuration doesn't match
- ConfigMismatchException(String) - Constructor for exception com.hazelcast.cluster.impl.ConfigMismatchException
-
- ConfigMismatchOperation - Class in com.hazelcast.cluster.impl.operations
-
When a node wants to join the cluster, its sends its ConfigCheck to the cluster where it is validated.
- ConfigMismatchOperation() - Constructor for class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
-
- ConfigMismatchOperation(String) - Constructor for class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
-
- configs - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- configs - Variable in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- ConfigurableService<T> - Interface in com.hazelcast.spi
-
A capability for SPI services.
- configure(GroupConfig, Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
-
- configure(SecurityConfig, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
-
- configure(T) - Method in interface com.hazelcast.spi.ConfigurableService
-
- configureBlocking(boolean) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- configureBlocking(boolean) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
- ConfigXmlGenerator - Class in com.hazelcast.config
-
The ConfigXmlGenerator is responsible for transforming a
Config
to a Hazelcast XML string.
- ConfigXmlGenerator() - Constructor for class com.hazelcast.config.ConfigXmlGenerator
-
Creates a ConfigXmlGenerator that will format the code.
- ConfigXmlGenerator(boolean) - Constructor for class com.hazelcast.config.ConfigXmlGenerator
-
Creates a ConfigXmlGenerator.
- connect(SocketAddress) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- connect(SocketAddress) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
- CONNECT_ALL_WAIT_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- Connection - Interface in com.hazelcast.nio
-
Represents a 'connection' between two machines.
- connection - Variable in class com.hazelcast.nio.tcp.DefaultPacketReader
-
- CONNECTION_MONITOR_INTERVAL - Variable in class com.hazelcast.instance.GroupProperties
-
- CONNECTION_MONITOR_MAX_FAULTS - Variable in class com.hazelcast.instance.GroupProperties
-
- connectionAdded(Connection) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- connectionAdded(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
-
- ConnectionListener - Interface in com.hazelcast.nio
-
A listener for the
ConnectionManager
to listen to connections
being added or removed.
- connectionManager - Variable in class com.hazelcast.instance.Node
-
- ConnectionManager - Interface in com.hazelcast.nio
-
- ConnectionManagerMBean - Class in com.hazelcast.jmx
-
- ConnectionManagerMBean(HazelcastInstance, ConnectionManager, ManagementService) - Constructor for class com.hazelcast.jmx.ConnectionManagerMBean
-
- connectionRemoved(Connection) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- connectionRemoved(Connection) - Method in interface com.hazelcast.nio.ConnectionListener
-
- ConnectionType - Enum in com.hazelcast.nio
-
An enumeration of all possible Connection types.
- ConsoleApp - Class in com.hazelcast.console
-
Special thanks to Alexandre Vasseur for providing this very nice test
application.
- ConsoleApp(HazelcastInstance) - Constructor for class com.hazelcast.console.ConsoleApp
-
- ConsoleApp.Echo - Class in com.hazelcast.console
-
Echoes to screen
- ConsoleApp.Echo() - Constructor for class com.hazelcast.console.ConsoleApp.Echo
-
- ConsoleApp.Echo(String) - Constructor for class com.hazelcast.console.ConsoleApp.Echo
-
- ConsoleCommandHandler - Class in com.hazelcast.management
-
Handler class for console commands that sent from Console application which located in Management Center.
- ConsoleCommandHandler(HazelcastInstance) - Constructor for class com.hazelcast.management.ConsoleCommandHandler
-
- ConsoleCommandRequest - Class in com.hazelcast.management.request
-
Request for sending console commands.
- ConsoleCommandRequest() - Constructor for class com.hazelcast.management.request.ConsoleCommandRequest
-
- ConsoleCommandRequest(String) - Constructor for class com.hazelcast.management.request.ConsoleCommandRequest
-
- ConsoleRequest - Interface in com.hazelcast.management.request
-
Represents request sent from Management Center.
- ConsoleRequestConstants - Class in com.hazelcast.management.request
-
Constants to identify serialized requests.
- CONSTANT_SERIALIZERS_LENGTH - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_BOOLEAN - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_BYTE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_BYTE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_CHAR - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_CHAR_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_DATA_SERIALIZABLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_DOUBLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_DOUBLE_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_FLOAT - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_FLOAT_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_INTEGER - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_INTEGER_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_LONG - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_LONG_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_NULL - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_PORTABLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_SHORT - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_SHORT_ARRAY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- CONSTANT_TYPE_STRING - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- ConstantSerializers - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.BooleanSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.BooleanSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.BooleanSerializer
-
- ConstantSerializers.ByteSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.ByteSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ByteSerializer
-
- ConstantSerializers.CharArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.CharArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.CharArraySerializer
-
- ConstantSerializers.CharSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.CharSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.CharSerializer
-
- ConstantSerializers.DoubleArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.DoubleArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.DoubleArraySerializer
-
- ConstantSerializers.DoubleSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.DoubleSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.DoubleSerializer
-
- ConstantSerializers.FloatArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.FloatArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.FloatArraySerializer
-
- ConstantSerializers.FloatSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.FloatSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.FloatSerializer
-
- ConstantSerializers.IntegerArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.IntegerArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.IntegerArraySerializer
-
- ConstantSerializers.IntegerSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.IntegerSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.IntegerSerializer
-
- ConstantSerializers.LongArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.LongArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.LongArraySerializer
-
- ConstantSerializers.LongSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.LongSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.LongSerializer
-
- ConstantSerializers.ShortArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.ShortArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ShortArraySerializer
-
- ConstantSerializers.ShortSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.ShortSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.ShortSerializer
-
- ConstantSerializers.StringSerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.StringSerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.StringSerializer
-
- ConstantSerializers.TheByteArraySerializer - Class in com.hazelcast.nio.serialization
-
- ConstantSerializers.TheByteArraySerializer() - Constructor for class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
-
- ConstructorFunction<K,V> - Interface in com.hazelcast.util
-
See ConcurrencyUtil
- container - Variable in class com.hazelcast.queue.impl.QueueItem
-
- contains(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- contains(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Determines if this store contains an entry for the specified key.
- contains(Object) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- contains(Set<Data>) - Method in class com.hazelcast.collection.CollectionContainer
-
- CONTAINS - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- contains(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- contains(Data) - Method in class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
-
- contains(E) - Method in interface com.hazelcast.core.IAtomicReference
-
Checks if the reference contains the value.
- CONTAINS - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- contains(Object) - Method in class com.hazelcast.query.impl.AndResultSet
-
- contains(Object) - Method in class com.hazelcast.query.impl.MultiResultSet
-
- contains(Object) - Method in class com.hazelcast.query.impl.OrResultSet
-
- contains(Object) - Method in class com.hazelcast.query.impl.SingleResultSet
-
- contains(Object) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- contains(Collection<Data>) - Method in class com.hazelcast.queue.impl.QueueContainer
-
This method does not trigger store load.
- CONTAINS - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- CONTAINS - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- contains(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Legacy method testing if some key maps into the specified value
in this table.
- CONTAINS_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- CONTAINS_ENTRY - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- CONTAINS_ENTRY - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- CONTAINS_KEY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CONTAINS_KEY - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- CONTAINS_KEY - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- CONTAINS_KEY - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- CONTAINS_VALUE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- CONTAINS_VALUE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- containsAll(Collection<?>) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- containsAll(Collection<?>) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- containsAtomicLong(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- containsAtomicReference(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- containsCollection(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-
- containsEntry(K, V) - Method in interface com.hazelcast.core.MultiMap
-
Returns whether the multimap contains the given key-value pair.
- containsEntry(boolean, Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- containsEntry(K, V) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- ContainsEntryOperation - Class in com.hazelcast.multimap.impl.operations
-
- ContainsEntryOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- ContainsEntryOperation(String, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- ContainsEntryOperation(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- containsInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- containsKey(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- containsKey(Object) - Method in interface com.hazelcast.core.BaseMap
-
Returns true
if this map contains an entry for the specified
key.
- containsKey(Object) - Method in interface com.hazelcast.core.IMap
-
Returns true
if this map contains an entry for the specified
key.
- containsKey(K) - Method in interface com.hazelcast.core.MultiMap
-
Returns whether the multimap contains an entry with the key.
- containsKey(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
- containsKey(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- containsKey(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- containsKey(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- containsKey(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- containsKey(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- containsKey(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- containsKey(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- containsKey(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- containsKey(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Tests if the specified object is a key in this table.
- containsKeyInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- ContainsKeyOperation - Class in com.hazelcast.map.impl.operation
-
- ContainsKeyOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- ContainsKeyOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- containsLatch(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- ContainsOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- ContainsOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- ContainsOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- ContainsOperation - Class in com.hazelcast.queue.impl.operations
-
Checks whether contain or not item in the Queue.
- ContainsOperation() - Constructor for class com.hazelcast.queue.impl.operations.ContainsOperation
-
- ContainsOperation(String, Collection<Data>) - Constructor for class com.hazelcast.queue.impl.operations.ContainsOperation
-
- containsQueue(String) - Method in class com.hazelcast.queue.impl.QueueService
-
- containsRecordId(long) - Method in class com.hazelcast.multimap.impl.MultiMapWrapper
-
- ContainsRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- ContainsRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-
- ContainsRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-
- ContainsRequest - Class in com.hazelcast.multimap.impl.client
-
The contains requests checks if a value is stored in the multimap.
- ContainsRequest() - Constructor for class com.hazelcast.multimap.impl.client.ContainsRequest
-
- ContainsRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.ContainsRequest
-
- ContainsRequest - Class in com.hazelcast.queue.impl.client
-
- ContainsRequest() - Constructor for class com.hazelcast.queue.impl.client.ContainsRequest
-
- ContainsRequest(String, Collection<Data>) - Constructor for class com.hazelcast.queue.impl.client.ContainsRequest
-
- containsSemaphore(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- containsValue(Object) - Method in interface com.hazelcast.core.IMap
- containsValue(Object) - Method in interface com.hazelcast.core.MultiMap
-
Returns whether the multimap contains an entry with the value.
- containsValue(Object) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- containsValue(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- containsValue(Object) - Method in interface com.hazelcast.map.impl.RecordStore
-
- containsValue(boolean, Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- containsValue(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- containsValue(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- containsValue(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- containsValue(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- containsValue(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns true if this map maps one or more keys to the
specified value.
- ContainsValueOperation - Class in com.hazelcast.map.impl.operation
-
- ContainsValueOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
-
- ContainsValueOperation() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperation
-
- ContainsValueOperationFactory - Class in com.hazelcast.map.impl.operation
-
- ContainsValueOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-
- ContainsValueOperationFactory(String, Data) - Constructor for class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-
- CONTENT_LENGTH - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- CONTENT_TYPE - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- CONTENT_TYPE_BINARY - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- CONTENT_TYPE_PLAIN_TEXT - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- Context<K,V> - Interface in com.hazelcast.mapreduce
-
The Context interface is used for emitting keys and values to the intermediate working space of
the MapReduce algorithm.
- context - Variable in class com.hazelcast.nio.serialization.DataAdapter
-
- convert(Throwable) - Method in interface com.hazelcast.client.impl.exceptionconverters.ClientExceptionConverter
-
- convert(Throwable) - Method in class com.hazelcast.client.impl.exceptionconverters.GenericClientExceptionConverter
-
- convert(Throwable) - Method in class com.hazelcast.client.impl.exceptionconverters.JavaClientExceptionConverter
-
- convert(long, MemoryUnit) - Method in enum com.hazelcast.memory.MemoryUnit
-
- convert(Comparable) - Method in class com.hazelcast.query.impl.UUIDConverter
-
- convert(Map.Entry, Comparable, Comparable) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
-
- convertToEventType(CacheEventType) - Static method in enum com.hazelcast.cache.impl.CacheEventType
-
- convertToObjectKeys(Collection) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-
- convertToStringKey(Object, SerializationService) - Static method in class com.hazelcast.concurrent.lock.LockProxy
-
- convertVersionToString(int) - Static method in class com.hazelcast.management.ManagementCenterIdentifier
-
- copyCollections() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- copyToDirectBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
-
- copyToHeapBuffer(ByteBuffer, ByteBuffer) - Static method in class com.hazelcast.nio.IOUtil
-
- CoreService - Interface in com.hazelcast.spi
-
Marker interface for core Hazelcast services.
- count() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation for counting all supplied values.
This aggregation is similar to
- COUNT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- COUNT - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- COUNT_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- COUNT_DOWN_LATCH_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- COUNT_DOWN_LATCH_REPLICATION_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- COUNT_DOWN_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- COUNT_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- CountAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined count aggregation.
- CountAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-
- countDown() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- countDown() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- countDown(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- countDown() - Method in interface com.hazelcast.core.ICountDownLatch
-
Decrements the count of the latch, releasing all waiting threads if
the count reaches zero.
- countDown() - Method in class com.hazelcast.jmx.CountDownLatchMBean
-
- CountDownLatchBackupOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- CountDownLatchBackupOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- CountDownLatchBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- CountDownLatchDataSerializerHook - Class in com.hazelcast.concurrent.countdownlatch
-
- CountDownLatchDataSerializerHook() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- CountDownLatchInfo - Class in com.hazelcast.concurrent.countdownlatch
-
- CountDownLatchInfo() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- CountDownLatchInfo(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- CountDownLatchMBean - Class in com.hazelcast.jmx
-
- CountDownLatchMBean(ICountDownLatch, ManagementService) - Constructor for class com.hazelcast.jmx.CountDownLatchMBean
-
- CountDownLatchPermission - Class in com.hazelcast.security.permission
-
- CountDownLatchPermission(String, String...) - Constructor for class com.hazelcast.security.permission.CountDownLatchPermission
-
- CountDownLatchPortableHook - Class in com.hazelcast.concurrent.countdownlatch.client
-
- CountDownLatchPortableHook() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.CountDownLatchPortableHook
-
- CountDownLatchProxy - Class in com.hazelcast.concurrent.countdownlatch
-
- CountDownLatchProxy(String, NodeEngine) - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- CountDownLatchReplicationOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- CountDownLatchReplicationOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- CountDownLatchReplicationOperation(Collection<CountDownLatchInfo>) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- CountDownLatchService - Class in com.hazelcast.concurrent.countdownlatch
-
- CountDownLatchService() - Constructor for class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- CountDownOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- CountDownOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- CountDownOperation(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- CountDownRequest - Class in com.hazelcast.concurrent.countdownlatch.client
-
- CountDownRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- CountDownRequest(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- countInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- CountOperation - Class in com.hazelcast.multimap.impl.operations
-
- CountOperation() - Constructor for class com.hazelcast.multimap.impl.operations.CountOperation
-
- CountOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.CountOperation
-
- CountRequest - Class in com.hazelcast.multimap.impl.client
-
- CountRequest() - Constructor for class com.hazelcast.multimap.impl.client.CountRequest
-
- CountRequest(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.client.CountRequest
-
- CPP - Static variable in class com.hazelcast.client.ClientTypes
-
CPP client protocol id
- create(int) - Method in class com.hazelcast.client.impl.client.ClientPortableFactory
-
- create(ClassLoader) - Static method in class com.hazelcast.instance.NodeExtensionFactory
-
- create(MapServiceContext) - Static method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- create(MemoryInfoAccessor, MapServiceContext) - Static method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- create(NodeEngine) - Static method in class com.hazelcast.map.impl.MapService
-
Static factory method which creates a new map service object.
- create(K, V, long, int) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.DelayedEntry
-
- create(K, V, long) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.DelayedEntry
-
- create(int) - Method in class com.hazelcast.nio.serialization.ArrayDataSerializableFactory
-
- create(int) - Method in class com.hazelcast.nio.serialization.ArrayPortableFactory
-
- create(int) - Method in interface com.hazelcast.nio.serialization.DataSerializableFactory
-
Creates an IdentifiedDataSerializable instance using given type id
- create(int) - Method in interface com.hazelcast.nio.serialization.PortableFactory
-
Creates a Portable instance using given class id
- create(String, QueueStoreConfig, SerializationService) - Static method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- CREATE - Static variable in class com.hazelcast.security.permission.InstancePermission
-
- CREATE - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- CREATE_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- CREATE_CONFIG - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- CREATE_PROXY - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- createAddressPicker(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
-
- createAddressPicker(Node) - Method in interface com.hazelcast.instance.NodeContext
-
- createBackupEntryProcessor() - Method in interface com.hazelcast.cache.BackupAwareEntryProcessor
-
Either creates a new, specialized EntryProcessor
to be executed on the backup-partition or returns
- createBindings() - Method in class com.hazelcast.osgi.OSGiScriptEngine
-
- createCache(String, C) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- createCacheConfig(String, C) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- createCacheConfigIfAbsent(CacheConfig, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createCacheConfigIfAbsent(CacheConfig, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- createCacheDataRecord(Data, long) - Method in class com.hazelcast.cache.impl.record.CacheRecordFactory
-
- createCacheEntryProcessorEntry(Data, R, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createCacheEntryProcessorEntry(Data, CacheRecord, long) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createCacheObjectRecord(Object, long) - Method in class com.hazelcast.cache.impl.record.CacheRecordFactory
-
- createCacheProxy(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- createCacheProxy(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- createCacheRecordFactory() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createCacheStatIfAbsent(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createCacheStatIfAbsent(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- createCachingProvider(HazelcastInstance) - Static method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
-
Helper method for creating caching provider for testing, etc.
- createClassDefinition(int, byte[]) - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- createClearOperationFactory(Integer) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createClearOperationFactory(Integer) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createClientLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
-
- createClientUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
-
- createCoalescedWriteBehindQueue() - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-
- createCollection(MultiMapConfig.ValueCollectionType) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
-
- createCollection(MultiMapConfig.ValueCollectionType, int) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
-
- createCollection(Collection) - Static method in class com.hazelcast.multimap.impl.ValueCollectionFactory
-
- createConfigCheck() - Method in class com.hazelcast.instance.Node
-
- createConfigOnAllMembers(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createConfigOnPartition(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- createConfigOnPartition(CacheConfig<K, V>) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- createConnectionManager(Node, ServerSocketChannel) - Method in class com.hazelcast.instance.DefaultNodeContext
-
- createConnectionManager(Node, ServerSocketChannel) - Method in interface com.hazelcast.instance.NodeContext
-
- createContainsKeyOperation(Data) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createContainsKeyOperation(Data) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createDefaultWriteBehindQueue() - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-
- createDistributedObject(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createDistributedObject(String) - Method in class com.hazelcast.collection.list.ListService
-
- createDistributedObject(String) - Method in class com.hazelcast.collection.set.SetService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- createDistributedObject(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- createDistributedObject(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- createDistributedObject(String) - Method in class com.hazelcast.map.impl.MapService
-
- createDistributedObject(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- createDistributedObject(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- createDistributedObject(String) - Method in class com.hazelcast.queue.impl.QueueService
-
- createDistributedObject(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- createDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
-
- createDistributedObject(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- createEmptyResponseHandler() - Static method in class com.hazelcast.spi.impl.ResponseHandlerFactory
-
- createEntryProcessorOperation(Data, Integer, EntryProcessor, Object...) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createEntryProcessorOperation(Data, Integer, EntryProcessor, Object...) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createErrorLoggingResponseHandler(ILogger) - Static method in class com.hazelcast.spi.impl.ResponseHandlerFactory
-
- createFactory() - Method in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.cache.impl.CachePortableHook
-
- createFactory() - Method in class com.hazelcast.client.impl.client.ClientPortableHook
-
- createFactory() - Method in class com.hazelcast.client.impl.ClientDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.collection.CollectionDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.collection.CollectionPortableHook
-
- createFactory() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
-
- createFactory() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
-
- createFactory() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownLatchPortableHook
-
- createFactory() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- createFactory() - Method in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphorePortableHook
-
- createFactory() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.executor.impl.ExecutorPortableHook
-
- createFactory() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.map.impl.MapPortableHook
-
- createFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- createFactory() - Method in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- createFactory() - Method in interface com.hazelcast.nio.serialization.DataSerializerHook
-
- createFactory() - Method in interface com.hazelcast.nio.serialization.PortableHook
-
- createFactory() - Method in class com.hazelcast.partition.PartitionDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.partition.PartitionPortableHook
-
- createFactory() - Method in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.queue.impl.QueuePortableHook
-
- createFactory() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- createFactory() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-
- createFactory() - Method in class com.hazelcast.topic.impl.TopicDataSerializerHook
-
- createFactory() - Method in class com.hazelcast.topic.impl.TopicPortableHook
-
- createFactory() - Method in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- createGetAllOperationFactory(Set<Data>, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetAllOperationFactory(Set<Data>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createGetAndRemoveOperation(Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetAndRemoveOperation(Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createGetAndReplaceOperation(Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetAndReplaceOperation(Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createGetOperation(Data, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createGetOperation(Data, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createHazelcastCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- createHazelcastCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
-
- createInput(Data, SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
-
- createInput(byte[], SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
-
- createInputOutputFactory() - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.ConfigMemberGroupFactory
-
- createInternalMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.HostAwareMemberGroupFactory
-
- createInvocationBuilder(String, Operation, int) - Method in class com.hazelcast.client.impl.client.InvocationClientRequest
-
- createInvocationBuilder(String, Operation, Address) - Method in class com.hazelcast.client.impl.client.InvocationClientRequest
-
- createInvocationBuilder(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
-
- createInvocationBuilder(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
-
- createJobProcessInformation(JobTaskConfiguration, JobSupervisor) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- createJobSupervisor(JobTaskConfiguration) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- createJoiner(Node) - Method in class com.hazelcast.instance.DefaultNodeContext
-
- createJoiner(Node) - Method in interface com.hazelcast.instance.NodeContext
-
- createJoinRequest() - Method in class com.hazelcast.instance.Node
-
- createJoinRequest(boolean) - Method in class com.hazelcast.instance.Node
-
- createKeyIteratorOperation(int, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createKeyIteratorOperation(int, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createLazyEntryView(K, V, Record, SerializationService, MapMergePolicy) - Static method in class com.hazelcast.map.impl.EntryViews
-
- createLoadAllOperationFactory(Set<Data>, boolean) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createLoadAllOperationFactory(Set<Data>, boolean) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createLocalMapStats(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-
- createLocalQueueStats(String, int) - Method in class com.hazelcast.queue.impl.QueueService
-
- createLockStore(int, ObjectNamespace) - Method in interface com.hazelcast.concurrent.lock.LockService
-
- createLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- createLogger(String) - Method in class com.hazelcast.logging.Log4j2Factory
-
- createLogger(String) - Method in class com.hazelcast.logging.Log4jFactory
-
- createLogger(String) - Method in class com.hazelcast.logging.LoggerFactorySupport
-
- createLogger(String) - Method in class com.hazelcast.logging.Slf4jFactory
-
- createLogger(String) - Method in class com.hazelcast.logging.StandardLoggerFactory
-
- createMapSizeEstimator() - Static method in class com.hazelcast.map.impl.SizeEstimators
-
- createMapStoreManager(MapContainer) - Method in class com.hazelcast.map.impl.MapContainer
-
- createMember(Address, String, String, Map<String, Object>) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- createMemberGroups(Collection<? extends Member>) - Method in interface com.hazelcast.partition.membergroup.MemberGroupFactory
-
- createMemberGroups(Collection<? extends Member>) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
-
- createMemberLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
-
- createMemberUuid(Address) - Static method in class com.hazelcast.util.UuidUtil
-
- createNearCacheSizeEstimator() - Static method in class com.hazelcast.map.impl.SizeEstimators
-
- createNew(K) - Method in interface com.hazelcast.util.ConstructorFunction
-
- createNewRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- createNewRecordStore(String, int) - Method in class com.hazelcast.cache.impl.CacheService
-
- createNullEntryView(K) - Static method in class com.hazelcast.map.impl.EntryViews
-
Creates a null entry view that has only key and no value.
- createObjectDataInput(byte[]) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataInput(Data) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataInput(byte[]) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectDataInput(Data) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectDataInputStream(InputStream) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataInputStream(InputStream) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectDataOutput(int) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataOutput(int) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectDataOutputStream(OutputStream) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createObjectDataOutputStream(OutputStream) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createObjectName(String, String) - Method in class com.hazelcast.jmx.ManagementService
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- createOperation() - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.EntrySetOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapKeySetOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapPutAllOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MapValuesOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperationFactory
-
- createOperation() - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
-
- createOperation() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory
-
- createOperation() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-
- createOperation() - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-
- createOperation() - Method in interface com.hazelcast.spi.OperationFactory
-
Creates the operation.
- createOperationFactory() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-
- createOperationFactory() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- createOperationFactory() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- createOperationFactory() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.client.AllPartitionsClientRequest
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-
- createOperationFactory() - Method in class com.hazelcast.client.impl.client.MultiTargetClientRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- createOperationFactory() - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.EntrySetRequest
-
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.KeySetRequest
-
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.SizeRequest
-
- createOperationFactory() - Method in class com.hazelcast.multimap.impl.client.ValuesRequest
-
- createOutput(int, SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
-
- createPacketReader(TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createPacketReader(TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a PacketReader for given Connection instance.
- createPacketReader(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
-
- createPacketReader(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
-
- createPacketReader(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- createPacketWriter(TcpIpConnection, IOService) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createPacketWriter(TcpIpConnection, IOService) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a PacketWriter for given Connection instance.
- createPacketWriter(TcpIpConnection) - Method in interface com.hazelcast.nio.IOService
-
- createPacketWriter(TcpIpConnection) - Method in class com.hazelcast.nio.NodeIOService
-
- createPacketWriter(TcpIpConnection) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- createPortableReader(Data) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- createPortableReader(Data) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createPutIfAbsentOperation(Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createPutIfAbsentOperation(Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createPutOperation(Data, Data, ExpiryPolicy, boolean, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createPutOperation(Data, Data, ExpiryPolicy, boolean, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createRecord(T, long, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(Object, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(Data, Object, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecord(T, long, long) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createRecord(Data, Object, long, long) - Method in class com.hazelcast.map.impl.MapContainer
-
- createRecordCacheMap() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRecordCacheMap() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- createRecordWithExpiry(Data, Object, ExpiryPolicy, long, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- createRemoteResponseHandler(NodeEngine, RemotePropagatable) - Static method in class com.hazelcast.spi.impl.ResponseHandlerFactory
-
- createRemoveAllOperationFactory(Set<Data>, Integer) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createRemoveAllOperationFactory(Set<Data>, Integer) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createRemoveOperation(Data, Data, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createRemoveOperation(Data, Data, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createReplaceOperation(Data, Data, Data, ExpiryPolicy, int) - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createReplaceOperation(Data, Data, Data, ExpiryPolicy, int) - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createSafeBoundedArrayWriteBehindQueue(int, AtomicInteger) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-
- createSafeWriteBehindQueue(WriteBehindQueue<T>) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueues
-
- createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
-
Creates secure callable that runs in a sandbox.
- createSerializationService() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createSerializationService() - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a SerializationService instance to be used by this Node.
- createSerializationService(InputOutputFactory) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- createSerializer() - Method in class com.hazelcast.mapreduce.impl.JobPartitionStateArraySerializerHook
-
- createSerializer() - Method in class com.hazelcast.mapreduce.impl.JobPartitionStateSerializerHook
-
- createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Creates a new serializer for the serialization type
- createSerializer() - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook
-
- createSerializer() - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook
-
- createSerializerAdapter(Serializer) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- createService(Class<T>) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- createService(Class<T>) - Method in interface com.hazelcast.instance.NodeExtension
-
Creates a service which is an implementation of given type parameter.
- createSimpleEntryView(K, V, Record) - Static method in class com.hazelcast.map.impl.EntryViews
-
- createSimpleEntryView() - Static method in class com.hazelcast.map.impl.EntryViews
-
- createSizeOperationFactory() - Method in interface com.hazelcast.cache.impl.CacheOperationProvider
-
- createSizeOperationFactory() - Method in class com.hazelcast.cache.impl.DefaultOperationProvider
-
- createStats(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- createStoreEvent(E) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent
-
- createSymmetricReaderCipher(SymmetricEncryptionConfig) - Static method in class com.hazelcast.nio.CipherHelper
-
- createSymmetricWriterCipher(SymmetricEncryptionConfig) - Static method in class com.hazelcast.nio.CipherHelper
-
- createThread(Runnable) - Method in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-
- createThread(Runnable) - Method in class com.hazelcast.util.executor.PoolExecutorThreadFactory
-
- createThread(Runnable) - Method in class com.hazelcast.util.executor.SingleExecutorThreadFactory
-
- createTimedMemberState() - Method in class com.hazelcast.management.DefaultTimedMemberStateFactory
-
- createTimedMemberState() - Method in interface com.hazelcast.management.TimedMemberStateFactory
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.collection.list.ListService
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.collection.set.SetService
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.map.impl.MapService
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- createTransactionalObject(String, TransactionSupport) - Method in class com.hazelcast.queue.impl.QueueService
-
- createTransactionalObject(String, TransactionSupport) - Method in interface com.hazelcast.spi.TransactionalService
-
- CreateTransactionRequest - Class in com.hazelcast.transaction.client
-
- CreateTransactionRequest() - Constructor for class com.hazelcast.transaction.client.CreateTransactionRequest
-
- CreateTransactionRequest(TransactionOptions, SerializableXID) - Constructor for class com.hazelcast.transaction.client.CreateTransactionRequest
-
- createWithNullKey(V, long) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.DelayedEntry
-
Used to put staging area.
- createWithNullValue(K, long, int) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.DelayedEntry
-
Used to removal operations from map store.
- createWriteBehindManager(MapContainer) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreManagers
-
- createWriteBehindProcessor(MapContainer) - Static method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessors
-
- createWriteBehindStore(MapContainer, int, WriteBehindProcessor) - Static method in class com.hazelcast.map.impl.mapstore.MapDataStores
-
Creates a write behind data store.
- createWriteThroughManager(MapContainer) - Static method in class com.hazelcast.map.impl.mapstore.MapStoreManagers
-
- createWriteThroughStore(MapContainer) - Static method in class com.hazelcast.map.impl.mapstore.MapDataStores
-
Creates a write through data store.
- creationTime - Variable in class com.hazelcast.collection.CollectionItem
-
- creationTime - Variable in class com.hazelcast.map.impl.record.RecordInfo
-
- creationTime - Variable in class com.hazelcast.queue.impl.QueueItem
-
- Credentials - Interface in com.hazelcast.security
-
Credentials is a container object for endpoint (Members and Clients)
security attributes.
- CredentialsFactoryConfig - Class in com.hazelcast.config
-
Contains the configuration for Credentials Factory.
- CredentialsFactoryConfig() - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
-
- CredentialsFactoryConfig(String) - Constructor for class com.hazelcast.config.CredentialsFactoryConfig
-
- CSHARP - Static variable in class com.hazelcast.client.ClientTypes
-
CSHARP client protocol id
- currentIndex - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- currentTimeMillis() - Static method in class com.hazelcast.util.Clock
-
- currentValue - Variable in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- currentValue - Variable in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- data - Variable in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- Data - Interface in com.hazelcast.nio.serialization
-
Data is basic unit of serialization.
- data - Variable in class com.hazelcast.nio.serialization.DataAdapter
-
- data - Variable in class com.hazelcast.queue.impl.QueueItem
-
- data - Variable in class com.hazelcast.topic.impl.TopicEvent
-
- DataAdapter - Class in com.hazelcast.nio.serialization
-
- DataAdapter(PortableContext) - Constructor for class com.hazelcast.nio.serialization.DataAdapter
-
- DataAdapter(Data, PortableContext) - Constructor for class com.hazelcast.nio.serialization.DataAdapter
-
- DataAwareEntryEvent - Class in com.hazelcast.map.impl
-
- DataAwareEntryEvent(Member, int, String, Data, Data, Data, SerializationService) - Constructor for class com.hazelcast.map.impl.DataAwareEntryEvent
-
- DataAwareItemEvent - Class in com.hazelcast.collection.common
-
- DataAwareItemEvent(String, ItemEventType, Data, Member, SerializationService) - Constructor for class com.hazelcast.collection.common.DataAwareItemEvent
-
- DataAwareMessage - Class in com.hazelcast.topic.impl
-
- DataAwareMessage(String, Data, long, Member, SerializationService) - Constructor for class com.hazelcast.topic.impl.DataAwareMessage
-
- dataKey - Variable in class com.hazelcast.map.impl.EntryEventData
-
- dataKey - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- dataKey - Variable in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- dataNewValue - Variable in class com.hazelcast.map.impl.EntryEventData
-
- dataOldValue - Variable in class com.hazelcast.map.impl.EntryEventData
-
- dataOldValue - Variable in class com.hazelcast.map.impl.operation.BasePutOperation
-
- dataOldValue - Variable in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- DataRecordFactory - Class in com.hazelcast.map.impl.record
-
- DataRecordFactory(MapConfig, SerializationService, PartitioningStrategy) - Constructor for class com.hazelcast.map.impl.record.DataRecordFactory
-
- DataRef - Interface in com.hazelcast.storage
-
- DataReplicatedRecordStore - Class in com.hazelcast.replicatedmap.impl.record
-
- DataReplicatedRecordStore(String, NodeEngine, ReplicatedMapService) - Constructor for class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
-
- DataSerializable - Interface in com.hazelcast.nio.serialization
-
DataSerializable is a serialization method as an alternative to standard Java serialization.
- dataSerializableFactories - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- DataSerializableFactory - Interface in com.hazelcast.nio.serialization
-
DataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization.
- DataSerializerHook - Interface in com.hazelcast.nio.serialization
-
- dataSize() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns size of binary data
- dataSize() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- dataToRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- dataToRecord(Data) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- dataToValue(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- dataToValue(Data) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- dataValue - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- DEAD_MEMBER_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- DeadMemberBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- DeadMemberBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-
- DeadMemberBackupOperation(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-
- decode(byte[]) - Static method in class com.hazelcast.util.Base64
-
Decodes Base64 data into octects
- decompress(byte[]) - Static method in class com.hazelcast.nio.IOUtil
-
- decrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- decrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically decrements the current value by one.
- decrementAndGet() - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- DEFAULT_ASNYC_FILLUP - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of asynchronous fill up
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
-
Asynchronous Backup Counter
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
-
The number of default asynchronous backup count
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
-
Default value of asynchronous backup count
- DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
-
Default asynchronous backup count
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
The number of default backup counter
- DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
-
The number of default backup counter
- DEFAULT_CALL_TIMEOUT - Static variable in class com.hazelcast.spi.InvocationBuilder
-
Default call timeout.
- DEFAULT_CHUNK_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default value of chunk size.
- DEFAULT_CHUNK_SIZE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
Default size for replication chunks
- DEFAULT_COMMUNICATE_STATS - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default boolean value of communication statics.define how a map reduce job behaves
- DEFAULT_CONCURRENCY_LEVEL - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of concurrency level
- DEFAULT_DESERIALIZE_RESULT - Static variable in class com.hazelcast.spi.InvocationBuilder
-
If the result of an operation automatically should be deserialized to an object.
- DEFAULT_EMPTY_QUEUE_TTL - Static variable in class com.hazelcast.config.QueueConfig
-
Default value of time to live for empty Queue
- DEFAULT_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
-
Whether the multicast discovery mechanism has been enabled
- DEFAULT_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
Default eviction percentage
- DEFAULT_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
-
The number of default eviction percentage
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
Default Eviction Policy.
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.MapConfig
-
Default policy for eviction
- DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default eviction policy
- DEFAULT_EVICTION_THRESHOLD_PERCENTAGE - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
The threshold default value for eviction
- DEFAULT_GLOBAL_ORDERING_ENABLED - Static variable in class com.hazelcast.config.TopicConfig
-
Default global ordering configuration
- DEFAULT_GRACEFUL_SHUTDOWN_WAIT - Static variable in class com.hazelcast.instance.LifecycleServiceImpl
-
- DEFAULT_GROUP_NAME - Static variable in class com.hazelcast.config.GroupConfig
-
Default group name
- DEFAULT_GROUP_PASSWORD - Static variable in class com.hazelcast.config.GroupConfig
-
Default group password
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
Default InMemory Format.
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.MapConfig
-
Default In-Memory format is binary
- DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of In-memory format
- DEFAULT_INITIAL_CAPACITY - Static variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- DEFAULT_MAP_MERGE_POLICY - Static variable in class com.hazelcast.config.MapConfig
-
Default policy for merging
- DEFAULT_MAP_NAME - Static variable in class com.hazelcast.ascii.memcache.MemcacheCommandProcessor
-
- DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.MapConfig
-
The number of default time to wait eviction
- DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default value of idle in seconds for eviction.
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.CollectionConfig
-
Maximum size Configuration
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.MaxSizeConfig
-
Default maximum size of map.
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default value of maximum size
- DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.QueueConfig
-
Default value of maximum size of Queue
- DEFAULT_MAX_THREAD_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default size of thread.
- DEFAULT_MEMORY_FORMAT - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default memory format
- DEFAULT_METADATA_SPACE_PERCENTAGE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default metadata space percentage
- DEFAULT_MIN_BLOCK_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default minimum block size
- DEFAULT_MIN_EVICTION_CHECK_MILLIS - Static variable in class com.hazelcast.config.MapConfig
-
Minimum time in milliseconds which should pass before asking
if a partition of this map is evictable or not.
- DEFAULT_MULTICAST_GROUP - Static variable in class com.hazelcast.config.MulticastConfig
-
Default group of multicast.
- DEFAULT_MULTICAST_PORT - Static variable in class com.hazelcast.config.MulticastConfig
-
Default value of port.
- DEFAULT_MULTICAST_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.MulticastConfig
-
Default timeout of multicast in seconds.
- DEFAULT_MULTICAST_TTL - Static variable in class com.hazelcast.config.MulticastConfig
-
Default value of time to live of multicast.
- DEFAULT_PAGE_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default page size
- DEFAULT_PARTITION_COUNT - Static variable in class com.hazelcast.monitor.impl.MemberStateImpl
-
- DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.ExecutorConfig
-
The number of executor threads per Member for the Executor based on this configuration.
- DEFAULT_PORT - Static variable in class com.hazelcast.config.NetworkConfig
-
Default value of port number
- DEFAULT_POWER - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Default power for page size
- DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.ExecutorConfig
-
Capacity of Queue
- DEFAULT_QUEUE_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default value of Queue size.
- DEFAULT_REPLICA_INDEX - Static variable in class com.hazelcast.spi.InvocationBuilder
-
Default replica index.
- DEFAULT_REPLICA_SYNC_DELAY - Static variable in interface com.hazelcast.partition.InternalPartitionService
-
- DEFAULT_REPLICATION_DELAY_MILLIS - Static variable in class com.hazelcast.config.ReplicatedMapConfig
-
Default value of delay of replication in millisecond
- DEFAULT_RETRY_COUNT - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Default value of retry counter.
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
-
Synchronous Backup Counter
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
-
The number of default synchronous backup count
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
-
Default value of sycronous backup count
- DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
-
Default synchronous backup count
- DEFAULT_TIMEOUT_MILLIS - Static variable in class com.hazelcast.transaction.TransactionOptions
-
2 minutes as default timeout value
- DEFAULT_TOPOLOGY_CHANGED_STRATEGY - Static variable in class com.hazelcast.config.JobTrackerConfig
-
Define how a map reduce job behaves.
- DEFAULT_TRY_COUNT - Static variable in class com.hazelcast.spi.InvocationBuilder
-
Default try count.
- DEFAULT_TRY_PAUSE_MILLIS - Static variable in class com.hazelcast.spi.InvocationBuilder
-
Default try pause in millis.
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.MapConfig
-
The number of default Time to Live seconds
- DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
-
Default value of time to live in seconds.
- DEFAULT_TYPE_BIG_DECIMAL - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_BIG_INTEGER - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_CLASS - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_DATE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_ENUM - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_EXTERNALIZABLE - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_TYPE_OBJECT - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
-
- DEFAULT_VALUE_COLLECTION_TYPE - Static variable in class com.hazelcast.config.MultiMapConfig
-
Default value collection type of multi-map.
- DEFAULT_WRITE_BATCH_SIZE - Static variable in class com.hazelcast.config.MapStoreConfig
-
Default batch size for writing
- DEFAULT_WRITE_DELAY_SECONDS - Static variable in class com.hazelcast.config.MapStoreConfig
-
Default delay seconds for writing
- defaultClassLoader - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- DefaultContext<KeyIn,ValueIn> - Class in com.hazelcast.mapreduce.impl.task
-
This is the internal default implementation of a map reduce context mappers emit values to.
- DefaultContext(CombinerFactory<KeyIn, ValueIn, ?>, MapCombineTask) - Constructor for class com.hazelcast.mapreduce.impl.task.DefaultContext
-
- DefaultData - Class in com.hazelcast.nio.serialization
-
- DefaultData() - Constructor for class com.hazelcast.nio.serialization.DefaultData
-
- DefaultData(int, byte[]) - Constructor for class com.hazelcast.nio.serialization.DefaultData
-
- DefaultData(int, byte[], int) - Constructor for class com.hazelcast.nio.serialization.DefaultData
-
- DefaultData(int, byte[], int, byte[]) - Constructor for class com.hazelcast.nio.serialization.DefaultData
-
- defaultExpiryPolicy - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- DefaultMapServiceContext - Class in com.hazelcast.map.impl
-
Default implementation of map service context.
- DefaultMapServiceContext(NodeEngine) - Constructor for class com.hazelcast.map.impl.DefaultMapServiceContext
-
- DefaultMemberGroup - Class in com.hazelcast.partition.membergroup
-
- DefaultMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- DefaultMemberGroup(Collection<Member>) - Constructor for class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- DefaultNodeContext - Class in com.hazelcast.instance
-
- DefaultNodeContext() - Constructor for class com.hazelcast.instance.DefaultNodeContext
-
- DefaultNodeExtension - Class in com.hazelcast.instance
-
- DefaultNodeExtension() - Constructor for class com.hazelcast.instance.DefaultNodeExtension
-
- DefaultObjectNamespace - Class in com.hazelcast.spi
-
- DefaultObjectNamespace() - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
-
- DefaultObjectNamespace(String, String) - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
-
- DefaultOperationProvider - Class in com.hazelcast.cache.impl
-
- DefaultOperationProvider(String) - Constructor for class com.hazelcast.cache.impl.DefaultOperationProvider
-
- DefaultPacketReader - Class in com.hazelcast.nio.tcp
-
- DefaultPacketReader(TcpIpConnection, IOService) - Constructor for class com.hazelcast.nio.tcp.DefaultPacketReader
-
- DefaultPacketWriter - Class in com.hazelcast.nio.tcp
-
- DefaultPacketWriter() - Constructor for class com.hazelcast.nio.tcp.DefaultPacketWriter
-
- DefaultPartitioningStrategy - Class in com.hazelcast.partition.strategy
-
- DefaultPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
-
- DefaultPortableReader - Class in com.hazelcast.nio.serialization
-
- DefaultPortableReader(PortableSerializer, BufferObjectDataInput, ClassDefinition) - Constructor for class com.hazelcast.nio.serialization.DefaultPortableReader
-
- DefaultPortableWriter - Class in com.hazelcast.nio.serialization
-
- DefaultPortableWriter(PortableSerializer, BufferObjectDataOutput, ClassDefinition) - Constructor for class com.hazelcast.nio.serialization.DefaultPortableWriter
-
- DefaultRecordStore - Class in com.hazelcast.map.impl
-
Default implementation of record-store.
- DefaultRecordStore(MapContainer, int) - Constructor for class com.hazelcast.map.impl.DefaultRecordStore
-
- DefaultSerializationServiceBuilder - Class in com.hazelcast.nio.serialization
-
- DefaultSerializationServiceBuilder() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- DefaultSerializers - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.BigDecimalSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.BigDecimalSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.BigDecimalSerializer
-
- DefaultSerializers.BigIntegerSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.BigIntegerSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.BigIntegerSerializer
-
- DefaultSerializers.ClassSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.ClassSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.ClassSerializer
-
- DefaultSerializers.DateSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.DateSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.DateSerializer
-
- DefaultSerializers.EnumSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.EnumSerializer() - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.EnumSerializer
-
- DefaultSerializers.Externalizer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.Externalizer(boolean) - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.Externalizer
-
- DefaultSerializers.ObjectSerializer - Class in com.hazelcast.nio.serialization
-
- DefaultSerializers.ObjectSerializer(boolean, boolean) - Constructor for class com.hazelcast.nio.serialization.DefaultSerializers.ObjectSerializer
-
- DefaultSocketChannelWrapper - Class in com.hazelcast.nio.tcp
-
- DefaultSocketChannelWrapper(SocketChannel) - Constructor for class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- DefaultSocketChannelWrapperFactory - Class in com.hazelcast.nio.tcp
-
- DefaultSocketChannelWrapperFactory() - Constructor for class com.hazelcast.nio.tcp.DefaultSocketChannelWrapperFactory
-
- DefaultTimedMemberStateFactory - Class in com.hazelcast.management
-
- DefaultTimedMemberStateFactory(HazelcastInstanceImpl) - Constructor for class com.hazelcast.management.DefaultTimedMemberStateFactory
-
- defaultURI - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- DelayedEntry<K,V> - Class in com.hazelcast.map.impl.mapstore.writebehind
-
Immutable store entry for delayed store operations.
- DelegatingFuture<V> - Class in com.hazelcast.util.executor
-
- DelegatingFuture(ICompletableFuture, SerializationService) - Constructor for class com.hazelcast.util.executor.DelegatingFuture
-
- DelegatingFuture(ICompletableFuture, SerializationService, V) - Constructor for class com.hazelcast.util.executor.DelegatingFuture
-
- delete(String, String) - Method in interface com.hazelcast.ascii.TextCommandService
-
- delete(String, String) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- delete(Object) - Method in interface com.hazelcast.core.BaseMap
-
Removes the mapping for a key from this map if it is present.
- delete(Object) - Method in interface com.hazelcast.core.IMap
-
Removes the mapping for a key from this map if it is present
(optional operation).
- delete(K) - Method in interface com.hazelcast.core.MapStore
-
Deletes the entry with a given key from the store.
- delete(K) - Method in class com.hazelcast.core.MapStoreAdapter
-
Deletes the entry with a given key from the store.
- delete(Long) - Method in interface com.hazelcast.core.QueueStore
-
Deletes the entry with a given key from the store.
- delete(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
- delete(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- DELETE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- delete(Object) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- delete(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- delete(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- delete(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- delete(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- delete() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- delete(Long) - Method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- deleteAll(String) - Method in interface com.hazelcast.ascii.TextCommandService
-
- deleteAll(String) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- deleteAll(Collection<K>) - Method in interface com.hazelcast.core.MapStore
-
Deletes multiple entries from the store.
- deleteAll(Collection<K>) - Method in class com.hazelcast.core.MapStoreAdapter
-
Deletes multiple entries from the store.
- deleteAll(Collection<Long>) - Method in interface com.hazelcast.core.QueueStore
-
Deletes multiple entries from the store.
- deleteAll(Collection) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- deleteAll(Collection<Long>) - Method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- deleteAllCacheEntry(Set<Data>) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- deleteCache(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- deleteCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deleteCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- deleteCacheEntry(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- deleteCacheStat(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deleteCacheStat(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- DeleteCommand - Class in com.hazelcast.ascii.memcache
-
- DeleteCommand(String, int, boolean) - Constructor for class com.hazelcast.ascii.memcache.DeleteCommand
-
- DeleteCommandParser - Class in com.hazelcast.ascii.memcache
-
- DeleteCommandParser() - Constructor for class com.hazelcast.ascii.memcache.DeleteCommandParser
-
- DeleteCommandProcessor - Class in com.hazelcast.ascii.memcache
-
- DeleteCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.ascii.memcache.DeleteCommandProcessor
-
- DELETED - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- DeleteOperation - Class in com.hazelcast.map.impl.operation
-
- DeleteOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
-
- DeleteOperation() - Constructor for class com.hazelcast.map.impl.operation.DeleteOperation
-
- deleteRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- delta - Variable in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- DenyAllPermissionCollection - Class in com.hazelcast.security.permission
-
- DenyAllPermissionCollection() - Constructor for class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- deregister(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- deregisterAllListener(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deregisterAllListener(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- deregisterAllListeners(String, String) - Method in interface com.hazelcast.spi.EventService
-
Deregisters all listeners belonging to the given service and topic.
- deregisterAllListeners(String, String) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- deregisterCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- deregisterListener(String, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- deregisterListener(String, String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- deregisterListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
-
Deregisters a listener with given registration id.
- deregisterListener(String, String, Object) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- destroy() - Method in interface com.hazelcast.cache.ICache
-
Closes the cache, clears the internal content and releases any resource.
- destroy() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
Destroy all managed caches.
- destroy() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- destroy() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- destroy() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Destroy is equivalent to below operations in the given order:
clear all.
close resources.
unregister all listeners.
- destroy() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- destroy() - Method in class com.hazelcast.collection.CollectionContainer
-
- destroy() - Method in interface com.hazelcast.core.DistributedObject
-
Destroys this object cluster-wide.
- destroy() - Method in interface com.hazelcast.core.MapLoaderLifecycleSupport
-
Hazelcast will call this method before shutting down.
- destroy() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- destroy() - Method in interface com.hazelcast.instance.NodeExtension
-
Destroys NodeExtension.
- destroy() - Method in class com.hazelcast.jmx.ManagementService
-
- destroy() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- destroy() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- destroy() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- destroy() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
-
- destroy() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- destroy() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- destroy() - Method in interface com.hazelcast.nio.serialization.Serializer
-
Called when instance is shutting down.
- destroy() - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook.ArrayListStreamSerializer
-
- destroy() - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook.LinkedListStreamSerializer
-
- destroy() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- destroy() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- destroy() - Method in interface com.hazelcast.security.ICredentialsFactory
-
- destroy() - Method in interface com.hazelcast.security.IPermissionPolicy
-
- DESTROY - Static variable in class com.hazelcast.security.permission.InstancePermission
-
- destroy() - Method in interface com.hazelcast.security.SecurityContext
-
- destroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- destroy() - Method in interface com.hazelcast.storage.Storage
-
- DESTROY_CACHE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- DESTROY_CACHE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- DESTROY_PROXY - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- destroyCache(String, boolean, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- destroyCache(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- destroyCache(String, boolean, String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- destroyCacheOnAllMembers(String, String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- destroyConnection(Connection) - Method in interface com.hazelcast.nio.ConnectionManager
-
- destroyConnection(Connection) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- destroyDistributedObject(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.collection.CollectionService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- destroyDistributedObject(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.map.impl.MapService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.queue.impl.QueueService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- destroyDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- destroyDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
-
- destroyDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
-
- destroyDistributedObject(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- destroyIndex(String) - Method in class com.hazelcast.query.impl.IndexService
-
- destroyJobSupervisor(JobSupervisor) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- destroyMap(String) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- destroyMap(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- destroyMapStores() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- destroyMapStores() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- destroySegments(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- didPing() - Method in class com.hazelcast.instance.MemberImpl
-
- didRead() - Method in class com.hazelcast.instance.MemberImpl
-
- didWrite() - Method in class com.hazelcast.instance.MemberImpl
-
- disable() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- dispatch(Object) - Method in interface com.hazelcast.spi.impl.BasicDispatcher
-
- dispatchEvent(Object, CacheEventListener) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- dispatchEvent(ClientEndpointImpl, ClientListener) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- dispatchEvent(MembershipEvent, MembershipListener) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- dispatchEvent(CollectionEvent, ItemListener) - Method in class com.hazelcast.collection.CollectionService
-
- dispatchEvent(EventData, EntryListener) - Method in class com.hazelcast.map.impl.MapService
-
- dispatchEvent(MapReduceNotification) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- dispatchEvent(EventData, EntryListener) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- dispatchEvent(MigrationEvent, MigrationListener) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- dispatchEvent(QueueEvent, ItemListener) - Method in class com.hazelcast.queue.impl.QueueService
-
- dispatchEvent(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- dispatchEvent(E, T) - Method in interface com.hazelcast.spi.EventPublishingService
-
- dispatchEvent(DistributedObjectEventPacket, Object) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- dispatchEvent(Object, Object) - Method in class com.hazelcast.topic.impl.TopicService
-
- disposeData(Data) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- disposeData(Data) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- DISTINCT_VALUES_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DISTINCT_VALUES_MAPPER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DISTINCT_VALUES_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- distinctValues() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation for selecting all distinct values.
This aggregation is similar to
- DistinctValuesAggregation<Key,Value,DistinctType> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined distinct value aggregation.
- DistinctValuesAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-
- distributeClear(boolean) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicationPublisher
-
- DISTRIBUTED_OBJECT_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-
- DISTRIBUTED_OBJECT_INFO - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- DistributedExecutorService - Class in com.hazelcast.executor.impl
-
- DistributedExecutorService() - Constructor for class com.hazelcast.executor.impl.DistributedExecutorService
-
- DistributedObject - Interface in com.hazelcast.core
-
Base interface for all distributed objects.
- distributedObjectCreated(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
-
Invoked when a DistributedObject is created.
- distributedObjectCreated(DistributedObjectEvent) - Method in class com.hazelcast.jmx.ManagementService
-
- distributedObjectDestroyed(DistributedObjectEvent) - Method in interface com.hazelcast.core.DistributedObjectListener
-
Invoked when a DistributedObject is destroyed.
- distributedObjectDestroyed(DistributedObjectEvent) - Method in class com.hazelcast.jmx.ManagementService
-
- DistributedObjectDestroyedException - Exception in com.hazelcast.spi.exception
-
- DistributedObjectDestroyedException(String, String) - Constructor for exception com.hazelcast.spi.exception.DistributedObjectDestroyedException
-
- DistributedObjectEvent - Class in com.hazelcast.core
-
DistributedObjectEvent is fired when a
DistributedObject
is created or destroyed cluster-wide.
- DistributedObjectEvent(DistributedObjectEvent.EventType, String, DistributedObject) - Constructor for class com.hazelcast.core.DistributedObjectEvent
-
- DistributedObjectEvent.EventType - Enum in com.hazelcast.core
-
- DistributedObjectEventPacket - Class in com.hazelcast.spi.impl
-
- DistributedObjectEventPacket() - Constructor for class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- DistributedObjectEventPacket(DistributedObjectEvent.EventType, String, String) - Constructor for class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- DistributedObjectInfo - Class in com.hazelcast.client.impl.client
-
- DistributedObjectInfo() - Constructor for class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- DistributedObjectInfo(String, String) - Constructor for class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- DistributedObjectListener - Interface in com.hazelcast.core
-
DistributedObjectListener allows to get notified when a
DistributedObject
is created or destroyed cluster-wide.
- DistributedObjectListenerRequest - Class in com.hazelcast.client.impl.client
-
- DistributedObjectListenerRequest() - Constructor for class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
-
- divideByAndCeilToInt(double, int) - Static method in class com.hazelcast.util.QuickMath
-
- divideByAndCeilToLong(double, int) - Static method in class com.hazelcast.util.QuickMath
-
- divideByAndRoundToInt(double, int) - Static method in class com.hazelcast.util.QuickMath
-
- divideByAndRoundToLong(double, int) - Static method in class com.hazelcast.util.QuickMath
-
- doActualRead(ByteBuffer) - Method in class com.hazelcast.ascii.rest.HttpPostCommand
-
- doJoin() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- doJoin() - Method in class com.hazelcast.cluster.impl.MulticastJoiner
-
- doJoin() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- doMatch(String, String, int) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- domLevel3 - Variable in class com.hazelcast.config.AbstractXmlConfigHelper
-
- done() - Method in class com.hazelcast.nio.serialization.DataAdapter
-
- doneProcessing() - Method in class com.hazelcast.partition.MigrationInfo
-
- DOUBLE_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- DOUBLE_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- DOUBLE_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
-
Double size in bytes
- DOUBLE_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- DOUBLE_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- doubleAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to calculate the double average of all supplied values.
This aggregation is similar to
- DoubleAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined average aggregation for values of type double.
- DoubleAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-
- doubleMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to find the double maximum of all supplied values.
This aggregation is similar to
- DoubleMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined maximum aggregation for values of type double.
- DoubleMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-
- doubleMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to find the double minimum of all supplied values.
This aggregation is similar to
- DoubleMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined minimum aggregation for values of type double.
- DoubleMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-
- doubleSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to calculate the double sum of all supplied values.
This aggregation is similar to
- DoubleSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined sum aggregation for values of type double.
- DoubleSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-
- drain(String) - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- drain() - Method in class com.hazelcast.jmx.SemaphoreMBean
-
- drain(int) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- DRAIN - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- DRAIN - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- DRAIN_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- DRAIN_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- DRAIN_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- DrainBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- DrainBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-
- DrainBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-
- DrainBackupOperation - Class in com.hazelcast.queue.impl.operations
-
This class stores items' id when DrainOperation run.
- DrainBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.DrainBackupOperation
-
- DrainBackupOperation(String, Set<Long>) - Constructor for class com.hazelcast.queue.impl.operations.DrainBackupOperation
-
- drainFromBackup(Set<Long>) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- DrainOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- DrainOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- DrainOperation(String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- DrainOperation - Class in com.hazelcast.queue.impl.operations
-
This class drain items according to drain condition.
- DrainOperation() - Constructor for class com.hazelcast.queue.impl.operations.DrainOperation
-
- DrainOperation(String, int) - Constructor for class com.hazelcast.queue.impl.operations.DrainOperation
-
- drainPermits() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- drainPermits() - Method in interface com.hazelcast.core.ISemaphore
-
Acquires and returns all permits that are immediately available.
- DrainRequest - Class in com.hazelcast.concurrent.semaphore.client
-
- DrainRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.DrainRequest
-
- DrainRequest(String) - Constructor for class com.hazelcast.concurrent.semaphore.client.DrainRequest
-
- DrainRequest - Class in com.hazelcast.queue.impl.client
-
- DrainRequest() - Constructor for class com.hazelcast.queue.impl.client.DrainRequest
-
- DrainRequest(String, int) - Constructor for class com.hazelcast.queue.impl.client.DrainRequest
-
- drainTo(Collection<? super E>) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- drainTo(Collection<? super E>, int) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- dumpAllThreads() - Static method in class com.hazelcast.management.ThreadDumpGenerator
-
- dumpDeadlocks() - Static method in class com.hazelcast.management.ThreadDumpGenerator
-
- duplicate() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- DuplicateInstanceNameException - Exception in com.hazelcast.core
-
Thrown when a duplicate instance name is detected.
- DuplicateInstanceNameException(String) - Constructor for exception com.hazelcast.core.DuplicateInstanceNameException
-
- DynamicByteBuffer - Class in com.hazelcast.nio
-
- DynamicByteBuffer(int, boolean) - Constructor for class com.hazelcast.nio.DynamicByteBuffer
-
- DynamicByteBuffer(byte[]) - Constructor for class com.hazelcast.nio.DynamicByteBuffer
-
- DynamicByteBuffer(byte[], int, int) - Constructor for class com.hazelcast.nio.DynamicByteBuffer
-
- DynamicByteBuffer(ByteBuffer) - Constructor for class com.hazelcast.nio.DynamicByteBuffer
-
- GCStatsSupport - Class in com.hazelcast.memory
-
Used to gather garbage collection statistics
- generate(Config) - Method in class com.hazelcast.config.ConfigXmlGenerator
-
Generates the XML string based on some Config.
- GENERIC_ERROR - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- GENERIC_OPERATION_THREAD_COUNT - Variable in class com.hazelcast.instance.GroupProperties
-
- GenericClientExceptionConverter - Class in com.hazelcast.client.impl.exceptionconverters
-
- GenericClientExceptionConverter() - Constructor for class com.hazelcast.client.impl.exceptionconverters.GenericClientExceptionConverter
-
- GenericError - Class in com.hazelcast.client.impl.client
-
- GenericError() - Constructor for class com.hazelcast.client.impl.client.GenericError
-
- GenericError(String, String, int) - Constructor for class com.hazelcast.client.impl.client.GenericError
-
- GenericError(String, String, String, int) - Constructor for class com.hazelcast.client.impl.client.GenericError
-
- get(String, String) - Method in interface com.hazelcast.ascii.TextCommandService
-
- get(String, String) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- get(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Gets a key with custom expiry policy.
- get(Data, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- GET - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- get() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorResult
-
- GET - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- get(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- get - Variable in class com.hazelcast.cache.impl.client.CachePutRequest
-
- get(Data, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets the value to which the specified key is mapped,
or null
if this cache contains no mapping for the key.
- get(ClientType) - Static method in class com.hazelcast.client.impl.exceptionconverters.ClientExceptionConverters
-
- get(int) - Method in class com.hazelcast.collection.list.ListContainer
-
- get(int) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- GET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- get() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- get() - Method in class com.hazelcast.concurrent.atomiclong.LongWrapper
-
- GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- get() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- get() - Method in class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
-
- get(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
- get(Object) - Method in interface com.hazelcast.core.BaseMap
-
Returns the value for the specified key, or null
if this map does not contain this key.
- get(K) - Method in interface com.hazelcast.core.BaseMultiMap
-
Returns the collection of values associated with the key.
- get() - Method in interface com.hazelcast.core.IAtomicLong
-
Gets the current value.
- get() - Method in interface com.hazelcast.core.IAtomicReference
-
Gets the current value.
- get(Object) - Method in interface com.hazelcast.core.IMap
-
Returns the value for the specified key, or null
if this map does not contain this key.
- get(K) - Method in interface com.hazelcast.core.MultiMap
-
Returns the collection of values associated with the key.
- get(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
- get(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
-
Returns the collection of values associated with the key.
- get(Data, boolean) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- GET - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- GET - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- get(E) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Gets item.
- get(Data) - Method in class com.hazelcast.map.impl.NearCache
-
- get(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- get(Data, boolean) - Method in interface com.hazelcast.map.impl.RecordStore
-
- get(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- get(long, TimeUnit) - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- GET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- GET - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- get(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- get(K) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- get() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- get(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- get(byte[]) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- get(byte[], int, int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
-
- get(String) - Method in class com.hazelcast.osgi.OSGiScriptEngine
-
- get(String) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- get(String) - Method in class com.hazelcast.query.EntryObject
-
- GET - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- get(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- get(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- get(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- get(int) - Method in interface com.hazelcast.security.Parameters
-
- get() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- get(int, REF) - Method in interface com.hazelcast.storage.Storage
-
- get(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns the value to which the specified key is mapped,
or null
if this map contains no mapping for the key.
- get() - Method in class com.hazelcast.util.executor.CompletedFuture
-
- get(long, TimeUnit) - Method in class com.hazelcast.util.executor.CompletedFuture
-
- get() - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- get(long, TimeUnit) - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- get(K) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
- GET_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_ALL - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- GET_ALL - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- GET_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- GET_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- GET_ALL_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_AND_ADD - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- GET_AND_ALTER - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- GET_AND_ALTER - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- GET_AND_REMOVE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_AND_REMOVE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- GET_AND_REPLACE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_AND_REPLACE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- GET_AND_SET - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- GET_AND_SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- GET_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- GET_CONFIG - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- GET_COUNT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- GET_DISTRIBUTED_OBJECT_INFO - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- GET_ENTRY_VIEW - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- GET_LOCAL_MAP_STATS - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- GET_LOCK_COUNT - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- GET_LOCK_COUNT - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- GET_PARTITIONS - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- GET_REMAINING_LEASE - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- GET_REMAINING_LEASETIME - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- GET_RESPONSE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- GET_RESULT_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- getAccessKey() - Method in class com.hazelcast.config.AwsConfig
-
Gets the access key to access AWS.
- getAcquireTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getActions() - Method in class com.hazelcast.config.PermissionConfig
-
- getActions() - Method in class com.hazelcast.security.permission.AllPermissions
-
- getActions() - Method in class com.hazelcast.security.permission.InstancePermission
-
- getActions() - Method in class com.hazelcast.security.permission.TransactionPermission
-
- getActiveConnectionCount() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
-
- getActiveConnectionCount() - Method in class com.hazelcast.management.SerializableConnectionManagerBean
-
- getActiveConnectionCount() - Method in interface com.hazelcast.nio.ConnectionManager
-
- getActiveConnectionCount() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getActiveMigrations() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getActiveMigrations() - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getActivePartitionCount() - Method in class com.hazelcast.jmx.PartitionServiceMBean
-
- getActivePartitionCount() - Method in class com.hazelcast.management.SerializablePartitionServiceBean
-
- getActualDelayMillis() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- getActualDelaySeconds() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- getAddress() - Method in class com.hazelcast.cluster.impl.JoinMessage
-
- getAddress() - Method in class com.hazelcast.cluster.MemberInfo
-
- getAddress() - Method in class com.hazelcast.instance.MemberImpl
-
- getAddress() - Method in class com.hazelcast.management.ManagementCenterIdentifier
-
- getAddress() - Method in class com.hazelcast.management.SerializableClientEndPoint
-
- getAddress() - Method in class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-
- getAddress() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getAddress() - Method in interface com.hazelcast.monitor.MemberState
-
- getAddress() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
-
- getAddress() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- getAddressHolder(String) - Static method in class com.hazelcast.util.AddressUtil
-
- getAddressHolder(String, int) - Static method in class com.hazelcast.util.AddressUtil
-
- getAddressMatcher(String) - Static method in class com.hazelcast.util.AddressUtil
-
Gets an AddressMatcher for a given addresses.
- getAdjustedTTLSeconds(int) - Method in interface com.hazelcast.ascii.TextCommandService
-
- getAdjustedTTLSeconds(int) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- getAlgorithm() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- getAll(Set<? extends K>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
getAll operation with custom expiry policy.
- getAll(Set<Data>, ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAll(Set<? extends K>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getAll(Set<Data>, ExpiryPolicy) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets a collection of entries from the store, returning them as
Map
of the values associated with the set of keys requested.
- getAll() - Method in class com.hazelcast.collection.CollectionContainer
-
- getAll(Set<K>) - Method in interface com.hazelcast.core.IMap
-
Returns the entries for the given keys.
- getAll(Set<Data>) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getAll(Set<K>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- getAll(Set<Data>) - Method in interface com.hazelcast.map.impl.RecordStore
-
- getAllDistributedObjects() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- getAllDistributedObjects() - Method in interface com.hazelcast.spi.ProxyService
-
- getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
-
Returns all active/running HazelcastInstances on this JVM.
- getAllHazelcastInstances() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-
- getAllInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- getAllKeys() - Method in class com.hazelcast.mapreduce.KeyValueSource
-
- getAllKeys0() - Method in class com.hazelcast.mapreduce.KeyValueSource
-
This method is meant for overriding to implement collecting of all clusterwide available keys
and returning them from
KeyValueSource.getAllKeys()
.
- getAllLocks() - Method in interface com.hazelcast.concurrent.lock.LockService
-
- getAllLocks() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- getAllocatorType() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- GetAllOperation - Class in com.hazelcast.map.impl.operation
-
- GetAllOperation(String, Set<Data>) - Constructor for class com.hazelcast.map.impl.operation.GetAllOperation
-
- GetAllOperation() - Constructor for class com.hazelcast.map.impl.operation.GetAllOperation
-
- GetAllOperation - Class in com.hazelcast.multimap.impl.operations
-
- GetAllOperation() - Constructor for class com.hazelcast.multimap.impl.operations.GetAllOperation
-
- GetAllOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.GetAllOperation
-
- GetAllRequest - Class in com.hazelcast.multimap.impl.client
-
- GetAllRequest() - Constructor for class com.hazelcast.multimap.impl.client.GetAllRequest
-
- GetAllRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.GetAllRequest
-
- GetAllRequest(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.client.GetAllRequest
-
- getAllTextConnections() - Method in interface com.hazelcast.nio.ConnectionManager
-
- getAllTextConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getAllThreads() - Static method in class com.hazelcast.management.ThreadDumpGenerator
-
- getAnchor() - Method in class com.hazelcast.query.PagingPredicate
-
Retrieve the anchor object which is the last value object on the previous page.
- getAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndAdd(long) - Method in class com.hazelcast.concurrent.atomiclong.LongWrapper
-
- getAndAdd(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically adds the given value to the current value.
- getAndAdd(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- GetAndAddOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- GetAndAddOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- GetAndAddOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- GetAndAddRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- GetAndAddRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-
- GetAndAddRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-
- getAndAlter(IFunction<Long, Long>) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndAlter(IFunction<E, E>) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getAndAlter(IFunction<Long, Long>) - Method in interface com.hazelcast.core.IAtomicLong
-
Alters the currently stored value by applying a function on it on and gets the old value.
- getAndAlter(IFunction<E, E>) - Method in interface com.hazelcast.core.IAtomicReference
-
Alters the currently stored reference by applying a function on it on and gets the old value.
- GetAndAlterOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- GetAndAlterOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-
- GetAndAlterOperation(String, IFunction<Long, Long>) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-
- GetAndAlterOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- GetAndAlterOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-
- GetAndAlterOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-
- GetAndAlterRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- GetAndAlterRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-
- GetAndAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-
- GetAndAlterRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- GetAndAlterRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-
- GetAndAlterRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-
- getAndIncrement() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndIncrement() - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically increments the current value by one.
- getAndIncrement() - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- getAndPut(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
getAndPut operation with custom expiry policy.
- getAndPut(Data, Object, ExpiryPolicy, String, boolean, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndPut(Data, Object, ExpiryPolicy, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndPut(Data, Object, ExpiryPolicy, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndPut(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getAndPut(Data, Object, ExpiryPolicy, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Associates the specified value with the specified key in this cache,
returning an existing value if one existed.
- getAndPutAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in this cache,
returning an existing value if one existed.
- getAndPutAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in this cache,
returning an existing value if one existed using a custom expiry policy.
- getAndRemove(Data, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndRemove(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getAndRemove(Data, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Atomically removes the entry for a key only if it is currently mapped to some
value.
- getAndRemoveAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the entry for a key returning the removed value if one existed.
- getAndReplace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
getAndReplace operation with custom expiry policy.
- getAndReplace(Data, Object, ExpiryPolicy, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getAndReplace(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getAndReplace(Data, Object, ExpiryPolicy, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Atomically replaces the value for a given key if and only if there is a
value currently mapped by the key.
- getAndReplaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the entry for a key only if it is currently mapped to some value.
- getAndReplaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the entry for a key only if it is currently mapped to some value
using custom expiry policy.
- getAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getAndSet(long) - Method in class com.hazelcast.concurrent.atomiclong.LongWrapper
-
- getAndSet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getAndSet(Data) - Method in class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
-
- getAndSet(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically sets the given value and returns the old value.
- getAndSet(E) - Method in interface com.hazelcast.core.IAtomicReference
-
Gets the value and sets the new value.
- getAndSet(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- GetAndSetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- GetAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- GetAndSetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- GetAndSetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- GetAndSetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- GetAndSetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- GetAndSetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- GetAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-
- GetAndSetRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-
- GetAndSetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- GetAndSetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-
- GetAndSetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-
- getArray(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getArray(JsonObject, String, JsonArray) - Static method in class com.hazelcast.util.JsonUtil
-
- getAsDataList() - Method in class com.hazelcast.queue.impl.QueueContainer
-
This method triggers store load.
- getAsReadOnly() - Method in class com.hazelcast.config.CacheConfig
-
Immutable CacheConfig instance
- getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.CollectionConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.EntryListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ExecutorConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ItemListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.JobTrackerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ListConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ListenerConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MapConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MapIndexConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MapStoreConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MaxSizeConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.MultiMapConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.NearCacheConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.QueueConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.SemaphoreConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.SetConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.TopicConfig
-
- getAsReadOnly() - Method in class com.hazelcast.config.WanReplicationRef
-
- getAssignment() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-
- getAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously gets an entry from cache.
- getAsync(K, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously gets an entry from cache with a provided expiry policy.
- getAsync(K) - Method in interface com.hazelcast.core.IMap
-
Asynchronously gets the given key.
- getAsync(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.collection.CollectionBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getAsyncBackupCount() - Method in interface com.hazelcast.concurrent.lock.LockStoreInfo
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- getAsyncBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
- getAsyncBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getAsyncBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
- getAsyncBackupCount() - Method in class com.hazelcast.config.MapConfig
-
- getAsyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
- getAsyncBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
- getAsyncBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
-
Returns the number of asynchronous backups.
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- getAsyncBackupCount() - Method in class com.hazelcast.queue.impl.operations.QueueBackupAwareOperation
-
- getAsyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
-
The asynchronous backup count.
- getAsyncExecutor() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- getAsyncExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getAtomicLong(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates cluster-wide atomic long.
- getAtomicLong(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getAtomicLong(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getAtomicNumber() - Method in class com.hazelcast.console.ConsoleApp
-
- getAtomicReference(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates cluster-wide atomic reference.
- getAtomicReference(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getAtomicReference(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getAttribute(Node, String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getAttribute() - Method in class com.hazelcast.config.MapIndexConfig
-
Gets the attribute that is going to be indexed.
- getAttribute(String) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- getAttribute(String) - Method in interface com.hazelcast.query.impl.QueryableEntry
-
- getAttribute(String) - Method in class com.hazelcast.query.impl.QueryEntry
-
- getAttribute() - Method in class com.hazelcast.query.PredicateBuilder
-
- getAttributeName() - Method in interface com.hazelcast.query.impl.Index
-
- getAttributeName() - Method in class com.hazelcast.query.impl.IndexImpl
-
- getAttributes() - Method in class com.hazelcast.cluster.impl.JoinRequest
-
- getAttributes() - Method in class com.hazelcast.cluster.MemberInfo
-
- getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getAttributes() - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- getAttributes() - Method in interface com.hazelcast.core.Member
-
Returns configured attributes for this member.
This method might not be available on all native clients.
- getAttributes() - Method in class com.hazelcast.instance.MemberImpl
-
- getAttributes(String[]) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- getAttributeType(String) - Method in interface com.hazelcast.query.impl.QueryableEntry
-
- getAttributeType(String) - Method in class com.hazelcast.query.impl.QueryEntry
-
- getAttributeType(Class) - Static method in class com.hazelcast.query.impl.ReflectionHelper
-
- getAttributeType(Object, String) - Static method in class com.hazelcast.query.impl.ReflectionHelper
-
- getAvailable() - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- getAvailable() - Method in class com.hazelcast.jmx.SemaphoreMBean
-
- getAverageGetTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute gets.
- getAverageGetTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getAverageGetTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getAverageGetTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getAverageGetTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
The mean time to execute gets
- getAveragePutTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute puts.
- getAveragePutTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getAveragePutTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getAveragePutTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getAveragePutTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
The mean time to execute puts
- getAverageRemoveTime() - Method in interface com.hazelcast.cache.CacheStatistics
-
The mean time to execute removes.
- getAverageRemoveTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getAverageRemoveTime() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getAverageRemoveTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getAverageRemoveTime() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
The mean time to execute removes
- getAvgAge() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getAvgAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the average age of the items in this member.
- getAwaitCount(Data, String) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
-
- getBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getBackupCount() - Method in interface com.hazelcast.concurrent.lock.LockStoreInfo
-
- getBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
- getBackupCount() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
- getBackupCount() - Method in class com.hazelcast.config.MapConfig
-
- getBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
- getBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
- getBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
-
Returns the number of synchronous backups.
- getBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
-
- getBackupCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getBackupCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getBackupCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of backups per entry.
- getBackupCount() - Method in class com.hazelcast.spi.impl.NormalResponse
-
- getBackupEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getBackupEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getBackupEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of backup entries hold by this member.
- getBackupEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getBackupEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getBackupEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns memory cost (number of bytes) of backup entries in this member.
- getBackupItemCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getBackupItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the number of backup items in this member.
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.CollectionAddAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.CollectionAddOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.CollectionClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.CollectionCompareAndRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.CollectionRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.list.ListAddOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.list.ListRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.list.ListSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.txn.CollectionPrepareOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.txn.CollectionRollbackOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.txn.CollectionTxnAddOperation
-
- getBackupOperation() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- getBackupOperation() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- getBackupOperation() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.operations.ClearOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.operations.DrainOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.tx.TxnPrepareOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- getBackupOperation() - Method in class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- getBackupOperation() - Method in interface com.hazelcast.spi.BackupAwareOperation
-
- getBackupProcessor() - Method in class com.hazelcast.map.AbstractEntryProcessor
-
- getBackupProcessor() - Method in interface com.hazelcast.map.EntryProcessor
-
Get the entry processor to be applied to backup entries.
- getBaseName(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- getBindAddress() - Method in interface com.hazelcast.instance.AddressPicker
-
- getBindings(int) - Method in class com.hazelcast.osgi.OSGiScriptEngine
-
- getBindings() - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- getBoolean() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getBoolean(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getBoolean(JsonObject, String, boolean) - Static method in class com.hazelcast.util.JsonUtil
-
- getBooleanAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getBooleanAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getBooleanAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getBranchQualifier() - Method in class com.hazelcast.transaction.impl.SerializableXID
-
- getBuild() - Method in class com.hazelcast.instance.BuildInfo
-
- getBuild() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getBuildInfo() - Static method in class com.hazelcast.instance.BuildInfoProvider
-
- getBuildInfo() - Method in class com.hazelcast.instance.Node
-
- getBuildNumber() - Method in class com.hazelcast.cluster.impl.JoinMessage
-
- getBuildNumber() - Method in class com.hazelcast.instance.BuildInfo
-
- getBuiltinDefinitions() - Method in class com.hazelcast.cache.impl.CachePortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.client.impl.client.ClientPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.collection.CollectionPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownLatchPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphorePortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.executor.impl.ExecutorPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.map.impl.MapPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- getBuiltinDefinitions() - Method in interface com.hazelcast.nio.serialization.PortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.partition.PartitionPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.queue.impl.QueuePortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.topic.impl.TopicPortableHook
-
- getBuiltinDefinitions() - Method in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- getBulkLoad() - Method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- getByte() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getByteArray(String, String) - Method in interface com.hazelcast.ascii.TextCommandService
-
- getByteArray(String, String) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- getByteAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getByteAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getByteAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getByteOrder() - Method in class com.hazelcast.config.SerializationConfig
-
Note that result of useNativeByteOrder is not reflected to return value of this method.
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- getByteOrder() - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- getByteOrder() - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
-
- getByteOrder() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- getByteOrder() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
-
- getByteOrder() - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- getByteOrder() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- getByteOrder() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- getBytes() - Method in class com.hazelcast.ascii.memcache.MemcacheEntry
-
- getBytes() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getByType(int) - Static method in enum com.hazelcast.cache.impl.CacheEventType
-
- getByType(int) - Static method in enum com.hazelcast.core.EntryEventType
-
- getByType(int) - Static method in enum com.hazelcast.core.ItemEventType
-
- getByType(int) - Static method in enum com.hazelcast.map.impl.client.AbstractTxnMapRequest.TxnMapRequestType
-
- getByValue(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-
- getCache(String, Class<K>, Class<V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCache(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCache(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- getCacheConfig(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheConfig(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getCacheConfig(String) - Method in class com.hazelcast.config.Config
-
- getCacheConfigFromPartition(String, String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheConfigFromPartition(String, String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- getCacheConfigLocal(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheConfigLocal(String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- getCacheConfigs() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheConfigs() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- getCacheConfigs() - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getCacheConfigs() - Method in class com.hazelcast.config.Config
-
- getCachedValue() - Method in interface com.hazelcast.map.impl.record.Record
-
- getCacheEntryEventFilterFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getCacheEntryListenerConfigurations() - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- getCacheEntryListenerFactory() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getCacheEntryListeners() - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- getCacheEventType() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets cache event type of this event data.
- getCacheEventType() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getCacheEvictions() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of evictions from the cache.
- getCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheEvictions() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheEvictions() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheEvictions() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
- getCacheExpiries() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
The total number of expiries from the cache.
- getCacheGets() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of requests to the cache.
- getCacheGets() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheGets() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheGets() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheGets() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
- getCacheGetTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheHitPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
-
This is a measure of cache efficiency.
- getCacheHitPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheHitPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheHitPercentage() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheHitPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
- getCacheHits() - Method in interface com.hazelcast.cache.CacheStatistics
-
The number of get requests that were satisfied by the cache.
- getCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheHits() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheHits() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheHits() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
- getCacheLoaderFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getCacheManager(URI, ClassLoader, Properties) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getCacheManager(URI, ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getCacheManager() - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getCacheMisses() - Method in interface com.hazelcast.cache.CacheStatistics
-
A miss is a get request that is not satisfied.
- getCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheMisses() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheMisses() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheMisses() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
- getCacheMissPercentage() - Method in interface com.hazelcast.cache.CacheStatistics
-
Returns the percentage of cache accesses that did not find a requested entry
in the cache.
- getCacheMissPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheMissPercentage() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheMissPercentage() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheMissPercentage() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
- getCacheNames() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheNameWithPrefix(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheOperationProvider(String, InMemoryFormat) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheOperationProvider(String, InMemoryFormat) - Method in interface com.hazelcast.cache.impl.ICacheService
-
Creates cache operations according to the storage-type of the cache
- getCachePuts() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of puts to the cache.
- getCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCachePuts() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCachePuts() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCachePuts() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
- getCachePutTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheRecordStore(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getCacheRecordStore(String, int) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getCacheRemovals() - Method in interface com.hazelcast.cache.CacheStatistics
-
The total number of removals from the cache.
- getCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheRemovals() - Method in class com.hazelcast.cache.impl.CacheStatisticsMXBeanImpl
-
- getCacheRemovals() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCacheRemovals() - Method in interface com.hazelcast.monitor.LocalCacheStats
-
- getCacheRemoveTimeTakenNanos() - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- getCacheStats() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getCacheStats() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets the Cache statistics associated with this
CacheService
.
- getCacheUnchecked(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCacheWriterFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getCachingProvider() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getCallback() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getCaller() - Method in interface com.hazelcast.map.impl.EventData
-
- getCallerAddress() - Method in interface com.hazelcast.spi.impl.RemotePropagatable
-
- getCallerAddress() - Method in class com.hazelcast.spi.Operation
-
- getCallerUuid() - Method in class com.hazelcast.spi.Operation
-
- getCallerUuid() - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- getCallId() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getCallId() - Method in class com.hazelcast.client.impl.client.ClientResponse
-
- getCallId() - Method in interface com.hazelcast.spi.impl.RemotePropagatable
-
- getCallId() - Method in class com.hazelcast.spi.impl.Response
-
Returns the call id of the operation this response belongs to.
- getCallId() - Method in class com.hazelcast.spi.Operation
-
- getCallTimeout() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getCallTimeout() - Method in class com.hazelcast.spi.Operation
-
- getCancelledTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getCancelledTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
-
Returns the number of cancelled operations of the executor service
- getChar() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getChar(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getChunk() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- getChunk() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- getChunkSize() - Method in class com.hazelcast.config.JobTrackerConfig
-
- getChunkSize() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getChunkSize() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- getClassDefinitions() - Method in class com.hazelcast.config.SerializationConfig
-
- getClassDefinitions(Data) - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- getClassId() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- getClassId() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-
- getClassId() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-
- getClassId() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- getClassId() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-
- getClassId() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- getClassId() - Method in class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
-
- getClassId() - Method in class com.hazelcast.client.impl.client.GenericError
-
- getClassId() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-
- getClassId() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-
- getClassId() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-
- getClassId() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-
- getClassId() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionAddAllRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionAddRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionClearRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionContainsRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionGetAllRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionIsEmptyRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionRemoveRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.CollectionSizeRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.ListAddAllRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.ListAddRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.ListGetRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.ListIndexOfRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.ListRemoveRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.ListSetRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.ListSubRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.TxnListAddRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.TxnListRemoveRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.TxnListSizeRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.TxnSetAddRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.TxnSetRemoveRequest
-
- getClassId() - Method in class com.hazelcast.collection.client.TxnSetSizeRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomiclong.client.SetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.GetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.atomicreference.client.SetRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.InitRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-
- getClassId() - Method in class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-
- getClassId() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-
- getClassId() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-
- getClassId() - Method in class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- getClassId() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-
- getClassId() - Method in class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapPutTransientRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapReplaceRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapSetRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapSQLQueryRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.TxnMapRequest
-
- getClassId() - Method in class com.hazelcast.map.impl.client.TxnMapRequestWithSQLQuery
-
- getClassId() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-
- getClassId() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-
- getClassId() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- getClassId() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.CountRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.EntrySetRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.KeySetRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.SizeRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapGetRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapSizeRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapValueCountRequest
-
- getClassId() - Method in class com.hazelcast.multimap.impl.client.ValuesRequest
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getClassId() - Method in interface com.hazelcast.nio.serialization.Portable
-
Returns class identifier for this portable class.
- getClassId() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.AddAllRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.ClearRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.ContainsRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.DrainRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.IsEmptyRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.IteratorRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.OfferRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.PeekRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.PollRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.RemainingCapacityRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.RemoveListenerRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.RemoveRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.SizeRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.TxnOfferRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.TxnPeekRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.TxnPollRequest
-
- getClassId() - Method in class com.hazelcast.queue.impl.client.TxnSizeRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntrySet
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapGetResponse
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeySet
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getClassId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-
- getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableCollection
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getClassId() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- getClassId() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- getClassId() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-
- getClassId() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getClassId() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- getClassId() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-
- getClassId() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-
- getClassId() - Method in class com.hazelcast.transaction.client.PrepareTransactionRequest
-
- getClassId() - Method in class com.hazelcast.transaction.client.RecoverAllTransactionsRequest
-
- getClassId() - Method in class com.hazelcast.transaction.client.RecoverTransactionRequest
-
- getClassId() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-
- getClassLoader() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getClassLoader() - Method in class com.hazelcast.config.Config
-
Returns the class-loader that will be used in serialization.
- getClassLoader() - Method in interface com.hazelcast.nio.ObjectDataInput
-
Returns class loader that internally used for objects
- getClassLoader() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- getClassLoader() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- getClassLoader() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- getClassName() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- getClassName() - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- getClassName() - Method in class com.hazelcast.config.ListenerConfig
-
Returns the name of the class of the EventListener.
- getClassName() - Method in class com.hazelcast.config.LoginModuleConfig
-
- getClassName() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the name of the MapStore implementation class
- getClassName() - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- getClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getClassName() - Method in class com.hazelcast.config.SecurityInterceptorConfig
-
- getClassName() - Method in class com.hazelcast.config.SerializerConfig
-
- getClassName() - Method in class com.hazelcast.config.ServiceConfig
-
- getClassName() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
- getClassVersion() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
Version for internal requests.
- getClassVersion(int, int) - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- getClassVersion() - Method in interface com.hazelcast.nio.serialization.VersionedPortable
-
Returns version for this Portable class
- getClientConnectionCount() - Method in class com.hazelcast.management.SerializableConnectionManagerBean
-
- getClientEndpointCount() - Method in interface com.hazelcast.client.ClientEngine
-
- getClientEndpointCount() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClientEndpointCount() - Method in class com.hazelcast.jmx.ClientEngineMBean
-
- getClientEngine() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getClientEngineMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getClientExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getClientLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientPermissionConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getClientPolicyConfig() - Method in class com.hazelcast.config.SecurityConfig
-
- getClients() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClients() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getClients() - Method in interface com.hazelcast.monitor.MemberState
-
- getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the client service of this Hazelcast instance.
- getClientService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getClientService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getClientType() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getClientType() - Method in interface com.hazelcast.core.Client
-
Returns type of this client
- getClientType() - Method in class com.hazelcast.management.SerializableClientEndPoint
-
- getCluster() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the Cluster that this Hazelcast instance is part of.
- getCluster() - Method in class com.hazelcast.core.InitialMembershipEvent
-
Returns the cluster of the event.
- getCluster() - Method in class com.hazelcast.core.MembershipEvent
-
Returns the cluster of the event.
- getCluster() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getCluster() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getClusterName() - Method in class com.hazelcast.management.ManagementCenterIdentifier
-
- getClusterName() - Method in class com.hazelcast.monitor.TimedMemberState
-
- getClusterProxy() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getClusterService() - Method in interface com.hazelcast.client.ClientEngine
-
- getClusterService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getClusterService() - Method in class com.hazelcast.instance.Node
-
- getClusterService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getClusterService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getClusterTime() - Method in interface com.hazelcast.cluster.ClusterService
-
Returns the cluster-time.
- getClusterTime() - Method in class com.hazelcast.cluster.impl.ClusterProxy
-
- getClusterTime() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getClusterTime() - Method in interface com.hazelcast.core.Cluster
-
Returns the cluster-wide time in milliseconds.
- getClusterTime() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getClusterTime() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getClusterTimeFor(long) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getCmdGet() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getCmdSet() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getCmdTouch() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getCollator() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
-
Returns a Collator implementation used in this aggregation
- getCollator() - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-
- getCollator() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-
- getCollected() - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-
- getCollection() - Method in class com.hazelcast.collection.CollectionContainer
-
- getCollection() - Method in class com.hazelcast.collection.list.ListContainer
-
- getCollection() - Method in class com.hazelcast.collection.set.SetContainer
-
- getCollection() - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- getCollection() - Method in class com.hazelcast.collection.txn.TransactionalListProxy
-
- getCollection() - Method in class com.hazelcast.collection.txn.TransactionalSetProxy
-
- getCollection(boolean) - Method in class com.hazelcast.multimap.impl.MultiMapWrapper
-
- getCollection() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- getCollection() - Method in class com.hazelcast.spi.impl.PortableCollection
-
- getCollection() - Method in class com.hazelcast.spi.impl.SerializableCollection
-
- getCollectionContainer(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-
- getCollectionWrapper() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- getCombinerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
-
Returns the CombinerFactory for this aggregation to pre-reduce values on mapping
nodes.
- getCombinerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-
- getCombinerFactory() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- GetCommand - Class in com.hazelcast.ascii.memcache
-
- GetCommand(TextCommandConstants.TextCommandType, String) - Constructor for class com.hazelcast.ascii.memcache.GetCommand
-
- GetCommand(String) - Constructor for class com.hazelcast.ascii.memcache.GetCommand
-
- getCommandHandler() - Method in class com.hazelcast.management.ManagementCenterService
-
- GetCommandParser - Class in com.hazelcast.ascii.memcache
-
- GetCommandParser() - Constructor for class com.hazelcast.ascii.memcache.GetCommandParser
-
- GetCommandProcessor - Class in com.hazelcast.ascii.memcache
-
- GetCommandProcessor(TextCommandService, boolean) - Constructor for class com.hazelcast.ascii.memcache.GetCommandProcessor
-
- getCommittedHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getCommittedHeap() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getCommittedNativeMemory() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getCommittedNativeMemory() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getComparator() - Method in class com.hazelcast.query.PagingPredicate
-
- getCompletableFuture() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- getCompletableFuture() - Method in interface com.hazelcast.mapreduce.TrackableJob
-
Returns the
ICompletableFuture
to add callbacks
or wait for the resulting value of the tracked job
- getCompletedMigrations() - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- getCompletedTaskCount() - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- getCompletedTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getCompletedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
-
Returns the number of completed operations of the executor service
- getCompletedTaskCount() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- getCompletedTaskCount() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-
- getCompletionId() - Method in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- getCompletionId() - Method in interface com.hazelcast.cache.impl.operation.MutableOperation
-
- getConcurrencyLevel() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getConditionId() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-
- getConfig() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getConfig() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets the configuration of the cache that this store belongs to.
- getConfig() - Method in interface com.hazelcast.client.ClientEngine
-
- getConfig() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- getConfig() - Method in class com.hazelcast.collection.CollectionContainer
-
- getConfig() - Method in class com.hazelcast.collection.list.ListContainer
-
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- getConfig() - Method in class com.hazelcast.collection.set.SetContainer
-
- getConfig(NodeEngine) - Method in class com.hazelcast.collection.set.SetProxyImpl
-
- getConfig() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the configuration of this Hazelcast instance.
- getConfig() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getConfig() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getConfig() - Method in class com.hazelcast.instance.Node
-
- getConfig() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getConfig() - Method in class com.hazelcast.jmx.MapMBean
-
- getConfig() - Method in class com.hazelcast.jmx.QueueMBean
-
- getConfig() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getConfig() - Method in class com.hazelcast.jmx.TopicMBean
-
- getConfig() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- getConfig() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getConfig() - Method in interface com.hazelcast.spi.NodeEngine
-
- getConfigCheck() - Method in class com.hazelcast.cluster.impl.JoinMessage
-
- getConfigClassLoader() - Method in class com.hazelcast.instance.Node
-
- getConfigClassLoader() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getConfigClassLoader() - Method in interface com.hazelcast.spi.NodeEngine
-
- getConfigObject() - Method in class com.hazelcast.config.ServiceConfig
-
- getConfigSource() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getConfiguration(Class<C>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getConfiguration() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getConfigurationFile() - Method in class com.hazelcast.config.Config
-
- getConfigurationFile() - Method in class com.hazelcast.config.XmlConfigLocator
-
- getConfigurationMembers(Config) - Static method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- getConfigurationUrl() - Method in class com.hazelcast.config.Config
-
- getConfigurationUrl() - Method in class com.hazelcast.config.XmlConfigLocator
-
- getConn() - Method in class com.hazelcast.nio.Packet
-
Gets the Connection this Packet was send with.
- getConnectedClients() - Method in class com.hazelcast.client.impl.ClientServiceProxy
-
- getConnectedClients() - Method in interface com.hazelcast.core.ClientService
-
Returns all connected clients to this member.
- getConnection() - Method in interface com.hazelcast.client.ClientEndpoint
-
- getConnection() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getConnection(Address) - Method in interface com.hazelcast.nio.ConnectionManager
-
- getConnection(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getConnection() - Method in interface com.hazelcast.spi.impl.RemotePropagatable
-
- getConnection() - Method in class com.hazelcast.spi.Operation
-
- getConnectionCount() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
-
- getConnectionCount() - Method in class com.hazelcast.management.SerializableConnectionManagerBean
-
- getConnectionCount() - Method in interface com.hazelcast.nio.ConnectionManager
-
- getConnectionCount() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getConnectionId() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getConnectionListener() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getConnectionManager() - Method in class com.hazelcast.instance.Node
-
- getConnectionManager() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
-
- getConnectionManager() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getConnectionManagerBean() - Method in class com.hazelcast.management.SerializableMXBeans
-
- getConnectionManagerMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getConnectionMonitorInterval() - Method in interface com.hazelcast.nio.IOService
-
- getConnectionMonitorInterval() - Method in class com.hazelcast.nio.NodeIOService
-
- getConnectionMonitorMaxFaults() - Method in interface com.hazelcast.nio.IOService
-
- getConnectionMonitorMaxFaults() - Method in class com.hazelcast.nio.NodeIOService
-
- getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.AwsConfig
-
Gets the connection timeout in seconds.
- getConnectionTimeoutSeconds() - Method in class com.hazelcast.config.TcpIpConfig
-
Returns the connection timeout.
- getConnTimeoutSeconds() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- getContainerMap() - Method in class com.hazelcast.collection.CollectionService
-
- getContainerMap() - Method in class com.hazelcast.collection.list.ListService
-
- getContainerMap() - Method in class com.hazelcast.collection.set.SetService
-
- getContentType() - Method in class com.hazelcast.ascii.rest.HttpPostCommand
-
- getContentType() - Method in class com.hazelcast.ascii.rest.RestValue
-
- getContext() - Method in class com.hazelcast.osgi.OSGiScriptEngine
-
- getConverter() - Method in enum com.hazelcast.query.impl.AttributeType
-
- getCost() - Method in interface com.hazelcast.core.EntryView
-
Returns the cost (in bytes) of the entry.
- getCost() - Method in class com.hazelcast.map.impl.NearCache.CacheRecord
-
- getCost() - Method in interface com.hazelcast.map.impl.record.Record
-
- getCost() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getCost(T) - Method in interface com.hazelcast.map.impl.SizeEstimator
-
- getCount() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- getCount() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- getCount() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- getCount(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- getCount() - Method in interface com.hazelcast.core.ICountDownLatch
-
Returns the current count.
- getCount() - Method in class com.hazelcast.jmx.CountDownLatchMBean
-
- getCountDownLatch(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates cluster-wide CountDownLatch.
- getCountDownLatch(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getCountDownLatch(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- GetCountOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- GetCountOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- GetCountOperation(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- GetCountRequest - Class in com.hazelcast.concurrent.countdownlatch.client
-
- GetCountRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- GetCountRequest(String) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- getCreationTime() - Method in class com.hazelcast.collection.CollectionItem
-
- getCreationTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the creation time of the entry.
- getCreationTime() - Method in interface com.hazelcast.map.impl.record.Record
-
- getCreationTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getCreationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-
- getCreationTime() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalInstanceStats
-
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the creation time of this map on this member.
- getCreationTime() - Method in interface com.hazelcast.monitor.LocalTopicStats
-
Returns the creation time of this topic on this member
- getCreationTime() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the creation time of this NearCache on this member
- getCreationTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- getCreationTime() - Method in class com.hazelcast.queue.impl.QueueItem
-
- getCredentials() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getCredentials() - Method in class com.hazelcast.cluster.impl.JoinRequest
-
- getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
-
- getCurrConnections() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getCurrentClientConnections() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
-
- getCurrentClientConnections() - Method in interface com.hazelcast.nio.ConnectionManager
-
- getCurrentClientConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getCurrentValue() - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- getData() - Method in class com.hazelcast.ascii.rest.HttpPostCommand
-
- getData() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns byte array representation of internal binary format.
- getData() - Method in class com.hazelcast.nio.serialization.DataAdapter
-
- getData() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- getData() - Method in class com.hazelcast.queue.impl.QueueItem
-
- getDataEntrySet() - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-
- getDataFromMap(long) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- getDataKey() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets cache entry key as
Data
.
- getDataKey() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getDataKey() - Method in class com.hazelcast.map.impl.EntryEventData
-
- getDataNewValue() - Method in class com.hazelcast.map.impl.EntryEventData
-
- getDataOldValue() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets the old value of entry as
Data
, if available.
- getDataOldValue() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getDataOldValue() - Method in class com.hazelcast.map.impl.EntryEventData
-
- getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
-
- getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
-
- getDataSize(Data, PortableContext) - Static method in class com.hazelcast.nio.serialization.DataAdapter
-
- getDataValue() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets cache entry value as
Data
.
- getDataValue() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getDecodedDataLength(byte[]) - Static method in class com.hazelcast.util.Base64
-
returns length of decoded data given an
array containing encoded data.
- getDecrHits() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getDecrMisses() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getDefault() - Static method in class com.hazelcast.transaction.TransactionOptions
-
Creates a new TransactionOptions configured with default settings.
- getDefaultClassLoader() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getDefaultClassLoader() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getDefaultProperties() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getDefaultProperties() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getDefaultScheduledExecutor() - Method in interface com.hazelcast.spi.ExecutionService
-
- getDefaultScheduledExecutor() - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- getDefaultURI() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- getDefaultURI() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getDeleteHits() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getDeleteMisses() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getDestination() - Method in class com.hazelcast.partition.MigrationInfo
-
- getDetails() - Method in class com.hazelcast.client.impl.client.GenericError
-
- getDirtyEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getDirtyEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getDirtyEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of entries that the member owns and are dirty (updated but not persisted yet).
- getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns DistributedObject instance
- getDistributedObject(String, Object) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getDistributedObject(String, Object) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
Deprecated.
- getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getDistributedObject(String, Object) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getDistributedObject(String, String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- getDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getDistributedObjectName() - Method in interface com.hazelcast.client.impl.client.SecureRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.collection.client.CollectionRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.queue.impl.client.QueueRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- getDistributedObjectName() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getDistributedObjectNames(String) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- getDistributedObjectNames(String) - Method in interface com.hazelcast.spi.ProxyService
-
- getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns all
DistributedObject
's such as; queue, map, set, list, topic, lock, multimap.
- getDistributedObjects() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getDistributedObjects() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getDistributedObjects(String) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- getDistributedObjects(String) - Method in interface com.hazelcast.spi.ProxyService
-
- GetDistributedObjectsRequest - Class in com.hazelcast.client.impl.client
-
- GetDistributedObjectsRequest() - Constructor for class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-
- getDistributedObjectType() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getDistributedObjectType() - Method in interface com.hazelcast.client.impl.client.SecureRequest
-
- getDistributedObjectType() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- getDistributedObjectType() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-
- getDistributedObjectType() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-
- getDistributedObjectType() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- getDistributedObjectType() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- getDistributedObjectType() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- getDouble() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getDouble(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getDouble(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getDouble(JsonObject, String, double) - Static method in class com.hazelcast.util.JsonUtil
-
- getDoubleAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getDoubleAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getDoubleAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getDurability() - Method in class com.hazelcast.transaction.TransactionOptions
-
Gets the transaction durability.
- getEmptyPollOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getEmptyPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns number of null returning poll operations.
- getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
-
- getEndpoint(Connection) - Method in interface com.hazelcast.client.ClientEndpointManager
-
Gets the endpoint for a given connection.
- getEndpoint() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getEndpoint(Connection) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- getEndPoint() - Method in interface com.hazelcast.nio.Connection
-
Gets the of the other side of this Connection.
- getEndPoint() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getEndPoint() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionMonitor
-
- getEndpoint() - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- getEndpoint() - Method in class com.hazelcast.security.AbstractCredentials
-
- getEndpoint() - Method in interface com.hazelcast.security.Credentials
-
Returns IP address of endpoint.
- getEndpointManager() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getEndpoints() - Method in interface com.hazelcast.client.ClientEndpointManager
-
Returns the current endpoints.
- getEndpoints(String) - Method in interface com.hazelcast.client.ClientEndpointManager
-
Gets all the endpoints for a given client.
- getEndpoints(String) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- getEndpoints() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
-
- getEndpoints() - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- getEngineByExtension(String) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- getEngineByMimeType(String) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- getEngineByName(String) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- getEngineFactories() - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- getEngineName() - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getEngineVersion() - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getEntries() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfig
-
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
-
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfig
-
- getEntryListenerConfigs() - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- getEntryObject() - Method in class com.hazelcast.query.PredicateBuilder
-
- getEntrySet() - Method in class com.hazelcast.map.impl.MapEntrySet
-
- getEntrySet() - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-
- getEntrySet() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntrySet
-
- getEntryView(K) - Method in interface com.hazelcast.core.IMap
-
Returns the EntryView for the specified key.
- getEntryView(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- getEntryView() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- GetEntryViewOperation - Class in com.hazelcast.map.impl.operation
-
- GetEntryViewOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- GetEntryViewOperation() - Constructor for class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- getEventObject() - Method in class com.hazelcast.wan.WanReplicationEvent
-
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getEventOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of Events Received
- getEventOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns number of event operations
- getEventQueueCapacity() - Method in class com.hazelcast.jmx.EventServiceMBean
-
- getEventQueueCapacity() - Method in class com.hazelcast.management.SerializableEventServiceBean
-
- getEventQueueCapacity() - Method in interface com.hazelcast.spi.EventService
-
Returns queue capacity per event thread.
- getEventQueueCapacity() - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- getEventQueueSize() - Method in class com.hazelcast.jmx.EventServiceMBean
-
- getEventQueueSize() - Method in class com.hazelcast.management.SerializableEventServiceBean
-
- getEventQueueSize() - Method in interface com.hazelcast.spi.EventService
-
Returns current total event queue size.
- getEventQueueSize() - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- getEvents() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getEventService() - Method in interface com.hazelcast.client.ClientEngine
-
- getEventService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getEventService() - Method in interface com.hazelcast.nio.IOService
-
- getEventService() - Method in class com.hazelcast.nio.NodeIOService
-
- getEventService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getEventService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getEventServiceBean() - Method in class com.hazelcast.management.SerializableMXBeans
-
- getEventServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getEventThreadCount() - Method in class com.hazelcast.jmx.EventServiceMBean
-
- getEventThreadCount() - Method in class com.hazelcast.management.SerializableEventServiceBean
-
- getEventThreadCount() - Method in interface com.hazelcast.spi.EventService
-
Returns event thread count.
- getEventThreadCount() - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- getEventType() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getEventType() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-
Returns the membership event type; #MEMBER_ADDED or #MEMBER_REMOVED
- getEventType() - Method in class com.hazelcast.core.AbstractIMapEvent
-
Return the event type
- getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
-
- getEventType() - Method in interface com.hazelcast.core.IMapEvent
-
Return the event type
- getEventType() - Method in class com.hazelcast.core.ItemEvent
-
Returns the event type.
- getEventType() - Method in class com.hazelcast.core.MembershipEvent
-
Returns the membership event type;
#MEMBER_ADDED
#MEMBER_REMOVED
#MEMBER_ATTRIBUTE_CHANGED
- getEventType() - Method in interface com.hazelcast.map.impl.EventData
-
- getEventType() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getEventType() - Method in class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- getEventType() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getEventType() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getEventType() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- getEvictionCriteriaNumber() - Method in interface com.hazelcast.map.impl.record.Record
-
- getEvictionCriteriaNumber() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getEvictionCriteriaNumber() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getEvictionOperator() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getEvictionOperator() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getEvictionPercentage() - Method in class com.hazelcast.config.CacheConfig
-
- getEvictionPercentage() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getEvictionPercentage() - Method in class com.hazelcast.config.MapConfig
-
- getEvictionPolicy() - Method in class com.hazelcast.config.CacheConfig
-
- getEvictionPolicy() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
-
- getEvictionPolicy() - Method in class com.hazelcast.config.NearCacheConfig
-
- getEvictionThresholdPercentage() - Method in class com.hazelcast.config.CacheConfig
-
- getEvictionThresholdPercentage() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getExecutedCount() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-
- getExecutedOperationCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
-
- getExecutedOperationCount() - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- getExecutedOperationCount() - Method in interface com.hazelcast.spi.OperationService
-
- getExecutionService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getExecutionService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
-
- getExecutor(String) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- getExecutorConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the ExecutorConfig for the given name
- getExecutorConfigs() - Method in class com.hazelcast.config.Config
-
- getExecutorName() - Method in class com.hazelcast.spi.InvocationBuilder
-
Gets the name of the Executor to use.
- getExecutorName() - Method in class com.hazelcast.spi.Operation
-
- getExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed executor service for the given
name.
- getExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getExecutorService(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getExecutorService(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- getExistingRecordStore(int, String) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getExistingRecordStore(int, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getExistingRecordStore(String) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getExpiration() - Method in class com.hazelcast.ascii.memcache.DeleteCommand
-
- getExpiration() - Method in class com.hazelcast.ascii.memcache.SetCommand
-
- getExpiration() - Method in class com.hazelcast.ascii.memcache.TouchCommand
-
- getExpirationManager() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getExpirationManager() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getExpirationTime() - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- getExpirationTime() - Method in interface com.hazelcast.cache.impl.record.Expirable
-
Gets the expiration time in milliseconds.
- getExpirationTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getExpirationTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the expiration time of the entry.
- getExpirationTime() - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- getExpirationTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getExpiryForAccess() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryForCreation() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryForUpdate() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getExpiryPolicy(ExpiryPolicy) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getExpiryPolicyFactory() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getExtensions() - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getFactory() - Method in class com.hazelcast.osgi.OSGiScriptEngine
-
- getFactoryClassName() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the name of the MapStoreFactory implementation class
- getFactoryClassName() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getFactoryClassName() - Method in class com.hazelcast.config.SSLConfig
-
- getFactoryId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheClearResponse
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.CachePortableHook
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientPortableHook
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.ClientResponse
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.GenericError
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-
- getFactoryId() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.client.impl.ClientDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-
- getFactoryId() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-
- getFactoryId() - Method in class com.hazelcast.cluster.impl.BindMessage
-
- getFactoryId() - Method in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.cluster.impl.ConfigCheck
-
- getFactoryId() - Method in class com.hazelcast.cluster.impl.operations.HeartbeatOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.collection.client.CollectionRequest
-
- getFactoryId() - Method in class com.hazelcast.collection.client.TxnCollectionRequest
-
- getFactoryId() - Method in class com.hazelcast.collection.CollectionDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.collection.CollectionEvent
-
- getFactoryId() - Method in class com.hazelcast.collection.CollectionEventFilter
-
- getFactoryId() - Method in class com.hazelcast.collection.CollectionItem
-
- getFactoryId() - Method in class com.hazelcast.collection.CollectionOperation
-
- getFactoryId() - Method in class com.hazelcast.collection.CollectionPortableHook
-
- getFactoryId() - Method in class com.hazelcast.collection.CollectionReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongPortableHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.client.AtomicReferencePortableHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownLatchPortableHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphorePortableHook
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.ExecutorPortableHook
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.operations.CallableTaskOperation
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-
- getFactoryId() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- getFactoryId() - Method in class com.hazelcast.instance.MemberImpl
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapEntrySet
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapKeySet
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapPortableHook
-
- getFactoryId() - Method in class com.hazelcast.map.impl.MapValueCollection
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.GetOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.PutOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-
- getFactoryId() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.CombinerResultList
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.HashMapAdapter
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- getFactoryId() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- getFactoryId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- getFactoryId() - Method in class com.hazelcast.nio.Address
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.DataSerializerHook
-
- getFactoryId(String, int) - Static method in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
-
Returns DataSerializableFactory factory id for this class.
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.Portable
-
Returns PortableFactory id for this portable class
- getFactoryId() - Method in interface com.hazelcast.nio.serialization.PortableHook
-
- getFactoryId() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-
- getFactoryId() - Method in class com.hazelcast.partition.client.PartitionsResponse
-
- getFactoryId() - Method in class com.hazelcast.partition.PartitionDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.partition.PartitionPortableHook
-
- getFactoryId() - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.client.QueueRequest
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.client.RemoveListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.client.TxnOfferRequest
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.client.TxnPeekRequest
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.client.TxnPollRequest
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.client.TxnSizeRequest
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.operations.OfferBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.operations.PeekOperation
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.operations.PollBackupOperation
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.operations.QueueReplicationOperation
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.QueueEvent
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.QueueEventFilter
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.QueueItem
-
- getFactoryId() - Method in class com.hazelcast.queue.impl.QueuePortableHook
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntrySet
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapGetResponse
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeySet
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getFactoryId() - Method in class com.hazelcast.replicatedmap.impl.record.VectorClockTimestamp
-
- getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.EventServiceImpl.EventPacket
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation.PartitionResponse
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableCollection
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.Response
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.SerializableCollection
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.spi.impl.SpiPortableHook
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.PublishOperation
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.TopicDataSerializerHook
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.TopicEvent
-
- getFactoryId() - Method in class com.hazelcast.topic.impl.TopicPortableHook
-
- getFactoryId() - Method in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- getFactoryId() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-
- getFactoryId() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-
- getFactoryId() - Method in class com.hazelcast.transaction.client.PrepareTransactionRequest
-
- getFactoryId() - Method in class com.hazelcast.transaction.client.RecoverAllTransactionsRequest
-
- getFactoryId() - Method in class com.hazelcast.transaction.client.RecoverTransactionRequest
-
- getFactoryId() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-
- getFactoryId() - Method in class com.hazelcast.util.QueryResultSet
-
- getFactoryImplementation() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the map store factory implementation object
- getFactoryImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getFactoryImplementation() - Method in class com.hazelcast.config.SSLConfig
-
- getField(String) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
-
- getField(int) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
-
- getField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getField(int) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldClassId(String) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
-
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldClassId(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- getFieldClassId(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldCount() - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
-
- getFieldCount() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldDefinition(ClassDefinition, String) - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- getFieldNames() - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
-
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldNames() - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- getFieldNames() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldType(String) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
-
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getFieldType(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getFieldVersion(String) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
-
- getFilter() - Method in interface com.hazelcast.spi.EventRegistration
-
- getFilter() - Method in class com.hazelcast.spi.impl.EventServiceImpl.Registration
-
- getFirst() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Gets first item in queue.
- getFirst() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- getFlag() - Method in class com.hazelcast.ascii.memcache.MemcacheEntry
-
- getFlag() - Method in class com.hazelcast.ascii.memcache.SetCommand
-
- getFlags() - Method in class com.hazelcast.query.Predicates.ILikePredicate
-
- getFlags() - Method in class com.hazelcast.query.Predicates.LikePredicate
-
- getFloat() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getFloat(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getFloat(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getFloat(JsonObject, String, float) - Static method in class com.hazelcast.util.JsonUtil
-
- getFloatAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getFloatAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getFloatAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getFormatId() - Method in class com.hazelcast.transaction.impl.SerializableXID
-
- getForUpdate(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
Locks the key and then gets and returns the value to which the specified key is mapped.
- getForUpdate(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- getForUpdateInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- getFreeHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getFreeHeap() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getFreeMemory() - Method in interface com.hazelcast.map.impl.eviction.MemoryInfoAccessor
-
- getFreeNativeMemory() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getFreeNativeMemory() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getFreePhysical() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getFreePhysical() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getFromNearCache(String, Data) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- getFunction() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- getGCStats() - Static method in class com.hazelcast.memory.GCStatsSupport
-
- getGCStats() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getGCStats() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getGenericOperationThreadCount() - Method in interface com.hazelcast.spi.OperationService
-
- getGetHits() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getGetMisses() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getGetOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getGetOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getGetOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of get operations
- getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
-
- getGlobalTransactionId() - Method in class com.hazelcast.transaction.impl.SerializableXID
-
- getGroupConfig() - Method in class com.hazelcast.config.Config
-
- getGroupName() - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- getGroupName() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getGroupName() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- getGroupName() - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- getGroupPassword() - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- getGroupProperties() - Method in class com.hazelcast.instance.Node
-
- getGroupProperties() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getGroupProperties() - Method in interface com.hazelcast.spi.NodeEngine
-
- getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
-
Returns the MemberGroupType configured.
- getHazelcastInstance(String) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-
- getHazelcastInstance() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getHazelcastInstance() - Method in class com.hazelcast.management.ManagementCenterService
-
- getHazelcastInstance() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getHazelcastInstance() - Method in interface com.hazelcast.spi.NodeEngine
-
- getHazelcastInstanceByName(String) - Static method in class com.hazelcast.core.Hazelcast
-
Returns an existing HazelcastInstance with instanceName.
- getHeader() - Method in class com.hazelcast.nio.Packet
-
Returns the header of the Packet.
- getHeader() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns byte array representation of header.
- getHeader() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- getHeapCost() - Method in interface com.hazelcast.map.impl.RecordStore
-
- getHeapCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getHeapCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getHeapCost() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Cost of map & near cache & backup in bytes
todo in object mode object size is zero.
- getHeapCost() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns approximate heap cost of this Data object in bytes.
- getHeapCost() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- getHeapMemoryUsage() - Static method in class com.hazelcast.memory.MemoryStatsSupport
-
- getHits() - Method in interface com.hazelcast.core.EntryView
-
Returns number of hits of the entry.
- getHits() - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- getHits() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getHits() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getHits() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getHits() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getHits() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of hits (reads) of the locally owned entries.
- getHits() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the number of hits (reads) of the locally owned entries.
- getHits() - Method in class com.hazelcast.multimap.impl.MultiMapWrapper
-
- getHits() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getHost() - Method in class com.hazelcast.nio.Address
-
- getHostHeader() - Method in class com.hazelcast.config.AwsConfig
-
Gets the host header; the address the EC2 API can be found.
- getId() - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- getId() - Method in class com.hazelcast.cache.impl.CacheClearResponse
-
- getId() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getId() - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- getId() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperation
-
- getId() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- getId() - Method in class com.hazelcast.client.impl.client.ClientResponse
-
- getId() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-
- getId() - Method in class com.hazelcast.cluster.impl.BindMessage
-
- getId() - Method in class com.hazelcast.cluster.impl.ConfigCheck
-
- getId() - Method in class com.hazelcast.cluster.impl.operations.HeartbeatOperation
-
- getId() - Method in enum com.hazelcast.cluster.MemberAttributeOperationType
-
- getId() - Method in class com.hazelcast.collection.CollectionAddAllBackupOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionAddAllOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionAddBackupOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionAddOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionClearBackupOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionClearOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionCompareAndRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionContainsOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionEvent
-
- getId() - Method in class com.hazelcast.collection.CollectionEventFilter
-
- getId() - Method in class com.hazelcast.collection.CollectionGetAllOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionIsEmptyOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionItem
-
- getId() - Method in class com.hazelcast.collection.CollectionRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionSizeOperation
-
- getId() - Method in class com.hazelcast.collection.CollectionTransactionRollbackOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListAddAllOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListAddOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListGetOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListIndexOfOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListReplicationOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListSetBackupOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListSetOperation
-
- getId() - Method in class com.hazelcast.collection.list.ListSubOperation
-
- getId() - Method in class com.hazelcast.collection.set.SetReplicationOperation
-
- getId() - Method in class com.hazelcast.collection.TxCollectionItem
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionPrepareOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionReserveAddOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionRollbackOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionTxnAddOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- getId() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- getId() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-
- getId() - Method in interface com.hazelcast.core.DistributedObject
-
- getId() - Method in class com.hazelcast.executor.impl.operations.CallableTaskOperation
-
- getId() - Method in class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-
- getId() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- getId() - Method in class com.hazelcast.instance.MemberImpl
-
- getId() - Method in class com.hazelcast.map.impl.MapEntrySet
-
- getId() - Method in class com.hazelcast.map.impl.MapKeySet
-
- getId() - Method in class com.hazelcast.map.impl.MapValueCollection
-
- getId() - Method in class com.hazelcast.map.impl.operation.GetOperation
-
- getId() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-
- getId() - Method in class com.hazelcast.map.impl.operation.PutOperation
-
- getId() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- getId() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-
- getId() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-
- getId() - Method in class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-
- getId() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- getId() - Method in class com.hazelcast.mapreduce.impl.CombinerResultList
-
- getId() - Method in class com.hazelcast.mapreduce.impl.HashMapAdapter
-
- getId() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-
- getId() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- getId() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- getId() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- getId() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- getId() - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- getId() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- getId() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.EntrySetOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.KeySetOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.SizeOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.operations.ValuesOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
-
- getId() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-
- getId() - Method in class com.hazelcast.nio.Address
-
- getId() - Method in enum com.hazelcast.nio.serialization.FieldType
-
- getId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
-
Returns type identifier for this class.
- getId() - Method in class com.hazelcast.partition.client.PartitionsResponse
-
- getId() - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- getId() - Method in class com.hazelcast.queue.impl.operations.AddAllBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.CheckAndEvictOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.ClearBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.ClearOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.ContainsOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.DrainBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.DrainOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.IsEmptyOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.IteratorOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.OfferBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.PeekOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.PollBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.QueueReplicationOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.RemainingCapacityOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.RemoveBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
-
- getId() - Method in class com.hazelcast.queue.impl.operations.SizeOperation
-
- getId() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- getId() - Method in class com.hazelcast.queue.impl.QueueEvent
-
- getId() - Method in class com.hazelcast.queue.impl.QueueEventFilter
-
- getId() - Method in class com.hazelcast.queue.impl.QueueItem
-
- getId() - Method in class com.hazelcast.queue.impl.tx.QueueTransactionRollbackOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnOfferBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnPeekOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnPollBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnPrepareBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnPrepareOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnReservePollBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnRollbackBackupOperation
-
- getId() - Method in class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- getId() - Method in class com.hazelcast.queue.impl.TxQueueItem
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getId() - Method in class com.hazelcast.replicatedmap.impl.record.VectorClockTimestamp
-
- getId() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
Deprecated.
- getId() - Method in interface com.hazelcast.spi.EventRegistration
-
Returns event registration id.
- getId() - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-
- getId() - Method in class com.hazelcast.spi.impl.EventServiceImpl.EventPacket
-
- getId() - Method in class com.hazelcast.spi.impl.EventServiceImpl.Registration
-
- getId() - Method in class com.hazelcast.spi.impl.NormalResponse
-
- getId() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- getId() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation.PartitionResponse
-
- getId() - Method in class com.hazelcast.spi.impl.SerializableCollection
-
- getId() - Method in class com.hazelcast.topic.impl.PublishOperation
-
- getId() - Method in class com.hazelcast.topic.impl.TopicEvent
-
- getId() - Method in class com.hazelcast.util.QueryResultSet
-
- getIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates cluster-wide unique IDs.
- getIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getIdGenerator(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getImpl() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- getImplementation() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- getImplementation() - Method in class com.hazelcast.config.EntryListenerConfig
-
- getImplementation() - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- getImplementation() - Method in class com.hazelcast.config.ItemListenerConfig
-
- getImplementation() - Method in class com.hazelcast.config.ListenerConfig
-
Returns the EventListener implementation.
- getImplementation() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the map store implementation object
- getImplementation() - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- getImplementation() - Method in class com.hazelcast.config.SecurityInterceptorConfig
-
- getImplementation() - Method in class com.hazelcast.config.SerializerConfig
-
- getImplementation() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
- getImplementationName() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- getImplementationVendor() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- getImplementationVersion() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- getIn() - Method in class com.hazelcast.config.XmlConfigLocator
-
- getIncrHits() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getIncrMisses() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getIndex(String) - Method in class com.hazelcast.query.impl.QueryContext
-
- getIndex(QueryContext) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
-
- getIndexes() - Method in class com.hazelcast.query.impl.IndexService
-
- getIndexKey() - Method in class com.hazelcast.query.impl.QueryEntry
-
- getIndexKey() - Method in interface com.hazelcast.query.impl.QueryResultEntry
-
- getIndexKey() - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- getIndexService() - Method in class com.hazelcast.map.impl.MapContainer
-
- getInetAddress() - Method in class com.hazelcast.instance.MemberImpl
-
- getInetAddress() - Method in class com.hazelcast.nio.Address
-
- getInetAddress() - Method in interface com.hazelcast.nio.Connection
-
Returns remote address of this Connection.
- getInetAddress() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getInetAddressFor(Inet6Address, String) - Static method in class com.hazelcast.util.AddressUtil
-
- getInetSocketAddress() - Method in interface com.hazelcast.core.Member
-
- getInetSocketAddress() - Method in class com.hazelcast.instance.MemberImpl
-
- getInetSocketAddress() - Method in class com.hazelcast.nio.Address
-
- getInitialKeys() - Method in class com.hazelcast.map.impl.MapContainer
-
- getInitialLoadMode() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns initial load mode
- getInitialPermits() - Method in class com.hazelcast.config.SemaphoreConfig
-
Gets the initial number of permits
- getInMemoryFormat() - Method in class com.hazelcast.config.CacheConfig
-
- getInMemoryFormat() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getInMemoryFormat() - Method in class com.hazelcast.config.MapConfig
-
- getInMemoryFormat() - Method in class com.hazelcast.config.NearCacheConfig
-
- getInMemoryFormat() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getInstanceMBean() - Method in class com.hazelcast.jmx.ManagementService
-
- getInstanceName() - Method in class com.hazelcast.config.Config
-
- getInstanceNames() - Method in class com.hazelcast.monitor.TimedMemberState
-
- getInt() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getInt(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getInt(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getInt(JsonObject, String, int) - Static method in class com.hazelcast.util.JsonUtil
-
- getInt(int) - Static method in class com.hazelcast.util.RandomPicker
-
- getIntAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getIntAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getIntAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getInteger() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getIntegerValue(String, String, int) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getInterceptorMap() - Method in class com.hazelcast.map.impl.MapContainer
-
- getInterceptors() - Method in class com.hazelcast.map.impl.MapContainer
-
- getInterfaces() - Method in class com.hazelcast.config.InterfacesConfig
-
- getInterfaces() - Method in class com.hazelcast.config.MemberGroupConfig
-
Gets an unmodifiable collection containing all interfaces.
- getInterfaces() - Method in class com.hazelcast.config.NetworkConfig
-
- getInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- getInternal(Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- getInvocationTime() - Method in class com.hazelcast.spi.Operation
-
- getIoExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getIOHandler() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getItem() - Method in class com.hazelcast.collection.common.DataAwareItemEvent
-
- getItem() - Method in class com.hazelcast.core.ItemEvent
-
Returns the item related to event.
- getItem() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- getItemData() - Method in class com.hazelcast.collection.common.DataAwareItemEvent
-
- getItemId() - Method in class com.hazelcast.collection.CollectionItem
-
- getItemId() - Method in class com.hazelcast.queue.impl.QueueItem
-
- getItemListenerConfigs() - Method in class com.hazelcast.config.CollectionConfig
-
- getItemListenerConfigs() - Method in class com.hazelcast.config.ListConfigReadOnly
-
- getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfig
-
- getItemListenerConfigs() - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- getItemListenerConfigs() - Method in class com.hazelcast.config.SetConfigReadOnly
-
- getItemQueue() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- getIterationType() - Method in class com.hazelcast.query.PagingPredicate
-
- getJobId() - Method in class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-
- getJobId() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-
- getJobId() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getJobId() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- getJobId() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-
- getJobId() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- getJobId() - Method in interface com.hazelcast.mapreduce.JobCompletableFuture
-
Returns the unique identifier for this mapreduce job.
- getJobId() - Method in interface com.hazelcast.mapreduce.TrackableJob
-
Returns the unique job id of the tracked job
- getJobOwner() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getJobOwner() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getJobProcessInformation() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getJobProcessInformation() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- getJobProcessInformation() - Method in interface com.hazelcast.mapreduce.TrackableJob
-
Returns an instance of
JobProcessInformation
to find out the state and
statistics of a running task or null if the underlying job id is not available because job is already
finished or not yet submitted.
It even returns null if not requested on the job issuing cluster member or client since those values are
not distributed to all clusters for traffic reasons.
- getJobResults() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getJobSupervisor(String, String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- getJobTracker(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the job tracker instance with the specified name.
- getJobTracker(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getJobTracker(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getJobTracker(String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- getJobTracker() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getJobTracker() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- getJobTracker() - Method in interface com.hazelcast.mapreduce.TrackableJob
-
- getJobTrackerConfig(String) - Method in class com.hazelcast.config.Config
-
- getJobTrackerConfig() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- getJobTrackerConfigs() - Method in class com.hazelcast.config.Config
-
- getJoin() - Method in class com.hazelcast.config.NetworkConfig
-
- getJoiner() - Method in class com.hazelcast.instance.Node
-
- getKey() - Method in class com.hazelcast.ascii.memcache.DeleteCommand
-
- getKey() - Method in class com.hazelcast.ascii.memcache.GetCommand
-
- getKey() - Method in class com.hazelcast.ascii.memcache.IncrementCommand
-
- getKey() - Method in class com.hazelcast.ascii.memcache.SetCommand
-
- getKey() - Method in class com.hazelcast.ascii.memcache.TouchCommand
-
- getKey() - Method in class com.hazelcast.cache.impl.CacheEntry
-
- getKey() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-
- getKey() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- getKey(int) - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- getKey() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- getKey() - Method in class com.hazelcast.client.impl.client.KeyBasedClientRequest
-
- getKey() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-
- getKey() - Method in class com.hazelcast.collection.txn.CollectionTransactionLog
-
- getKey() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- getKey() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- getKey() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- getKey() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-
- getKey() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-
- getKey() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
Deprecated.
- getKey() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getKey() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- getKey() - Method in class com.hazelcast.core.EntryEvent
-
Returns the key of the entry event
- getKey() - Method in interface com.hazelcast.core.EntryView
-
Returns the key of the entry.
- getKey() - Method in interface com.hazelcast.core.ILock
-
- getKey() - Method in class com.hazelcast.core.MemberAttributeEvent
-
- getKey() - Method in class com.hazelcast.core.PartitionAwareKey
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- getKey() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- getKey() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-
- getKey() - Method in class com.hazelcast.map.impl.EntryEventFilter
-
- getKey() - Method in class com.hazelcast.map.impl.NearCache.CacheRecord
-
- getKey() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- getKey() - Method in interface com.hazelcast.map.impl.record.Record
-
- getKey() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
-
- getKey() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getKey() - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
-
- getKey() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- getKey() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-
- getKey() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- getKey() - Method in interface com.hazelcast.query.impl.QueryableEntry
-
- getKey() - Method in class com.hazelcast.query.impl.QueryEntry
-
- getKey() - Method in class com.hazelcast.queue.impl.tx.QueueTransactionLog
-
- getKey() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getKey() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getKey() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedEntryEventFilter
-
- getKey() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getKey() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getKey() - Method in interface com.hazelcast.transaction.impl.KeyAwareTransactionLog
-
- getKey() - Method in interface com.hazelcast.util.executor.StripedRunnable
-
- getKey() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- getKeyData() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- getKeyData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-
- getKeyData() - Method in class com.hazelcast.query.impl.QueryEntry
-
- getKeyData() - Method in interface com.hazelcast.query.impl.QueryResultEntry
-
- getKeyData() - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- getKeyMember(Object) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- getKeys() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- getKeySet() - Method in class com.hazelcast.map.impl.MapKeySet
-
- getKeySet() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeySet
-
- getKeyType() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- getKeyType() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getKeyValueSource() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getLanguageName() - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getLanguageVersion() - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getLastAccessTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last access time to the entry.
- getLastAccessTime() - Method in interface com.hazelcast.map.impl.record.Record
-
- getLastAccessTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getLastAccessTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getLastAccessTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the last access (read) time of the locally owned entries.
- getLastAccessTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- getLastAccessTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getLastCleanupTime() - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getLastCleanupTimeCopy() - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getLastPing() - Method in class com.hazelcast.instance.MemberImpl
-
- getLastRead() - Method in class com.hazelcast.instance.MemberImpl
-
- getLastStoredTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last time value is flushed to mapstore.
- getLastStoredTime() - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- getLastStoredTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
-
Returns the last time value is updated.
- getLastUpdateTime() - Method in interface com.hazelcast.map.impl.record.Record
-
- getLastUpdateTime() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getLastUpdateTime() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getLastUpdateTime() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the last update time of the locally owned entries.
- getLastUpdateTime() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- getLastWrite() - Method in class com.hazelcast.instance.MemberImpl
-
- getLatch(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- getLatestUpdateHash() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getLevel() - Method in interface com.hazelcast.logging.ILogger
-
Gets the logging Level.
- getLicenseKey() - Method in class com.hazelcast.config.Config
-
- getLifecycleService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the lifecycle service for this instance.
- getLifecycleService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getLifecycleService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getList() - Method in class com.hazelcast.console.ConsoleApp
-
- getList(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed list instance with the specified name.
- getList(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getList(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getList(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional list instance with the specified name.
- getListConfig(String) - Method in class com.hazelcast.config.Config
-
- getListConfigs() - Method in class com.hazelcast.config.Config
-
- getListener() - Method in class com.hazelcast.spi.impl.EventServiceImpl.Registration
-
- getListenerConfigs() - Method in class com.hazelcast.config.Config
-
- getListenerConfigs() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getLocalAddress() - Method in class com.hazelcast.cluster.impl.BindMessage
-
- getLocalAddress() - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- getLocalAvgAge() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalBackupCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalBackupCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalBackupEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalBackupEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalBackupEntryMemoryCost() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalBackupEntryMemoryCost() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalBackupItemCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalCacheStatistics() - Method in interface com.hazelcast.cache.ICache
-
Directly access to local Cache Statistics.
- getLocalCacheStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getLocalCacheStats(String) - Method in interface com.hazelcast.monitor.MemberState
-
- getLocalCancelledTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-
- getLocalCompletedTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-
- getLocalCreationTime() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalCreationTime() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalCreationTime() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalCreationTime() - Method in class com.hazelcast.jmx.TopicMBean
-
- getLocalDirtyEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalDirtyEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalEmptyPollOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalEndpoint() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the local Endpoint which this HazelcastInstance is belongs to.
- getLocalEndpoint() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getLocalEndpoint() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getLocalEventOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalEventOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalEventOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalEventOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalExecutorStats() - Method in interface com.hazelcast.core.IExecutorService
-
Returns local statistics related to this executor service.
- getLocalExecutorStats() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- getLocalExecutorStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getLocalExecutorStats(String) - Method in interface com.hazelcast.monitor.MemberState
-
- getLocalGetOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalGetOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalGetOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalHits() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalHits() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalHits() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalLastAccessTime() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalLastAccessTime() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalLastAccessTime() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalLastUpdateTime() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalLastUpdateTime() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalLastUpdateTime() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalLockedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalLockedEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalMapStats() - Method in interface com.hazelcast.core.IMap
-
Returns LocalMapStats for this map.
- getLocalMapStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getLocalMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
-
- getLocalMapStatsImpl(String) - Method in class com.hazelcast.map.impl.LocalMapStatsProvider
-
- getLocalMapStatsProvider() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getLocalMapStatsProvider() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getLocalMaxAge() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalMaxGetLatency() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalMaxGetLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalMaxGetLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalMaxPutLatency() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalMaxPutLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalMaxPutLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalMember() - Method in interface com.hazelcast.client.ClientEngine
-
- getLocalMember() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getLocalMember() - Method in class com.hazelcast.cluster.impl.ClusterProxy
-
- getLocalMember() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getLocalMember() - Method in interface com.hazelcast.core.Cluster
-
Returns this Hazelcast instance member
- getLocalMember() - Method in class com.hazelcast.instance.Node
-
- getLocalMember() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getLocalMember() - Method in interface com.hazelcast.spi.NodeEngine
-
- getLocalMemoryStats() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getLocalMemoryStats() - Method in interface com.hazelcast.monitor.MemberState
-
- getLocalMinAge() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalMultiMapStats() - Method in interface com.hazelcast.core.MultiMap
-
Returns LocalMultiMapStats for this map.
- getLocalMultiMapStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getLocalMultiMapStats(String) - Method in interface com.hazelcast.monitor.MemberState
-
- getLocalMultiMapStats() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- getLocalMultiMapStatsImpl(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- getLocalOfferOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalOtherOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalOtherOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalOtherOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalOtherOperationsCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalOwnedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalOwnedEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalOwnedEntryCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalOwnedEntryMemoryCost() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalOwnedEntryMemoryCost() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalOwnedItemCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalPendingTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-
- getLocalPollOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalPublishOperationCount() - Method in class com.hazelcast.jmx.TopicMBean
-
- getLocalPutOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalPutOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalPutOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalQueueStats() - Method in interface com.hazelcast.core.IQueue
-
Returns LocalQueueStats for this queue.
- getLocalQueueStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getLocalQueueStats(String) - Method in interface com.hazelcast.monitor.MemberState
-
- getLocalQueueStats() - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- getLocalQueueStatsImpl(String) - Method in class com.hazelcast.queue.impl.QueueService
-
- getLocalReceiveOperationCount() - Method in class com.hazelcast.jmx.TopicMBean
-
- getLocalRejectedOfferOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getLocalRemoveOperationCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalRemoveOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalRemoveOperationCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalReplicationEventCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalStartedTaskCount() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-
- getLocalTopicStats() - Method in interface com.hazelcast.core.ITopic
-
Returns statistics of this topic,like total number of publishes/receives
- getLocalTopicStats(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getLocalTopicStats(String) - Method in interface com.hazelcast.monitor.MemberState
-
- getLocalTopicStats() - Method in class com.hazelcast.topic.impl.TopicProxy
-
- getLocalTopicStats(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- getLocalTotalExecutionLatency() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-
- getLocalTotalGetLatency() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalTotalGetLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalTotalGetLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalTotalPutLatency() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalTotalPutLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalTotalPutLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalTotalRemoveLatency() - Method in class com.hazelcast.jmx.MapMBean
-
- getLocalTotalRemoveLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getLocalTotalRemoveLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getLocalTotalStartLatency() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
-
- getLocalUpdatePolicy() - Method in class com.hazelcast.config.NearCacheConfig
-
- getLock(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed lock instance for the specified key object.
- getLock(Object) - Method in interface com.hazelcast.core.HazelcastInstance
-
- getLock(Object) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
Deprecated.
- getLock(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getLock(Object) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getLock(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getLockContainer(int) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- getLockCount() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- getLockCount(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-
- getLockCount() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getLockCount(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- getLockCount(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getLockCount(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- getLockCount() - Method in interface com.hazelcast.core.ILock
-
Returns re-entrant lock hold count, regardless of lock ownership.
- getLockCount() - Method in class com.hazelcast.jmx.LockMBean
-
- GetLockCountOperation - Class in com.hazelcast.concurrent.lock.operations
-
- GetLockCountOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-
- GetLockCountOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-
- GetLockCountRequest - Class in com.hazelcast.concurrent.lock.client
-
- GetLockCountRequest() - Constructor for class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- GetLockCountRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- getLockedCount() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- getLockedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getLockedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getLockedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of currently locked locally owned keys.
- getLockedKeys() - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- getLockedKeys() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getLockedKeys() - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- getLockObject() - Method in class com.hazelcast.jmx.LockMBean
-
- getLockOwnerInfo(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getLockOwnerInfo(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- getLockOwnerInfo(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- getLocks() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getLockStore(int, ObjectNamespace) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- getLockStores() - Method in class com.hazelcast.concurrent.lock.LockStoreContainer
-
- getLogger(Class) - Method in interface com.hazelcast.client.ClientEngine
-
- getLogger(Class) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getLogger(String) - Method in class com.hazelcast.instance.Node
-
- getLogger(Class) - Method in class com.hazelcast.instance.Node
-
- getLogger(Class) - Static method in class com.hazelcast.logging.Logger
-
- getLogger(String) - Static method in class com.hazelcast.logging.Logger
-
- getLogger(String) - Method in interface com.hazelcast.logging.LoggerFactory
-
- getLogger(String) - Method in class com.hazelcast.logging.LoggerFactorySupport
-
- getLogger(String) - Method in interface com.hazelcast.logging.LoggingService
-
- getLogger(Class) - Method in interface com.hazelcast.logging.LoggingService
-
- getLogger(String) - Method in class com.hazelcast.logging.LoggingServiceImpl
-
- getLogger(Class) - Method in class com.hazelcast.logging.LoggingServiceImpl
-
- getLogger(String) - Method in class com.hazelcast.logging.NoLogFactory
-
- getLogger(String) - Method in interface com.hazelcast.nio.IOService
-
- getLogger(String) - Method in class com.hazelcast.nio.NodeIOService
-
- getLogger(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getLogger(Class) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getLogger(String) - Method in interface com.hazelcast.spi.NodeEngine
-
- getLogger(Class) - Method in interface com.hazelcast.spi.NodeEngine
-
- getLogger() - Method in class com.hazelcast.spi.Operation
-
- getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the logging service of this Hazelcast instance.
- getLoggingService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getLoggingService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getLogRecord() - Method in class com.hazelcast.logging.LogEvent
-
- GetLogsRequest - Class in com.hazelcast.management.request
-
Deprecated.
- GetLogsRequest() - Constructor for class com.hazelcast.management.request.GetLogsRequest
-
Deprecated.
- getLong() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getLong() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getLong(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getLong(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getLong(JsonObject, String, long) - Static method in class com.hazelcast.util.JsonUtil
-
- getLongAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getLongAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getLongAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getLongValue(String, String, long) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getMajorCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- getMajorCollectionCount() - Method in interface com.hazelcast.monitor.LocalGCStats
-
- getMajorCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- getMajorCollectionTime() - Method in interface com.hazelcast.monitor.LocalGCStats
-
- getManagedContext() - Method in class com.hazelcast.config.Config
-
- getManagedContext() - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- getManagedContext() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- getManagedContext() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- getManagedExecutorBean(String) - Method in class com.hazelcast.management.SerializableMXBeans
-
- getManagedTransaction(Xid) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- getManagementCenterConfig() - Method in class com.hazelcast.config.Config
-
- getManagementCenterService() - Method in class com.hazelcast.instance.Node
-
- getManagementCenterService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getManagementService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getManagerClassLoader(ClassLoader) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getManagerPrefix() - Method in class com.hazelcast.config.CacheConfig
-
- getManagerUri(URI) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- getMap() - Method in class com.hazelcast.collection.CollectionContainer
-
- getMap() - Method in class com.hazelcast.collection.list.ListContainer
-
- getMap() - Method in class com.hazelcast.collection.set.SetContainer
-
- getMap() - Method in class com.hazelcast.console.ConsoleApp
-
- getMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed map instance with the specified name.
- getMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional distributed map instance with the specified name.
- getMapCombineTask(String) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- getMapConfig(String) - Method in class com.hazelcast.config.Config
-
- getMapConfig() - Method in class com.hazelcast.management.MapConfigAdapter
-
- GetMapConfigOperation - Class in com.hazelcast.management.operation
-
Operation to fetch Map configuration.
- GetMapConfigOperation() - Constructor for class com.hazelcast.management.operation.GetMapConfigOperation
-
- GetMapConfigOperation(String) - Constructor for class com.hazelcast.management.operation.GetMapConfigOperation
-
- getMapConfigs() - Method in class com.hazelcast.config.Config
-
- getMapContainer(String) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getMapContainer(String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getMapContainer() - Method in interface com.hazelcast.map.impl.RecordStore
-
- getMapContainers() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getMapContainers() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getMapContextQuerySupport() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getMapContextQuerySupport() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getMapDataStore() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getMapDataStore(int) - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
-
- getMapDataStore(int) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
-
- getMapDataStore(int) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
-
- getMapDataStore() - Method in interface com.hazelcast.map.impl.RecordStore
-
- getMapEntry(Data, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getMapEntry(Data, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- GetMapEntryRequest - Class in com.hazelcast.management.request
-
Request for fetching map entries.
- GetMapEntryRequest() - Constructor for class com.hazelcast.management.request.GetMapEntryRequest
-
- GetMapEntryRequest(String, String, String) - Constructor for class com.hazelcast.management.request.GetMapEntryRequest
-
- getMapEventPublisher() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getMapEventPublisher() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfig
-
- getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
-
- getMapName() - Method in interface com.hazelcast.map.impl.EventData
-
- getMapName() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- getMapName() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- getMapName() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- getMapper(Supplier<Key, ?, Supplied>) - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
-
Returns the Mapper for this aggregation.
- getMapper(Supplier<KeyIn, ValueIn, SuppliedValue>) - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-
- getMapper(Supplier<Key, Value, BigDecimal>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-
- getMapper(Supplier<Key, Value, BigDecimal>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-
- getMapper(Supplier<Key, Value, BigDecimal>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-
- getMapper(Supplier<Key, Value, BigDecimal>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-
- getMapper(Supplier<Key, Value, BigInteger>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-
- getMapper(Supplier<Key, Value, BigInteger>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-
- getMapper(Supplier<Key, Value, BigInteger>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-
- getMapper(Supplier<Key, Value, BigInteger>) - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-
- getMapper(Supplier<Key, Value, Comparable>) - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-
- getMapper(Supplier<Key, Value, Comparable>) - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-
- getMapper(Supplier<Key, Value, Object>) - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-
- getMapper(Supplier<Key, Value, DistinctType>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-
- getMapper(Supplier<Key, Value, Double>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-
- getMapper(Supplier<Key, Value, Double>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-
- getMapper(Supplier<Key, Value, Double>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-
- getMapper(Supplier<Key, Value, Double>) - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-
- getMapper(Supplier<Key, Value, Integer>) - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-
- getMapper(Supplier<Key, Value, Integer>) - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-
- getMapper(Supplier<Key, Value, Integer>) - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-
- getMapper(Supplier<Key, Value, Integer>) - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-
- getMapper(Supplier<Key, Value, Long>) - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-
- getMapper(Supplier<Key, Value, Long>) - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-
- getMapper(Supplier<Key, Value, Long>) - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-
- getMapper(Supplier<Key, Value, Long>) - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-
- getMapper() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getMapReduceService() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getMaps() - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getMapService() - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getMapServiceContext() - Method in class com.hazelcast.map.impl.MapContainer
-
- getMapServiceContext() - Method in class com.hazelcast.map.impl.MapService
-
- getMapStore() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- getMapStoreConfig() - Method in class com.hazelcast.config.MapConfig
-
Returns the map store configuration
- getMapStoreConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
-
- getMapStoreManager() - Method in class com.hazelcast.map.impl.MapContainer
-
- getMaster() - Method in class com.hazelcast.monitor.TimedMemberState
-
- getMaster() - Method in class com.hazelcast.partition.MigrationInfo
-
- getMasterAddress() - Method in interface com.hazelcast.client.ClientEngine
-
- getMasterAddress() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getMasterAddress() - Method in interface com.hazelcast.cluster.ClusterService
-
Returns the address of the master member.
- getMasterAddress() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getMasterAddress() - Method in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-
- getMasterAddress() - Method in class com.hazelcast.instance.Node
-
- getMasterAddress() - Method in class com.hazelcast.jmx.NodeMBean
-
- getMasterAddress() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getMasterAddress() - Method in interface com.hazelcast.spi.NodeEngine
-
- getMasterTime() - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- getMasterUuid() - Method in class com.hazelcast.partition.MigrationInfo
-
- getMatchingIpv4Addresses(AddressUtil.AddressMatcher) - Static method in class com.hazelcast.util.AddressUtil
-
- getMaxAge() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getMaxAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the max age of the items in this member.
- getMaxBackupCount() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getMaxBackupCount() - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getMaxGetLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getMaxGetLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getMaxGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the maximum latency of get operations.
- getMaxHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getMaxHeap() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getMaxIdleSeconds() - Method in class com.hazelcast.config.MapConfig
-
- getMaxIdleSeconds() - Method in class com.hazelcast.config.NearCacheConfig
-
- getMaximumPoolSize() - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- getMaximumPoolSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- getMaximumPoolSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-
- getMaxJoinMillis() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- getMaxJoinTimeToMasterNode() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- getMaxMemory() - Method in interface com.hazelcast.map.impl.eviction.MemoryInfoAccessor
-
- getMaxNativeMemory() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getMaxNativeMemory() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getMaxPutLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getMaxPutLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getMaxPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the maximum latency of put operations.
- getMaxRemoveLatency() - Method in class com.hazelcast.jmx.MapMBean
-
- getMaxRemoveLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getMaxRemoveLatency() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getMaxRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getMaxRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getMaxRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the maximum latency of remove operations.
- getMaxSize() - Method in class com.hazelcast.config.CollectionConfig
-
- getMaxSize() - Method in class com.hazelcast.config.NearCacheConfig
-
- getMaxSize() - Method in class com.hazelcast.config.QueueConfig
-
- getMaxSizeChecker() - Method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfig
-
- getMaxSizeConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
-
- getMaxSizePolicy() - Method in class com.hazelcast.config.MaxSizeConfig
-
- getMaxThreadSize() - Method in class com.hazelcast.config.JobTrackerConfig
-
- getMBeanInfo() - Method in class com.hazelcast.jmx.HazelcastMBean
-
- getMBeanServerId() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- getMember() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-
Returns the removed or added member.
- getMember(Address) - Method in interface com.hazelcast.cluster.ClusterService
-
Gets the member for the given address.
- getMember(String) - Method in interface com.hazelcast.cluster.ClusterService
-
Gets the member with the given uuid.
- getMember(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getMember(String) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getMember() - Method in class com.hazelcast.core.AbstractIMapEvent
-
Returns the member fired this event.
- getMember() - Method in interface com.hazelcast.core.IMapEvent
-
Returns the member fired this event.
- getMember() - Method in class com.hazelcast.core.ItemEvent
-
Returns the member fired this event.
- getMember() - Method in class com.hazelcast.core.MemberAttributeEvent
-
- getMember() - Method in exception com.hazelcast.core.MemberLeftException
-
Returns the member which left the cluster
- getMember() - Method in class com.hazelcast.core.MembershipEvent
-
Returns the removed or added member.
- getMember() - Method in class com.hazelcast.logging.LogEvent
-
- getMember(Address) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getMember(Address) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getMember() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation.MemberMapPair
-
- getMember() - Method in class com.hazelcast.spi.MembershipServiceEvent
-
Returns the removed or added member.
- getMemberAttributeChange() - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-
- getMemberAttributeConfig() - Method in class com.hazelcast.config.Config
-
- getMemberCount() - Method in class com.hazelcast.cluster.impl.JoinMessage
-
- getMemberCount() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getMemberCredentialsConfig() - Method in class com.hazelcast.config.SecurityConfig
-
- getMemberGroupConfigs() - Method in class com.hazelcast.config.PartitionGroupConfig
-
- getMemberGroupsSize() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getMemberGroupsSize() - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getMemberList() - Method in interface com.hazelcast.cluster.ClusterService
-
Gets the collection of members.
- getMemberList() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getMemberList() - Method in class com.hazelcast.monitor.TimedMemberState
-
- getMemberLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getMemberPartitions(Address) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getMemberPartitions(Address) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getMemberPartitionsMap() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getMemberPartitionsMap() - Method in interface com.hazelcast.partition.InternalPartitionService
-
Gets member partition IDs.
- getMembers() - Method in interface com.hazelcast.cluster.ClusterService
-
Returns a collection of all members part of the cluster.
- getMembers() - Method in class com.hazelcast.cluster.impl.ClusterProxy
-
- getMembers() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getMembers() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- getMembers() - Method in class com.hazelcast.config.TcpIpConfig
-
Gets a list of all the well known members.
- getMembers() - Method in interface com.hazelcast.core.Cluster
-
Set of current members of the cluster.
- getMembers() - Method in class com.hazelcast.core.InitialMembershipEvent
-
- getMembers() - Method in class com.hazelcast.core.MembershipEvent
-
Returns a consistent view of the the members exactly after this MembershipEvent has been processed.
- getMembers() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getMembers() - Method in class com.hazelcast.partition.client.PartitionsResponse
-
- getMembers() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- getMembers() - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- getMemberSocketInterceptor() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getMemberSocketInterceptor() - Method in interface com.hazelcast.instance.NodeExtension
-
Returns MemberSocketInterceptor for this Node if available,
otherwise returns null.
- getMemberSocketInterceptor() - Method in interface com.hazelcast.nio.IOService
-
- getMemberSocketInterceptor() - Method in class com.hazelcast.nio.NodeIOService
-
- getMemberState() - Method in class com.hazelcast.monitor.TimedMemberState
-
- GetMemberSystemPropertiesRequest - Class in com.hazelcast.management.request
-
Request for fetching member system properties.
- GetMemberSystemPropertiesRequest() - Constructor for class com.hazelcast.management.request.GetMemberSystemPropertiesRequest
-
- getMemoryLimit() - Method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- getMemoryStats() - Method in class com.hazelcast.management.DefaultTimedMemberStateFactory
-
- getMemoryStats() - Static method in class com.hazelcast.memory.MemoryStatsSupport
-
- getMergePolicy() - Method in class com.hazelcast.config.MapConfig
-
- getMergePolicy() - Method in class com.hazelcast.config.WanReplicationRef
-
- getMergePolicy() - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- getMergePolicy(String) - Method in class com.hazelcast.map.merge.MergePolicyProvider
-
- getMergePolicyProvider() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getMergePolicyProvider() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getMessage() - Method in class com.hazelcast.client.impl.client.GenericError
-
- getMessage() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-
- getMessageData() - Method in class com.hazelcast.topic.impl.DataAwareMessage
-
- getMessageListenerConfigs() - Method in class com.hazelcast.config.TopicConfig
-
- getMessageListenerConfigs() - Method in class com.hazelcast.config.TopicConfigReadOnly
-
- getMessageObject() - Method in class com.hazelcast.core.Message
-
Returns published message
- getMessageObject() - Method in class com.hazelcast.topic.impl.DataAwareMessage
-
- getMetadataSpacePercentage() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- getMethodCallSyntax(String, String, String...) - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- getMethodName() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- getMethodName() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getMethodName() - Method in interface com.hazelcast.client.impl.client.SecureRequest
-
Used for
SecurityInterceptor
Method name which called via a distributedObject
for map.put, methodName will be 'put'
For requests which do not produced via a distributedObject should return null, for example internal client.
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionAddAllRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionAddRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionClearRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionContainsRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionGetAllRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionIsEmptyRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionRemoveRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.CollectionSizeRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.ListGetRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.ListIndexOfRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.ListRemoveRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.ListSetRequest
-
- getMethodName() - Method in class com.hazelcast.collection.client.ListSubRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomiclong.client.SetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.GetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.atomicreference.client.SetRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.InitRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-
- getMethodName() - Method in class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapPutTransientRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapReplaceRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapSetRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- getMethodName() - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.CountRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.EntrySetRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.KeySetRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.SizeRequest
-
- getMethodName() - Method in class com.hazelcast.multimap.impl.client.ValuesRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.AddAllRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.ClearRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.ContainsRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.DrainRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.IsEmptyRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.IteratorRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.OfferRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.PeekRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.PollRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.RemainingCapacityRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.RemoveListenerRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.RemoveRequest
-
- getMethodName() - Method in class com.hazelcast.queue.impl.client.SizeRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-
- getMethodName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-
- getMethodName() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- getMethodName() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getMethodName() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- getMigrationData(PartitionReplicationEvent) - Method in class com.hazelcast.collection.CollectionService
-
- getMigrationEndpoint() - Method in class com.hazelcast.spi.PartitionMigrationEvent
-
- getMigrationQueueSize() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getMigrationQueueSize() - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getMimeTypes() - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getMinAge() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getMinAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the min age of the items in this member.
- getMinBlockSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- getMinEvictionCheckMillis() - Method in class com.hazelcast.config.MapConfig
-
Returns minimum milliseconds which should pass before asking if a partition of this map is evictable or not.
- getMinorCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- getMinorCollectionCount() - Method in interface com.hazelcast.monitor.LocalGCStats
-
- getMinorCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- getMinorCollectionTime() - Method in interface com.hazelcast.monitor.LocalGCStats
-
- getMisses() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getMisses() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the number of misses of the locally owned entries.
- getMonitor() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getMonthSeconds() - Static method in class com.hazelcast.ascii.TextCommandConstants
-
- getMulticastConfig() - Method in class com.hazelcast.config.JoinConfig
-
- getMulticastGroup() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast group.
- getMulticastPort() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast port.
- getMulticastTimeoutSeconds() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the multicast timeout in seconds.
- getMulticastTimeToLive() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the time to live of the multicast package.
- getMultiMap() - Method in class com.hazelcast.console.ConsoleApp
-
- getMultiMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed multimap instance with the specified name.
- getMultiMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getMultiMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getMultiMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional multimap instance with the specified name.
- getMultiMapConfig(String) - Method in class com.hazelcast.config.Config
-
- getMultiMapConfigs() - Method in class com.hazelcast.config.Config
-
- getMXBeans() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getMXBeans() - Method in interface com.hazelcast.monitor.MemberState
-
- getName() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getName() - Method in class com.hazelcast.cache.impl.CacheDistributedObject
-
- getName() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Gets the name of the cache.
- getName() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- getName() - Method in class com.hazelcast.cache.impl.CacheProxy
-
- getName() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets the name of the distributed object name of the cache.
- getName() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- getName() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- getName() - Method in class com.hazelcast.client.impl.client.GenericError
-
- getName() - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- getName() - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- getName() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getName() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- getName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- getName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-
- getName() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- getName() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- getName() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- getName() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- getName() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- getName() - Method in class com.hazelcast.config.CacheConfig
-
- getName() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getName() - Method in class com.hazelcast.config.CollectionConfig
-
- getName() - Method in class com.hazelcast.config.ExecutorConfig
-
- getName() - Method in class com.hazelcast.config.GroupConfig
-
Gets the group name of the group.
- getName() - Method in class com.hazelcast.config.JobTrackerConfig
-
- getName() - Method in class com.hazelcast.config.MapConfig
-
- getName() - Method in class com.hazelcast.config.MultiMapConfig
-
- getName() - Method in class com.hazelcast.config.NearCacheConfig
-
- getName() - Method in class com.hazelcast.config.PermissionConfig
-
- getName() - Method in class com.hazelcast.config.QueueConfig
-
- getName() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getName() - Method in class com.hazelcast.config.SemaphoreConfig
-
Gets the name of the semaphore.
- getName() - Method in class com.hazelcast.config.ServiceConfig
-
- getName() - Method in class com.hazelcast.config.TopicConfig
-
Gets the name of the topic, null if nothing is set.
- getName() - Method in class com.hazelcast.config.WanReplicationConfig
-
- getName() - Method in class com.hazelcast.config.WanReplicationRef
-
- getName() - Method in class com.hazelcast.core.AbstractIMapEvent
-
Returns the name of the map for this event.
- getName() - Method in interface com.hazelcast.core.DistributedObject
-
Returns the unique name for this DistributedObject.
- getName() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the name of this Hazelcast instance
- getName() - Method in interface com.hazelcast.core.IAtomicLong
-
Returns the name of this IAtomicLong instance.
- getName() - Method in interface com.hazelcast.core.ICollection
-
Returns the name of this collection
- getName() - Method in interface com.hazelcast.core.IMapEvent
-
Returns the name of the map for this event.
- getName() - Method in interface com.hazelcast.core.ISemaphore
-
Returns the name of this ISemaphore instance.
- getName() - Method in interface com.hazelcast.core.ITopic
-
Returns the name of this ITopic instance
- getName() - Method in interface com.hazelcast.core.MultiMap
-
Returns the name of this multimap.
- getName() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- getName() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getName() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getName() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getName() - Method in class com.hazelcast.instance.Node
-
- getName() - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- getName() - Method in class com.hazelcast.jmx.AtomicReferenceMBean
-
- getName() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getName() - Method in class com.hazelcast.jmx.ListMBean
-
- getName() - Method in class com.hazelcast.jmx.LockMBean
-
- getName() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-
- getName() - Method in class com.hazelcast.jmx.MapMBean
-
- getName() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getName() - Method in class com.hazelcast.jmx.NodeMBean
-
- getName() - Method in class com.hazelcast.jmx.QueueMBean
-
- getName() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getName() - Method in class com.hazelcast.jmx.SemaphoreMBean
-
- getName() - Method in class com.hazelcast.jmx.SetMBean
-
- getName() - Method in class com.hazelcast.jmx.TopicMBean
-
- getName() - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- getName() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- getName() - Method in interface com.hazelcast.map.impl.RecordStore
-
- getName() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- getName() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- getName() - Method in class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-
- getName() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-
- getName() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getName() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- getName() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-
- getName() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- getName() - Method in interface com.hazelcast.mapreduce.TrackableJob
-
- getName() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- getName() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- getName() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getName() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- getName() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- getName() - Method in class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- getName() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- getName() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation.MemberMapPair
-
- getName() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- getName() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- getName() - Method in class com.hazelcast.spi.impl.AbstractNamedOperation
-
- getName() - Method in class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- getName() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getName() - Method in class com.hazelcast.spi.ServiceInfo
-
- getName() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- getName() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-
- getName() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
-
- getNameAsPartitionAwareData() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- getNames() - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-
- getNamespace() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-
- getNamespace() - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-
- getNamespace() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getNamespace() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- getNamespace() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-
- getNamespace() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-
- getNamespace() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- getNamespace() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- getNamespace() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- getNameWithPrefix() - Method in class com.hazelcast.config.CacheConfig
-
- getNativeDataStorage() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getNativeDataStorage() - Method in interface com.hazelcast.instance.NodeExtension
-
Deprecated.
- getNativeMemoryConfig() - Method in class com.hazelcast.config.Config
-
- getNearCache(String) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- getNearCacheConfig() - Method in class com.hazelcast.config.CacheConfig
-
- getNearCacheConfig() - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- getNearCacheConfig() - Method in class com.hazelcast.config.MapConfig
-
- getNearCacheConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
-
- getNearCacheProvider() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getNearCacheProvider() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getNearCacheSizeEstimator() - Method in class com.hazelcast.map.impl.MapContainer
-
- getNearCacheSizeEstimator() - Method in class com.hazelcast.map.impl.NearCache
-
- getNearCacheStats() - Method in class com.hazelcast.map.impl.NearCache
-
- getNearCacheStats() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getNearCacheStats() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getNearCacheStats() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns statistics related to the Near Cache.
- getNetworkConfig() - Method in class com.hazelcast.config.Config
-
- getNewAddress() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-
- getNewOwner() - Method in class com.hazelcast.core.MigrationEvent
-
Returns the new owner of the migrating partition
- getNewValueData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-
- getNextRecordId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- getNode() - Method in interface com.hazelcast.ascii.TextCommandService
-
- getNode() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- getNode() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getNode() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getNodeEngine() - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getNodeEngine() - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getNodeEngine() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getNodeEngine() - Method in class com.hazelcast.instance.Node
-
- getNodeEngine() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getNodeEngine() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getNodeEngine() - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- getNodeEngine() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getNodeEngine() - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- getNodeEngine() - Method in class com.hazelcast.queue.impl.QueueService
-
- getNodeEngine() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
Gets the node engine.
- getNodeEngine() - Method in class com.hazelcast.spi.Operation
-
- getNodeExtension() - Method in class com.hazelcast.instance.Node
-
- getNodeMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getNodeName() - Method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
- getNotificationInfo() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- getNotifiedKey() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- getNotifiedKey() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- getNotifiedKey() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- getNotifiedKey() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- getNotifiedKey() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- getNotifiedKey() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- getNotifiedKey() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- getNotifiedKey() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- getNotifiedKey() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- getNotifiedKey() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- getNotifiedKey() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.operations.ClearOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.operations.DrainOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- getNotifiedKey() - Method in class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- getNotifiedKey() - Method in interface com.hazelcast.spi.Notifier
-
- getNumber(String) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- getNumber() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-
- getNumberOfAffectedEntries() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getNumberOfEntries() - Method in class com.hazelcast.map.impl.MapEventData
-
- getNumberOfEntriesAffected() - Method in class com.hazelcast.core.MapEvent
-
Returns the number of entries affected by this event.
- getObject() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-
- getObject(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getObject(JsonObject, String, JsonObject) - Static method in class com.hazelcast.util.JsonUtil
-
- getObjectCollection(NodeEngine) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- getObjectEntrySet(NodeEngine) - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-
- getObjectId() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns identifier of related DistributedObject
- getObjectName() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-
- getObjectName() - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
-
- getObjectName() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
-
- getObjectName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
-
- getObjectName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
-
- getObjectName() - Method in interface com.hazelcast.spi.ObjectNamespace
-
- getObjectName() - Method in interface com.hazelcast.spi.WaitNotifyKey
-
- getOfferOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the number of offer/put/add operations.
- getOfferWaitNotifyKey() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- getOffHeapStorage() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getOffHeapStorage() - Method in interface com.hazelcast.spi.NodeEngine
-
- getOldAddress() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-
- getOldOwner() - Method in class com.hazelcast.core.MigrationEvent
-
Returns the old owner of the migrating partition
- getOldValue() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-
- getOldValue() - Method in class com.hazelcast.core.EntryEvent
-
Returns the old value of the entry event
- getOldValue() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-
- getOldValue() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getOldValue() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getOldValueData() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-
- getOp() - Method in class com.hazelcast.spi.InvocationBuilder
-
- GetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- GetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-
- GetOperation(String) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-
- GetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- GetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-
- GetOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-
- GetOperation - Class in com.hazelcast.map.impl.operation
-
- GetOperation() - Constructor for class com.hazelcast.map.impl.operation.GetOperation
-
- GetOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.GetOperation
-
- getOperationExecutorQueueSize() - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- getOperationExecutorQueueSize() - Method in class com.hazelcast.spi.impl.BasicOperationScheduler
-
- getOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.OperationService
-
- getOperationProvider() - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- getOperationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getOperationService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getOperationServiceBean() - Method in class com.hazelcast.management.SerializableMXBeans
-
- getOperationServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getOperationThreadCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
-
- getOperationThreadCount() - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- getOperationType() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-
- getOperationType() - Method in class com.hazelcast.core.MemberAttributeEvent
-
- getOrConnect(Address) - Method in interface com.hazelcast.nio.ConnectionManager
-
- getOrConnect(Address, boolean) - Method in interface com.hazelcast.nio.ConnectionManager
-
- getOrConnect(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getOrConnect(Address, boolean) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getOrCreateCache(String, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getOrCreateCache(String) - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- getOrCreateCache(String, int) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getOrCreateCollectionContainer(int, String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- getOrCreateCollectionWrapper() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- getOrCreateCombiner(KeyIn) - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-
- getOrCreateContainer() - Method in class com.hazelcast.collection.CollectionOperation
-
- getOrCreateContainer(String, boolean) - Method in class com.hazelcast.collection.CollectionService
-
- getOrCreateContainer(String, boolean) - Method in class com.hazelcast.collection.list.ListService
-
- getOrCreateContainer(String, boolean) - Method in class com.hazelcast.collection.set.SetService
-
- getOrCreateContainer() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- getOrCreateContainer() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- getOrCreateContainer(String, boolean) - Method in class com.hazelcast.queue.impl.QueueService
-
- getOrCreateContext(MapCombineTask) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getOrCreateHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
-
Gets or creates the HazelcastInstance with a certain name.
- getOrCreateHazelcastInstance(Config) - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-
- getOrCreateListContainer() - Method in class com.hazelcast.collection.CollectionOperation
-
- getOrCreateMultiMapContainer(String) - Method in class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-
- getOrCreatePermit(String) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- getOrderLock(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- getOrigin() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getOrPutIfAbsent(ConcurrentMap<K, V>, K, ConstructorFunction<K, V>) - Static method in class com.hazelcast.util.ConcurrencyUtil
-
- getOrPutSynchronized(ConcurrentMap<K, V>, K, Object, ConstructorFunction<K, V>) - Static method in class com.hazelcast.util.ConcurrencyUtil
-
- getOtherOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getOtherOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getOtherOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the total number of Other Operations
- getOtherOperationsCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getOtherOperationsCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns number of other operations
- getOutboundPortDefinitions() - Method in class com.hazelcast.config.NetworkConfig
-
- getOutboundPorts() - Method in class com.hazelcast.config.NetworkConfig
-
- getOutboundPorts() - Method in interface com.hazelcast.nio.IOService
-
- getOutboundPorts() - Method in class com.hazelcast.nio.NodeIOService
-
- getOutputStatement(String) - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getOwnedEntryCount() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getOwnedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of entries owned by this member.
- getOwnedEntryCount() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the number of entries owned by this member.
- getOwnedEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getOwnedEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getOwnedEntryMemoryCost() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getOwnedEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns memory cost (number of bytes) of owned entries in this member.
- getOwnedEntryMemoryCost() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns memory cost (number of bytes) of entries in this cache.
- getOwnedItemCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getOwnedItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the number of owned items in this member.
- getOwnedPartitions() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getOwnedPartitions() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getOwner() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getOwner() - Method in interface com.hazelcast.core.Partition
-
Returns the current member that owns this partition.
- getOwner() - Method in class com.hazelcast.mapreduce.impl.task.JobPartitionStateImpl
-
- getOwner() - Method in interface com.hazelcast.mapreduce.JobPartitionState
-
Returns the owner of this partition
- getOwner() - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
-
- getOwnerIndexes() - Method in class com.hazelcast.partition.client.PartitionsResponse
-
- getOwnerInfo(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- getOwnerInfo(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getOwnerInfo(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- getOwnerOrNull() - Method in interface com.hazelcast.partition.InternalPartition
-
Returns the Address of the owner of this partition.
- getOwnerUuid() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-
- getOwnerUuid() - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- getPacketVersion() - Method in class com.hazelcast.cluster.impl.JoinMessage
-
- getPage() - Method in class com.hazelcast.query.PagingPredicate
-
- getPageSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- getPageSize() - Method in class com.hazelcast.query.PagingPredicate
-
- getParameter(String) - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- getParameters() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- getParameters() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- getParameters() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getParameters() - Method in interface com.hazelcast.client.impl.client.SecureRequest
-
Used for
SecurityInterceptor
Parameters passed to the method by a distributedObject
for map.put(key, value) parameters should be 'key' and 'value'
parameters can be in binary or object form, underlying implementation will de-serialize lazily
- getParameters() - Method in class com.hazelcast.collection.client.CollectionAddAllRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.CollectionAddRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.CollectionContainsRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.CollectionRemoveRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.ListAddAllRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.ListAddRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.ListGetRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.ListIndexOfRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.ListRemoveRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.ListSetRequest
-
- getParameters() - Method in class com.hazelcast.collection.client.ListSubRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.atomicreference.client.SetRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-
- getParameters() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapPutTransientRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapReplaceRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapSetRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-
- getParameters() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- getParameters() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- getParameters() - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-
- getParameters() - Method in class com.hazelcast.multimap.impl.client.CountRequest
-
- getParameters() - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-
- getParameters() - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-
- getParameters() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-
- getParameters() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-
- getParameters() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-
- getParameters() - Method in class com.hazelcast.queue.impl.client.AddAllRequest
-
- getParameters() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- getParameters() - Method in class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
-
- getParameters() - Method in class com.hazelcast.queue.impl.client.ContainsRequest
-
- getParameters() - Method in class com.hazelcast.queue.impl.client.DrainRequest
-
- getParameters() - Method in class com.hazelcast.queue.impl.client.OfferRequest
-
- getParameters() - Method in class com.hazelcast.queue.impl.client.PollRequest
-
- getParameters() - Method in class com.hazelcast.queue.impl.client.RemoveRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getParameters() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- getParameters() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- getParameters() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getPartition() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- getPartition() - Method in class com.hazelcast.client.impl.client.KeyBasedClientRequest
-
- getPartition() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
-
- getPartition() - Method in class com.hazelcast.collection.client.CollectionRequest
-
- getPartition() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- getPartition() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- getPartition() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-
- getPartition() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- getPartition() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-
- getPartition() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-
- getPartition() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- getPartition(Object) - Method in interface com.hazelcast.core.PartitionService
-
Returns partition which given key belongs to.
- getPartition() - Method in class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- getPartition() - Method in class com.hazelcast.multimap.impl.client.MultiMapKeyBasedRequest
-
- getPartition(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartition(int, boolean) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartition(int) - Method in interface com.hazelcast.partition.InternalPartitionService
-
Returns the InternalPartition for a given partitionId.
- getPartition(int, boolean) - Method in interface com.hazelcast.partition.InternalPartitionService
-
Returns the InternalPartition for a given partitionId.
- getPartition(Object) - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- getPartition(int) - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- getPartition() - Method in class com.hazelcast.queue.impl.client.QueueRequest
-
- getPartition() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getPartitionContainer(int) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getPartitionContainer(int) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getPartitionContainer(int) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- getPartitionCount() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- getPartitionCount() - Method in class com.hazelcast.jmx.PartitionServiceMBean
-
- getPartitionCount() - Method in class com.hazelcast.management.SerializablePartitionServiceBean
-
- getPartitionCount() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitionCount() - Method in interface com.hazelcast.partition.InternalPartitionService
-
Returns the number of partitions.
- getPartitionGroupConfig() - Method in class com.hazelcast.config.Config
-
- getPartitionHash() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns partition hash calculated for serialized object.
- getPartitionHash() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- getPartitionId() - Method in class com.hazelcast.cache.impl.CachePartitionSegment
-
- getPartitionId(NodeEngine, Data) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
- getPartitionId() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getPartitionId() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getPartitionId() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- getPartitionId() - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- getPartitionId() - Method in class com.hazelcast.core.MigrationEvent
-
Returns the id of the partition which is (or being) migrated
- getPartitionId() - Method in interface com.hazelcast.core.Partition
-
Returns id of the partition.
- getPartitionId() - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getPartitionId() - Method in interface com.hazelcast.map.impl.RecordStore
-
- getPartitionId() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- getPartitionId() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- getPartitionId() - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-
- getPartitionId() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- getPartitionId() - Method in class com.hazelcast.nio.Packet
-
Returns the partition id of this packet.
- getPartitionId(Data) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitionId(Object) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitionId() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-
- getPartitionId() - Method in interface com.hazelcast.partition.InternalPartition
-
Returns the partition id.
- getPartitionId(Data) - Method in interface com.hazelcast.partition.InternalPartitionService
-
Returns the partition id for a Data key.
- getPartitionId(Object) - Method in interface com.hazelcast.partition.InternalPartitionService
-
Returns the partition id for a given object.
- getPartitionId() - Method in class com.hazelcast.partition.MigrationInfo
-
- getPartitionId() - Method in class com.hazelcast.partition.PartitionInfo
-
- getPartitionId() - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
-
- getPartitionId() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getPartitionId() - Method in class com.hazelcast.spi.Operation
-
- getPartitionId() - Method in interface com.hazelcast.spi.PartitionAwareOperation
-
- getPartitionId() - Method in class com.hazelcast.spi.PartitionMigrationEvent
-
- getPartitionId() - Method in class com.hazelcast.spi.PartitionReplicationEvent
-
The id of the partition.
- getPartitionIds() - Method in class com.hazelcast.map.impl.QueryResult
-
- getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getPartitioningStrategy(ClassLoader) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getPartitioningStrategy() - Method in class com.hazelcast.map.impl.MapContainer
-
- getPartitioningStrategyClass() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfig
-
- getPartitioningStrategyConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
-
- getPartitionKey() - Method in interface com.hazelcast.core.DistributedObject
-
Returns the key of partition this DistributedObject is assigned to.
- getPartitionKey() - Method in interface com.hazelcast.core.PartitionAware
-
The key that will be used by Hazelcast to specify the partition.
- getPartitionKey() - Method in class com.hazelcast.core.PartitionAwareKey
-
- getPartitionKey(K) - Method in interface com.hazelcast.core.PartitioningStrategy
-
Returns the key object that will be used by Hazelcast to specify the partition.
- getPartitionKey() - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- getPartitionKey() - Method in class com.hazelcast.jmx.AtomicReferenceMBean
-
- getPartitionKey() - Method in class com.hazelcast.jmx.CountDownLatchMBean
-
- getPartitionKey() - Method in class com.hazelcast.jmx.LockMBean
-
- getPartitionKey() - Method in class com.hazelcast.jmx.QueueMBean
-
- getPartitionKey() - Method in class com.hazelcast.jmx.SemaphoreMBean
-
- getPartitionKey() - Method in class com.hazelcast.jmx.SetMBean
-
- getPartitionKey() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.DefaultPartitioningStrategy
-
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
-
- getPartitionKey(Object) - Method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- getPartitionKey(String) - Static method in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- getPartitionKey() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- getPartitionKey() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- getPartitionMigrationTimeout() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitionOperationThreadCount() - Method in interface com.hazelcast.spi.OperationService
-
- getPartitionOwner(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitionOwner(int) - Method in interface com.hazelcast.partition.InternalPartitionService
-
Gets the owner of the partition if it's set.
- getPartitionOwnerOrWait(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitionOwnerOrWait(int) - Method in interface com.hazelcast.partition.InternalPartitionService
-
Gets the owner of the partition.
- getPartitionReplicaVersions(int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitionReplicaVersions(int) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getPartitions() - Method in class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-
- getPartitions() - Method in interface com.hazelcast.core.PartitionService
-
Returns a set containing all the
Partition
s in the cluster.
- getPartitions() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- getPartitions() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getPartitions() - Method in interface com.hazelcast.monitor.MemberState
-
- getPartitions() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitions() - Method in interface com.hazelcast.partition.InternalPartitionService
-
- getPartitions() - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- getPartitions() - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- getPartitionService() - Method in interface com.hazelcast.client.ClientEngine
-
- getPartitionService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getPartitionService() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the partition service of this Hazelcast instance.
- getPartitionService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getPartitionService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getPartitionService() - Method in class com.hazelcast.instance.Node
-
- getPartitionService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getPartitionService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getPartitionServiceBean() - Method in class com.hazelcast.management.SerializableMXBeans
-
- getPartitionServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getPartitionServiceProxy() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- getPartitionServiceProxy() - Method in interface com.hazelcast.partition.InternalPartitionService
-
- GetPartitionsRequest - Class in com.hazelcast.partition.client
-
- GetPartitionsRequest() - Constructor for class com.hazelcast.partition.client.GetPartitionsRequest
-
- getPartitionStates() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- getPartitionStates() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- getPartitionStates() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
-
- getPassword() - Method in class com.hazelcast.config.GroupConfig
-
Gets the password of the group.
- getPassword() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getPendingTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getPendingTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
-
Returns the number of pending operations of the executor service
- getPermission(String, String, String...) - Static method in class com.hazelcast.security.permission.ActionConstants
-
Creates a permission
- getPermissions(Subject, Class<? extends Permission>) - Method in interface com.hazelcast.security.IPermissionPolicy
-
Determines permissions of subject.
- getPermissions() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- getPermit() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-
- getPollOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the number of poll/take/remove operations.
- getPollWaitNotifyKey() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- getPoolSize() - Method in class com.hazelcast.config.ExecutorConfig
-
- getPoolSize() - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- getPoolSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- getPoolSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-
- getPort() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the port the Hazelcast member is going to try to bind on.
- getPort() - Method in class com.hazelcast.instance.MemberImpl
-
- getPort() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getPort() - Method in class com.hazelcast.nio.Address
-
- getPort() - Method in interface com.hazelcast.nio.Connection
-
The remote port.
- getPort() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getPort() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
-
- getPortableContext() - Method in interface com.hazelcast.nio.IOService
-
- getPortableContext() - Method in class com.hazelcast.nio.NodeIOService
-
- getPortableContext() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- getPortableContext() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- getPortableContext() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- getPortableContext() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getPortableFactories() - Method in class com.hazelcast.config.SerializationConfig
-
- getPortableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
-
- getPortableVersion() - Method in class com.hazelcast.config.SerializationConfig
-
Portable version will be used to differentiate two same class that have changes on it
, like adding/removing field or changing a type of a field.
- getPortCount() - Method in class com.hazelcast.config.NetworkConfig
-
Returns the maximum number of ports allowed to try to bind on.
- getPossibleInetAddressesFor(Inet6Address) - Static method in class com.hazelcast.util.AddressUtil
-
- getPostJoinOperation() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getPostJoinOperation() - Method in class com.hazelcast.map.impl.MapService
-
- getPostJoinOperation() - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- getPostJoinOperation() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- getPostJoinOperation() - Method in interface com.hazelcast.spi.PostJoinAwareService
-
Post join operations must be lock free; means no locks at all;
no partition locks, no key-based locks, no service level locks!
Post join operations should return response, at least a null response.
- getPostJoinOperations() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
Post join operations must be lock free; means no locks at all;
no partition locks, no key-based locks, no service level locks!
Post join operations should return response, at least a null response.
- getPredicate() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- getPredicate() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- getPredicate() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- getPredicate() - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-
- getPredicate() - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-
- getPredicate() - Method in class com.hazelcast.map.impl.client.MapSQLQueryRequest
-
- getPredicate() - Method in class com.hazelcast.map.impl.client.TxnMapRequest
-
- getPredicate() - Method in class com.hazelcast.map.impl.client.TxnMapRequestWithSQLQuery
-
- getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-
- getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
-
- getPredicate() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-
- getPredicate() - Method in class com.hazelcast.map.impl.QueryEventFilter
-
- getPredicate() - Method in class com.hazelcast.query.PagingPredicate
-
- getPredicate() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedQueryEventFilter
-
- getPrincipal() - Method in interface com.hazelcast.client.ClientEndpoint
-
- getPrincipal() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getPrincipal() - Method in class com.hazelcast.config.PermissionConfig
-
- getPrincipal() - Method in class com.hazelcast.security.AbstractCredentials
-
- getPrincipal() - Method in interface com.hazelcast.security.Credentials
-
Returns principal of endpoint.
- getPriorityOperationExecutorQueueSize() - Method in class com.hazelcast.spi.impl.BasicOperationScheduler
-
- getPriorityOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.OperationService
-
- getProcessedRecords() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- getProcessedRecords() - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- getProcessedRecords() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
-
Returns the number of processed records.
The number of processed records is not a real time value but updated
on regular base (after 1000 processed elements per node).
- getProgram(String...) - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getProperties() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getProperties() - Method in class com.hazelcast.config.Config
-
- getProperties() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- getProperties() - Method in class com.hazelcast.config.LoginModuleConfig
-
- getProperties() - Method in class com.hazelcast.config.MapStoreConfig
-
- getProperties() - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- getProperties() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getProperties() - Method in class com.hazelcast.config.ServiceConfig
-
- getProperties() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Gets all properties.
- getProperties() - Method in class com.hazelcast.config.SSLConfig
-
Gets all properties.
- getProperties() - Method in class com.hazelcast.config.XmlConfigBuilder
-
Gets the current used properties.
- getProperty(String) - Method in class com.hazelcast.config.Config
-
- getProperty(String) - Method in class com.hazelcast.config.MapStoreConfig
-
- getProperty(String) - Method in class com.hazelcast.config.QueueStoreConfig
-
- getProperty(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Gets a property.
- getProperty(String) - Method in class com.hazelcast.config.SSLConfig
-
Gets a property.
- getProxyCount() - Method in class com.hazelcast.jmx.ProxyServiceMBean
-
- getProxyCount() - Method in class com.hazelcast.management.SerializableProxyServiceBean
-
- getProxyCount() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- getProxyCount() - Method in interface com.hazelcast.spi.ProxyService
-
- getProxyService() - Method in interface com.hazelcast.client.ClientEngine
-
- getProxyService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getProxyService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getProxyService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getProxyServiceBean() - Method in class com.hazelcast.management.SerializableMXBeans
-
- getProxyServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getPublicAddress() - Method in class com.hazelcast.config.NetworkConfig
-
- getPublicAddress() - Method in interface com.hazelcast.instance.AddressPicker
-
- getPublishingMember() - Method in class com.hazelcast.core.Message
-
Returns the member that published the message
- getPublishOperationCount() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-
- getPublishOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
-
Returns the total number of published messages of this topic on this member
- getPublishTime() - Method in class com.hazelcast.core.Message
-
Return the time when the message is published
- getPublishTime() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-
- getPutOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getPutOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getPutOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of put operations
- getQueryExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getQueue() - Method in class com.hazelcast.console.ConsoleApp
-
- getQueue(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed queue instance with the specified name.
- getQueue(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getQueue(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getQueue(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional queue instance with the specified name.
- getQueueCapacity() - Method in class com.hazelcast.config.ExecutorConfig
-
- getQueueConfig(String) - Method in class com.hazelcast.config.Config
-
- getQueueConfigs() - Method in class com.hazelcast.config.Config
-
- getQueueService() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- getQueueSize() - Method in class com.hazelcast.config.JobTrackerConfig
-
- getQueueSize() - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- getQueueSize() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- getQueueSize() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-
- getQueueSize() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
-
- getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfig
-
- getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- getRatio() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- getRatio() - Method in interface com.hazelcast.monitor.NearCacheStats
-
Returns the hit/miss ratio of the locally owned entries.
- getRawDataInput() - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- getRawDataInput() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getRawDataOutput() - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
-
- getRawDataOutput() - Method in interface com.hazelcast.nio.serialization.PortableWriter
-
After writing portable fields, one can write remaining fields in old fashioned way consecutively at the end
of stream.
- getReadHandler() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getReadonlyMap() - Method in class com.hazelcast.map.impl.NearCache
-
- getReadOnlyRecords() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getReadOnlyRecords() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Returns a readonly map of the internal key value store.
- getReceiveOperationCount() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-
- getReceiveOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
-
Returns the total number of received messages of this topic on this member
- getRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- getRecord(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Gets internal record of the store by key.
- getRecord(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getRecord(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- getRecordCollection(NodeEngine) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- getRecordFactory() - Method in class com.hazelcast.map.impl.MapContainer
-
- getRecordId() - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-
- getRecordId() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- getRecordId() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- getRecordIds() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- getRecordMap() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getRecordMap() - Method in interface com.hazelcast.map.impl.RecordStore
-
Returns records map.
- getRecordMap(Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
-
- getRecordMap(Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- getRecordMap(Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- getRecordOrNull(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- getRecordOrNull(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
Returns live record or null if record is already expired.
- getRecords(Comparable[]) - Method in interface com.hazelcast.query.impl.Index
-
- getRecords(Comparable) - Method in interface com.hazelcast.query.impl.Index
-
- getRecords(Comparable[]) - Method in class com.hazelcast.query.impl.IndexImpl
-
- getRecords(Comparable) - Method in class com.hazelcast.query.impl.IndexImpl
-
- getRecords(Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
-
- getRecords(MultiResultSet, Set<Comparable>) - Method in interface com.hazelcast.query.impl.IndexStore
-
- getRecords(Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- getRecords(MultiResultSet, Set<Comparable>) - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- getRecords(Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- getRecords(MultiResultSet, Set<Comparable>) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- getRecordStore(int, String) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getRecordStore(int, String) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getRecordStore(String) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- getRecordValue(R) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- getRecordValues() - Method in class com.hazelcast.query.impl.IndexImpl
-
- getReducerAddressByKey(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getReducerByKey(Object) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getReducerEventInterests(int) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- getReducerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.Aggregation
-
Returns the ReducerFactory for this aggregation.
- getReducerFactory() - Method in interface com.hazelcast.mapreduce.aggregation.impl.AggType
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalAvgAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMaxAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalMinAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigDecimalSumAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerAvgAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMaxAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerMinAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.BigIntegerSumAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMaxAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.ComparableMinAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.CountAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DistinctValuesAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleAvgAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMaxAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleMinAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.DoubleSumAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongAvgAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMaxAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongMinAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.aggregation.impl.LongSumAggregation
-
- getReducerFactory() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getReducerTask(String) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- getReference(String) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- getReference() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-
- getRegion() - Method in class com.hazelcast.config.AwsConfig
-
Gets the region where the EC2 instances running the Hazelcast members will be running.
- getRegistrationId() - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- getRegistrations(String, String) - Method in interface com.hazelcast.spi.EventService
-
Returns all registrations belonging to the given service and topic.
- getRegistrations(String, String) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- getRegistrationsAsArray(String, String) - Method in interface com.hazelcast.spi.EventService
-
Returns all registrations belonging to the given service and topic as an array.
- getRegistrationsAsArray(String, String) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- getRejectedOfferOperationCount() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- getRejectedOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
-
Returns the number of rejected offers.
- GetRemainingLeaseRequest - Class in com.hazelcast.concurrent.lock.client
-
- GetRemainingLeaseRequest() - Constructor for class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- GetRemainingLeaseRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- getRemainingLeaseTime() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- getRemainingLeaseTime(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-
- getRemainingLeaseTime() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getRemainingLeaseTime(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- getRemainingLeaseTime(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getRemainingLeaseTime(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- getRemainingLeaseTime() - Method in interface com.hazelcast.core.ILock
-
Returns remaining lease time in milliseconds.
- getRemainingLeaseTime() - Method in class com.hazelcast.jmx.LockMBean
-
- GetRemainingLeaseTimeOperation - Class in com.hazelcast.concurrent.lock.operations
-
- GetRemainingLeaseTimeOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-
- GetRemainingLeaseTimeOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-
- getRemainingQueueCapacity() - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- getRemainingQueueCapacity() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- getRemainingQueueCapacity() - Method in interface com.hazelcast.util.executor.ManagedExecutorService
-
- getRemainingQueueCapacity() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
-
- getRemoteOperationCount() - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- getRemoteOperationsCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
-
- getRemoteOperationsCount() - Method in interface com.hazelcast.spi.OperationService
-
- getRemoteSocketAddress() - Method in interface com.hazelcast.nio.Connection
-
Returns the address of the endpoint this Connection is connected to, or
null
if it is unconnected.
- getRemoteSocketAddress() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getRemoveOperationCount() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getRemoveOperationCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getRemoveOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the number of Remove operations
- getRemoveTime() - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- getReplicaAddress(int) - Method in interface com.hazelcast.partition.InternalPartition
-
Returns Address of the replica.
- getReplicaAddress(int) - Method in class com.hazelcast.partition.PartitionInfo
-
- getReplicaAddresses() - Method in class com.hazelcast.partition.PartitionInfo
-
- getReplicaCount() - Method in class com.hazelcast.partition.PartitionInfo
-
- getReplicaIndex() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
-
- getReplicaIndex() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-
- getReplicaIndex() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getReplicaIndex() - Method in class com.hazelcast.spi.Operation
-
- getReplicaIndex() - Method in class com.hazelcast.spi.PartitionReplicationEvent
-
The replica index.
- getReplicatedMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the replicated map instance with the specified name.
- getReplicatedMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getReplicatedMap(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getReplicatedMapConfig(String) - Method in class com.hazelcast.config.Config
-
- getReplicatedMapConfig(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- getReplicatedMapConfigs() - Method in class com.hazelcast.config.Config
-
- getReplicatedMapStats() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- getReplicatedRecord(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- getReplicatedRecord(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- getReplicatedRecordStore() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- getReplicatedRecordStore() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getReplicatedRecordStore(String, boolean) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- getReplicationDelayMillis() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getReplicationEventCount() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getReplicationEventCount() - Method in interface com.hazelcast.monitor.LocalReplicatedMapStats
-
- getReplicationImpl() - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- getReplicationImplObject() - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- getReplicationMessages() - Method in class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- getReplicationPublisher() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- getReplicatorExecutorService() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- getRequest() - Method in class com.hazelcast.cluster.impl.operations.JoinRequestOperation
-
- GetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- GetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetRequest
-
- GetRequest(String) - Constructor for class com.hazelcast.concurrent.atomicreference.client.GetRequest
-
- getRequestId() - Method in class com.hazelcast.ascii.AbstractTextCommand
-
- getRequestId() - Method in interface com.hazelcast.ascii.TextCommand
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionAddAllRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionAddRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionClearRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionContainsRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionGetAllRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionIsEmptyRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionRemoveRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.CollectionSizeRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.ListGetRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.ListIndexOfRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.ListRemoveRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.ListSetRequest
-
- getRequiredAction() - Method in class com.hazelcast.collection.client.ListSubRequest
-
- getRequiredMember() - Method in class com.hazelcast.config.TcpIpConfig
-
Gets the required member.
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-
- getRequiredPermission() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-
- getRequiredPermission() - Method in interface com.hazelcast.client.impl.client.SecureRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.CollectionRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.TxnListAddRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.TxnListRemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.TxnListSizeRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.TxnSetAddRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.TxnSetRemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.collection.client.TxnSetSizeRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.LockRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.lock.client.UnlockRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.InitRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-
- getRequiredPermission() - Method in class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-
- getRequiredPermission() - Method in class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapLockRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-
- getRequiredPermission() - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- getRequiredPermission() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-
- getRequiredPermission() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-
- getRequiredPermission() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-
- getRequiredPermission() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.AddAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.ClearRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.DrainRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.OfferRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.PollRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.QueueRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.RemoveListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.RemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.TxnOfferRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.TxnPeekRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.TxnPollRequest
-
- getRequiredPermission() - Method in class com.hazelcast.queue.impl.client.TxnSizeRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapClearRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapEntrySetRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapIsEmptyRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapKeySetRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapSizeRequest
-
- getRequiredPermission() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapValuesRequest
-
- getRequiredPermission() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getRequiredPermission() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.PrepareTransactionRequest
-
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.RecoverAllTransactionsRequest
-
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.RecoverTransactionRequest
-
- getRequiredPermission() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-
- getResource(String) - Method in class com.hazelcast.util.FilteringClassLoader
-
- getResourceAsStream(String) - Method in class com.hazelcast.util.FilteringClassLoader
-
- getResources(String) - Method in class com.hazelcast.util.FilteringClassLoader
-
- getResponse() - Method in class com.hazelcast.cache.impl.CacheClearResponse
-
- getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getResponse() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- getResponse() - Method in class com.hazelcast.client.impl.client.ClientResponse
-
- getResponse() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.JoinCheckOperation
-
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.MasterClaimOperation
-
- getResponse() - Method in class com.hazelcast.cluster.impl.operations.PrepareMergeOperation
-
- getResponse() - Method in class com.hazelcast.collection.CollectionOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- getResponse() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-
- getResponse() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-
- getResponse() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
-
- getResponse() - Method in class com.hazelcast.management.operation.GetMapConfigOperation
-
- getResponse() - Method in class com.hazelcast.management.operation.ScriptExecutorOperation
-
- getResponse() - Method in class com.hazelcast.management.operation.ThreadDumpOperation
-
- getResponse() - Method in class com.hazelcast.management.operation.UpdateManagementCenterUrlOperation
-
- getResponse() - Method in class com.hazelcast.management.operation.UpdateMapConfigOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.GetOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapEntrySetOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapIsEmptyOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapKeySetOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapSizeOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MapValuesOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.QueryOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.QueryPartitionOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.SetOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.operation.WanOriginatedDeleteOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
-
- getResponse() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-
- getResponse() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-
- getResponse() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- getResponse() - Method in class com.hazelcast.partition.impl.AssignPartitions
-
- getResponse() - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-
- getResponse() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-
- getResponse() - Method in class com.hazelcast.partition.impl.HasOngoingMigration
-
- getResponse() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-
- getResponse() - Method in class com.hazelcast.partition.impl.MigrationOperation
-
- getResponse() - Method in class com.hazelcast.partition.impl.MigrationRequestOperation
-
- getResponse() - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-
- getResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- getResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- getResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- getResponse() - Method in class com.hazelcast.partition.impl.SafeStateCheckOperation
-
- getResponse() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- getResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-
- getResponse() - Method in class com.hazelcast.spi.AbstractOperation
-
- getResponse() - Method in class com.hazelcast.spi.impl.EventServiceImpl.DeregistrationOperation
-
- getResponse() - Method in class com.hazelcast.spi.impl.EventServiceImpl.RegistrationOperation
-
- getResponse() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- getResponse() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl.DistributedObjectDestroyOperation
-
- getResponse() - Method in class com.hazelcast.spi.Operation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.BeginTxBackupOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.RecoverTxnOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- getResponse() - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- getResponseHandler() - Method in interface com.hazelcast.spi.impl.RemotePropagatable
-
- getResponseHandler() - Method in class com.hazelcast.spi.Operation
-
- getResponseQueueSize() - Method in class com.hazelcast.jmx.OperationServiceMBean
-
- getResponseQueueSize() - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- getResponseQueueSize() - Method in class com.hazelcast.spi.impl.BasicOperationScheduler
-
- getResponseQueueSize() - Method in interface com.hazelcast.spi.OperationService
-
- getResult() - Method in class com.hazelcast.map.impl.QueryResult
-
- getResult() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- getResult() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- GetResultOperation - Class in com.hazelcast.mapreduce.impl.operation
-
This operation is used to retrieve results from a remote node
- GetResultOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- GetResultOperation(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- GetResultOperationFactory - Class in com.hazelcast.mapreduce.impl.operation
-
- GetResultOperationFactory(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory
-
- getResultState() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-
- getResultState() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- getRetryCount() - Method in class com.hazelcast.config.JobTrackerConfig
-
- getRevision() - Method in class com.hazelcast.instance.BuildInfo
-
- getRunnable() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- getRunningOperationsCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
-
- getRunningOperationsCount() - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- getRunningOperationsCount() - Method in interface com.hazelcast.spi.OperationService
-
- getRuntimeProps() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- getRuntimeProps() - Method in interface com.hazelcast.monitor.MemberState
-
- getSafely() - Method in interface com.hazelcast.spi.InternalCompletableFuture
-
- getSalt() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- getScheduledDelayMillis() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- getScheduledExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
-
- getScheduledExecutor(String) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- getScheduledExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getScheduleStartTimeInNanos() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- getScopedHost() - Method in class com.hazelcast.nio.Address
-
- getScopeId() - Method in class com.hazelcast.nio.Address
-
- getScopeId() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
-
- getScriptEngine() - Method in class com.hazelcast.osgi.OSGiScriptEngineFactory
-
- getScriptEngineManager() - Static method in class com.hazelcast.management.ScriptEngineManagerContext
-
- getSecond() - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- getSecretKey() - Method in class com.hazelcast.config.AwsConfig
-
Gets the secret key to access AWS.
- getSecurityConfig() - Method in class com.hazelcast.config.Config
-
- getSecurityContext() - Method in interface com.hazelcast.client.ClientEngine
-
- getSecurityContext() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getSecurityContext() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getSecurityContext() - Method in interface com.hazelcast.instance.NodeExtension
-
Returns SecurityContext for this Node if available, otherwise returns null.
- getSecurityGroupName() - Method in class com.hazelcast.config.AwsConfig
-
Gets the security group name.
- getSecurityInterceptorConfigs() - Method in class com.hazelcast.config.SecurityConfig
-
- getSegment(int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getSegment(int) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getSelector() - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- getSelector() - Method in interface com.hazelcast.nio.tcp.IOSelector
-
- getSelectorThreadCount() - Method in interface com.hazelcast.nio.IOService
-
- getSelectorThreadCount() - Method in class com.hazelcast.nio.NodeIOService
-
- getSemaphore(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Creates cluster-wide semaphore.
- getSemaphore(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getSemaphore(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getSemaphoreConfig(String) - Method in class com.hazelcast.config.Config
-
Returns the SemaphoreConfig for the given name
- getSemaphoreConfigs() - Method in class com.hazelcast.config.Config
-
Returns the collection of semaphore configs.
- getSender() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- getSerializationConfig() - Method in class com.hazelcast.config.Config
-
- getSerializationService() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getSerializationService() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getSerializationService() - Method in class com.hazelcast.instance.Node
-
- getSerializationService() - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- getSerializationService() - Method in interface com.hazelcast.nio.IOService
-
- getSerializationService() - Method in class com.hazelcast.nio.NodeIOService
-
- getSerializationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getSerializationService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getSerializationType() - Method in class com.hazelcast.mapreduce.impl.JobPartitionStateArraySerializerHook
-
- getSerializationType() - Method in class com.hazelcast.mapreduce.impl.JobPartitionStateSerializerHook
-
- getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Returns the actual class type of the serialized object
- getSerializationType() - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook
-
- getSerializationType() - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook
-
- getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
-
- getServerSocketChannel() - Method in interface com.hazelcast.instance.AddressPicker
-
- getService() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getService() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getService() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getService() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
Gets the Service of this AbstractDistributedObject.
- getService(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getService() - Method in class com.hazelcast.spi.Operation
-
- getService() - Method in class com.hazelcast.spi.ServiceInfo
-
- getServiceConfig(String) - Method in class com.hazelcast.config.ServicesConfig
-
- getServiceConfigs() - Method in class com.hazelcast.config.ServicesConfig
-
- getServiceImpl() - Method in class com.hazelcast.config.ServiceConfig
-
- getServiceInfos(Class) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getServiceName() - Method in class com.hazelcast.cache.impl.CacheDistributedObject
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheRemoveEntryListenerRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- getServiceName() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.DistributedObjectListenerRequest
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.RemoveAllListeners
-
- getServiceName() - Method in class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-
- getServiceName() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- getServiceName() - Method in class com.hazelcast.client.impl.operations.PostJoinClientOperation
-
- getServiceName() - Method in class com.hazelcast.cluster.client.AddMembershipListenerRequest
-
- getServiceName() - Method in class com.hazelcast.cluster.client.ClientPingRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.CollectionRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.TxnListAddRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.TxnListRemoveRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.TxnListSizeRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.TxnSetAddRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.TxnSetRemoveRequest
-
- getServiceName() - Method in class com.hazelcast.collection.client.TxnSetSizeRequest
-
- getServiceName() - Method in class com.hazelcast.collection.CollectionService
-
- getServiceName() - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- getServiceName() - Method in class com.hazelcast.collection.list.ListService
-
- getServiceName() - Method in class com.hazelcast.collection.set.SetProxyImpl
-
- getServiceName() - Method in class com.hazelcast.collection.set.SetService
-
- getServiceName() - Method in class com.hazelcast.collection.txn.TransactionalListProxy
-
- getServiceName() - Method in class com.hazelcast.collection.txn.TransactionalSetProxy
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- getServiceName() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.ConditionKey
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
-
- getServiceName() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-
- getServiceName() - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- getServiceName() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- getServiceName() - Method in interface com.hazelcast.core.DistributedObject
-
Returns the service name for this object.
- getServiceName() - Method in class com.hazelcast.core.DistributedObjectEvent
-
Returns service name of related DistributedObject
- getServiceName() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-
- getServiceName() - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-
- getServiceName() - Method in class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- getServiceName() - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-
- getServiceName() - Method in class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- getServiceName() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- getServiceName() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-
- getServiceName() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-
- getServiceName() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-
- getServiceName() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- getServiceName() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-
- getServiceName() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- getServiceName() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- getServiceName() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- getServiceName() - Method in class com.hazelcast.partition.client.GetPartitionsRequest
-
- getServiceName() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-
- getServiceName() - Method in class com.hazelcast.partition.impl.HasOngoingMigration
-
- getServiceName() - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-
- getServiceName() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- getServiceName() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- getServiceName() - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- getServiceName() - Method in class com.hazelcast.queue.impl.client.QueueRequest
-
- getServiceName() - Method in class com.hazelcast.queue.impl.client.RemoveListenerRequest
-
- getServiceName() - Method in class com.hazelcast.queue.impl.client.TxnOfferRequest
-
- getServiceName() - Method in class com.hazelcast.queue.impl.client.TxnPeekRequest
-
- getServiceName() - Method in class com.hazelcast.queue.impl.client.TxnPollRequest
-
- getServiceName() - Method in class com.hazelcast.queue.impl.client.TxnSizeRequest
-
- getServiceName() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- getServiceName() - Method in class com.hazelcast.queue.impl.operations.QueueReplicationOperation
-
- getServiceName() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveEntryListenerRequest
-
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- getServiceName() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- getServiceName() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- getServiceName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
-
- getServiceName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
-
- getServiceName() - Method in class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- getServiceName() - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- getServiceName() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl.PostJoinProxyOperation
-
- getServiceName() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getServiceName() - Method in interface com.hazelcast.spi.ObjectNamespace
-
- getServiceName() - Method in class com.hazelcast.spi.Operation
-
- getServiceName() - Method in interface com.hazelcast.spi.WaitNotifyKey
-
- getServiceName() - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- getServiceName() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- getServiceName() - Method in class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- getServiceName() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-
- getServiceName() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-
- getServiceName() - Method in class com.hazelcast.transaction.client.PrepareTransactionRequest
-
- getServiceName() - Method in class com.hazelcast.transaction.client.RecoverAllTransactionsRequest
-
Deprecated.
- getServiceName() - Method in class com.hazelcast.transaction.client.RecoverTransactionRequest
-
Deprecated.
- getServiceName() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-
- getServiceName() - Method in class com.hazelcast.wan.WanReplicationEvent
-
- getServices(Class<S>) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
Returns a list of services matching provides service class/interface.
- getServicesConfig() - Method in class com.hazelcast.config.Config
-
- getSet() - Method in class com.hazelcast.console.ConsoleApp
-
- getSet(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed set instance with the specified name.
- getSet(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getSet(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getSet(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
Returns the transactional set instance with the specified name.
- getSetConfig(String) - Method in class com.hazelcast.config.Config
-
- getSetConfigs() - Method in class com.hazelcast.config.Config
-
- getSharedService(String) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getSharedService(String) - Method in interface com.hazelcast.spi.NodeEngine
-
- getShort() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getShort(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- getShortAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getShortAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getShortAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getSignalKey(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getSize() - Method in interface com.hazelcast.cluster.ClusterService
-
Gets the current number of members.
- getSize() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getSize() - Method in class com.hazelcast.config.MaxSizeConfig
-
- getSize() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- getSize() - Method in class com.hazelcast.jmx.MapMBean
-
- getSize() - Method in class com.hazelcast.jmx.MultiMapMBean
-
- getSize() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getSize() - Method in interface com.hazelcast.map.impl.SizeEstimator
-
- getSnapShot() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
- getSocketAddress() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getSocketAddress() - Method in interface com.hazelcast.core.Client
-
Returns socket address of this client
- getSocketAddress() - Method in interface com.hazelcast.core.Endpoint
-
Returns socket address of this endpoint
- getSocketAddress() - Method in interface com.hazelcast.core.Member
-
Returns the socket address of this member.
- getSocketAddress() - Method in class com.hazelcast.instance.MemberImpl
-
- getSocketChannelWrapper() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getSocketChannelWrapperFactory() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getSocketChannelWrapperFactory() - Method in interface com.hazelcast.instance.NodeExtension
-
Returns SocketChannelWrapperFactory instance to be used by this Node.
- getSocketChannelWrapperFactory() - Method in interface com.hazelcast.nio.IOService
-
- getSocketChannelWrapperFactory() - Method in class com.hazelcast.nio.NodeIOService
-
- getSocketInterceptorConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getSocketInterceptorConfig() - Method in interface com.hazelcast.nio.IOService
-
- getSocketInterceptorConfig() - Method in class com.hazelcast.nio.NodeIOService
-
- getSocketKeepAlive() - Method in interface com.hazelcast.nio.IOService
-
- getSocketKeepAlive() - Method in class com.hazelcast.nio.NodeIOService
-
- getSocketLingerSeconds() - Method in interface com.hazelcast.nio.IOService
-
- getSocketLingerSeconds() - Method in class com.hazelcast.nio.NodeIOService
-
- getSocketNoDelay() - Method in interface com.hazelcast.nio.IOService
-
- getSocketNoDelay() - Method in class com.hazelcast.nio.NodeIOService
-
- getSocketReceiveBufferSize() - Method in interface com.hazelcast.nio.IOService
-
- getSocketReceiveBufferSize() - Method in class com.hazelcast.nio.NodeIOService
-
- getSocketSendBufferSize() - Method in interface com.hazelcast.nio.IOService
-
- getSocketSendBufferSize() - Method in class com.hazelcast.nio.NodeIOService
-
- getSocketTextReader() - Method in class com.hazelcast.ascii.AbstractTextCommand
-
- getSocketTextReader() - Method in interface com.hazelcast.ascii.TextCommand
-
- getSocketTextWriter() - Method in class com.hazelcast.ascii.AbstractTextCommand
-
- getSocketTextWriter() - Method in interface com.hazelcast.ascii.TextCommand
-
- getSocketTextWriter() - Method in class com.hazelcast.nio.ascii.SocketTextReader
-
- getSocketWriter() - Method in class com.hazelcast.nio.tcp.WriteHandler
-
- getSource() - Method in class com.hazelcast.core.AbstractIMapEvent
-
- getSource() - Method in interface com.hazelcast.map.impl.EventData
-
- getSource() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreEvent
-
- getSource() - Method in class com.hazelcast.partition.MigrationInfo
-
- getSpecificationName() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- getSpecificationVendor() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- getSpecificationVersion() - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getSSLConfig() - Method in interface com.hazelcast.nio.IOService
-
- getSSLConfig() - Method in class com.hazelcast.nio.NodeIOService
-
- getSSLContext() - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
-
- getSSLContext() - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
-
- getStartedTaskCount() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getStartedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
-
Returns the number of started operations of the executor service
- getStartTime() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- getStartTime() - Method in interface com.hazelcast.cluster.Joiner
-
- getStartTime() - Method in class com.hazelcast.spi.Operation
-
- getStartTime() - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- getState() - Method in class com.hazelcast.core.LifecycleEvent
-
- getState() - Method in class com.hazelcast.mapreduce.impl.task.JobPartitionStateImpl
-
- getState() - Method in interface com.hazelcast.mapreduce.JobPartitionState
-
Returns the current processing state of this partition
- getState() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- getState() - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- getStatistics(String) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- getStatistics(String) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- getStatistics() - Method in interface com.hazelcast.map.impl.record.Record
-
- getStatistics() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getStats() - Method in interface com.hazelcast.ascii.TextCommandService
-
- getStats() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- getStats() - Method in class com.hazelcast.management.ThreadMonitoringService
-
- getStatsMap() - Method in class com.hazelcast.topic.impl.TopicService
-
- getStatus() - Method in class com.hazelcast.core.MigrationEvent
-
Returns the status of the migration: Started, completed or failed
- getStorageFormat() - Method in class com.hazelcast.map.impl.record.DataRecordFactory
-
- getStorageFormat() - Method in class com.hazelcast.map.impl.record.NativeRecordFactory
-
- getStorageFormat() - Method in class com.hazelcast.map.impl.record.ObjectRecordFactory
-
- getStorageFormat() - Method in interface com.hazelcast.map.impl.record.RecordFactory
-
- getStore() - Method in class com.hazelcast.map.impl.MapContainer
-
- getStore() - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-
- getStoreImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
-
- getString() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getString(JsonObject, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getString(JsonObject, String, String) - Static method in class com.hazelcast.util.JsonUtil
-
- getStringAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- getStringAttribute(String) - Method in interface com.hazelcast.core.Member
-
Returns the value of the specified key for this member or
null if value is undefined.
- getStringAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- getSubject() - Method in interface com.hazelcast.client.ClientEndpoint
-
- getSubject() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getSubRecords(ComparisonType, Comparable) - Method in interface com.hazelcast.query.impl.Index
-
- getSubRecords(ComparisonType, Comparable) - Method in class com.hazelcast.query.impl.IndexImpl
-
- getSubRecords(MultiResultSet, ComparisonType, Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
-
- getSubRecords(MultiResultSet, ComparisonType, Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- getSubRecords(MultiResultSet, ComparisonType, Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- getSubRecordsBetween(Comparable, Comparable) - Method in interface com.hazelcast.query.impl.Index
-
- getSubRecordsBetween(Comparable, Comparable) - Method in class com.hazelcast.query.impl.IndexImpl
-
- getSubRecordsBetween(MultiResultSet, Comparable, Comparable) - Method in interface com.hazelcast.query.impl.IndexStore
-
- getSubRecordsBetween(MultiResultSet, Comparable, Comparable) - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- getSubRecordsBetween(MultiResultSet, Comparable, Comparable) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- getSubscriber() - Method in interface com.hazelcast.spi.EventRegistration
-
Returns subscriber of this registration.
- getSubscriber() - Method in class com.hazelcast.spi.impl.EventServiceImpl.Registration
-
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.NetworkConfig
-
- getSymmetricEncryptionConfig() - Method in interface com.hazelcast.nio.IOService
-
- getSymmetricEncryptionConfig() - Method in class com.hazelcast.nio.NodeIOService
-
- getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.collection.CollectionBackupAwareOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- getSyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
Deprecated.
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- getSyncBackupCount() - Method in class com.hazelcast.queue.impl.operations.QueueBackupAwareOperation
-
- getSyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
-
The synchronous backup count.
- getSystemExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
-
- GetSystemWarningsRequest - Class in com.hazelcast.management.request
-
Deprecated.
- GetSystemWarningsRequest() - Constructor for class com.hazelcast.management.request.GetSystemWarningsRequest
-
Deprecated.
- getTableIndex() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- getTagKey() - Method in class com.hazelcast.config.AwsConfig
-
Gets the tag key; if nothing is specified null is returned.
- getTagValue() - Method in class com.hazelcast.config.AwsConfig
-
Gets the tag value.
- getTarget() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- getTarget() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- getTarget() - Method in class com.hazelcast.client.impl.client.TargetClientRequest
-
- getTarget() - Method in class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- getTarget() - Method in exception com.hazelcast.spi.exception.WrongTargetException
-
- getTarget() - Method in class com.hazelcast.spi.impl.BasicPartitionInvocation
-
- getTarget() - Method in class com.hazelcast.spi.impl.BasicTargetInvocation
-
- getTarget() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getTargetAddress() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- getTargetAddress() - Method in class com.hazelcast.cluster.impl.BindMessage
-
- getTargetClusterConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
-
- getTargets() - Method in class com.hazelcast.client.impl.client.MultiTargetClientRequest
-
- getTargets() - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- getTargets() - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- getTcpIpConfig() - Method in class com.hazelcast.config.JoinConfig
-
- getTextCommandService() - Method in class com.hazelcast.instance.Node
-
- getTextCommandService() - Method in interface com.hazelcast.nio.IOService
-
- getTextCommandService() - Method in class com.hazelcast.nio.NodeIOService
-
- getTextContent(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- getThisAddress() - Method in interface com.hazelcast.client.ClientEngine
-
- getThisAddress() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getThisAddress() - Method in interface com.hazelcast.cluster.ClusterService
-
Gets the address of this member.
- getThisAddress() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- getThisAddress() - Method in class com.hazelcast.instance.Node
-
- getThisAddress() - Method in interface com.hazelcast.nio.IOService
-
- getThisAddress() - Method in class com.hazelcast.nio.NodeIOService
-
- getThisAddress() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getThisAddress() - Method in interface com.hazelcast.spi.NodeEngine
-
- getThreadGroup() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getThreadGroup() - Method in interface com.hazelcast.nio.IOService
-
- getThreadGroup() - Method in class com.hazelcast.nio.NodeIOService
-
- getThreadId() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- getThreadId() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- getThreadId() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- getThreadId() - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- getThreadId() - Static method in class com.hazelcast.util.ThreadUtil
-
- getThreadNamePrefix(String) - Method in class com.hazelcast.instance.Node
-
- getThreadPoolNamePrefix(String) - Method in class com.hazelcast.instance.Node
-
- getThreadPrefix() - Method in interface com.hazelcast.nio.IOService
-
- getThreadPrefix() - Method in class com.hazelcast.nio.NodeIOService
-
- getThreads() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getTime() - Method in class com.hazelcast.monitor.TimedMemberState
-
- getTimedMemberStateFactory() - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- getTimedMemberStateFactory() - Method in interface com.hazelcast.instance.NodeExtension
-
- getTimeInMillis(long, TimeUnit) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- getTimeout() - Method in interface com.hazelcast.util.executor.TimeoutRunnable
-
- getTimeoutMillis() - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- getTimeoutMillis() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- getTimeoutMillis() - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- getTimeoutMillis() - Method in class com.hazelcast.transaction.TransactionOptions
-
Gets the timeout in milliseconds.
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.MapConfig
-
- getTimeToLiveSeconds() - Method in class com.hazelcast.config.NearCacheConfig
-
- getTimeUnit() - Method in interface com.hazelcast.util.executor.TimeoutRunnable
-
- getTopic() - Method in class com.hazelcast.console.ConsoleApp
-
- getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns the distributed topic instance with the specified name.
- getTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getTopic(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getTopicConfig(String) - Method in class com.hazelcast.config.Config
-
- getTopicConfigs() - Method in class com.hazelcast.config.Config
-
- getTopologyChangedStrategy() - Method in class com.hazelcast.config.JobTrackerConfig
-
- getTopologyChangedStrategy() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- getTotalAddedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getTotalAddedEntryCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getTotalAddedItemCount() - Method in class com.hazelcast.jmx.ListMBean
-
- getTotalAddedItemCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getTotalAddedItemCount() - Method in class com.hazelcast.jmx.SetMBean
-
- getTotalBackupCount() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getTotalBackupCount() - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- getTotalBackupCount() - Method in class com.hazelcast.config.CacheConfig
-
- getTotalBackupCount() - Method in class com.hazelcast.config.CollectionConfig
-
- getTotalBackupCount() - Method in class com.hazelcast.config.MapConfig
-
- getTotalBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
-
- getTotalBackupCount() - Method in class com.hazelcast.config.QueueConfig
-
- getTotalBackupCount() - Method in class com.hazelcast.config.SemaphoreConfig
-
Returns the total number of backups; the returned value will always equal or bigger than 0.
- getTotalBackupCount() - Method in class com.hazelcast.map.impl.MapContainer
-
- getTotalConnections() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getTotalEvictedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getTotalExecutionLatency() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getTotalExecutionLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
-
Returns the total execution time of operations finished
- getTotalGetLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getTotalGetLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getTotalGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the total latency of get operations.
- getTotalMemory() - Method in interface com.hazelcast.map.impl.eviction.MemoryInfoAccessor
-
- getTotalMessageCount() - Method in class com.hazelcast.jmx.TopicMBean
-
- getTotalPhysical() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getTotalPhysical() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getTotalPutLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getTotalPutLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getTotalPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the total latency of put operations.
- getTotalRemovedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getTotalRemovedEntryCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getTotalRemovedItemCount() - Method in class com.hazelcast.jmx.ListMBean
-
- getTotalRemovedItemCount() - Method in class com.hazelcast.jmx.QueueMBean
-
- getTotalRemovedItemCount() - Method in class com.hazelcast.jmx.SetMBean
-
- getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- getTotalRemoveLatency() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- getTotalRemoveLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the total latency of remove operations.
- getTotalStartLatency() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- getTotalStartLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
-
Returns the total start latency of operations started
- getTotalUpdatedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
-
- getTotalUpdatedEntryCount() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- getTraceIdentifier() - Method in interface com.hazelcast.spi.TraceableOperation
-
- getTrackableJob(String) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- getTrackableJob(String) - Method in interface com.hazelcast.mapreduce.JobTracker
-
Returns an implementation of
TrackableJob
if the job or null if the job id is not available
or is already finished.
- getTransaction(TransactionContext) - Static method in class com.hazelcast.transaction.impl.TransactionAccessor
-
- getTransactionalObject(String, String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
-
- getTransactionContext(String) - Method in interface com.hazelcast.client.ClientEndpoint
-
- getTransactionContext(String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getTransactionId() - Method in class com.hazelcast.collection.TxCollectionItem
-
- getTransactionId() - Method in class com.hazelcast.queue.impl.TxQueueItem
-
- getTransactionLog(Object) - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- getTransactionManagerService() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- getTransactionManagerService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getTransactionManagerService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getTransactionTimeout() - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
-
- getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
-
Gets the trusted interfaces.
- getTryCount() - Method in class com.hazelcast.cluster.impl.JoinRequest
-
- getTryCount() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getTryPauseMillis() - Method in class com.hazelcast.spi.InvocationBuilder
-
- getTtl() - Method in interface com.hazelcast.core.EntryView
-
Returns last set time to live second.
- getTtl() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- getTtl() - Method in interface com.hazelcast.map.impl.record.Record
-
- getTtl() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getTtl() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getTtlMillis() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapGetResponse
-
- getTtlMillis() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getTtlMillis() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getTxLogs() - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- getTxnId() - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- getTxnId() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- getTxnId() - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- getTxnId() - Method in interface com.hazelcast.transaction.TransactionContext
-
Gets the id that uniquely identifies the transaction.
- getType() - Method in class com.hazelcast.ascii.AbstractTextCommand
-
- getType() - Method in interface com.hazelcast.ascii.TextCommand
-
- getType() - Method in enum com.hazelcast.cache.impl.CacheEventType
-
- getType() - Method in class com.hazelcast.client.impl.client.GenericError
-
- getType() - Method in class com.hazelcast.cluster.impl.MulticastJoiner
-
- getType() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- getType() - Method in interface com.hazelcast.cluster.Joiner
-
- getType() - Method in class com.hazelcast.config.PermissionConfig
-
- getType(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
- getType() - Method in enum com.hazelcast.core.EntryEventType
-
- getType() - Method in enum com.hazelcast.core.ItemEventType
-
- getType() - Method in class com.hazelcast.management.request.ClusterPropsRequest
-
- getType() - Method in class com.hazelcast.management.request.ConsoleCommandRequest
-
- getType() - Method in interface com.hazelcast.management.request.ConsoleRequest
-
- getType() - Method in class com.hazelcast.management.request.ExecuteScriptRequest
-
- getType() - Method in class com.hazelcast.management.request.GetLogsRequest
-
Deprecated.
- getType() - Method in class com.hazelcast.management.request.GetMapEntryRequest
-
- getType() - Method in class com.hazelcast.management.request.GetMemberSystemPropertiesRequest
-
- getType() - Method in class com.hazelcast.management.request.GetSystemWarningsRequest
-
Deprecated.
- getType() - Method in class com.hazelcast.management.request.MapConfigRequest
-
- getType() - Method in class com.hazelcast.management.request.MemberConfigRequest
-
- getType() - Method in class com.hazelcast.management.request.RunGcRequest
-
- getType() - Method in class com.hazelcast.management.request.ShutdownMemberRequest
-
- getType() - Method in class com.hazelcast.management.request.ThreadDumpRequest
-
- getType() - Method in interface com.hazelcast.nio.Connection
-
- getType() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns serialization type of binary form.
- getType() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
-
- getType() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getTypeClass() - Method in class com.hazelcast.config.SerializerConfig
-
- getTypeClassName() - Method in class com.hazelcast.config.SerializerConfig
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.BooleanSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ByteSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.CharArraySerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.CharSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.DoubleArraySerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.DoubleSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.FloatArraySerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.FloatSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.IntegerArraySerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.IntegerSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.LongArraySerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.LongSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ShortArraySerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ShortSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.StringSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.DefaultSerializers.BigDecimalSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.DefaultSerializers.BigIntegerSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.DefaultSerializers.ClassSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.DefaultSerializers.DateSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.DefaultSerializers.EnumSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.DefaultSerializers.Externalizer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.DefaultSerializers.ObjectSerializer
-
- getTypeId() - Method in interface com.hazelcast.nio.serialization.Serializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook.ArrayListStreamSerializer
-
- getTypeId() - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook.LinkedListStreamSerializer
-
- getUnit() - Method in class com.hazelcast.memory.MemorySize
-
Returns unit of memory size
- getUnknownCollectionCount() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- getUnknownCollectionCount() - Method in interface com.hazelcast.monitor.LocalGCStats
-
- getUnknownCollectionTime() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- getUnknownCollectionTime() - Method in interface com.hazelcast.monitor.LocalGCStats
-
- getUpdateHash() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getUpdateInterval() - Method in class com.hazelcast.config.ManagementCenterConfig
-
- getUpdateTime() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapGetResponse
-
- getUpdateTime() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getUptime() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getURI() - Method in class com.hazelcast.ascii.rest.HttpCommand
-
- getURI() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- getUriString() - Method in class com.hazelcast.config.CacheConfig
-
- getUrl() - Method in class com.hazelcast.config.ManagementCenterConfig
-
- getUsage() - Method in class com.hazelcast.config.LoginModuleConfig
-
- getUsedHeap() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getUsedHeap() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getUsedNativeMemory() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- getUsedNativeMemory() - Method in interface com.hazelcast.monitor.LocalMemoryStats
-
- getUserContext() - Method in class com.hazelcast.config.Config
-
- getUserContext() - Method in interface com.hazelcast.core.HazelcastInstance
-
Returns a ConcurrentMap that can be used to add user-context to the HazelcastInstance.
- getUserContext() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- getUserContext() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- getUsername() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- getUuid() - Method in interface com.hazelcast.client.ClientEndpoint
-
- getUuid() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-
- getUuid() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- getUuid() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-
- getUuid() - Method in class com.hazelcast.cluster.impl.JoinMessage
-
- getUuid() - Method in class com.hazelcast.cluster.MemberInfo
-
- getUuid() - Method in interface com.hazelcast.core.Client
-
Returns unique uuid for this client
- getUuid() - Method in interface com.hazelcast.core.Endpoint
-
Returns unique uuid for this endpoint
- getUuid() - Method in interface com.hazelcast.core.Member
-
Returns UUID of this member.
- getUuid() - Method in class com.hazelcast.instance.MemberImpl
-
- getUuid() - Method in class com.hazelcast.management.SerializableClientEndPoint
-
- getUuid() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getUuid() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getUuid() - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- getUuid() - Method in class com.hazelcast.topic.impl.client.PortableMessage
-
- getValue() - Method in class com.hazelcast.ascii.memcache.IncrementCommand
-
- getValue() - Method in class com.hazelcast.ascii.memcache.MemcacheEntry
-
- getValue() - Method in class com.hazelcast.ascii.memcache.SetCommand
-
- getValue() - Method in class com.hazelcast.ascii.rest.RestValue
-
- getValue() - Method in enum com.hazelcast.ascii.TextCommandConstants.TextCommandType
-
- getValue() - Method in class com.hazelcast.cache.impl.CacheEntry
-
- getValue() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-
- getValue() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- getValue() - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
-
- getValue() - Method in interface com.hazelcast.cache.impl.record.CacheRecord
-
- getValue() - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-
- getValue(int) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
-
- getValue() - Method in class com.hazelcast.collection.CollectionItem
-
- getValue() - Method in class com.hazelcast.core.EntryEvent
-
Returns the value of the entry event
- getValue() - Method in interface com.hazelcast.core.EntryView
-
Returns the value of the entry.
- getValue() - Method in class com.hazelcast.core.MemberAttributeEvent
-
- getValue() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- getValue() - Method in class com.hazelcast.map.impl.DataAwareEntryEvent
-
- getValue() - Method in class com.hazelcast.map.impl.mapstore.writebehind.DelayedEntry
-
- getValue() - Method in class com.hazelcast.map.impl.NearCache.CacheRecord
-
- getValue() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- getValue() - Method in interface com.hazelcast.map.impl.record.Record
-
- getValue() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
-
- getValue() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getValue() - Method in class com.hazelcast.memory.MemorySize
-
Returns value of memory size in its original unit.
- getValue() - Method in interface com.hazelcast.query.impl.QueryableEntry
-
- getValue() - Method in class com.hazelcast.query.impl.QueryEntry
-
- getValue() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapGetResponse
-
- getValue() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- getValue() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getValue() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getValue() - Method in class com.hazelcast.spi.impl.NormalResponse
-
- getValue() - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- getValue() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- getValueCollectionType() - Method in class com.hazelcast.config.MultiMapConfig
-
- getValueCollectionType(MultiMapContainer) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- getValueData() - Method in class com.hazelcast.query.impl.QueryEntry
-
- getValueData() - Method in interface com.hazelcast.query.impl.QueryResultEntry
-
- getValueData() - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- getValues() - Method in class com.hazelcast.map.impl.MapValueCollection
-
- getValues() - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-
- getValueType() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- getValueType() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- getVectorClockTimestamp() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- getVectorClockTimestamp() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- getVersion(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- getVersion() - Method in interface com.hazelcast.core.EntryView
-
Returns the version of the entry
- getVersion() - Method in class com.hazelcast.instance.BuildInfo
-
- getVersion() - Method in class com.hazelcast.jmx.InstanceMBean
-
- getVersion() - Method in class com.hazelcast.management.ManagementCenterIdentifier
-
- getVersion() - Method in interface com.hazelcast.map.impl.record.Record
-
- getVersion() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- getVersion() - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- getVersion() - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
-
- getVersion() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- getVersion() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- getVersion() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- getVersion() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
-
- getVersion() - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- getVersion() - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
-
- getVersion() - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- getVersion() - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- getVersion() - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- getVersionAsInt(String) - Static method in class com.hazelcast.management.ManagementCenterIdentifier
-
- getVersionString() - Method in class com.hazelcast.management.ManagementCenterIdentifier
-
- getWaitingRequests() - Method in class com.hazelcast.ascii.memcache.Stats
-
- getWaitKey() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- getWaitKey() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- getWaitKey() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-
- getWaitKey() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- getWaitKey() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- getWaitKey() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- getWaitKey() - Method in class com.hazelcast.map.impl.operation.GetOperation
-
- getWaitKey() - Method in class com.hazelcast.map.impl.operation.LockAwareOperation
-
- getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
-
- getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
-
- getWaitKey() - Method in class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-
- getWaitKey() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-
- getWaitKey() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- getWaitKey() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- getWaitKey() - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- getWaitKey() - Method in class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- getWaitKey() - Method in interface com.hazelcast.spi.WaitSupport
-
- getWaitNotifyService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getWaitNotifyService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getWaitTimeout() - Method in class com.hazelcast.spi.Operation
-
- getWaitTimeout() - Method in interface com.hazelcast.spi.WaitSupport
-
- getWanMergePolicy() - Method in class com.hazelcast.map.impl.MapContainer
-
- getWanReplicationConfig(String) - Method in class com.hazelcast.config.Config
-
- getWanReplicationConfigs() - Method in class com.hazelcast.config.Config
-
- getWanReplicationPublisher() - Method in class com.hazelcast.map.impl.MapContainer
-
- getWanReplicationPublisher(String) - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-
- getWanReplicationPublisher(String) - Method in interface com.hazelcast.wan.WanReplicationService
-
- getWanReplicationRef() - Method in class com.hazelcast.config.MapConfig
-
- getWanReplicationRef() - Method in class com.hazelcast.config.MapConfigReadOnly
-
- getWanReplicationService() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- getWanReplicationService() - Method in interface com.hazelcast.spi.NodeEngine
-
- getWorkQueueSize() - Method in class com.hazelcast.util.executor.StripedExecutor
-
Returns the total number of tasks pending to be executed.
- getWriteBatchSize() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the number of operations to be included in each batch processing round.
- getWriteBehindQueue() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- getWriteBehindQueueItemCounter() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- getWriteBehindQueueItemCounter() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns the number of seconds to delay the store writes.
- getWriteHandler() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- getXaResource() - Method in interface com.hazelcast.transaction.TransactionContext
-
Gets xaResource which will participate in XATransaction
- getXid() - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- gigaBytes() - Method in class com.hazelcast.memory.MemorySize
-
Returns value of memory size in giga-bytes.
- globalPartitioningStrategy - Variable in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- GlobalSerializerConfig - Class in com.hazelcast.config
-
Contains the configuration for global serializer.
- GlobalSerializerConfig() - Constructor for class com.hazelcast.config.GlobalSerializerConfig
-
- GRACEFUL_SHUTDOWN_MAX_WAIT - Variable in class com.hazelcast.instance.GroupProperties
-
- greaterEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
-
- greaterEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
- greaterThan(Comparable) - Method in class com.hazelcast.query.EntryObject
-
- greaterThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
-
- GroupConfig - Class in com.hazelcast.config
-
Contains the configuration for Hazelcast groups.
- GroupConfig() - Constructor for class com.hazelcast.config.GroupConfig
-
Creates a GroupConfig with default group-name and group-password.
- GroupConfig(String) - Constructor for class com.hazelcast.config.GroupConfig
-
Creates a GroupConfig with the given group-name and default group-password
- GroupConfig(String, String) - Constructor for class com.hazelcast.config.GroupConfig
-
Creates a GroupConfig with the given group-name and group-password
- GroupMismatchOperation - Class in com.hazelcast.cluster.impl.operations
-
- GroupMismatchOperation() - Constructor for class com.hazelcast.cluster.impl.operations.GroupMismatchOperation
-
- GroupProperties - Class in com.hazelcast.instance
-
The GroupProperties contain the Hazelcast properties.
- GroupProperties(Config) - Constructor for class com.hazelcast.instance.GroupProperties
-
- groupProperties - Variable in class com.hazelcast.instance.Node
-
- GroupProperties.GroupProperty - Class in com.hazelcast.instance
-
- IAtomicLong - Interface in com.hazelcast.core
-
- IAtomicReference<E> - Interface in com.hazelcast.core
-
- ICache<K,V> - Interface in com.hazelcast.cache
-
Hazelcast Cache
extension
- ICacheRecordStore - Interface in com.hazelcast.cache.impl
-
ICacheRecordStore
is the core contract providing internal functionality to
ICache
implementations on partition scope.
- ICacheService - Interface in com.hazelcast.cache.impl
-
- ICMP_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- ICMP_TIMEOUT - Variable in class com.hazelcast.instance.GroupProperties
-
- ICMP_TTL - Variable in class com.hazelcast.instance.GroupProperties
-
- ICollection<E> - Interface in com.hazelcast.core
-
Concurrent, distributed, partitioned, listenable collection.
- ICompletableFuture<V> - Interface in com.hazelcast.core
-
A Future where one can asynchronously listen on completion.
- ICondition - Interface in com.hazelcast.core
-
- ICountDownLatch - Interface in com.hazelcast.core
-
- ICredentialsFactory - Interface in com.hazelcast.security
-
ICredentialsFactory is used to create
Credentials
objects to be used
during node authentication before connection accepted by master node.
- ID - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- ID - Static variable in class com.hazelcast.client.impl.ClientDataSerializerHook
-
ClientDataSerializable Factory ID
- ID - Static variable in class com.hazelcast.nio.Address
-
- ID - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-
- IdentifiedDataSerializable - Interface in com.hazelcast.nio.serialization
-
IdentifiedDataSerializable is an extension to
DataSerializable
to avoid reflection during de-serialization.
- IdGenerator - Interface in com.hazelcast.core
-
The IdGenerator is responsible for creating unique id's (a long) in a cluster.
- IdGeneratorProxy - Class in com.hazelcast.concurrent.idgen
-
- IdGeneratorProxy(IAtomicLong, String, NodeEngine, IdGeneratorService) - Constructor for class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-
- IdGeneratorService - Class in com.hazelcast.concurrent.idgen
-
- IdGeneratorService(NodeEngine) - Constructor for class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- IExecutorService - Interface in com.hazelcast.core
-
- IFunction<T,R> - Interface in com.hazelcast.core
-
Represents a function that accepts one argument and produces a result.
- ignore(Throwable) - Static method in class com.hazelcast.util.EmptyStatement
-
Does totally nothing.
- IGNORE_ALL_EXCEPT_LOG_MEMBER_LEFT - Static variable in class com.hazelcast.util.FutureUtil
-
Ignores all exceptions but still logs
MemberLeftException
per future and just tries
to finish all of the given ones.
- IGNORE_ALL_EXCEPTIONS - Static variable in class com.hazelcast.util.FutureUtil
-
Ignores all exceptions
- IGNORE_COMPLETION - Static variable in interface com.hazelcast.cache.impl.operation.MutableOperation
-
Completion Id to be ignored.
- ilike(String, String) - Static method in class com.hazelcast.query.Predicates
-
- IList<E> - Interface in com.hazelcast.core
-
Concurrent, distributed implementation of
List
The Hazelcast IList is not a partitioned data-structure.
- ILock - Interface in com.hazelcast.core
-
Distributed implementation of
Lock
.
- ILogger - Interface in com.hazelcast.logging
-
The Hazelcast logging interface.
- IMap<K,V> - Interface in com.hazelcast.core
-
Concurrent, distributed, observable and queryable map.
- IMapEvent - Interface in com.hazelcast.core
-
Map events common contract.
- implementation - Variable in class com.hazelcast.config.ListenerConfig
-
- implementation - Variable in class com.hazelcast.config.SecurityInterceptorConfig
-
- implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- implies(Permission) - Method in class com.hazelcast.security.permission.AllPermissions
-
- implies(Permission) - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- implies(Permission) - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- implies(Permission) - Method in class com.hazelcast.security.permission.InstancePermission
-
- implies(Permission) - Method in class com.hazelcast.security.permission.TransactionPermission
-
- in(Comparable...) - Method in class com.hazelcast.query.EntryObject
-
- in(String, Comparable...) - Static method in class com.hazelcast.query.Predicates
-
- inactivate(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
Just inactivates HazelcastInstance; leaves threads, connections untouched.
- inactivate() - Method in class com.hazelcast.instance.Node
-
- inactivate(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher.Helper
-
- includeValue - Variable in class com.hazelcast.map.impl.client.AbstractMapAddEntryListenerRequest
-
- increaseCacheEvictions(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increases the counter by the number specified.
- increaseCacheExpiries(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increases the counter by the number specified.
- increaseCacheHits(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increases the counter by the number specified.
- increaseCacheMisses(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increases the counter by the number specified.
- increaseCachePuts(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increases the counter by the number specified.
- increaseCacheRemovals(long) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
Increases the counter by the number specified.
- incrementAndGet() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- incrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically increments the current value by one.
- incrementAndGet() - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- incrementBackupEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementBackupEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- IncrementCommand - Class in com.hazelcast.ascii.memcache
-
User: sancar
Date: 3/8/13
Time: 3:33 PM
- IncrementCommand(TextCommandConstants.TextCommandType, String, int, boolean) - Constructor for class com.hazelcast.ascii.memcache.IncrementCommand
-
- IncrementCommandParser - Class in com.hazelcast.ascii.memcache
-
User: sancar
Date: 3/8/13
Time: 3:32 PM
- IncrementCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.memcache.IncrementCommandParser
-
- IncrementCommandProcessor - Class in com.hazelcast.ascii.memcache
-
- IncrementCommandProcessor(TextCommandServiceImpl) - Constructor for class com.hazelcast.ascii.memcache.IncrementCommandProcessor
-
- incrementDecrHitCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementDecrHitCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementDecrMissCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementDecrMissCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementDeleteHitCount(int) - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementDeleteHitCount(int) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementDeleteMissCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementDeleteMissCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementDirtyEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementEmptyPolls() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- incrementGetHitCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementGetHitCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementGetMissCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementGetMissCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementGets(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementGets(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- incrementHeapCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementHit() - Method in class com.hazelcast.multimap.impl.MultiMapWrapper
-
- incrementHits(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementHits() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- incrementIncHitCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementIncHitCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementIncMissCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementIncMissCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementLockedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementMisses() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- incrementOffers() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- incrementOtherOperations() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- incrementOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementPartitionReplicaVersions(int, int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- incrementPartitionReplicaVersions(int, int) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- incrementPolls() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- incrementPublishes() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-
- incrementPublishes(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- incrementPuts(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementPuts(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- incrementReceivedEvents() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- incrementReceivedMessages(String) - Method in class com.hazelcast.topic.impl.TopicService
-
- incrementReceivedReplicationEvents() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- incrementReceives() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-
- incrementRejectedOffers() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- incrementRemoves(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- incrementRemoves(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- incrementSetCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementSetCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementTextConnections() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- incrementTouchCount() - Method in interface com.hazelcast.ascii.TextCommandService
-
- incrementTouchCount() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- incrementVectorClock(Member) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- index - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- Index - Interface in com.hazelcast.query.impl
-
This interface contains the methods related to index of Query.
- INDEX_OF - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- IndexAwarePredicate - Interface in com.hazelcast.query
-
This interface using for create filterable Predicates.
- IndexImpl - Class in com.hazelcast.query.impl
-
- IndexImpl(String, boolean) - Constructor for class com.hazelcast.query.impl.IndexImpl
-
- IndexImpl.NullObject - Class in com.hazelcast.query.impl
-
Provides comparable null object.
- IndexImpl.NullObject() - Constructor for class com.hazelcast.query.impl.IndexImpl.NullObject
-
- indexOf(boolean, Data) - Method in class com.hazelcast.collection.list.ListContainer
-
- indexOf(Object) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- IndexService - Class in com.hazelcast.query.impl
-
This class contains methods which manipulate and access index.
- IndexService() - Constructor for class com.hazelcast.query.impl.IndexService
-
- IndexStore - Interface in com.hazelcast.query.impl
-
This interface stores indexes of Query.
- info(String) - Method in class com.hazelcast.logging.AbstractLogger
-
- info(String) - Method in interface com.hazelcast.logging.ILogger
-
- init(SocketTextReader, long) - Method in class com.hazelcast.ascii.AbstractTextCommand
-
- init(SocketTextReader, long) - Method in interface com.hazelcast.ascii.TextCommand
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- init(NodeEngine) - Method in class com.hazelcast.collection.CollectionContainer
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.collection.CollectionService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- init(long) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- init(int) - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- init(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- init(long) - Method in interface com.hazelcast.core.IdGenerator
-
Try to initialize this IdGenerator instance with given id.
- init(InitialMembershipEvent) - Method in interface com.hazelcast.core.InitialMembershipListener
-
Is called when this listener is registered.
- init(int) - Method in interface com.hazelcast.core.ISemaphore
-
Try to initialize this ISemaphore instance with given permit count
- init(HazelcastInstance, Properties, String) - Method in interface com.hazelcast.core.MapLoaderLifecycleSupport
-
Initializes this MapLoader implementation.
- init(NodeEngine, Properties) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.map.impl.MapService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- init() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- init(Properties) - Method in interface com.hazelcast.nio.SocketInterceptor
-
- init(Properties) - Method in class com.hazelcast.nio.ssl.BasicSSLContextFactory
-
- init(Properties) - Method in interface com.hazelcast.nio.ssl.SSLContextFactory
-
Initializes this class with config from
SSLConfig
- init(NodeEngine, Properties) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- init(boolean) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.queue.impl.QueueService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- init(NodeEngine, Properties) - Method in interface com.hazelcast.spi.ManagedService
-
Initializes this ManagedService
- init(NodeEngine, Properties) - Method in class com.hazelcast.topic.impl.TopicService
-
- init(NodeEngine, Properties) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- init(Node, String, String, String...) - Method in class com.hazelcast.wan.impl.WanNoDelayReplication
-
- init(Node, String, String, String...) - Method in interface com.hazelcast.wan.WanReplicationEndpoint
-
Initializes the endpoint using the given arguments
- INIT_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- INIT_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- InitBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- InitBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-
- InitBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-
- INITIAL_CAPACITY - Static variable in class com.hazelcast.concurrent.semaphore.Permit
-
- INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Initial memory size in megabytes
- INITIAL_MIN_CLUSTER_SIZE - Variable in class com.hazelcast.instance.GroupProperties
-
- INITIAL_WAIT_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- initialize() - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
-
Initialize the given object instance.
- initialize(Object) - Method in class com.hazelcast.instance.HazelcastManagedContext
-
- initialize(Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.LifecycleMapper
-
This method is called before the
Mapper.map(Object, Object, Context)
method is executed for every value and
can be used to initialize the internal state of the mapper or to emit a special value.
- initialize(Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
-
This method is called before the
Mapper.map(Object, Object, Context)
method is executed for every value and
can be used to initialize the internal state of the mapper or to emit a special value.
- initialize() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- initialize(Collection<MemberGroup>, int) - Method in interface com.hazelcast.partition.impl.PartitionStateGenerator
-
Returns the initial layout for the partitions.
- initialize(Collection<MemberGroup>, int) - Method in class com.hazelcast.partition.impl.PartitionStateGeneratorImpl
-
- initialize() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- initialize() - Method in interface com.hazelcast.spi.InitializingObject
-
- initializeDistributedObject(String, String) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- initializeDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
-
- InitializingObject - Interface in com.hazelcast.spi
-
Can be implemented by DistributedObject (proxies) to indicate that they want to be initialized.
- InitialMembershipEvent - Class in com.hazelcast.core
-
- InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.core.InitialMembershipEvent
-
- InitialMembershipListener - Interface in com.hazelcast.core
-
- initialOutputBufferSize - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicLongPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.AtomicReferencePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.CountDownLatchPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.ExecutorServicePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.InstancePermission
-
init mask
- initMask(String[]) - Method in class com.hazelcast.security.permission.ListPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.LockPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.MapPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.MapReducePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.QueuePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.ReplicatedMapPermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.SemaphorePermission
-
- initMask(String[]) - Method in class com.hazelcast.security.permission.TopicPermission
-
- InitOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- InitOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- InitOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- initPartitionsContainers() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- initPartitionsContainers() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- InitRequest - Class in com.hazelcast.concurrent.semaphore.client
-
- InitRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.InitRequest
-
- InitRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.InitRequest
-
- initSocket(Socket) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- initWanReplication(NodeEngine) - Method in class com.hazelcast.map.impl.MapContainer
-
- injectManagedContext(NodeEngine, Object, Object...) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- inMemoryFormat - Variable in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- inMemoryFormat - Variable in class com.hazelcast.cache.impl.record.CacheRecordFactory
-
- InMemoryFormat - Enum in com.hazelcast.config
-
Storage format type of values stored in cluster
- InMemoryXmlConfig - Class in com.hazelcast.config
-
Creates a
Config
loaded from an in memory Hazelcast XML String.
- InMemoryXmlConfig(String) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
-
Creates a Config from the provided XML and uses the System.properties to resolve variables
in the XML.
- InMemoryXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.InMemoryXmlConfig
-
Creates a Config from the provided XML and properties to resolve the variables in the XML.
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- innerBeforeRun() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- innerBeforeRun() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- innerCall() - Method in class com.hazelcast.collection.client.TxnListAddRequest
-
- innerCall() - Method in class com.hazelcast.collection.client.TxnListRemoveRequest
-
- innerCall() - Method in class com.hazelcast.collection.client.TxnListSizeRequest
-
- innerCall() - Method in class com.hazelcast.collection.client.TxnSetAddRequest
-
- innerCall() - Method in class com.hazelcast.collection.client.TxnSetRemoveRequest
-
- innerCall() - Method in class com.hazelcast.collection.client.TxnSetSizeRequest
-
- innerCall() - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapGetRequest
-
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapSizeRequest
-
- innerCall() - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapValueCountRequest
-
- innerCall() - Method in class com.hazelcast.queue.impl.client.TxnOfferRequest
-
- innerCall() - Method in class com.hazelcast.queue.impl.client.TxnPeekRequest
-
- innerCall() - Method in class com.hazelcast.queue.impl.client.TxnPollRequest
-
- innerCall() - Method in class com.hazelcast.queue.impl.client.TxnSizeRequest
-
- innerCall() - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-
- innerCall() - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-
- innerCall() - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-
- innerCall() - Method in class com.hazelcast.transaction.client.PrepareTransactionRequest
-
- innerCall() - Method in class com.hazelcast.transaction.client.RollbackTransactionRequest
-
- InputOutputFactory - Interface in com.hazelcast.nio.serialization
-
- inputOutputFactory - Variable in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- InSelectorImpl - Class in com.hazelcast.nio.tcp
-
- InSelectorImpl(ThreadGroup, String, ILogger, IOSelectorOutOfMemoryHandler) - Constructor for class com.hazelcast.nio.tcp.InSelectorImpl
-
- insertMigratedData(int, Map<String, Map>) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- insertMigrationData(Map<String, Permit>) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- inspectOutputMemoryError(Throwable) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringAndPartitionAwarePartitioningStrategy
-
- INSTANCE - Static variable in class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- INSTANCE - Static variable in class com.hazelcast.query.impl.UUIDConverter
-
Singleton
- INSTANCE - Static variable in class com.hazelcast.query.TruePredicate
-
An instance of the TruePredicate.
- InstanceMBean - Class in com.hazelcast.jmx
-
- InstanceMBean(HazelcastInstanceImpl, ManagementService) - Constructor for class com.hazelcast.jmx.InstanceMBean
-
- instanceOf(Class) - Static method in class com.hazelcast.query.Predicates
-
- InstancePermission - Class in com.hazelcast.security.permission
-
- InstancePermission(String, String...) - Constructor for class com.hazelcast.security.permission.InstancePermission
-
- INT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- INT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- INT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
-
Integer size in bytes
- INTEGER_AVG_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- INTEGER_AVG_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- INTEGER_MAX_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- INTEGER_MAX_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- INTEGER_MIN_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- INTEGER_MIN_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- INTEGER_SUM_COMBINER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- INTEGER_SUM_REDUCER_FACTORY - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- integerAvg() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to calculate the integer average of all supplied values.
This aggregation is similar to
- IntegerAvgAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined average aggregation for values of type integer.
- IntegerAvgAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.IntegerAvgAggregation
-
- integerMax() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to find the integer maximum of all supplied values.
This aggregation is similar to
- IntegerMaxAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined maximum aggregation for values of type integer.
- IntegerMaxAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.IntegerMaxAggregation
-
- integerMin() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to find the integer minimum of all supplied values.
This aggregation is similar to
- IntegerMinAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined minimum aggregation for values of type integer.
- IntegerMinAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.IntegerMinAggregation
-
- integerSum() - Static method in class com.hazelcast.mapreduce.aggregation.Aggregations
-
Returns an aggregation to calculate the integer sum of all supplied values.
This aggregation is similar to
- IntegerSumAggregation<Key,Value> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The predefined sum aggregation for values of type integer.
- IntegerSumAggregation() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.IntegerSumAggregation
-
- interceptAfter(Credentials, String, String, String) - Method in interface com.hazelcast.security.SecurityContext
-
intercepts a request after process if any
SecurityInterceptor
configured
Any exception thrown during interception will be ignored
- interceptAfterGet(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- interceptAfterPut(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- interceptAfterRemove(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- interceptBefore(Credentials, String, String, String, Object[]) - Method in interface com.hazelcast.security.SecurityContext
-
- interceptGet(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- interceptGet(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Intercept get operation before returning value.
- interceptPut(String, Object, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- interceptPut(Object, Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Intercept put operation before modifying map data.
- interceptRemove(String, Object) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- interceptRemove(Object) - Method in interface com.hazelcast.map.MapInterceptor
-
Intercept remove operation before removing the data.
- interceptSocket(Socket, boolean) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- InterfacesConfig - Class in com.hazelcast.config
-
Contains the configuration for an Interfaces.
- InterfacesConfig() - Constructor for class com.hazelcast.config.InterfacesConfig
-
- IntermediateChunkNotification<KeyOut,Value> - Class in com.hazelcast.mapreduce.impl.notification
-
Notification that is fired every time the chunk limit is reached and is send to the reducers
- IntermediateChunkNotification() - Constructor for class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- IntermediateChunkNotification(Address, String, String, Map<KeyOut, Value>, int) - Constructor for class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- InternalCompletableFuture<E> - Interface in com.hazelcast.spi
-
A
ICompletableFuture
with more functionality like getting
the result without needing to deal with checked exceptions.
- InternalLockNamespace - Class in com.hazelcast.concurrent.lock
-
- InternalLockNamespace() - Constructor for class com.hazelcast.concurrent.lock.InternalLockNamespace
-
- InternalLockNamespace(String) - Constructor for class com.hazelcast.concurrent.lock.InternalLockNamespace
-
- InternalOperationService - Interface in com.hazelcast.spi.impl
-
This is the interface that needs to be implemented by actual InternalOperationService.
- InternalPartition - Interface in com.hazelcast.partition
-
Represents a Partition.
- InternalPartitionService - Interface in com.hazelcast.partition
-
- InternalPartitionServiceImpl - Class in com.hazelcast.partition.impl
-
- InternalPartitionServiceImpl(Node) - Constructor for class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- invalidate(Data) - Method in class com.hazelcast.map.impl.NearCache
-
- invalidate(Collection<Data>) - Method in class com.hazelcast.map.impl.NearCache
-
- invalidate() - Method in interface com.hazelcast.map.impl.record.Record
-
- invalidate() - Method in class com.hazelcast.partition.MigrationInfo
-
- invalidate() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- invalidateAllNearCaches(String, Data) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- invalidateAllNearCaches(String, Set<Data>) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- invalidateNearCache(String, Data) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- invalidateNearCache(String, Collection<Data>) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- InvalidateNearCacheOperation - Class in com.hazelcast.map.impl.operation
-
- InvalidateNearCacheOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.InvalidateNearCacheOperation
-
- InvalidateNearCacheOperation() - Constructor for class com.hazelcast.map.impl.operation.InvalidateNearCacheOperation
-
- invalidateNearCaches() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- invalidateNearCaches(Set<Data>) - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- INVALIDATION_MESSAGE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- invertBit(byte, int) - Static method in class com.hazelcast.nio.Bits
-
Inverts n-th bit of the byte value
- invertBit(int, int) - Static method in class com.hazelcast.nio.Bits
-
Inverts n-th bit of the integer value
- InvocationBuilder - Class in com.hazelcast.spi
-
The InvocationBuilder is responsible for building an invocation of an operation and invoking it.
- InvocationBuilder(NodeEngineImpl, String, Operation, int, Address) - Constructor for class com.hazelcast.spi.InvocationBuilder
-
Creates an InvocationBuilder
- InvocationClientRequest - Class in com.hazelcast.client.impl.client
-
- InvocationClientRequest() - Constructor for class com.hazelcast.client.impl.client.InvocationClientRequest
-
- invoke(Data, EntryProcessor, Object[]) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- invoke(K, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- invoke(Data, EntryProcessor, Object[]) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Invokes an EntryProcessor
against the Cache.Entry
specified by
the provided key.
- invoke() - Method in class com.hazelcast.client.impl.client.InvocationClientRequest
-
- invoke(CollectionOperation) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- invoke() - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-
- invoke(String, Object[], String[]) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- invoke() - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- invoke(Operation, int) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- invoke(Collator) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-
- invoke() - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-
- invoke() - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-
- invoke() - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- invoke(Collator) - Method in class com.hazelcast.mapreduce.impl.task.KeyValueJob
-
- invoke() - Method in class com.hazelcast.spi.impl.BasicInvocationBuilder
-
- invoke() - Method in class com.hazelcast.spi.InvocationBuilder
-
- invoke() - Method in class com.hazelcast.transaction.client.RecoverAllTransactionsRequest
-
- invokeAll(Set<? extends K>, EntryProcessor<K, V, T>, Object...) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- invokeAll(Collection<? extends Callable<T>>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- invokeOnAllPartitions(String, OperationFactory) - Method in interface com.hazelcast.spi.OperationService
-
Invokes a set of operation on each partition.
- invokeOnPartition(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
-
- invokeOnPartitions(String, OperationFactory, Collection<Integer>) - Method in interface com.hazelcast.spi.OperationService
-
Invokes an set of operation on selected set of partitions
*
This method blocks until all operations complete.
- invokeOnTarget(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
-
- IO_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the io executor.
- IO_QUEUE_CAPACITY - Variable in class com.hazelcast.instance.GroupProperties
-
- IO_THREAD_COUNT - Variable in class com.hazelcast.instance.GroupProperties
-
- IOSelector - Interface in com.hazelcast.nio.tcp
-
- IOSelectorOutOfMemoryHandler - Interface in com.hazelcast.nio.tcp
-
- IOService - Interface in com.hazelcast.nio
-
- ioService - Variable in class com.hazelcast.nio.tcp.DefaultPacketReader
-
- IOUtil - Class in com.hazelcast.nio
-
- IPermissionPolicy - Interface in com.hazelcast.security
-
IPermissionPolicy is used to determine any
Subject
's
permissions to perform a security sensitive Hazelcast operation.
- IQueue<E> - Interface in com.hazelcast.core
-
Concurrent, blocking, distributed, observable queue.
- is(String) - Method in class com.hazelcast.query.EntryObject
-
- IS_EMPTY - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- IS_EMPTY - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- IS_EMPTY - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- IS_EMPTY - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- IS_LOCKED - Static variable in class com.hazelcast.concurrent.lock.client.LockPortableHook
-
- IS_LOCKED - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- IS_LOCKED - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- IS_LOCKED - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- IS_NULL - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- IS_SHUTDOWN_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-
- isActive() - Method in class com.hazelcast.instance.Node
-
- isActive() - Method in interface com.hazelcast.nio.IOService
-
- isActive() - Method in class com.hazelcast.nio.NodeIOService
-
- isActive() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- isActive() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- isActive() - Method in interface com.hazelcast.spi.NodeEngine
-
- isAlive() - Method in interface com.hazelcast.client.ClientEndpoint
-
Checks if the endpoint is alive.
- isAlive() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- isAlive() - Method in interface com.hazelcast.nio.Connection
-
Checks if the Connection is still alive.
- isAlive() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- isAllKeysSupported() - Method in class com.hazelcast.mapreduce.KeyValueSource
-
If it is possible to collect all clusterwide available keys for this KeyValueSource
implementation then this method should return true.
If true is returned a call to
KeyValueSource.getAllKeys()
must return all available keys
to execute a preselection of interesting partitions / nodes based on returns keys.
- isAllowUnsafe() - Method in class com.hazelcast.config.SerializationConfig
-
Default value is false.
- isArrayByteBase64(byte[]) - Static method in class com.hazelcast.util.Base64
-
- isAsyncFillup() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- isAuthenticated() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- isAvailable(int) - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- isBase64(String) - Static method in class com.hazelcast.util.Base64
-
- isBase64(byte) - Static method in class com.hazelcast.util.Base64
-
- isBinary() - Method in class com.hazelcast.config.MultiMapConfig
-
- isBinary() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- isBinary() - Method in enum com.hazelcast.nio.ConnectionType
-
- isBinary() - Method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- isBitSet(int, int) - Static method in class com.hazelcast.nio.Bits
-
Returns true if n-th bit of the value is set, false otherwise
- isBlacklisted(Address) - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- isBlacklisted(Address) - Method in interface com.hazelcast.cluster.Joiner
-
Checks if an address is blacklisted.
- isBlocking() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- isBlocking() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
- isCacheLocalEntries() - Method in class com.hazelcast.config.NearCacheConfig
-
- isCallTimedOut(Operation) - Method in interface com.hazelcast.spi.impl.InternalOperationService
-
- isCancelled() - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
-
- isCancelled() - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- isCancelled() - Method in class com.hazelcast.util.executor.CompletedFuture
-
- isCancelled() - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
-
Default value is true.
- isClaimingMaster() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- isClient() - Method in interface com.hazelcast.nio.Connection
-
Checks if it is a client connection.
- isClient() - Method in enum com.hazelcast.nio.ConnectionType
-
- isClient() - Method in interface com.hazelcast.nio.IOService
-
- isClient() - Method in class com.hazelcast.nio.NodeIOService
-
- isClient() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- isClosed() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- isClusterSafe() - Method in interface com.hazelcast.core.PartitionService
-
Checks whether the cluster is in a safe state.
- isClusterSafe() - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- isCommunicateStats() - Method in class com.hazelcast.config.JobTrackerConfig
-
- isCommunicateStats() - Method in class com.hazelcast.mapreduce.impl.task.JobTaskConfiguration
-
- isCompatible(ConfigCheck) - Method in class com.hazelcast.cluster.impl.ConfigCheck
-
Checks if 2 Hazelcast configurations are compatible.
- isCompatible(Config) - Method in class com.hazelcast.config.Config
-
- isCompatible(MapConfig) - Method in class com.hazelcast.config.MapConfig
-
- isConfigurableService() - Method in class com.hazelcast.spi.ServiceInfo
-
- isConnected() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- isConnected() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
- isCoreService() - Method in class com.hazelcast.spi.ServiceInfo
-
- isData(byte) - Static method in class com.hazelcast.util.Base64
-
- isDefaultClassLoader - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- isDefaultURI - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- isDestroy() - Method in class com.hazelcast.cache.impl.CacheDistributedObject
-
- isDirect() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- isDone() - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- isDone() - Method in class com.hazelcast.util.executor.CompletedFuture
-
- isDone() - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- ISemaphore - Interface in com.hazelcast.core
-
ISemaphore is a backed-up distributed alternative to the
Semaphore
.
- isEmpty() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- isEmpty() - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- isEmpty() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-
- isEmpty() - Method in interface com.hazelcast.core.BaseMap
-
Returns true if this map contains no entries.
- isEmpty() - Method in interface com.hazelcast.core.TransactionalMap
-
- isEmpty() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- isEmpty() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-
- isEmpty() - Method in interface com.hazelcast.map.impl.RecordStore
-
- isEmpty() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- isEmpty() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- isEmpty() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- isEmpty() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- isEmpty() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns true if this map contains no key-value mappings.
- IsEmptyOperation - Class in com.hazelcast.queue.impl.operations
-
check if queue is empty
- IsEmptyOperation() - Constructor for class com.hazelcast.queue.impl.operations.IsEmptyOperation
-
- IsEmptyOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.IsEmptyOperation
-
- IsEmptyOperationFactory - Class in com.hazelcast.map.impl.operation
-
- IsEmptyOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-
- IsEmptyOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-
- IsEmptyRequest - Class in com.hazelcast.queue.impl.client
-
Request to check if the Queue is empty
- IsEmptyRequest() - Constructor for class com.hazelcast.queue.impl.client.IsEmptyRequest
-
- IsEmptyRequest(String) - Constructor for class com.hazelcast.queue.impl.client.IsEmptyRequest
-
- isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
-
Enables compression when default java serialization is used.
- isEnabled() - Method in class com.hazelcast.config.AwsConfig
-
Checks if the aws join mechanism is enabled.
- isEnabled() - Method in class com.hazelcast.config.InterfacesConfig
-
- isEnabled() - Method in class com.hazelcast.config.ManagementCenterConfig
-
- isEnabled() - Method in class com.hazelcast.config.MapStoreConfig
-
Returns if this configuration is enabled
- isEnabled() - Method in class com.hazelcast.config.MulticastConfig
-
Check if the multicast discovery mechanism has been enabled.
- isEnabled() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- isEnabled() - Method in class com.hazelcast.config.PartitionGroupConfig
-
Checks if this PartitionGroupConfig is enabled.
- isEnabled() - Method in class com.hazelcast.config.QueueStoreConfig
-
- isEnabled() - Method in class com.hazelcast.config.SecurityConfig
-
- isEnabled() - Method in class com.hazelcast.config.ServiceConfig
-
- isEnabled() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Returns if this configuration is enabled
- isEnabled() - Method in class com.hazelcast.config.SSLConfig
-
Returns if this configuration is enabled
- isEnabled() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- isEnabled() - Method in class com.hazelcast.config.TcpIpConfig
-
Checks if the Tcp/Ip join mechanism is enabled.
- isEnabled() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Empty or a real queue.
- isEnabled() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- isEnabled() - Method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- isEnableDefaults() - Method in class com.hazelcast.config.ServicesConfig
-
- isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
-
Default value is true.
- isEnterprise() - Method in class com.hazelcast.instance.BuildInfo
-
- isEquals(Object, Object) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- isEquals(Object, Object) - Method in class com.hazelcast.map.impl.record.DataRecordFactory
-
- isEquals(Object, Object) - Method in class com.hazelcast.map.impl.record.NativeRecordFactory
-
- isEquals(Object, Object) - Method in class com.hazelcast.map.impl.record.ObjectRecordFactory
-
- isEquals(Object, Object) - Method in interface com.hazelcast.map.impl.record.RecordFactory
-
- isError() - Method in class com.hazelcast.client.impl.client.ClientResponse
-
- ISet<E> - Interface in com.hazelcast.core
-
Concurrent, distributed implementation of
Set
This class is not a general-purpose Set implementation! While this class implements
the Set interface, it intentionally violates Set's general contract, which mandates the
use of the equals method when comparing objects.
- isEventBatchingEnabled - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- isEventsEnabled - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- isEvictable() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- isEvictionRequired() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- isEvictionRequired() - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- isExpirable() - Method in interface com.hazelcast.map.impl.RecordStore
-
- isExpiredAt(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- isExpiredAt(long, long) - Static method in class com.hazelcast.cache.impl.record.CacheRecordFactory
-
Determines whether the Cache Entry associated with this value would be expired
at the specified time.
- isExpiredAt(long) - Method in interface com.hazelcast.cache.impl.record.Expirable
-
Checks whether the expiration time is passed with respect to the provided time.
- isFinestEnabled() - Method in class com.hazelcast.logging.AbstractLogger
-
- isFinestEnabled() - Method in interface com.hazelcast.logging.ILogger
-
- isFirstConnection() - Method in interface com.hazelcast.client.ClientEndpoint
-
- isFirstConnection() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- isGlobalOrderingEnabled() - Method in class com.hazelcast.config.TopicConfig
-
- isHazelcastEnterpriseActive() - Method in class com.hazelcast.nio.UTFEncoderDecoder
-
- isHeaderSet(int) - Method in class com.hazelcast.nio.Packet
-
- isIncludeValue() - Method in class com.hazelcast.collection.CollectionEventFilter
-
- isIncludeValue() - Method in class com.hazelcast.config.EntryListenerConfig
-
- isIncludeValue() - Method in class com.hazelcast.config.ItemListenerConfig
-
- isIncludeValue() - Method in class com.hazelcast.config.ListenerConfig
-
- isIncludeValue() - Method in class com.hazelcast.map.impl.EntryEventFilter
-
- isIncludeValue() - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-
- isIncludeValue() - Method in class com.hazelcast.queue.impl.QueueEventFilter
-
- isIndexed(QueryContext) - Method in interface com.hazelcast.query.IndexAwarePredicate
-
- isIndexed(QueryContext) - Method in class com.hazelcast.query.PagingPredicate
-
- isIndexed(QueryContext) - Method in class com.hazelcast.query.PredicateBuilder
-
- isIndexed(QueryContext) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
-
- isIndexed(QueryContext) - Method in class com.hazelcast.query.Predicates.AndPredicate
-
- isIndexed(QueryContext) - Method in class com.hazelcast.query.Predicates.OrPredicate
-
- isIndexed(QueryContext) - Method in class com.hazelcast.query.SqlPredicate
-
- isInstanceOf(Class) - Method in class com.hazelcast.spi.ServiceInfo
-
- isInternalType(Class) - Static method in class com.hazelcast.nio.ClassLoaderUtil
-
- isInvalidateOnChange() - Method in class com.hazelcast.config.NearCacheConfig
-
- isIpAddress(String) - Static method in class com.hazelcast.util.AddressUtil
-
- isIPv4() - Method in class com.hazelcast.nio.Address
-
- isIPv4() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- isIPv6() - Method in class com.hazelcast.nio.Address
-
- isIPv6() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- isJoinInProgress() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- isJoinOperation(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
-
- isLive() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- isLive() - Method in class com.hazelcast.util.executor.StripedExecutor
-
Checks if this StripedExecutor is alive (so not shut down).
- isLoaded() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- isLoaded() - Method in interface com.hazelcast.map.impl.RecordStore
-
- isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
-
- isLocal() - Method in class com.hazelcast.config.ListenerConfig
-
- isLocal() - Method in interface com.hazelcast.spi.ResponseHandler
-
- isLocalMemberSafe() - Method in interface com.hazelcast.core.PartitionService
-
Check if local member is safe to shutdown, means check if at least one backup of the partitions
those owned by local member are in sync with primary.
- isLocalMemberSafe() - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- isLocalOnly() - Method in interface com.hazelcast.spi.EventRegistration
-
Returns true if this registration is for locally fired events only.
- isLocalOnly() - Method in class com.hazelcast.spi.impl.EventServiceImpl.Registration
-
- isLocked() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- isLocked(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-
- isLocked() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- isLocked(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- isLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- isLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- isLocked() - Method in interface com.hazelcast.core.ILock
-
Returns whether this lock is locked or not.
- isLocked(K) - Method in interface com.hazelcast.core.IMap
-
Checks the lock for the specified key.
- isLocked(K) - Method in interface com.hazelcast.core.MultiMap
-
Checks the lock for the specified key.
- isLocked(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- isLocked(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- isLocked(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- isLocked(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- isLocked(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- isLockedBy(String, long) - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- isLockedBy(Data, String, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- isLockedBy(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- isLockedBy(Data, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- isLockedByCurrentThread() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- isLockedByCurrentThread(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-
- isLockedByCurrentThread() - Method in interface com.hazelcast.core.ILock
-
Returns whether this lock is locked by current thread or not.
- IsLockedOperation - Class in com.hazelcast.concurrent.lock.operations
-
- IsLockedOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-
- IsLockedOperation(ObjectNamespace, Data) - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-
- IsLockedOperation(ObjectNamespace, Data, long) - Constructor for class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-
- IsLockedRequest - Class in com.hazelcast.concurrent.lock.client
-
- IsLockedRequest() - Constructor for class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- IsLockedRequest(Data) - Constructor for class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- IsLockedRequest(Data, long) - Constructor for class com.hazelcast.concurrent.lock.client.IsLockedRequest
-
- isLoggable(Level) - Method in interface com.hazelcast.logging.ILogger
-
Checks if a message at the provided level is going to be logged by this logger.
- isManagedService() - Method in class com.hazelcast.spi.ServiceInfo
-
- isManagementEnabled() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- isManagementEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- isMaster() - Method in interface com.hazelcast.cluster.ClusterService
-
Checks if this member is the master.
- isMaster() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- isMaster() - Method in class com.hazelcast.instance.Node
-
- isMemberSafe(Member) - Method in interface com.hazelcast.core.PartitionService
-
Check if the given member is safe to shutdown, means check if at least one backup of the partitions
those owned by given member are in sync with primary.
- isMemberSafe(Member) - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- isMemberStateSafe() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- isMemberStateSafe() - Method in interface com.hazelcast.partition.InternalPartitionService
-
Query and return if this member in a safe state or not.
- isMemcacheEnabled() - Method in interface com.hazelcast.nio.IOService
-
- isMemcacheEnabled() - Method in class com.hazelcast.nio.NodeIOService
-
- isMigrating() - Method in interface com.hazelcast.partition.InternalPartition
-
Checks if there currently is a migration going on in this partition.
- isMigrationActive() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- isMigrationOperation(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
-
- isModified() - Method in class com.hazelcast.map.impl.MapEntrySimple
-
- isNearCacheAndInvalidationEnabled(String) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- isNearCacheEnabled() - Method in class com.hazelcast.config.MapConfig
-
- isNearCacheEnabled() - Method in class com.hazelcast.map.impl.MapContainer
-
- isNearCacheEnabled(String) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- isNot(String) - Method in class com.hazelcast.query.EntryObject
-
- isNotNegative(long, String) - Static method in class com.hazelcast.util.ValidationUtil
-
- isNotNull() - Method in class com.hazelcast.query.EntryObject
-
- isNotNull(E, String) - Static method in class com.hazelcast.util.ValidationUtil
-
- isNull() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- isNull() - Method in class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
-
- isNull() - Method in interface com.hazelcast.core.IAtomicReference
-
Checks if the stored reference is null.
- isNull() - Method in class com.hazelcast.query.EntryObject
-
- IsNullOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- IsNullOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-
- IsNullOperation(String) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-
- isNullOrEmpty(String) - Static method in class com.hazelcast.util.StringUtil
-
- IsNullRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- IsNullRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-
- IsNullRequest(String) - Constructor for class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-
- isOldValueAvailable() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-
- isOldValueAvailable() - Method in interface com.hazelcast.cache.impl.CacheEventData
-
Returns true if old value is available.
- isOldValueAvailable() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- isOldValueRequired() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- isOpen() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- isOpen() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
- isOperationExecuting(Address, String, Object) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- isOperationExecuting(Address, String, Object) - Method in interface com.hazelcast.spi.ExecutionTracingService
-
- isOptimizeQueries() - Method in class com.hazelcast.config.MapConfig
-
- isOrdered() - Method in class com.hazelcast.config.MapIndexConfig
-
Checks if the index should be ordered.
- isOrdered() - Method in interface com.hazelcast.query.impl.Index
-
- isOrdered() - Method in class com.hazelcast.query.impl.IndexImpl
-
- isOverwritable() - Method in class com.hazelcast.mapreduce.impl.JobPartitionStateArraySerializerHook
-
- isOverwritable() - Method in class com.hazelcast.mapreduce.impl.JobPartitionStateSerializerHook
-
- isOverwritable() - Method in interface com.hazelcast.nio.serialization.SerializerHook
-
Defines if this serializer can be overridden by defining a custom
serializer in the configurations (codebase or configuration file)
- isOverwritable() - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook
-
- isOverwritable() - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook
-
- isOwnedKey(Data) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- isOwnedKey(Data) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
Check if key belongs on partitions of the this node
- isOwnerNode() - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- isOwnerOrBackup(Address) - Method in interface com.hazelcast.partition.InternalPartition
-
Checks if given address is owner of primary or backup of this partition.
- isPad(byte) - Static method in class com.hazelcast.util.Base64
-
- isPollOperation() - Method in class com.hazelcast.queue.impl.TxQueueItem
-
- isPortable() - Method in interface com.hazelcast.nio.serialization.Data
-
Returns true if this Data is created from a
Portable
object,
false otherwise.
- isPortable() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- isPortAutoIncrement() - Method in class com.hazelcast.config.NetworkConfig
-
Checks if a Hazelcast member is allowed find a free port by incrementing the port number when it encounters
an occupied port.
- isPostProcessingMapStore() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- isPowerOfTwo(long) - Static method in class com.hazelcast.util.QuickMath
-
Return true if input argument is power of two.
- isProcessing() - Method in class com.hazelcast.partition.MigrationInfo
-
- isReadBackupData() - Method in class com.hazelcast.config.MapConfig
-
- isReadThrough() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- isReadThrough() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- isReadThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- isRemove() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- isRemoveOperation() - Method in class com.hazelcast.collection.TxCollectionItem
-
- IsReplicaVersionSync - Class in com.hazelcast.partition.impl
-
Queries if replica version is sync between partitions.
- IsReplicaVersionSync() - Constructor for class com.hazelcast.partition.impl.IsReplicaVersionSync
-
- IsReplicaVersionSync(long) - Constructor for class com.hazelcast.partition.impl.IsReplicaVersionSync
-
- isRestEnabled() - Method in interface com.hazelcast.nio.IOService
-
- isRestEnabled() - Method in class com.hazelcast.nio.NodeIOService
-
- isResultDeserialized() - Method in class com.hazelcast.spi.InvocationBuilder
-
Checks if the Future should automatically deserialize the result.
- isReuseAddress() - Method in class com.hazelcast.config.NetworkConfig
-
- isRunning() - Method in interface com.hazelcast.core.LifecycleService
-
whether the instance is running
- isRunning() - Method in class com.hazelcast.instance.LifecycleServiceImpl
-
- isRunning() - Method in class com.hazelcast.instance.TerminatedLifecycleService
-
- isRunning() - Method in class com.hazelcast.jmx.InstanceMBean
-
- isSameGroup(ConfigCheck) - Method in class com.hazelcast.cluster.impl.ConfigCheck
-
- isSameRM(XAResource) - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- isShutdown(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- isShutdown() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- isShutdown() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-
- isShutdown() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- IsShutdownRequest - Class in com.hazelcast.executor.impl.client
-
- IsShutdownRequest() - Constructor for class com.hazelcast.executor.impl.client.IsShutdownRequest
-
- IsShutdownRequest(String) - Constructor for class com.hazelcast.executor.impl.client.IsShutdownRequest
-
- isSingleConnection() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- isSocketBind() - Method in interface com.hazelcast.nio.IOService
-
- isSocketBind() - Method in class com.hazelcast.nio.NodeIOService
-
- isSocketBindAny() - Method in interface com.hazelcast.nio.IOService
-
- isSocketBindAny() - Method in class com.hazelcast.nio.NodeIOService
-
- isSocketInterceptorEnabled() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- isSSlEnabled() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapperFactory
-
- isSSlEnabled() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapperFactory
-
- isSSLEnabled() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- isStatisticsEnabled() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- isStatisticsEnabled() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- isStatisticsEnabled() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- isStatisticsEnabled() - Method in class com.hazelcast.config.CollectionConfig
-
- isStatisticsEnabled() - Method in class com.hazelcast.config.ExecutorConfig
-
- isStatisticsEnabled() - Method in class com.hazelcast.config.MapConfig
-
- isStatisticsEnabled() - Method in class com.hazelcast.config.MultiMapConfig
-
- isStatisticsEnabled() - Method in class com.hazelcast.config.QueueConfig
-
- isStatisticsEnabled() - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- isStatisticsEnabled() - Method in class com.hazelcast.config.TopicConfig
-
Checks if statistics are enabled.
- isStatusSet(int) - Method in class com.hazelcast.nio.serialization.DataAdapter
-
- IsStillExecutingOperation - Class in com.hazelcast.spi.impl
-
An operation that checks if another operation is still running.
- isStoreByValue() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- isSuitableForCompare(Comparator<Map.Entry>, IterationType, Map.Entry) - Static method in class com.hazelcast.util.SortingUtil
-
- isSupported(OptionalFeature) - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- isSupported(OptionalFeature) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- isSymmetricEncryptionEnabled(IOService) - Static method in class com.hazelcast.nio.CipherHelper
-
- isSynchronous() - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- isTerminated() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- isTerminated() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-
- isTerminated() - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- isTerminated() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- isTombstone() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- isTransactional() - Method in interface com.hazelcast.concurrent.lock.LockResource
-
- isTransactionallyLocked(Data) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- isTransactionallyLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- isTransactionallyLocked(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- isTransactionallyLocked(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- isTransactionallyLocked(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- isTransactionallyLocked(Data) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- isUrgent() - Method in class com.hazelcast.ascii.AbstractTextCommand
-
- isUrgent() - Method in class com.hazelcast.nio.Packet
-
- isUrgent() - Method in class com.hazelcast.nio.serialization.DataAdapter
-
- isUrgent() - Method in interface com.hazelcast.nio.SocketWritable
-
Checks if this SocketWritable is urgent.
- isUrgent() - Method in interface com.hazelcast.spi.impl.RemotePropagatable
-
- isUrgent() - Method in class com.hazelcast.spi.impl.Response
-
Check if this Response is an urgent response.
- isUrgent() - Method in class com.hazelcast.spi.Operation
-
- isUseNativeByteOrder() - Method in class com.hazelcast.config.SerializationConfig
-
- isValid() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-
- isValid() - Method in class com.hazelcast.partition.MigrationInfo
-
- isWhiteSpace(byte) - Static method in class com.hazelcast.util.Base64
-
- isWriteThrough() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- isWriteThrough() - Method in class com.hazelcast.cache.impl.CacheMXBeanImpl
-
- isWriteThrough() - Method in class com.hazelcast.config.CacheSimpleConfig
-
- isXAManaged() - Method in interface com.hazelcast.transaction.TransactionContext
-
Indicates that related transaction is managed by XAResource
- item - Variable in class com.hazelcast.core.ItemEvent
-
- ITEM_EVENT - Static variable in class com.hazelcast.spi.impl.SpiPortableHook
-
- itemAdded(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- itemAdded(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
-
Invoked when an item is added.
- ItemEvent<E> - Class in com.hazelcast.core
-
Map Item event.
- ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.core.ItemEvent
-
- ItemEventType - Enum in com.hazelcast.core
-
Type of item event.
- itemId - Variable in class com.hazelcast.collection.CollectionAddOperation
-
- itemId - Variable in class com.hazelcast.collection.CollectionItem
-
- itemId - Variable in class com.hazelcast.queue.impl.QueueItem
-
- itemIdSet - Variable in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- ItemListener<E> - Interface in com.hazelcast.core
-
- ItemListenerConfig - Class in com.hazelcast.config
-
Contains the configuration for an Item Listener.
- ItemListenerConfig() - Constructor for class com.hazelcast.config.ItemListenerConfig
-
- ItemListenerConfig(String, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
-
- ItemListenerConfig(ItemListener, boolean) - Constructor for class com.hazelcast.config.ItemListenerConfig
-
- ItemListenerConfig(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfig
-
- ItemListenerConfigReadOnly - Class in com.hazelcast.config
-
Contains the configuration for an Item Listener(Read-only).
- ItemListenerConfigReadOnly(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfigReadOnly
-
- itemMap - Variable in class com.hazelcast.collection.CollectionContainer
-
- itemRemoved(ItemEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
-
Invoked when an item is removed.
- ITERATE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- IterationType - Enum in com.hazelcast.util
-
To differentiate users selection on result collection on map-wide operations
like values , keySet , query etc.
- iterator(int, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- iterator() - Method in class com.hazelcast.cache.impl.CacheProxy
-
- iterator(int, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Starting from the provided table index, a set of keys are returned with a maximum size of size
- iterator() - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- iterator() - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- iterator() - Method in class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
-
- iterator() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- iterator(long, boolean) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- iterator() - Method in interface com.hazelcast.map.impl.RecordStore
-
Iterates over record store values.
- iterator(long, boolean) - Method in interface com.hazelcast.map.impl.RecordStore
-
Iterates over record store values by respecting expiration.
- iterator() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- iterator() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-
- iterator() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- iterator() - Method in class com.hazelcast.query.impl.AndResultSet
-
- iterator() - Method in class com.hazelcast.query.impl.MultiResultSet
-
- iterator() - Method in class com.hazelcast.query.impl.OrResultSet
-
- iterator() - Method in class com.hazelcast.query.impl.SingleResultSet
-
- iterator() - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- ITERATOR - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- ITERATOR - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- iterator() - Method in class com.hazelcast.spi.impl.SerializableCollection
-
- iterator() - Method in class com.hazelcast.util.QueryResultSet
-
- iterator(Class<T>, String, ClassLoader) - Static method in class com.hazelcast.util.ServiceLoader
-
- iterator() - Method in class com.hazelcast.util.SortedQueryResultSet
-
- IteratorOperation - Class in com.hazelcast.queue.impl.operations
-
Provides iterator functionality for Queue.
- IteratorOperation() - Constructor for class com.hazelcast.queue.impl.operations.IteratorOperation
-
- IteratorOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.IteratorOperation
-
- IteratorRequest - Class in com.hazelcast.queue.impl.client
-
- IteratorRequest() - Constructor for class com.hazelcast.queue.impl.client.IteratorRequest
-
- IteratorRequest(String) - Constructor for class com.hazelcast.queue.impl.client.IteratorRequest
-
- ITopic<E> - Interface in com.hazelcast.core
-
Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers
which is also known as publish/subscribe (pub/sub) messaging model.
- main(String[]) - Static method in class com.hazelcast.console.ConsoleApp
-
Starts the test application.
- main(String[]) - Static method in class com.hazelcast.core.server.StartServer
-
Creates a server instance of Hazelcast
- ManagedAnnotation - Annotation Type in com.hazelcast.jmx
-
Annotation for management bean attributes.
- ManagedContext - Interface in com.hazelcast.core
-
Container managed context, such as Spring, Guice and etc.
- managedContext - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- managedContext - Variable in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- ManagedDescription - Annotation Type in com.hazelcast.jmx
-
Annotation for management bean descriptions.
- ManagedExecutorService - Interface in com.hazelcast.util.executor
-
- ManagedExecutorServiceMBean - Class in com.hazelcast.jmx
-
- ManagedExecutorServiceMBean(HazelcastInstance, ManagedExecutorService, ManagementService) - Constructor for class com.hazelcast.jmx.ManagedExecutorServiceMBean
-
- ManagedService - Interface in com.hazelcast.spi
-
A interface that can be implemented by a SPI Service to receive lifecycle calls:
initialization
shutdown
reset
- MANAGEMENT_CONFIG - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- MANAGEMENT_CONFIG - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- ManagementCenterConfig - Class in com.hazelcast.config
-
Contains the configuration for a Management Center.
- ManagementCenterConfig() - Constructor for class com.hazelcast.config.ManagementCenterConfig
-
- ManagementCenterConfig(String, int) - Constructor for class com.hazelcast.config.ManagementCenterConfig
-
- ManagementCenterIdentifier - Class in com.hazelcast.management
-
Identifier for the ManagementCenter.
- ManagementCenterIdentifier() - Constructor for class com.hazelcast.management.ManagementCenterIdentifier
-
- ManagementCenterIdentifier(String, String, String) - Constructor for class com.hazelcast.management.ManagementCenterIdentifier
-
- ManagementCenterService - Class in com.hazelcast.management
-
ManagementCenterService is responsible for sending statistics data to the Management Center.
- ManagementCenterService(HazelcastInstanceImpl) - Constructor for class com.hazelcast.management.ManagementCenterService
-
- ManagementCenterService.MemberListenerImpl - Class in com.hazelcast.management
-
MembershipListener to send Management Center URL to the new members.
- ManagementCenterService.MemberListenerImpl() - Constructor for class com.hazelcast.management.ManagementCenterService.MemberListenerImpl
-
- ManagementService - Class in com.hazelcast.jmx
-
Service responsible for registering hazelcast management beans to the platform management bean server.
- ManagementService(HazelcastInstanceImpl) - Constructor for class com.hazelcast.jmx.ManagementService
-
- map(KeyIn, ValueIn, Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
-
The map method is called for every single key-value pair in the bound
KeyValueSource
instance
on this cluster node and partition.
Due to it's nature of a DataGrid Hazelcast distributes values all over the cluster and so this method
is executed on multiple servers at the same time.
If you want to know more about the implementation of MapReduce algorithms read the
Google Whitepaper on MapReduce.
- map(KeyIn, ValueIn, Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.Mapper
-
The map method is called for every single key-value pair in the bound
KeyValueSource
instance
on this cluster node and partition.
Due to it's nature of a DataGrid Hazelcast distributes values all over the cluster and so this method
is executed on multiple servers at the same time.
If you want to know more about the implementation of MapReduce algorithms read the
Google Whitepaper on MapReduce.
- MAP_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- MAP_ENTRY_EVENT - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- MAP_ENTRY_SET - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- MAP_KEY_SET - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- MAP_LOAD_ALL_KEYS_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
- MAP_LOAD_CHUNK_SIZE - Variable in class com.hazelcast.instance.GroupProperties
-
- MAP_LOADER_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
- MAP_NAME_PRECEDER - Static variable in class com.hazelcast.ascii.memcache.MemcacheCommandProcessor
-
- MAP_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- MAP_REDUCE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- MAP_REDUCE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MAP_STATS - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- MAP_WRITE_BEHIND_QUEUE_CAPACITY - Variable in class com.hazelcast.instance.GroupProperties
-
- MapAddEntryListenerRequest - Class in com.hazelcast.map.impl.client
-
- MapAddEntryListenerRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- MapAddEntryListenerRequest(String, boolean) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- MapAddEntryListenerRequest(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- MapAddEntryListenerRequest(String, Data, boolean, Predicate) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- MapAddEntryListenerSqlRequest - Class in com.hazelcast.map.impl.client
-
- MapAddEntryListenerSqlRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-
- MapAddEntryListenerSqlRequest(String, boolean) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-
- MapAddEntryListenerSqlRequest(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-
- MapAddEntryListenerSqlRequest(String, Data, boolean, String) - Constructor for class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-
- MapAddIndexRequest - Class in com.hazelcast.map.impl.client
-
- MapAddIndexRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- MapAddIndexRequest(String, String, boolean) - Constructor for class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- MapAddInterceptorRequest - Class in com.hazelcast.map.impl.client
-
- MapAddInterceptorRequest() - Constructor for class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- MapAddInterceptorRequest(String, MapInterceptor) - Constructor for class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- mapCleared(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- mapCleared(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
-
- mapCleared(MapEvent) - Method in interface com.hazelcast.core.EntryListener
-
- MapClearRequest - Class in com.hazelcast.map.impl.client
-
- MapClearRequest() - Constructor for class com.hazelcast.map.impl.client.MapClearRequest
-
- MapClearRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapClearRequest
-
- MapCombineTask<KeyIn,ValueIn,KeyOut,ValueOut,Chunk> - Class in com.hazelcast.mapreduce.impl.task
-
This class acutally executed the mapping-combine phase.
- MapCombineTask(JobTaskConfiguration, JobSupervisor, MappingPhase<KeyIn, ValueIn, KeyOut, ValueOut>) - Constructor for class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- mapCombineTasks - Variable in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- MapConfig - Class in com.hazelcast.config
-
Contains the configuration for an
IMap
.
- MapConfig(String) - Constructor for class com.hazelcast.config.MapConfig
-
- MapConfig() - Constructor for class com.hazelcast.config.MapConfig
-
- MapConfig(MapConfig) - Constructor for class com.hazelcast.config.MapConfig
-
- MapConfigAdapter - Class in com.hazelcast.management
-
- MapConfigAdapter() - Constructor for class com.hazelcast.management.MapConfigAdapter
-
- MapConfigAdapter(MapConfig) - Constructor for class com.hazelcast.management.MapConfigAdapter
-
- MapConfigReadOnly - Class in com.hazelcast.config
-
Contains the configuration for an
IMap
(read-only).
- MapConfigRequest - Class in com.hazelcast.management.request
-
Request for updating map configuration from Management Center.
- MapConfigRequest() - Constructor for class com.hazelcast.management.request.MapConfigRequest
-
- MapConfigRequest(String, MapConfigAdapter, boolean) - Constructor for class com.hazelcast.management.request.MapConfigRequest
-
- MapContainer - Class in com.hazelcast.map.impl
-
Map container.
- MapContainer(String, MapConfig, MapServiceContext) - Constructor for class com.hazelcast.map.impl.MapContainer
-
- mapContainer - Variable in class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- mapContainer - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- MapContainsKeyRequest - Class in com.hazelcast.map.impl.client
-
- MapContainsKeyRequest() - Constructor for class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- MapContainsKeyRequest(String, Data) - Constructor for class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- MapContainsKeyRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- MapContainsValueRequest - Class in com.hazelcast.map.impl.client
-
- MapContainsValueRequest() - Constructor for class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- MapContainsValueRequest(String, Data) - Constructor for class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- MapContextQuerySupport - Interface in com.hazelcast.map.impl
-
Support interface which is used in map specific query operations.
- MapDataSerializerHook - Class in com.hazelcast.map.impl
-
- MapDataSerializerHook() - Constructor for class com.hazelcast.map.impl.MapDataSerializerHook
-
- MapDataStore<K,V> - Interface in com.hazelcast.map.impl.mapstore
-
Map data store general contract.
- MapDataStores - Class in com.hazelcast.map.impl.mapstore
-
Factory class responsible for creating various daa store implementations.
- MapDeleteRequest - Class in com.hazelcast.map.impl.client
-
- MapDeleteRequest() - Constructor for class com.hazelcast.map.impl.client.MapDeleteRequest
-
- MapDeleteRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapDeleteRequest
-
- mapDrainIterator(int, Map) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- MapEntrySet - Class in com.hazelcast.map.impl
-
- MapEntrySet() - Constructor for class com.hazelcast.map.impl.MapEntrySet
-
- MapEntrySet(Set<Map.Entry<Data, Data>>) - Constructor for class com.hazelcast.map.impl.MapEntrySet
-
- MapEntrySetOperation - Class in com.hazelcast.map.impl.operation
-
- MapEntrySetOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapEntrySetOperation
-
- MapEntrySetOperation() - Constructor for class com.hazelcast.map.impl.operation.MapEntrySetOperation
-
- MapEntrySetRequest - Class in com.hazelcast.map.impl.client
-
- MapEntrySetRequest() - Constructor for class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- MapEntrySetRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- MapEntrySimple<K,V> - Class in com.hazelcast.map.impl
-
- MapEntrySimple(K, V) - Constructor for class com.hazelcast.map.impl.MapEntrySimple
-
- MapEvent - Class in com.hazelcast.core
-
- MapEvent(Object, Member, int, int) - Constructor for class com.hazelcast.core.MapEvent
-
- MapEventData - Class in com.hazelcast.map.impl
-
Map wide event's data.
- MapEventData() - Constructor for class com.hazelcast.map.impl.MapEventData
-
- MapEventData(String, String, Address, int, int) - Constructor for class com.hazelcast.map.impl.MapEventData
-
- MapEventPublisher - Interface in com.hazelcast.map.impl
-
Helper methods for publishing events.
- MapEvictAllRequest - Class in com.hazelcast.map.impl.client
-
Evict all entries request used by clients.
- MapEvictAllRequest() - Constructor for class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- MapEvictAllRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- mapEvicted(MapEvent) - Method in class com.hazelcast.console.ConsoleApp
-
- mapEvicted(MapEvent) - Method in class com.hazelcast.core.EntryAdapter
-
- mapEvicted(MapEvent) - Method in interface com.hazelcast.core.EntryListener
-
- MapEvictRequest - Class in com.hazelcast.map.impl.client
-
- MapEvictRequest() - Constructor for class com.hazelcast.map.impl.client.MapEvictRequest
-
- MapEvictRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapEvictRequest
-
- MapExecuteOnAllKeysRequest - Class in com.hazelcast.map.impl.client
-
- MapExecuteOnAllKeysRequest() - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- MapExecuteOnAllKeysRequest(String, EntryProcessor) - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- MapExecuteOnKeyRequest - Class in com.hazelcast.map.impl.client
-
- MapExecuteOnKeyRequest() - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- MapExecuteOnKeyRequest(String, EntryProcessor, Data) - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- MapExecuteOnKeysRequest - Class in com.hazelcast.map.impl.client
-
- MapExecuteOnKeysRequest() - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- MapExecuteOnKeysRequest(String, EntryProcessor, Set<Data>) - Constructor for class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- MapExecuteWithPredicateRequest - Class in com.hazelcast.map.impl.client
-
- MapExecuteWithPredicateRequest() - Constructor for class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- MapExecuteWithPredicateRequest(String, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- MapFlushOperation - Class in com.hazelcast.map.impl.operation
-
- MapFlushOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperation
-
- MapFlushOperation() - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperation
-
- MapFlushOperationFactory - Class in com.hazelcast.map.impl.operation
-
- MapFlushOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-
- MapFlushOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-
- MapFlushRequest - Class in com.hazelcast.map.impl.client
-
- MapFlushRequest() - Constructor for class com.hazelcast.map.impl.client.MapFlushRequest
-
- MapFlushRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapFlushRequest
-
- MapGetAllOperationFactory - Class in com.hazelcast.map.impl.operation
-
- MapGetAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-
- MapGetAllOperationFactory(String, Set<Data>) - Constructor for class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-
- MapGetAllRequest - Class in com.hazelcast.map.impl.client
-
- MapGetAllRequest() - Constructor for class com.hazelcast.map.impl.client.MapGetAllRequest
-
- MapGetAllRequest(String, Set<Data>) - Constructor for class com.hazelcast.map.impl.client.MapGetAllRequest
-
- MapGetEntryViewRequest - Class in com.hazelcast.map.impl.client
-
- MapGetEntryViewRequest() - Constructor for class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- MapGetEntryViewRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- MapGetRequest - Class in com.hazelcast.map.impl.client
-
- MapGetRequest() - Constructor for class com.hazelcast.map.impl.client.MapGetRequest
-
- MapGetRequest(String, Data) - Constructor for class com.hazelcast.map.impl.client.MapGetRequest
-
- MapGetRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapGetRequest
-
- MapIndexConfig - Class in com.hazelcast.config
-
Contains the configuration for an index in a map.
- MapIndexConfig() - Constructor for class com.hazelcast.config.MapIndexConfig
-
Creates a MapIndexConfig without an attribute and with ordered is false.
- MapIndexConfig(String, boolean) - Constructor for class com.hazelcast.config.MapIndexConfig
-
Creates a MapIndexConfig with the given attribute and ordered setting.
- MapIndexConfig(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfig
-
- MapIndexConfigReadOnly - Class in com.hazelcast.config
-
Contains the configuration for a index of Map.
- MapIndexConfigReadOnly(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfigReadOnly
-
- MapInterceptor - Interface in com.hazelcast.map
-
- MapIsEmptyOperation - Class in com.hazelcast.map.impl.operation
-
- MapIsEmptyOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapIsEmptyOperation
-
- MapIsEmptyOperation() - Constructor for class com.hazelcast.map.impl.operation.MapIsEmptyOperation
-
- MapIsEmptyRequest - Class in com.hazelcast.map.impl.client
-
- MapIsEmptyRequest() - Constructor for class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- MapIsEmptyRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- MapIsLockedRequest - Class in com.hazelcast.map.impl.client
-
- MapIsLockedRequest() - Constructor for class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- MapIsLockedRequest(String, Data) - Constructor for class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- mapIterateAndRemove(Map) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- MapKeySet - Class in com.hazelcast.map.impl
-
- MapKeySet(Set<Data>) - Constructor for class com.hazelcast.map.impl.MapKeySet
-
- MapKeySet() - Constructor for class com.hazelcast.map.impl.MapKeySet
-
- MapKeySetOperation - Class in com.hazelcast.map.impl.operation
-
- MapKeySetOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapKeySetOperation
-
- MapKeySetOperation() - Constructor for class com.hazelcast.map.impl.operation.MapKeySetOperation
-
- MapKeySetOperationFactory - Class in com.hazelcast.map.impl.operation
-
- MapKeySetOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapKeySetOperationFactory
-
- MapKeySetOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.MapKeySetOperationFactory
-
- MapKeySetRequest - Class in com.hazelcast.map.impl.client
-
- MapKeySetRequest() - Constructor for class com.hazelcast.map.impl.client.MapKeySetRequest
-
- MapKeySetRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapKeySetRequest
-
- MapKeyValueSource<K,V> - Class in com.hazelcast.mapreduce.impl
-
- MapKeyValueSource(String) - Constructor for class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- MapLoadAllKeysRequest - Class in com.hazelcast.map.impl.client
-
Triggers the load of all keys from defined map store.
- MapLoadAllKeysRequest() - Constructor for class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- MapLoadAllKeysRequest(String, boolean) - Constructor for class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- MapLoadAllOperationFactory - Class in com.hazelcast.map.impl.operation
-
Operation factory for load all operations.
- MapLoadAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-
- MapLoadAllOperationFactory(String, List<Data>, boolean) - Constructor for class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-
- MapLoader<K,V> - Interface in com.hazelcast.core
-
Hazelcast distributed map implementation is an in-memory data store but
it can be backed by any type of data store such as RDBMS, OODBMS, or simply
a file based data store.
- MapLoaderLifecycleSupport - Interface in com.hazelcast.core
-
Provides Lifecycle support for the implementing MapLoader class.
- MapLoadGivenKeysRequest - Class in com.hazelcast.map.impl.client
-
Loads all given keys from a map store.
- MapLoadGivenKeysRequest() - Constructor for class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- MapLoadGivenKeysRequest(String, List<Data>, boolean) - Constructor for class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- MapLockRequest - Class in com.hazelcast.map.impl.client
-
- MapLockRequest() - Constructor for class com.hazelcast.map.impl.client.MapLockRequest
-
- MapLockRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapLockRequest
-
- MapLockRequest(String, Data, long, long, long) - Constructor for class com.hazelcast.map.impl.client.MapLockRequest
-
- MapMBean - Class in com.hazelcast.jmx
-
- MapMBean(IMap, ManagementService) - Constructor for class com.hazelcast.jmx.MapMBean
-
- MapMergePolicy - Interface in com.hazelcast.map.merge
-
A policy for merging maps after a splitbrain was detected and the different network partitions need
to be merged.
- MapOperationType - Enum in com.hazelcast.map.impl.operation
-
- mapper - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-
- mapper(Mapper<KeyIn, ValueIn, KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-
- mapper - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- mapper(Mapper<KeyIn, ValueIn, KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.Job
-
Defines the mapper for this task.
- Mapper<KeyIn,ValueIn,KeyOut,ValueOut> - Interface in com.hazelcast.mapreduce
-
The interface Mapper is used to build mappers for the
Job
.
- MapPermission - Class in com.hazelcast.security.permission
-
- MapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapPermission
-
- MappingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
-
This interface describes a mapping mapreduce Job.
For further information
Job
.
- MappingPhase<KeyIn,ValueIn,KeyOut,ValueOut> - Class in com.hazelcast.mapreduce.impl.task
-
This is the base of all mapping phase implementations.
- MappingPhase(Collection<KeyIn>, KeyPredicate<KeyIn>) - Constructor for class com.hazelcast.mapreduce.impl.task.MappingPhase
-
- MapPortableHook - Class in com.hazelcast.map.impl
-
- MapPortableHook() - Constructor for class com.hazelcast.map.impl.MapPortableHook
-
- MapProxyImpl<K,V> - Class in com.hazelcast.map.impl.proxy
-
Proxy implementation of
IMap
interface.
- MapProxyImpl(String, MapService, NodeEngine) - Constructor for class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- MapPutAllOperationFactory - Class in com.hazelcast.map.impl.operation
-
- MapPutAllOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapPutAllOperationFactory
-
- MapPutAllOperationFactory(String, MapEntrySet) - Constructor for class com.hazelcast.map.impl.operation.MapPutAllOperationFactory
-
- MapPutAllRequest - Class in com.hazelcast.map.impl.client
-
- MapPutAllRequest() - Constructor for class com.hazelcast.map.impl.client.MapPutAllRequest
-
- MapPutAllRequest(String, MapEntrySet) - Constructor for class com.hazelcast.map.impl.client.MapPutAllRequest
-
- MapPutIfAbsentRequest - Class in com.hazelcast.map.impl.client
-
- MapPutIfAbsentRequest() - Constructor for class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-
- MapPutIfAbsentRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-
- MapPutIfAbsentRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-
- MapPutRequest - Class in com.hazelcast.map.impl.client
-
- MapPutRequest() - Constructor for class com.hazelcast.map.impl.client.MapPutRequest
-
- MapPutRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapPutRequest
-
- MapPutRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapPutRequest
-
- MapPutTransientRequest - Class in com.hazelcast.map.impl.client
-
- MapPutTransientRequest() - Constructor for class com.hazelcast.map.impl.client.MapPutTransientRequest
-
- MapPutTransientRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapPutTransientRequest
-
- MapPutTransientRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapPutTransientRequest
-
- MapQueryRequest - Class in com.hazelcast.map.impl.client
-
- MapQueryRequest() - Constructor for class com.hazelcast.map.impl.client.MapQueryRequest
-
- MapQueryRequest(String, Predicate, IterationType) - Constructor for class com.hazelcast.map.impl.client.MapQueryRequest
-
- MapRecordKey - Class in com.hazelcast.map.impl
-
- MapRecordKey(String, Data) - Constructor for class com.hazelcast.map.impl.MapRecordKey
-
- MapReduceDataSerializerHook - Class in com.hazelcast.mapreduce.impl
-
This class contains all the ID hooks for IdentifiedDataSerializable classes used inside the MR framework.
- MapReduceDataSerializerHook() - Constructor for class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- MapReduceNotification - Class in com.hazelcast.mapreduce.impl.notification
-
Base class for all map reduce framework notifications
- MapReduceNotification() - Constructor for class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-
- MapReduceNotification(String, String) - Constructor for class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-
- MapReducePermission - Class in com.hazelcast.security.permission
-
To be able to map-reduce from a client in a secure environment
- MapReducePermission(String, String...) - Constructor for class com.hazelcast.security.permission.MapReducePermission
-
- MapReducePortableHook - Class in com.hazelcast.mapreduce.impl
-
This class registers all Portable serializers that are needed for communication between nodes and clients
- MapReducePortableHook() - Constructor for class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- mapReduceService - Variable in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- MapReduceService - Class in com.hazelcast.mapreduce.impl
-
The MapReduceService class is the base point for the map reduce implementation.
- MapReduceService(NodeEngine) - Constructor for class com.hazelcast.mapreduce.impl.MapReduceService
-
- MapReduceUtil - Class in com.hazelcast.mapreduce.impl
-
This utility class contains a few basic operations that are needed in multiple places
- MapRemoveEntryListenerRequest - Class in com.hazelcast.map.impl.client
-
- MapRemoveEntryListenerRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-
- MapRemoveEntryListenerRequest(String, String) - Constructor for class com.hazelcast.map.impl.client.MapRemoveEntryListenerRequest
-
- MapRemoveIfSameRequest - Class in com.hazelcast.map.impl.client
-
- MapRemoveIfSameRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- MapRemoveIfSameRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- MapRemoveInterceptorRequest - Class in com.hazelcast.map.impl.client
-
- MapRemoveInterceptorRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- MapRemoveInterceptorRequest(String, String) - Constructor for class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- MapRemoveRequest - Class in com.hazelcast.map.impl.client
-
- MapRemoveRequest() - Constructor for class com.hazelcast.map.impl.client.MapRemoveRequest
-
- MapRemoveRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapRemoveRequest
-
- MapReplaceIfSameRequest - Class in com.hazelcast.map.impl.client
-
- MapReplaceIfSameRequest() - Constructor for class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-
- MapReplaceIfSameRequest(String, Data, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-
- MapReplaceRequest - Class in com.hazelcast.map.impl.client
-
- MapReplaceRequest() - Constructor for class com.hazelcast.map.impl.client.MapReplaceRequest
-
- MapReplaceRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapReplaceRequest
-
- MapReplicationOperation - Class in com.hazelcast.map.impl.operation
-
- MapReplicationOperation() - Constructor for class com.hazelcast.map.impl.operation.MapReplicationOperation
-
- MapReplicationOperation(MapService, PartitionContainer, int, int) - Constructor for class com.hazelcast.map.impl.operation.MapReplicationOperation
-
- MapReplicationRemove - Class in com.hazelcast.map.impl.wan
-
- MapReplicationRemove(String, Data, long) - Constructor for class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- MapReplicationRemove() - Constructor for class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- MapReplicationUpdate - Class in com.hazelcast.map.impl.wan
-
- MapReplicationUpdate() - Constructor for class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- MapReplicationUpdate(String, MapMergePolicy, EntryView) - Constructor for class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- mapResultToMember(JobSupervisor, Map<K, V>) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- MapService - Class in com.hazelcast.map.impl
-
Defines map service behavior.
- mapService - Variable in class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- mapService - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- MapServiceContext - Interface in com.hazelcast.map.impl
-
Context which is needed by a map service.
- MapServiceContextEventListenerSupport - Interface in com.hazelcast.map.impl
-
- MapServiceContextInterceptorSupport - Interface in com.hazelcast.map.impl
-
- MapSetRequest - Class in com.hazelcast.map.impl.client
-
- MapSetRequest() - Constructor for class com.hazelcast.map.impl.client.MapSetRequest
-
- MapSetRequest(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapSetRequest
-
- MapSetRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapSetRequest
-
- mapSize(int) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- MapSizeOperation - Class in com.hazelcast.map.impl.operation
-
- MapSizeOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapSizeOperation
-
- MapSizeOperation() - Constructor for class com.hazelcast.map.impl.operation.MapSizeOperation
-
- MapSizeRequest - Class in com.hazelcast.map.impl.client
-
- MapSizeRequest() - Constructor for class com.hazelcast.map.impl.client.MapSizeRequest
-
- MapSizeRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapSizeRequest
-
- MapSQLQueryRequest - Class in com.hazelcast.map.impl.client
-
- MapSQLQueryRequest() - Constructor for class com.hazelcast.map.impl.client.MapSQLQueryRequest
-
- MapSQLQueryRequest(String, String, IterationType) - Constructor for class com.hazelcast.map.impl.client.MapSQLQueryRequest
-
- MapStore<K,V> - Interface in com.hazelcast.core
-
Hazelcast distributed map implementation is an in-memory data store but
it can be backed by any type of data store such as RDBMS, OODBMS, NOSQL or simply
a file based data store.
- MapStoreAdapter<K,V> - Class in com.hazelcast.core
-
Adapter for MapStore.
- MapStoreAdapter() - Constructor for class com.hazelcast.core.MapStoreAdapter
-
- MapStoreConfig - Class in com.hazelcast.config
-
Contains the configuration for a Map Store.
- MapStoreConfig() - Constructor for class com.hazelcast.config.MapStoreConfig
-
- MapStoreConfig(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfig
-
- MapStoreConfig.InitialLoadMode - Enum in com.hazelcast.config
-
Initial load module
- MapStoreConfigReadOnly - Class in com.hazelcast.config
-
Contains the configuration for a Map Store (read-only).
- MapStoreConfigReadOnly(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfigReadOnly
-
- MapStoreFactory<K,V> - Interface in com.hazelcast.core
-
Factory for MapLoader or MapStore instances, specifiable in MapStoreConfig.
- MapStoreManager - Interface in com.hazelcast.map.impl.mapstore
-
Central interface to manage map store.
- MapStoreManagers - Class in com.hazelcast.map.impl.mapstore
-
Static factory class for various map store managers.
- MapStoreWrapper - Class in com.hazelcast.map.impl
-
- MapStoreWrapper(Object, String, boolean) - Constructor for class com.hazelcast.map.impl.MapStoreWrapper
-
- MapTransactionLog - Class in com.hazelcast.map.impl.tx
-
Represents an operation on the map in the transaction log.
- MapTransactionLog() - Constructor for class com.hazelcast.map.impl.tx.MapTransactionLog
-
- MapTransactionLog(String, Data, Operation, long, String) - Constructor for class com.hazelcast.map.impl.tx.MapTransactionLog
-
- MapTryPutRequest - Class in com.hazelcast.map.impl.client
-
- MapTryPutRequest() - Constructor for class com.hazelcast.map.impl.client.MapTryPutRequest
-
- MapTryPutRequest(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapTryPutRequest
-
- MapTryRemoveRequest - Class in com.hazelcast.map.impl.client
-
- MapTryRemoveRequest() - Constructor for class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- MapTryRemoveRequest(String, Data, long, long) - Constructor for class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- MapTxnOperation - Interface in com.hazelcast.map.impl.tx
-
Transactional operation interface for
IMap
- MapUnlockRequest - Class in com.hazelcast.map.impl.client
-
- MapUnlockRequest() - Constructor for class com.hazelcast.map.impl.client.MapUnlockRequest
-
- MapUnlockRequest(String, Data, long) - Constructor for class com.hazelcast.map.impl.client.MapUnlockRequest
-
- MapUnlockRequest(String, Data, long, boolean) - Constructor for class com.hazelcast.map.impl.client.MapUnlockRequest
-
- MapValueCollection - Class in com.hazelcast.map.impl
-
- MapValueCollection(Collection<Data>) - Constructor for class com.hazelcast.map.impl.MapValueCollection
-
- MapValueCollection() - Constructor for class com.hazelcast.map.impl.MapValueCollection
-
- MapValuesOperation - Class in com.hazelcast.map.impl.operation
-
- MapValuesOperation(String) - Constructor for class com.hazelcast.map.impl.operation.MapValuesOperation
-
- MapValuesOperation() - Constructor for class com.hazelcast.map.impl.operation.MapValuesOperation
-
- MapValuesOperationFactory - Class in com.hazelcast.map.impl.operation
-
- MapValuesOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MapValuesOperationFactory
-
- MapValuesOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.MapValuesOperationFactory
-
- MapValuesRequest - Class in com.hazelcast.map.impl.client
-
- MapValuesRequest() - Constructor for class com.hazelcast.map.impl.client.MapValuesRequest
-
- MapValuesRequest(String) - Constructor for class com.hazelcast.map.impl.client.MapValuesRequest
-
- mark() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- mark(int) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- markSupported() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- marshallKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
-
- marshallKey(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ObjectReplicatedRecordStorage
-
- marshallKey(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- marshallValue(Object) - Method in class com.hazelcast.replicatedmap.impl.record.DataReplicatedRecordStore
-
- marshallValue(Object) - Method in class com.hazelcast.replicatedmap.impl.record.ObjectReplicatedRecordStorage
-
- marshallValue(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- mask - Variable in class com.hazelcast.security.permission.InstancePermission
-
- MASTER_CONFIRMATION_INTERVAL_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- masterAddress - Variable in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-
- MasterClaimOperation - Class in com.hazelcast.cluster.impl.operations
-
- MasterClaimOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MasterClaimOperation
-
- MasterConfirmationOperation - Class in com.hazelcast.cluster.impl.operations
-
- MasterConfirmationOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MasterConfirmationOperation
-
- MasterDiscoveryOperation - Class in com.hazelcast.cluster.impl.operations
-
- MasterDiscoveryOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-
- MasterDiscoveryOperation(JoinMessage) - Constructor for class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-
- match(String[], String[], int) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- match(AddressUtil.AddressMatcher) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- match(String) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- matchAnyDomain(String, Collection<String>) - Static method in class com.hazelcast.util.AddressUtil
-
- matchAnyInterface(String, Collection<String>) - Static method in class com.hazelcast.util.AddressUtil
-
- matchDomain(String, String) - Static method in class com.hazelcast.util.AddressUtil
-
- matches(KeyIn) - Method in class com.hazelcast.mapreduce.impl.task.MappingPhase
-
- matchInterface(String, String) - Static method in class com.hazelcast.util.AddressUtil
-
- MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
The number of maximum backup counter
- MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
-
The number of maximum backup counter
- MAX_BACKUP_COUNT - Static variable in interface com.hazelcast.partition.InternalPartition
-
- MAX_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
Maximum eviction percentage
- MAX_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
-
The number of maximum eviction percentage
- MAX_JOIN_MERGE_TARGET_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MAX_JOIN_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MAX_NO_HEARTBEAT_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MAX_NO_MASTER_CONFIRMATION_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MAX_REPLICA_COUNT - Static variable in interface com.hazelcast.partition.InternalPartition
-
- MAX_WAIT_SECONDS_BEFORE_JOIN - Variable in class com.hazelcast.instance.GroupProperties
-
- maxPoolSize() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-
- MaxSizeChecker - Class in com.hazelcast.map.impl.eviction
-
- MaxSizeChecker(MapServiceContext) - Constructor for class com.hazelcast.map.impl.eviction.MaxSizeChecker
-
- MaxSizeChecker(MemoryInfoAccessor, MapServiceContext) - Constructor for class com.hazelcast.map.impl.eviction.MaxSizeChecker
-
- MaxSizeConfig - Class in com.hazelcast.config
-
Configuration for map's capacity.
- MaxSizeConfig() - Constructor for class com.hazelcast.config.MaxSizeConfig
-
- MaxSizeConfig(int, MaxSizeConfig.MaxSizePolicy) - Constructor for class com.hazelcast.config.MaxSizeConfig
-
- MaxSizeConfig(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfig
-
- MaxSizeConfig.MaxSizePolicy - Enum in com.hazelcast.config
-
Maximum Size Policy
- MaxSizeConfigReadOnly - Class in com.hazelcast.config
-
Contains the configuration for a size of Map.
- MaxSizeConfigReadOnly(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfigReadOnly
-
- MC_MAX_INSTANCE_COUNT - Variable in class com.hazelcast.instance.GroupProperties
-
- MC_URL_CHANGE_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- megaBytes() - Method in class com.hazelcast.memory.MemorySize
-
Returns value of memory size in mega-bytes.
- MEM_COPY_THRESHOLD - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- MEMBER - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-
- Member - Interface in com.hazelcast.core
-
Cluster member interface.
- MEMBER_ADDED - Static variable in class com.hazelcast.cluster.client.ClientMembershipEvent
-
- MEMBER_ADDED - Static variable in class com.hazelcast.core.MembershipEvent
-
This event type is fired when a new member joins the cluster.
- MEMBER_ATTRIBUTE_CHANGED - Static variable in class com.hazelcast.cluster.client.ClientMembershipEvent
-
- MEMBER_ATTRIBUTE_CHANGED - Static variable in class com.hazelcast.core.MembershipEvent
-
This event type is fired if a member attribute has been changed or removed.
- MEMBER_CALLABLE_TASK - Static variable in class com.hazelcast.executor.impl.ExecutorDataSerializerHook
-
- MEMBER_LIST_PUBLISH_INTERVAL_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MEMBER_REMOVED - Static variable in class com.hazelcast.cluster.client.ClientMembershipEvent
-
- MEMBER_REMOVED - Static variable in class com.hazelcast.core.MembershipEvent
-
This event type is fired if a member left the cluster or was decided to be
unresponsive by other members for a extended time range.
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- memberAdded(MembershipEvent) - Method in class com.hazelcast.core.MembershipAdapter
-
- memberAdded(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
-
Invoked when a new member is added to the cluster.
- memberAdded(MembershipEvent) - Method in class com.hazelcast.management.ManagementCenterService.MemberListenerImpl
-
- memberAdded(MemberImpl) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- memberAdded(MemberImpl) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- memberAdded(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
-
Invoked when a new member is added to the cluster.
- memberAdded(MembershipServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- MemberAssigningJobProcessInformationImpl - Class in com.hazelcast.mapreduce.impl.task
-
This
JobProcessInformationImpl
extending class is
used in non partitionId based map reduce tasks where partitions are kind of simulated using
a unique id per member.
- MemberAssigningJobProcessInformationImpl(int, JobSupervisor) - Constructor for class com.hazelcast.mapreduce.impl.task.MemberAssigningJobProcessInformationImpl
-
- MemberAttributeChange - Class in com.hazelcast.cluster.client
-
- MemberAttributeChange() - Constructor for class com.hazelcast.cluster.client.MemberAttributeChange
-
- MemberAttributeChange(String, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.cluster.client.MemberAttributeChange
-
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.core.MembershipAdapter
-
- memberAttributeChanged(MemberAttributeEvent) - Method in interface com.hazelcast.core.MembershipListener
-
Invoked when an attribute of a member was changed.
- memberAttributeChanged(MemberAttributeEvent) - Method in class com.hazelcast.management.ManagementCenterService.MemberListenerImpl
-
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
-
Invoked when a member attribute is changed.
- memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- MemberAttributeChangedOperation - Class in com.hazelcast.cluster.impl.operations
-
- MemberAttributeChangedOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MemberAttributeChangedOperation
-
- MemberAttributeChangedOperation(MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.cluster.impl.operations.MemberAttributeChangedOperation
-
- MemberAttributeConfig - Class in com.hazelcast.config
-
Contains configuration for attribute of member.
- MemberAttributeConfig() - Constructor for class com.hazelcast.config.MemberAttributeConfig
-
- MemberAttributeConfig(MemberAttributeConfig) - Constructor for class com.hazelcast.config.MemberAttributeConfig
-
- MemberAttributeConfigReadOnly - Class in com.hazelcast.config
-
Contains configuration for attribute of member (Read-Only).
- MemberAttributeEvent - Class in com.hazelcast.core
-
- MemberAttributeEvent() - Constructor for class com.hazelcast.core.MemberAttributeEvent
-
- MemberAttributeEvent(Cluster, MemberImpl, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.core.MemberAttributeEvent
-
- MemberAttributeOperationType - Enum in com.hazelcast.cluster
-
Used to identify the type of member attribute change, either PUT or REMOVED
- MemberAttributeServiceEvent - Class in com.hazelcast.spi
-
This service event is fired to inform services about a change in a member's attributes collection
- MemberAttributeServiceEvent() - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
-
- MemberAttributeServiceEvent(Cluster, MemberImpl, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
-
- MemberAwareMapReduceNotification - Class in com.hazelcast.mapreduce.impl.notification
-
Base class for all notifications based on a member
- MemberAwareMapReduceNotification() - Constructor for class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-
- MemberAwareMapReduceNotification(Address, String, String) - Constructor for class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-
- MemberCallableTaskOperation - Class in com.hazelcast.executor.impl.operations
-
- MemberCallableTaskOperation() - Constructor for class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-
- MemberCallableTaskOperation(String, String, Data) - Constructor for class com.hazelcast.executor.impl.operations.MemberCallableTaskOperation
-
- MemberConfigRequest - Class in com.hazelcast.management.request
-
Request for fetching member XML configuration.
- MemberConfigRequest() - Constructor for class com.hazelcast.management.request.MemberConfigRequest
-
- memberCount - Variable in class com.hazelcast.cluster.impl.JoinMessage
-
- MemberGroup - Interface in com.hazelcast.partition.membergroup
-
- MemberGroupConfig - Class in com.hazelcast.config
-
Contains the configuration for a single member group.
- MemberGroupConfig() - Constructor for class com.hazelcast.config.MemberGroupConfig
-
- MemberGroupFactory - Interface in com.hazelcast.partition.membergroup
-
- MemberGroupFactoryFactory - Class in com.hazelcast.partition.membergroup
-
- MemberImpl - Class in com.hazelcast.instance
-
- MemberImpl() - Constructor for class com.hazelcast.instance.MemberImpl
-
- MemberImpl(Address, boolean) - Constructor for class com.hazelcast.instance.MemberImpl
-
- MemberImpl(Address, boolean, String, HazelcastInstanceImpl) - Constructor for class com.hazelcast.instance.MemberImpl
-
- MemberImpl(Address, boolean, String, HazelcastInstanceImpl, Map<String, Object>) - Constructor for class com.hazelcast.instance.MemberImpl
-
- MemberImpl(MemberImpl) - Constructor for class com.hazelcast.instance.MemberImpl
-
- MemberInfo - Class in com.hazelcast.cluster
-
- MemberInfo() - Constructor for class com.hazelcast.cluster.MemberInfo
-
- MemberInfo(Address) - Constructor for class com.hazelcast.cluster.MemberInfo
-
- MemberInfo(Address, String, Map<String, Object>) - Constructor for class com.hazelcast.cluster.MemberInfo
-
- MemberInfo(MemberImpl) - Constructor for class com.hazelcast.cluster.MemberInfo
-
- MemberInfoUpdateOperation - Class in com.hazelcast.cluster.impl.operations
-
- MemberInfoUpdateOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-
- MemberInfoUpdateOperation(Collection<MemberInfo>, long, boolean) - Constructor for class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-
- MemberLeftException - Exception in com.hazelcast.core
-
- MemberLeftException() - Constructor for exception com.hazelcast.core.MemberLeftException
-
- MemberLeftException(Member) - Constructor for exception com.hazelcast.core.MemberLeftException
-
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- memberRemoved(String) - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- memberRemoved(MembershipEvent) - Method in class com.hazelcast.core.MembershipAdapter
-
- memberRemoved(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
-
Invoked when an existing member leaves the cluster.
- memberRemoved(MembershipEvent) - Method in class com.hazelcast.management.ManagementCenterService.MemberListenerImpl
-
- memberRemoved(MemberImpl) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- memberRemoved(MemberImpl) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- memberRemoved(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
-
Invoked when an existing member leaves the cluster.
- memberRemoved(MembershipServiceEvent) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- MemberRemoveOperation - Class in com.hazelcast.cluster.impl.operations
-
- MemberRemoveOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MemberRemoveOperation
-
- MemberRemoveOperation(Address) - Constructor for class com.hazelcast.cluster.impl.operations.MemberRemoveOperation
-
- members - Variable in class com.hazelcast.partition.PartitionRuntimeState
-
- MemberSelector - Interface in com.hazelcast.core
-
Implementations of this interface are thought to select members
that are capable of executing a special kind of task.
The
MemberSelector.select(Member)
method is called for every available
member in the cluster and it's up to the implementation to decide
if the member is going to be used or not.
- MEMBERSHIP_EVENT - Static variable in class com.hazelcast.cluster.impl.ClusterDataSerializerHook
-
- MEMBERSHIP_LISTENER - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- MembershipAdapter - Class in com.hazelcast.core
-
Adapter for MembershipListener.
- MembershipAdapter() - Constructor for class com.hazelcast.core.MembershipAdapter
-
- MembershipAwareService - Interface in com.hazelcast.spi
-
An interface that can be implemented by a SPI service that needs to be notified members joining and leaving
the cluster.
- MembershipEvent - Class in com.hazelcast.core
-
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
- MembershipEvent(Cluster, Member, int, Set<Member>) - Constructor for class com.hazelcast.core.MembershipEvent
-
- MembershipListener - Interface in com.hazelcast.core
-
Cluster membership listener.
- MembershipServiceEvent - Class in com.hazelcast.spi
-
Membership event fired when a new member is added
to the cluster and/or when a member leaves the cluster.
- MembershipServiceEvent(MembershipEvent) - Constructor for class com.hazelcast.spi.MembershipServiceEvent
-
- MemberSocketInterceptor - Interface in com.hazelcast.nio
-
- membersString() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- MemberState - Interface in com.hazelcast.monitor
-
- MemberStateImpl - Class in com.hazelcast.monitor.impl
-
- MemberStateImpl() - Constructor for class com.hazelcast.monitor.impl.MemberStateImpl
-
- MEMCACHE_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- MemcacheCommandProcessor<T> - Class in com.hazelcast.ascii.memcache
-
- MemcacheCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.ascii.memcache.MemcacheCommandProcessor
-
- MemcacheEntry - Class in com.hazelcast.ascii.memcache
-
- MemcacheEntry(String, byte[], int) - Constructor for class com.hazelcast.ascii.memcache.MemcacheEntry
-
- MemcacheEntry() - Constructor for class com.hazelcast.ascii.memcache.MemcacheEntry
-
- MemoryInfoAccessor - Interface in com.hazelcast.map.impl.eviction
-
Used for providing runtime memory information of Java virtual machine.
- MemorySize - Class in com.hazelcast.memory
-
MemorySize represents a memory size with given value and MemoryUnit.
- MemorySize(long) - Constructor for class com.hazelcast.memory.MemorySize
-
- MemorySize(long, MemoryUnit) - Constructor for class com.hazelcast.memory.MemorySize
-
- MemoryStatsSupport - Class in com.hazelcast.memory
-
This class provides heap usage statistics
- MemoryUnit - Enum in com.hazelcast.memory
-
MemoryUnit represents memory size at a given unit of
granularity and provides utility methods to convert across units.
- merge(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- merge(Data, EntryView, MapMergePolicy) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- merge(Data, EntryView, MapMergePolicy) - Method in interface com.hazelcast.map.impl.RecordStore
-
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
-
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
-
- merge(String, EntryView, EntryView) - Method in interface com.hazelcast.map.merge.MapMergePolicy
-
Returns the value of the entry after the merge
of entries with the same key.
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
-
- merge(String, EntryView, EntryView) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
-
- MERGE_FIRST_RUN_DELAY_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MERGE_NEXT_RUN_DELAY_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MergeClustersOperation - Class in com.hazelcast.cluster.impl.operations
-
- MergeClustersOperation() - Constructor for class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-
- MergeClustersOperation(Address) - Constructor for class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-
- MergeOperation - Class in com.hazelcast.map.impl.operation
-
- MergeOperation(String, Data, EntryView<Data, Data>, MapMergePolicy) - Constructor for class com.hazelcast.map.impl.operation.MergeOperation
-
- MergeOperation() - Constructor for class com.hazelcast.map.impl.operation.MergeOperation
-
- MergePolicyProvider - Class in com.hazelcast.map.merge
-
- MergePolicyProvider(NodeEngine) - Constructor for class com.hazelcast.map.merge.MergePolicyProvider
-
- Message<E> - Class in com.hazelcast.core
-
- Message(String, E, long, Member) - Constructor for class com.hazelcast.core.Message
-
- MessageListener<E> - Interface in com.hazelcast.core
-
- messageObject - Variable in class com.hazelcast.core.Message
-
- MIGRATION_MIN_DELAY_ON_MEMBER_REMOVED_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- MigrationAwareService - Interface in com.hazelcast.spi
-
An interface that can be implemented by SPI services to get notified of partition changes.
- migrationCompleted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
-
Invoked when a partition migration is completed.
- MigrationCycleOperation - Interface in com.hazelcast.partition
-
- migrationData - Variable in class com.hazelcast.collection.CollectionReplicationOperation
-
- MigrationEndpoint - Enum in com.hazelcast.partition
-
- MigrationEvent - Class in com.hazelcast.core
-
An event fired when a partition migration starts, completes or fails.
- MigrationEvent() - Constructor for class com.hazelcast.core.MigrationEvent
-
- MigrationEvent(int, Member, Member, MigrationEvent.MigrationStatus) - Constructor for class com.hazelcast.core.MigrationEvent
-
- MigrationEvent.MigrationStatus - Enum in com.hazelcast.core
-
Migration status: Started, completed or failed
- migrationFailed(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
-
Invoked when a partition migration is failed.
- migrationInfo - Variable in class com.hazelcast.partition.impl.BaseMigrationOperation
-
- MigrationInfo - Class in com.hazelcast.partition
-
- MigrationInfo() - Constructor for class com.hazelcast.partition.MigrationInfo
-
- MigrationInfo(int, Address, Address) - Constructor for class com.hazelcast.partition.MigrationInfo
-
- MigrationListener - Interface in com.hazelcast.core
-
MigrationListener provides the ability to listen to partition migration events.
- MigrationOperation - Class in com.hazelcast.partition.impl
-
- MigrationOperation() - Constructor for class com.hazelcast.partition.impl.MigrationOperation
-
- MigrationOperation(MigrationInfo, long[], Collection<Operation>) - Constructor for class com.hazelcast.partition.impl.MigrationOperation
-
- MigrationRequestOperation - Class in com.hazelcast.partition.impl
-
- MigrationRequestOperation() - Constructor for class com.hazelcast.partition.impl.MigrationRequestOperation
-
- MigrationRequestOperation(MigrationInfo) - Constructor for class com.hazelcast.partition.impl.MigrationRequestOperation
-
- migrationStarted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
-
Invoked when a partition migration is started.
- MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
The number of minimum backup counter
- MIN_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
-
The number of minimum backup counter
- MIN_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.CacheSimpleConfig
-
Minimum eviction percentage
- MIN_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
-
The number of minimum eviction percentage
- MIN_FORCED_EVICT_PERCENTAGE - Static variable in interface com.hazelcast.cache.impl.ICacheRecordStore
-
- MIN_INITIAL_MEMORY_SIZE - Static variable in class com.hazelcast.config.NativeMemoryConfig
-
Minimum initial memory size in megabytes
- ModifyRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- ModifyRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-
- ModifyRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-
- modPowerOfTwo(int, int) - Static method in class com.hazelcast.util.QuickMath
-
Computes the remainder of the division of a
by b
.
- modPowerOfTwo(long, int) - Static method in class com.hazelcast.util.QuickMath
-
Computes the remainder of the division of a
by b
.
- MonitoredThread - Class in com.hazelcast.management
-
Holds monitoring information( CPU percentage etc.) for threads.
- MonitoredThread(String, long, int) - Constructor for class com.hazelcast.management.MonitoredThread
-
- MorphingPortableReader - Class in com.hazelcast.nio.serialization
-
- MorphingPortableReader(PortableSerializer, BufferObjectDataInput, ClassDefinition) - Constructor for class com.hazelcast.nio.serialization.MorphingPortableReader
-
- MulticastConfig - Class in com.hazelcast.config
-
Contains the configuration for the multicast discovery mechanism.
- MulticastConfig() - Constructor for class com.hazelcast.config.MulticastConfig
-
- MulticastJoiner - Class in com.hazelcast.cluster.impl
-
- MulticastJoiner(Node) - Constructor for class com.hazelcast.cluster.impl.MulticastJoiner
-
- MulticastListener - Interface in com.hazelcast.cluster.impl
-
- MulticastService - Class in com.hazelcast.cluster.impl
-
- MulticastService(Node, MulticastSocket) - Constructor for class com.hazelcast.cluster.impl.MulticastService
-
- multicastService - Variable in class com.hazelcast.instance.Node
-
- MultiExecutionCallback - Interface in com.hazelcast.core
-
MultiExecutionCallback allows to get notified when an execution is completed on each member
which task is submitted to.
- MultiMap<K,V> - Interface in com.hazelcast.core
-
A specialized map whose keys can be associated with multiple values.
- MULTIMAP_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- MULTIMAP_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- MultiMapAllPartitionRequest - Class in com.hazelcast.multimap.impl.client
-
- MultiMapAllPartitionRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-
- MultiMapAllPartitionRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-
- MultiMapBackupAwareOperation - Class in com.hazelcast.multimap.impl.operations
-
- MultiMapBackupAwareOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-
- MultiMapBackupAwareOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-
- MultiMapConfig - Class in com.hazelcast.config
-
Configuration for Multi-map.
- MultiMapConfig() - Constructor for class com.hazelcast.config.MultiMapConfig
-
- MultiMapConfig(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfig
-
- MultiMapConfig.ValueCollectionType - Enum in com.hazelcast.config
-
Type of value collection
- MultiMapConfigReadOnly - Class in com.hazelcast.config
-
Contains the configuration for an
MultiMap
.
- MultiMapConfigReadOnly(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfigReadOnly
-
- MultiMapContainer - Class in com.hazelcast.multimap.impl
-
Multi-map container.
- MultiMapContainer(String, MultiMapService, int) - Constructor for class com.hazelcast.multimap.impl.MultiMapContainer
-
- MultiMapDataSerializerHook - Class in com.hazelcast.multimap.impl
-
- MultiMapDataSerializerHook() - Constructor for class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- MultiMapEventFilter - Class in com.hazelcast.multimap.impl
-
- MultiMapEventFilter() - Constructor for class com.hazelcast.multimap.impl.MultiMapEventFilter
-
- MultiMapEventFilter(boolean, Data) - Constructor for class com.hazelcast.multimap.impl.MultiMapEventFilter
-
- MultiMapEventsPublisher - Class in com.hazelcast.multimap.impl
-
Publishes multimap entry and map events through eventService
- MultiMapEventsPublisher(NodeEngine) - Constructor for class com.hazelcast.multimap.impl.MultiMapEventsPublisher
-
- MultiMapIsLockedRequest - Class in com.hazelcast.multimap.impl.client
-
- MultiMapIsLockedRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- MultiMapIsLockedRequest(Data, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- MultiMapKeyBasedOperation - Class in com.hazelcast.multimap.impl.operations
-
- MultiMapKeyBasedOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- MultiMapKeyBasedOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- MultiMapKeyBasedOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- MultiMapKeyBasedRequest - Class in com.hazelcast.multimap.impl.client
-
- MultiMapKeyBasedRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapKeyBasedRequest
-
- MultiMapKeyBasedRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapKeyBasedRequest
-
- MultiMapKeyValueSource<K,V> - Class in com.hazelcast.mapreduce.impl
-
- MultiMapKeyValueSource(String) - Constructor for class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- MultiMapLockRequest - Class in com.hazelcast.multimap.impl.client
-
- MultiMapLockRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- MultiMapLockRequest(Data, long, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- MultiMapLockRequest(Data, long, long, long, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- MultiMapMBean - Class in com.hazelcast.jmx
-
- MultiMapMBean(MultiMap, ManagementService) - Constructor for class com.hazelcast.jmx.MultiMapMBean
-
- MultiMapMigrationOperation - Class in com.hazelcast.multimap.impl.operations
-
- MultiMapMigrationOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapMigrationOperation
-
- MultiMapMigrationOperation(Map<String, Map>) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapMigrationOperation
-
- MultiMapOperation - Class in com.hazelcast.multimap.impl.operations
-
- MultiMapOperation() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- MultiMapOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- MultiMapOperationFactory - Class in com.hazelcast.multimap.impl.operations
-
- MultiMapOperationFactory() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-
- MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-
- MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType, Data, Data) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-
- MultiMapOperationFactory(String, MultiMapOperationFactory.OperationFactoryType, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-
- MultiMapOperationFactory.OperationFactoryType - Enum in com.hazelcast.multimap.impl.operations
-
- MultiMapPartitionContainer - Class in com.hazelcast.multimap.impl
-
- MultiMapPartitionContainer(MultiMapService, int) - Constructor for class com.hazelcast.multimap.impl.MultiMapPartitionContainer
-
- MultiMapPermission - Class in com.hazelcast.security.permission
-
- MultiMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.MultiMapPermission
-
- MultiMapPortableHook - Class in com.hazelcast.multimap.impl
-
- MultiMapPortableHook() - Constructor for class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- MultiMapProxySupport - Class in com.hazelcast.multimap.impl
-
- MultiMapProxySupport(MultiMapService, NodeEngine, String) - Constructor for class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- MultiMapRecord - Class in com.hazelcast.multimap.impl
-
- MultiMapRecord() - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
-
- MultiMapRecord(Object) - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
-
- MultiMapRecord(long, Object) - Constructor for class com.hazelcast.multimap.impl.MultiMapRecord
-
- MultiMapRequest - Class in com.hazelcast.multimap.impl.client
-
- MultiMapRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapRequest
-
- MultiMapRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapRequest
-
- MultiMapResponse - Class in com.hazelcast.multimap.impl.operations
-
- MultiMapResponse() - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- MultiMapResponse(Collection, MultiMapConfig.ValueCollectionType) - Constructor for class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- MultiMapService - Class in com.hazelcast.multimap.impl
-
- MultiMapService(NodeEngine) - Constructor for class com.hazelcast.multimap.impl.MultiMapService
-
- MultiMapTransactionLog - Class in com.hazelcast.multimap.impl.txn
-
- MultiMapTransactionLog() - Constructor for class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- MultiMapTransactionLog(Data, String, long, long) - Constructor for class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- MultiMapUnlockRequest - Class in com.hazelcast.multimap.impl.client
-
- MultiMapUnlockRequest() - Constructor for class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- MultiMapUnlockRequest(Data, long, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- MultiMapUnlockRequest(Data, long, boolean, String) - Constructor for class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- MultiMapWrapper - Class in com.hazelcast.multimap.impl
-
- MultiMapWrapper(Collection<MultiMapRecord>) - Constructor for class com.hazelcast.multimap.impl.MultiMapWrapper
-
- MultiPartitionClientRequest - Class in com.hazelcast.client.impl.client
-
- MultiPartitionClientRequest() - Constructor for class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-
- MultipleEntryBackupOperation - Class in com.hazelcast.map.impl.operation
-
- MultipleEntryBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-
- MultipleEntryBackupOperation(String, Set<Data>, EntryBackupProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-
- MultipleEntryOperation - Class in com.hazelcast.map.impl.operation
-
- MultipleEntryOperation() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- MultipleEntryOperation(String, Set<Data>, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- MultipleEntryOperationFactory - Class in com.hazelcast.map.impl.operation
-
- MultipleEntryOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-
- MultipleEntryOperationFactory(String, Set<Data>, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-
- MultiReplicationMessage - Class in com.hazelcast.replicatedmap.impl.messages
-
This replicated message contains multiple replications at once
- MultiReplicationMessage() - Constructor for class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- MultiReplicationMessage(String, ReplicationMessage[]) - Constructor for class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- MultiResultSet - Class in com.hazelcast.query.impl
-
Multiple result set for Predicates.
- MultiResultSet() - Constructor for class com.hazelcast.query.impl.MultiResultSet
-
- MultiTargetClientRequest - Class in com.hazelcast.client.impl.client
-
Base class for client request that will be send more than one member
- MultiTargetClientRequest() - Constructor for class com.hazelcast.client.impl.client.MultiTargetClientRequest
-
- MurmurHash3_fmix(int) - Static method in class com.hazelcast.util.HashUtil
-
- MurmurHash3_fmix(long) - Static method in class com.hazelcast.util.HashUtil
-
- MurmurHash3_x64_64(byte[], int, int) - Static method in class com.hazelcast.util.HashUtil
-
- MurmurHash3_x64_64(byte[], int, int, int) - Static method in class com.hazelcast.util.HashUtil
-
- MurmurHash3_x64_64_direct(long, int, int) - Static method in class com.hazelcast.util.HashUtil
-
- MurmurHash3_x64_64_direct(long, int, int, int) - Static method in class com.hazelcast.util.HashUtil
-
- MurmurHash3_x86_32(byte[], int, int) - Static method in class com.hazelcast.util.HashUtil
-
- MurmurHash3_x86_32(byte[], int, int, int) - Static method in class com.hazelcast.util.HashUtil
-
Returns the MurmurHash3_x86_32 hash.
- MurmurHash3_x86_32_direct(long, int, int) - Static method in class com.hazelcast.util.HashUtil
-
- MurmurHash3_x86_32_direct(long, int, int, int) - Static method in class com.hazelcast.util.HashUtil
-
Returns the MurmurHash3_x86_32 hash.
- MutableOperation - Interface in com.hazelcast.cache.impl.operation
-
- MXBeanUtil - Class in com.hazelcast.cache.impl
-
MXBean utility methods related to registration of the beans.
- Packet - Class in com.hazelcast.nio
-
A Packet is a piece of data send over the line.
- Packet(PortableContext) - Constructor for class com.hazelcast.nio.Packet
-
- Packet(Data, PortableContext) - Constructor for class com.hazelcast.nio.Packet
-
- Packet(Data, int, PortableContext) - Constructor for class com.hazelcast.nio.Packet
-
- packet - Variable in class com.hazelcast.nio.tcp.DefaultPacketReader
-
- PacketReader - Interface in com.hazelcast.nio.tcp
-
- packetVersion - Variable in class com.hazelcast.cluster.impl.JoinMessage
-
- PacketWriter - Interface in com.hazelcast.nio.tcp
-
- PagingPredicate - Class in com.hazelcast.query
-
This class is a special Predicate which helps to get a page-by-page result of a query
Can be constructed with a page-size, an inner predicate for filtering, A comparator for sorting \
This class is not thread-safe and stateless.
- PagingPredicate() - Constructor for class com.hazelcast.query.PagingPredicate
-
Used for serialization internally
- PagingPredicate(int) - Constructor for class com.hazelcast.query.PagingPredicate
-
Construct with a pageSize
results will not be filtered
results will be natural ordered
throws
IllegalArgumentException
if pageSize is not greater than 0
- PagingPredicate(Predicate, int) - Constructor for class com.hazelcast.query.PagingPredicate
-
- PagingPredicate(Comparator<Map.Entry>, int) - Constructor for class com.hazelcast.query.PagingPredicate
-
Construct with a comparator and pageSize
results will not be filtered
results will be ordered via comparator
throws
IllegalArgumentException
if pageSize is not greater than 0
- PagingPredicate(Predicate, Comparator<Map.Entry>, int) - Constructor for class com.hazelcast.query.PagingPredicate
-
- PagingPredicateAccessor - Class in com.hazelcast.query
-
This class provides paging accessor of predicate.
- Parameters - Interface in com.hazelcast.security
-
- parse(String) - Static method in class com.hazelcast.memory.MemorySize
-
Parses string representation of a memory size value.
- parse(String, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
-
Parses string representation of a memory size value.
- parse(Element) - Method in interface com.hazelcast.spi.ServiceConfigurationParser
-
- parser(SocketTextReader, String, int) - Method in interface com.hazelcast.ascii.CommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.memcache.DeleteCommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.memcache.GetCommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.memcache.IncrementCommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.memcache.SetCommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.memcache.SimpleCommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.memcache.TouchCommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.rest.HttpDeleteCommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.rest.HttpGetCommandParser
-
- parser(SocketTextReader, String, int) - Method in class com.hazelcast.ascii.rest.HttpPostCommandParser
-
- parseSerialization(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- parseSocketInterceptorConfig(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
-
- PartialGetCommand - Class in com.hazelcast.ascii.memcache
-
- PartialGetCommand(String) - Constructor for class com.hazelcast.ascii.memcache.PartialGetCommand
-
- Partition - Interface in com.hazelcast.core
-
In Hazelcast the data is split up in partitions.
- PARTITION_BACKUP_SYNC_INTERVAL - Variable in class com.hazelcast.instance.GroupProperties
-
- PARTITION_CALLABLE_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-
- PARTITION_COUNT - Variable in class com.hazelcast.instance.GroupProperties
-
- PARTITION_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- PARTITION_MAX_PARALLEL_REPLICATIONS - Variable in class com.hazelcast.instance.GroupProperties
-
- PARTITION_MIGRATION_INTERVAL - Variable in class com.hazelcast.instance.GroupProperties
-
- PARTITION_MIGRATION_TIMEOUT - Variable in class com.hazelcast.instance.GroupProperties
-
- PARTITION_MIGRATION_ZIP_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- PARTITION_OPERATION_THREAD_COUNT - Variable in class com.hazelcast.instance.GroupProperties
-
- PARTITION_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- PARTITION_TABLE_SEND_INTERVAL - Variable in class com.hazelcast.instance.GroupProperties
-
- PartitionAware<T> - Interface in com.hazelcast.core
-
PartitionAware mean that data will be based in the same member based on partition key
and implementing tasks will be executed on the
PartitionAware.getPartitionKey()
's owner member.
- PartitionAwareKey<K,P> - Class in com.hazelcast.core
-
- PartitionAwareKey(K, P) - Constructor for class com.hazelcast.core.PartitionAwareKey
-
Creates a new PartitionAwareKey.
- PartitionAwareOperation - Interface in com.hazelcast.spi
-
An interface that can be implemented by an operation to indicate that is should
be invoked on a particular partition.
- PartitionCallableRequest - Class in com.hazelcast.executor.impl.client
-
This class is used for sending the task to a particular partition
- PartitionCallableRequest() - Constructor for class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- PartitionCallableRequest(String, String, Callable, int) - Constructor for class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- PartitionCheckIfLoadedOperation - Class in com.hazelcast.map.impl.operation
-
- PartitionCheckIfLoadedOperation(String) - Constructor for class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperation
-
- PartitionCheckIfLoadedOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperation
-
- PartitionCheckIfLoadedOperationFactory - Class in com.hazelcast.map.impl.operation
-
- PartitionCheckIfLoadedOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperationFactory
-
- PartitionCheckIfLoadedOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperationFactory
-
- PartitionClientRequest - Class in com.hazelcast.client.impl.client
-
Base class for partition based client request.
- PartitionClientRequest() - Constructor for class com.hazelcast.client.impl.client.PartitionClientRequest
-
- partitionContainer - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- PartitionContainer - Class in com.hazelcast.map.impl
-
- PartitionContainer(MapService, int) - Constructor for class com.hazelcast.map.impl.PartitionContainer
-
- partitionCount - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- PartitionDataSerializerHook - Class in com.hazelcast.partition
-
- PartitionDataSerializerHook() - Constructor for class com.hazelcast.partition.PartitionDataSerializerHook
-
- PartitionGroupConfig - Class in com.hazelcast.config
-
With PartitionGroupConfig you can control how primary and backup partitions are mapped to physical Members.
- PartitionGroupConfig() - Constructor for class com.hazelcast.config.PartitionGroupConfig
-
- PartitionGroupConfig.MemberGroupType - Enum in com.hazelcast.config
-
Type of member group
- partitionId - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- partitionId - Variable in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- partitionId - Variable in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- partitionId - Variable in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- partitionId - Variable in class com.hazelcast.spi.InvocationBuilder
-
- PartitionIdAware - Interface in com.hazelcast.mapreduce
-
This interface can be used to mark implementation being aware of the data partition
it is currently working on.
- partitionIndex - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- PartitionInfo - Class in com.hazelcast.partition
-
A DTO for Partition Information.
- PartitionInfo(int, Address[]) - Constructor for class com.hazelcast.partition.PartitionInfo
-
- PARTITIONING_STRATEGY - Static variable in class com.hazelcast.spi.AbstractDistributedObject
-
- PARTITIONING_STRATEGY_CLASS - Variable in class com.hazelcast.instance.GroupProperties
-
- PartitioningStrategy<K> - Interface in com.hazelcast.core
-
PartitioningStrategy allows keys to be located on the same member
This makes related data to be stored in the same location.
- partitioningStrategy - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- PartitioningStrategyConfig - Class in com.hazelcast.config
-
Contains the configuration for partitioning strategy.
- PartitioningStrategyConfig() - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
-
- PartitioningStrategyConfig(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
-
- PartitioningStrategyConfig(String) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
-
- PartitioningStrategyConfig(PartitioningStrategy) - Constructor for class com.hazelcast.config.PartitioningStrategyConfig
-
- PartitioningStrategyConfigReadOnly - Class in com.hazelcast.config
-
Contains the configuration for strategy of partitioning
- PartitioningStrategyConfigReadOnly(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfigReadOnly
-
- PartitionIteratingOperation - Class in com.hazelcast.spi.impl
-
- PartitionIteratingOperation(List<Integer>, OperationFactory) - Constructor for class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- PartitionIteratingOperation() - Constructor for class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- PartitionIteratingOperation.PartitionResponse - Class in com.hazelcast.spi.impl
-
- PartitionIteratingOperation.PartitionResponse() - Constructor for class com.hazelcast.spi.impl.PartitionIteratingOperation.PartitionResponse
-
- PartitionIteratingOperation.PartitionResponse(Map<Integer, Object>) - Constructor for class com.hazelcast.spi.impl.PartitionIteratingOperation.PartitionResponse
-
- PartitionListener - Interface in com.hazelcast.partition.impl
-
- PartitionMigratingException - Exception in com.hazelcast.spi.exception
-
A
RetryableHazelcastException
that is thrown when an operation is executed
on a partition, but that partition is currently being moved around.
- PartitionMigratingException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.PartitionMigratingException
-
- PartitionMigrationEvent - Class in com.hazelcast.spi
-
- PartitionMigrationEvent(MigrationEndpoint, int) - Constructor for class com.hazelcast.spi.PartitionMigrationEvent
-
- PartitionPortableHook - Class in com.hazelcast.partition
-
- PartitionPortableHook() - Constructor for class com.hazelcast.partition.PartitionPortableHook
-
- PartitionReplicaChangeEvent - Class in com.hazelcast.partition.impl
-
- PartitionReplicaChangeEvent(int, int, Address, Address) - Constructor for class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-
- PartitionReplicationEvent - Class in com.hazelcast.spi
-
- PartitionReplicationEvent(int, int) - Constructor for class com.hazelcast.spi.PartitionReplicationEvent
-
Creates a PartitionReplicationEvent
- PartitionRuntimeState - Class in com.hazelcast.partition
-
- PartitionRuntimeState() - Constructor for class com.hazelcast.partition.PartitionRuntimeState
-
- PartitionRuntimeState(ILogger, Collection<MemberInfo>, InternalPartition[], Collection<MigrationInfo>, long, int) - Constructor for class com.hazelcast.partition.PartitionRuntimeState
-
- PARTITIONS - Static variable in class com.hazelcast.partition.PartitionDataSerializerHook
-
- PartitionService - Interface in com.hazelcast.core
-
- partitionService - Variable in class com.hazelcast.instance.Node
-
- PartitionServiceMBean - Class in com.hazelcast.jmx
-
- PartitionServiceMBean(HazelcastInstanceImpl, InternalPartitionService, ManagementService) - Constructor for class com.hazelcast.jmx.PartitionServiceMBean
-
- PartitionServiceProxy - Class in com.hazelcast.partition
-
- PartitionServiceProxy(InternalPartitionService) - Constructor for class com.hazelcast.partition.PartitionServiceProxy
-
- PartitionServiceProxy.PartitionProxy - Class in com.hazelcast.partition
-
- PartitionsResponse - Class in com.hazelcast.partition.client
-
- PartitionsResponse() - Constructor for class com.hazelcast.partition.client.PartitionsResponse
-
- PartitionsResponse(Address[], int[]) - Constructor for class com.hazelcast.partition.client.PartitionsResponse
-
- PartitionStateGenerator - Interface in com.hazelcast.partition.impl
-
- PartitionStateGeneratorImpl - Class in com.hazelcast.partition.impl
-
- PartitionStateGeneratorImpl() - Constructor for class com.hazelcast.partition.impl.PartitionStateGeneratorImpl
-
- PartitionStateOperation - Class in com.hazelcast.partition.impl
-
- PartitionStateOperation() - Constructor for class com.hazelcast.partition.impl.PartitionStateOperation
-
- PartitionStateOperation(PartitionRuntimeState) - Constructor for class com.hazelcast.partition.impl.PartitionStateOperation
-
- PartitionStateOperation(PartitionRuntimeState, boolean) - Constructor for class com.hazelcast.partition.impl.PartitionStateOperation
-
- partitionStrategy - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- PartitionWideEntryBackupOperation - Class in com.hazelcast.map.impl.operation
-
- PartitionWideEntryBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-
- PartitionWideEntryBackupOperation(String, EntryBackupProcessor) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-
- PartitionWideEntryOperation - Class in com.hazelcast.map.impl.operation
-
GOTCHA : This operation does NOT load missing keys from map-store for now.
- PartitionWideEntryOperation(String, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- PartitionWideEntryOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- PartitionWideEntryOperationFactory - Class in com.hazelcast.map.impl.operation
-
- PartitionWideEntryOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
-
- PartitionWideEntryOperationFactory(String, EntryProcessor) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
-
- PartitionWideEntryWithPredicateBackupOperation - Class in com.hazelcast.map.impl.operation
-
- PartitionWideEntryWithPredicateBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
-
- PartitionWideEntryWithPredicateBackupOperation(String, EntryBackupProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
-
- PartitionWideEntryWithPredicateOperation - Class in com.hazelcast.map.impl.operation
-
- PartitionWideEntryWithPredicateOperation() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-
- PartitionWideEntryWithPredicateOperation(String, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-
- PartitionWideEntryWithPredicateOperationFactory - Class in com.hazelcast.map.impl.operation
-
date: 9/16/13
author: eminn
- PartitionWideEntryWithPredicateOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-
- PartitionWideEntryWithPredicateOperationFactory(String, EntryProcessor, Predicate) - Constructor for class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-
- PassThroughMergePolicy - Class in com.hazelcast.map.merge
-
PassThroughMergePolicy causes the merging entry to be merged from source to destination map
unless merging entry is null.
- PassThroughMergePolicy() - Constructor for class com.hazelcast.map.merge.PassThroughMergePolicy
-
- pauseMigration() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- pauseMigration() - Method in interface com.hazelcast.partition.InternalPartitionService
-
- peek() - Method in interface com.hazelcast.core.TransactionalQueue
- peek(long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
- peek() - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- peek() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- PEEK - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- PEEK - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- peek() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxy
-
- peek(long, TimeUnit) - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxy
-
- peekInternal(long) - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- PeekOperation - Class in com.hazelcast.queue.impl.operations
-
Peek operation for Queue.
- PeekOperation() - Constructor for class com.hazelcast.queue.impl.operations.PeekOperation
-
- PeekOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.PeekOperation
-
- PeekRequest - Class in com.hazelcast.queue.impl.client
-
- PeekRequest() - Constructor for class com.hazelcast.queue.impl.client.PeekRequest
-
- PeekRequest(String) - Constructor for class com.hazelcast.queue.impl.client.PeekRequest
-
- percentageString(double) - Static method in class com.hazelcast.util.HealthMonitor
-
- PermissionConfig - Class in com.hazelcast.config
-
Contains the configuration for a permission.
- PermissionConfig() - Constructor for class com.hazelcast.config.PermissionConfig
-
- PermissionConfig(PermissionConfig.PermissionType, String, String) - Constructor for class com.hazelcast.config.PermissionConfig
-
- PermissionConfig.PermissionType - Enum in com.hazelcast.config
-
Type of permission
- PermissionPolicyConfig - Class in com.hazelcast.config
-
Contains the configuration for policy of permission
- PermissionPolicyConfig() - Constructor for class com.hazelcast.config.PermissionPolicyConfig
-
- PermissionPolicyConfig(String) - Constructor for class com.hazelcast.config.PermissionPolicyConfig
-
- Permit - Class in com.hazelcast.concurrent.semaphore
-
- Permit() - Constructor for class com.hazelcast.concurrent.semaphore.Permit
-
- Permit(int, SemaphoreConfig) - Constructor for class com.hazelcast.concurrent.semaphore.Permit
-
- permitCount - Variable in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- permitCount - Variable in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-
- pickAddress() - Method in interface com.hazelcast.instance.AddressPicker
-
- poll(String, int) - Method in interface com.hazelcast.ascii.TextCommandService
-
- poll(String) - Method in interface com.hazelcast.ascii.TextCommandService
-
- poll(String, int) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- poll(String) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- poll() - Method in interface com.hazelcast.core.BaseQueue
-
Retrieves and removes the head of this queue,
or returns null if this queue is empty.
- poll(long, TimeUnit) - Method in interface com.hazelcast.core.BaseQueue
-
Retrieves and removes the head of this queue, waiting up to the
specified wait time if necessary for an element to become available.
- poll() - Method in interface com.hazelcast.core.TransactionalQueue
-
Retrieves and removes the head of this queue,
or returns null if this queue is empty.
- poll(long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
-
Retrieves and removes the head of this queue, waiting up to the
specified wait time if necessary for an element to become available.
- poll(long, TimeUnit) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- poll() - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- poll() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- POLL - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- POLL - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- poll() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxy
-
- poll(long, TimeUnit) - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxy
-
- POLL_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- pollBackup(long) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- PollBackupOperation - Class in com.hazelcast.queue.impl.operations
-
Backup items during pool operation.
- PollBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.PollBackupOperation
-
- PollBackupOperation(String, long) - Constructor for class com.hazelcast.queue.impl.operations.PollBackupOperation
-
- pollExpiredAwaitOp(Data) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- pollInternal(long) - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- PollOperation - Class in com.hazelcast.queue.impl.operations
-
Pool operation for Queue.
- PollOperation() - Constructor for class com.hazelcast.queue.impl.operations.PollOperation
-
- PollOperation(String, long) - Constructor for class com.hazelcast.queue.impl.operations.PollOperation
-
- PollRequest - Class in com.hazelcast.queue.impl.client
-
- PollRequest() - Constructor for class com.hazelcast.queue.impl.client.PollRequest
-
- PollRequest(String) - Constructor for class com.hazelcast.queue.impl.client.PollRequest
-
- PollRequest(String, long) - Constructor for class com.hazelcast.queue.impl.client.PollRequest
-
- PoolExecutorThreadFactory - Class in com.hazelcast.util.executor
-
- PoolExecutorThreadFactory(ThreadGroup, String, ClassLoader) - Constructor for class com.hazelcast.util.executor.PoolExecutorThreadFactory
-
- poolSize() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
-
- pop() - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- pop() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- Portable - Interface in com.hazelcast.nio.serialization
-
Portable provides an alternative serialization method.
- PORTABLE_MESSAGE - Static variable in class com.hazelcast.topic.impl.TopicPortableHook
-
- PortableAdapter<T> - Interface in com.hazelcast.nio.serialization
-
- PortableCollection - Class in com.hazelcast.spi.impl
-
- PortableCollection() - Constructor for class com.hazelcast.spi.impl.PortableCollection
-
- PortableCollection(Collection<Data>) - Constructor for class com.hazelcast.spi.impl.PortableCollection
-
- PortableContext - Interface in com.hazelcast.nio.serialization
-
- portableContext - Variable in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- PortableDistributedObjectEvent - Class in com.hazelcast.spi.impl
-
- PortableDistributedObjectEvent() - Constructor for class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- PortableDistributedObjectEvent(DistributedObjectEvent.EventType, String, String) - Constructor for class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- PortableEntryEvent - Class in com.hazelcast.spi.impl
-
- PortableEntryEvent() - Constructor for class com.hazelcast.spi.impl.PortableEntryEvent
-
- PortableEntryEvent(Data, Data, Data, EntryEventType, String) - Constructor for class com.hazelcast.spi.impl.PortableEntryEvent
-
- PortableEntryEvent(EntryEventType, String, int) - Constructor for class com.hazelcast.spi.impl.PortableEntryEvent
-
- PortableEntrySetResponse - Class in com.hazelcast.multimap.impl.client
-
- PortableEntrySetResponse() - Constructor for class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-
- PortableEntrySetResponse(Set<Map.Entry>) - Constructor for class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-
- portableFactories - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- PortableFactory - Interface in com.hazelcast.nio.serialization
-
PortableFactory is used to create Portable instances during de-serialization.
- PortableHook - Interface in com.hazelcast.nio.serialization
-
- PortableItemEvent - Class in com.hazelcast.spi.impl
-
- PortableItemEvent() - Constructor for class com.hazelcast.spi.impl.PortableItemEvent
-
- PortableItemEvent(Data, ItemEventType, String) - Constructor for class com.hazelcast.spi.impl.PortableItemEvent
-
- PortableMessage - Class in com.hazelcast.topic.impl.client
-
- PortableMessage() - Constructor for class com.hazelcast.topic.impl.client.PortableMessage
-
- PortableMessage(Data, long, String) - Constructor for class com.hazelcast.topic.impl.client.PortableMessage
-
- PortableReader - Interface in com.hazelcast.nio.serialization
-
Provides a mean of reading portable fields from a binary in form of java primitives
arrays of java primitives , nested portable fields and array of portable fields.
- PortableWriter - Interface in com.hazelcast.nio.serialization
-
Provides a mean of writing portable fields to a binary in form of java primitives
arrays of java primitives , nested portable fields and array of portable fields.
- position() - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- position(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- position() - Method in interface com.hazelcast.nio.BufferObjectDataOutput
-
- position(int) - Method in interface com.hazelcast.nio.BufferObjectDataOutput
-
- position() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- position(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- postClose() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- postClose() - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- postDeregister() - Method in class com.hazelcast.jmx.HazelcastMBean
-
- postDestroy() - Method in class com.hazelcast.cache.impl.CacheDistributedObject
-
- postDestroy() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorProxy
-
- postDestroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- PostJoinAwareService - Interface in com.hazelcast.spi
-
- PostJoinClientOperation - Class in com.hazelcast.client.impl.operations
-
- PostJoinClientOperation() - Constructor for class com.hazelcast.client.impl.operations.PostJoinClientOperation
-
- PostJoinClientOperation(Map<String, String>) - Constructor for class com.hazelcast.client.impl.operations.PostJoinClientOperation
-
- PostJoinMapOperation - Class in com.hazelcast.map.impl.operation
-
- PostJoinMapOperation() - Constructor for class com.hazelcast.map.impl.operation.PostJoinMapOperation
-
- PostJoinOperation - Class in com.hazelcast.cluster.impl.operations
-
- PostJoinOperation() - Constructor for class com.hazelcast.cluster.impl.operations.PostJoinOperation
-
- PostJoinOperation(Operation...) - Constructor for class com.hazelcast.cluster.impl.operations.PostJoinOperation
-
- POSTPONE_PARTITION_PROCESSING_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- PostPonePartitionProcessing - Class in com.hazelcast.mapreduce.impl.operation
-
This operation is used to tell the job owner to postpone a mapping phase for the defined
partitionId.
- PostPonePartitionProcessing() - Constructor for class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-
- PostPonePartitionProcessing(String, String, int) - Constructor for class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-
- PostProcessingMapStore - Interface in com.hazelcast.core
-
Implement this interface if you modify the value in MapStore.store(K key, V value) method.
- postRegister(Boolean) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- preDeregister() - Method in class com.hazelcast.jmx.HazelcastMBean
-
- preDeregister() - Method in class com.hazelcast.jmx.ListMBean
-
- preDeregister() - Method in class com.hazelcast.jmx.MapMBean
-
- preDeregister() - Method in class com.hazelcast.jmx.QueueMBean
-
- preDeregister() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- preDeregister() - Method in class com.hazelcast.jmx.SetMBean
-
- preDeregister() - Method in class com.hazelcast.jmx.TopicMBean
-
- predicate - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-
- predicate - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- Predicate<K,V> - Interface in com.hazelcast.query
-
Predicate instance must be thread-safe.
- PREDICATE_SUPPLIER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- PredicateBuilder - Class in com.hazelcast.query
-
This class provides functionality to build predicate.
- PredicateBuilder() - Constructor for class com.hazelcast.query.PredicateBuilder
-
- Predicates - Class in com.hazelcast.query
-
A utility class to create
Predicate
instances.
- predicates - Variable in class com.hazelcast.query.Predicates.AndPredicate
-
- Predicates.AbstractPredicate - Class in com.hazelcast.query
-
Provides some functionality for some predicates
such as Between, In.
- Predicates.AbstractPredicate() - Constructor for class com.hazelcast.query.Predicates.AbstractPredicate
-
- Predicates.AbstractPredicate(String) - Constructor for class com.hazelcast.query.Predicates.AbstractPredicate
-
- Predicates.AndPredicate - Class in com.hazelcast.query
-
And Predicate
- Predicates.AndPredicate() - Constructor for class com.hazelcast.query.Predicates.AndPredicate
-
- Predicates.AndPredicate(Predicate...) - Constructor for class com.hazelcast.query.Predicates.AndPredicate
-
- Predicates.BetweenPredicate - Class in com.hazelcast.query
-
Between Predicate
- Predicates.BetweenPredicate() - Constructor for class com.hazelcast.query.Predicates.BetweenPredicate
-
- Predicates.BetweenPredicate(String, Comparable, Comparable) - Constructor for class com.hazelcast.query.Predicates.BetweenPredicate
-
- Predicates.EqualPredicate - Class in com.hazelcast.query
-
Equal Predicate
- Predicates.EqualPredicate() - Constructor for class com.hazelcast.query.Predicates.EqualPredicate
-
- Predicates.EqualPredicate(String) - Constructor for class com.hazelcast.query.Predicates.EqualPredicate
-
- Predicates.EqualPredicate(String, Comparable) - Constructor for class com.hazelcast.query.Predicates.EqualPredicate
-
- Predicates.GreaterLessPredicate - Class in com.hazelcast.query
-
Greater Less Predicate
- Predicates.GreaterLessPredicate() - Constructor for class com.hazelcast.query.Predicates.GreaterLessPredicate
-
- Predicates.GreaterLessPredicate(String, Comparable, boolean, boolean) - Constructor for class com.hazelcast.query.Predicates.GreaterLessPredicate
-
- Predicates.ILikePredicate - Class in com.hazelcast.query
-
Ilike Predicate
- Predicates.ILikePredicate() - Constructor for class com.hazelcast.query.Predicates.ILikePredicate
-
- Predicates.ILikePredicate(String, String) - Constructor for class com.hazelcast.query.Predicates.ILikePredicate
-
- Predicates.InPredicate - Class in com.hazelcast.query
-
In Predicate
- Predicates.InPredicate() - Constructor for class com.hazelcast.query.Predicates.InPredicate
-
- Predicates.InPredicate(String, Comparable...) - Constructor for class com.hazelcast.query.Predicates.InPredicate
-
- Predicates.LikePredicate - Class in com.hazelcast.query
-
Like Predicate
- Predicates.LikePredicate() - Constructor for class com.hazelcast.query.Predicates.LikePredicate
-
- Predicates.LikePredicate(String, String) - Constructor for class com.hazelcast.query.Predicates.LikePredicate
-
- Predicates.NotEqualPredicate - Class in com.hazelcast.query
-
Not Equal Predicate
- Predicates.NotEqualPredicate() - Constructor for class com.hazelcast.query.Predicates.NotEqualPredicate
-
- Predicates.NotEqualPredicate(String, Comparable) - Constructor for class com.hazelcast.query.Predicates.NotEqualPredicate
-
- Predicates.NotPredicate - Class in com.hazelcast.query
-
Not Predicate
- Predicates.NotPredicate(Predicate) - Constructor for class com.hazelcast.query.Predicates.NotPredicate
-
- Predicates.NotPredicate() - Constructor for class com.hazelcast.query.Predicates.NotPredicate
-
- Predicates.OrPredicate - Class in com.hazelcast.query
-
Or Predicate
- Predicates.OrPredicate() - Constructor for class com.hazelcast.query.Predicates.OrPredicate
-
- Predicates.OrPredicate(Predicate...) - Constructor for class com.hazelcast.query.Predicates.OrPredicate
-
- Predicates.RegexPredicate - Class in com.hazelcast.query
-
Regex Predicate
- Predicates.RegexPredicate() - Constructor for class com.hazelcast.query.Predicates.RegexPredicate
-
- Predicates.RegexPredicate(String, String) - Constructor for class com.hazelcast.query.Predicates.RegexPredicate
-
- PredicateSupplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation.impl
-
The default supplier for
Predicate
s, used
to filter and optionally transform data (using the given
Supplier
).
- PredicateSupplier(Predicate<KeyIn, ValueIn>) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-
- PredicateSupplier(Predicate<KeyIn, ValueIn>, Supplier<KeyIn, ValueIn, ValueOut>) - Constructor for class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-
- PREFER_IPv4_STACK - Variable in class com.hazelcast.instance.GroupProperties
-
- prepare(NodeEngine) - Method in class com.hazelcast.collection.txn.CollectionTransactionLog
-
- prepare(NodeEngine) - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
-
- prepare(NodeEngine) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- prepare(NodeEngine) - Method in class com.hazelcast.queue.impl.tx.QueueTransactionLog
-
- PREPARE - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- prepare() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- prepare(NodeEngine) - Method in interface com.hazelcast.transaction.impl.TransactionLog
-
- prepare(Xid) - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- prepareKeyPredicate() - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-
- PrepareMergeOperation - Class in com.hazelcast.cluster.impl.operations
-
- PrepareMergeOperation() - Constructor for class com.hazelcast.cluster.impl.operations.PrepareMergeOperation
-
- PrepareMergeOperation(Address) - Constructor for class com.hazelcast.cluster.impl.operations.PrepareMergeOperation
-
- prepareMergeRunnable() - Method in class com.hazelcast.map.impl.MapService
-
- prepareMergeRunnable() - Method in interface com.hazelcast.spi.SplitBrainHandlerService
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- prepareOperation() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
-
- prepareOperation() - Method in class com.hazelcast.client.impl.client.TargetClientRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionAddAllRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionAddRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionClearRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionContainsRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionGetAllRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionIsEmptyRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionRemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.CollectionSizeRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.ListAddAllRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.ListAddRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.ListGetRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.ListIndexOfRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.ListRemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.ListSetRequest
-
- prepareOperation() - Method in class com.hazelcast.collection.client.ListSubRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.AddAndGetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterAndGetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.AlterRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAddRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndAlterRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.GetAndSetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomiclong.client.SetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterAndGetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.AlterRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndAlterRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.GetAndSetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.GetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.IsNullRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.atomicreference.client.SetRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.semaphore.client.AvailableRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.semaphore.client.DrainRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.semaphore.client.InitRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-
- prepareOperation() - Method in class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-
- prepareOperation() - Method in class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- prepareOperation() - Method in class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapPutIfAbsentRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapPutTransientRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapReplaceRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapSetRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-
- prepareOperation() - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.multimap.impl.client.CountRequest
-
- prepareOperation() - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-
- prepareOperation() - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-
- prepareOperation() - Method in class com.hazelcast.multimap.impl.client.PutRequest
-
- prepareOperation() - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-
- prepareOperation() - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.AddAllRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.ClearRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.ContainsRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.DrainRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.IsEmptyRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.IteratorRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.OfferRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.PeekRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.PollRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.RemainingCapacityRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.RemoveRequest
-
- prepareOperation() - Method in class com.hazelcast.queue.impl.client.SizeRequest
-
- prepareOperation() - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.cache.impl.CacheService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.collection.list.ListService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.collection.set.SetService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.map.impl.MapService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in class com.hazelcast.queue.impl.QueueService
-
- prepareReplicationOperation(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
-
- prepareToMerge(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- prepareToSafeShutdown(long, TimeUnit) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- prepareToSafeShutdown(long, TimeUnit) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- PrepareTransactionRequest - Class in com.hazelcast.transaction.client
-
- PrepareTransactionRequest() - Constructor for class com.hazelcast.transaction.client.PrepareTransactionRequest
-
- preRegister(MBeanServer, ObjectName) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- preReplicateMessage(ReplicationMessage, ReplicationChannel) - Method in interface com.hazelcast.replicatedmap.impl.PreReplicationHook
-
- preReplicateMultiMessage(MultiReplicationMessage, ReplicationChannel) - Method in interface com.hazelcast.replicatedmap.impl.PreReplicationHook
-
- PreReplicationHook - Interface in com.hazelcast.replicatedmap.impl
-
This is an interceptor interface to hook into the current replication process.
- previousPage() - Method in class com.hazelcast.query.PagingPredicate
-
setting the page value to previous page
- PRIMITIVE_TYPE_BOOLEAN - Static variable in class com.hazelcast.nio.IOUtil
-
- PRIMITIVE_TYPE_BYTE - Static variable in class com.hazelcast.nio.IOUtil
-
- PRIMITIVE_TYPE_DOUBLE - Static variable in class com.hazelcast.nio.IOUtil
-
- PRIMITIVE_TYPE_FLOAT - Static variable in class com.hazelcast.nio.IOUtil
-
- PRIMITIVE_TYPE_INTEGER - Static variable in class com.hazelcast.nio.IOUtil
-
- PRIMITIVE_TYPE_LONG - Static variable in class com.hazelcast.nio.IOUtil
-
- PRIMITIVE_TYPE_SHORT - Static variable in class com.hazelcast.nio.IOUtil
-
- PRIMITIVE_TYPE_UTF - Static variable in class com.hazelcast.nio.IOUtil
-
- PRINCIPAL - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- print(Object) - Method in class com.hazelcast.console.ConsoleApp
-
- println(Object) - Method in class com.hazelcast.console.ConsoleApp
-
- printNodeInfo(Node) - Method in class com.hazelcast.instance.DefaultNodeExtension
-
- printNodeInfo(Node) - Method in interface com.hazelcast.instance.NodeExtension
-
Called to print node information during startup
- printPartitionStates(JobPartitionState[]) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- PrivateApi - Annotation Type in com.hazelcast.spi.annotation
-
Marker for private api.
- process() - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- process() - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- process() - Method in class com.hazelcast.client.impl.client.AllPartitionsClientRequest
-
- process() - Method in class com.hazelcast.client.impl.client.CallableClientRequest
-
- process() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- process() - Method in class com.hazelcast.client.impl.client.GetDistributedObjectsRequest
-
- process() - Method in class com.hazelcast.client.impl.client.InvocationClientRequest
-
- process() - Method in class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-
- process() - Method in class com.hazelcast.client.impl.client.MultiTargetClientRequest
-
- process() - Method in class com.hazelcast.client.impl.client.PartitionClientRequest
-
- process() - Method in class com.hazelcast.client.impl.client.TargetClientRequest
-
- process(EntryTaskScheduler<Data, Integer>, Collection<ScheduledEntry<Data, Integer>>) - Method in class com.hazelcast.concurrent.lock.LockEvictionProcessor
-
- process(Map.Entry<K, V>) - Method in interface com.hazelcast.map.EntryProcessor
-
Process the entry without worrying about concurrency.
- process(List<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindProcessor
-
Process store operations and returns failed operation per partition map.
- process() - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- process(EntryTaskScheduler<String, Void>, Collection<ScheduledEntry<String, Void>>) - Method in class com.hazelcast.queue.impl.QueueEvictionProcessor
-
- process(EntryTaskScheduler<Object, Object>, Collection<ScheduledEntry<Object, Object>>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapEvictionProcessor
-
- process(EntryTaskScheduler<K, V>, Collection<ScheduledEntry<K, V>>) - Method in interface com.hazelcast.util.scheduler.ScheduledEntryProcessor
-
Processes all entries.
- PROCESS_STATS_UPDATE_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- processBackup(Map.Entry<K, V>) - Method in interface com.hazelcast.map.EntryBackupProcessor
-
- processChunk(Map<Key, Chunk>) - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-
- processChunk(int, Address, Map<Key, Chunk>) - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-
- processExpiredEntry(Data, R, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- processExpiredEntry(Data, R, long, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- ProcessingOperation - Class in com.hazelcast.mapreduce.impl.operation
-
This is the base class for all map reduce framework operations, it always contains the name of
the JobTracker and the unique jobId
- ProcessingOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-
- ProcessingOperation(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-
- processMapping(int, DefaultContext<KeyOut, ValueOut>, KeyValueSource<KeyIn, ValueIn>) - Method in class com.hazelcast.mapreduce.impl.task.MapCombineTask
-
- processMemberUpdate() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-
- processRequest(TextCommand) - Method in interface com.hazelcast.ascii.TextCommandService
-
- processRequest(TextCommand) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- processRequest(Address, ProcessingOperation, String) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- ProcessStatsUpdateOperation - Class in com.hazelcast.mapreduce.impl.operation
-
This operation is used to update the process statistics on the owner node
- ProcessStatsUpdateOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-
- ProcessStatsUpdateOperation(String, String, int) - Constructor for class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-
- PROP_APPLICATION_VALIDATION_TOKEN - Static variable in class com.hazelcast.instance.GroupProperties
-
This property can be used to verify that Hazelcast nodes only join when their 'application' level configuration is the
same.
- PROP_CLIENT_ENGINE_THREAD_COUNT - Static variable in class com.hazelcast.instance.GroupProperties
-
The number of threads the client engine has available for processing requests that are not partition specific.
- PROP_CLIENT_MAX_NO_HEARTBEAT_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_CONNECT_ALL_WAIT_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_CONNECTION_MONITOR_INTERVAL - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_CONNECTION_MONITOR_MAX_FAULTS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ELASTIC_MEMORY_CHUNK_SIZE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ELASTIC_MEMORY_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ELASTIC_MEMORY_SHARED_STORAGE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ELASTIC_MEMORY_TOTAL_SIZE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ELASTIC_MEMORY_UNSAFE_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ENABLE_JMX - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ENABLE_JMX_DETAILED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ENTERPRISE_LICENSE_KEY - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ENTERPRISE_WAN_REP_QUEUESIZE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_EVENT_QUEUE_CAPACITY - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_EVENT_QUEUE_TIMEOUT_MILLIS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_EVENT_THREAD_COUNT - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_GENERIC_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_GRACEFUL_SHUTDOWN_MAX_WAIT - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_HEALTH_MONITORING_DELAY_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_HEALTH_MONITORING_LEVEL - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_HEARTBEAT_INTERVAL_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ICMP_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ICMP_TIMEOUT - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_ICMP_TTL - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_INITIAL_MIN_CLUSTER_SIZE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_INITIAL_WAIT_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_IO_QUEUE_CAPACITY - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_IO_THREAD_COUNT - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_JCACHE_PROVIDER_TYPE - Static variable in class com.hazelcast.instance.GroupProperties
-
forces the jcache provider which can have values client or server to force provider type,
if not provided provider will be client or server whichever found on classPath first respectively
- PROP_LOGGING_TYPE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MAP_LOAD_CHUNK_SIZE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MAP_REPLICA_SCHEDULED_TASK_DELAY_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MAP_WRITE_BEHIND_QUEUE_CAPACITY - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MASTER_CONFIRMATION_INTERVAL_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MAX_JOIN_MERGE_TARGET_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MAX_JOIN_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MAX_NO_HEARTBEAT_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MAX_NO_MASTER_CONFIRMATION_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MAX_WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MC_MAX_VISIBLE_INSTANCE_COUNT - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MC_URL_CHANGE_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MEMBER_LIST_PUBLISH_INTERVAL_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MEMCACHE_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MERGE_FIRST_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MERGE_NEXT_RUN_DELAY_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_MIGRATION_MIN_DELAY_ON_MEMBER_REMOVED_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_OPERATION_CALL_TIMEOUT_MILLIS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PARTITION_BACKUP_SYNC_INTERVAL - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PARTITION_COUNT - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PARTITION_MAX_PARALLEL_REPLICATIONS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PARTITION_MIGRATION_INTERVAL - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PARTITION_MIGRATION_TIMEOUT - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PARTITION_MIGRATION_ZIP_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PARTITION_OPERATION_THREAD_COUNT - Static variable in class com.hazelcast.instance.GroupProperties
-
The number of partition threads per Member.
- PROP_PARTITION_TABLE_SEND_INTERVAL - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PARTITIONING_STRATEGY_CLASS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_PREFER_IPv4_STACK - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_REST_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SHUTDOWNHOOK_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_BIND_ANY - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_CLIENT_BIND - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_CLIENT_BIND_ANY - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_KEEP_ALIVE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_LINGER_SECONDS - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_NO_DELAY - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_RECEIVE_BUFFER_SIZE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_SEND_BUFFER_SIZE - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SOCKET_SERVER_BIND_ANY - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_SYSTEM_LOG_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_VERSION_CHECK_ENABLED - Static variable in class com.hazelcast.instance.GroupProperties
-
- PROP_WAIT_SECONDS_BEFORE_JOIN - Static variable in class com.hazelcast.instance.GroupProperties
-
- properties - Variable in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- propertiesByInstanceName(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
-
create the properties with the provided instance name
- propertiesByLocation(String) - Static method in class com.hazelcast.cache.HazelcastCachingProvider
-
create the properties with the provided config file location
- PropertyExtractor<ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce.aggregation
-
The PropertyExtractor interface is used in suppliers to retrieve values from
input value types and extract or transform them to some other type to be used
in aggregations.
- Protocols - Class in com.hazelcast.nio
-
First bytes to send a node that defines selected protocol
- ProxyService - Interface in com.hazelcast.spi
-
A
CoreService
responsible for managing the DistributedObject proxies.
- ProxyServiceImpl - Class in com.hazelcast.spi.impl
-
- ProxyServiceImpl.DistributedObjectDestroyOperation - Class in com.hazelcast.spi.impl
-
- ProxyServiceImpl.DistributedObjectDestroyOperation() - Constructor for class com.hazelcast.spi.impl.ProxyServiceImpl.DistributedObjectDestroyOperation
-
- ProxyServiceImpl.DistributedObjectDestroyOperation(String, String) - Constructor for class com.hazelcast.spi.impl.ProxyServiceImpl.DistributedObjectDestroyOperation
-
- ProxyServiceImpl.PostJoinProxyOperation - Class in com.hazelcast.spi.impl
-
- ProxyServiceImpl.PostJoinProxyOperation() - Constructor for class com.hazelcast.spi.impl.ProxyServiceImpl.PostJoinProxyOperation
-
- ProxyServiceImpl.PostJoinProxyOperation(Collection<ProxyServiceImpl.ProxyInfo>) - Constructor for class com.hazelcast.spi.impl.ProxyServiceImpl.PostJoinProxyOperation
-
- ProxyServiceMBean - Class in com.hazelcast.jmx
-
- ProxyServiceMBean(HazelcastInstance, ProxyService, ManagementService) - Constructor for class com.hazelcast.jmx.ProxyServiceMBean
-
- publish(E) - Method in interface com.hazelcast.core.ITopic
-
Publishes the message to all subscribers of this topic
- PUBLISH - Static variable in class com.hazelcast.topic.impl.TopicDataSerializerHook
-
- PUBLISH - Static variable in class com.hazelcast.topic.impl.TopicPortableHook
-
- publish(E) - Method in class com.hazelcast.topic.impl.TopicProxy
-
- publish(Object) - Method in class com.hazelcast.topic.impl.TotalOrderedTopicProxy
-
- publishBatchedEvents(String, CacheEventType, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- publishCompletedEvent(String, int, Data, int) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- publishCompletedEvent(String, int, Data, int) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Publish a Completion Event.
- publishEntryEvent(String, EntryEventType, Data, Object) - Method in class com.hazelcast.multimap.impl.MultiMapEventsPublisher
-
- publishEntryEvent(String, EntryEventType, Data, Object) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- publisherAddress - Variable in class com.hazelcast.topic.impl.TopicEvent
-
- publishEvent(String, CacheEventType, Data, Data, Data, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- publishEvent(String, CacheEventType, Data, Data, Data, boolean, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- publishEvent(String, CacheEventSet, int) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- publishEvent(String, CacheEventType, Data, Data, Data, boolean, int) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- publishEvent(String, CacheEventSet, int) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- publishEvent(ItemEventType, Data) - Method in class com.hazelcast.collection.CollectionOperation
-
- publishEvent(Address, String, EntryEventType, Data, Data, Data) - Method in interface com.hazelcast.map.impl.MapEventPublisher
-
- publishEvent(EntryEventType, Data, Object) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- publishEvent(ItemEventType, Data) - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- publishEvent(String, String, Object, int) - Method in interface com.hazelcast.spi.EventService
-
Publishes an event for all event registrations belonging to specified service name and topic.
- publishEvent(String, EventRegistration, Object, int) - Method in interface com.hazelcast.spi.EventService
-
Publishes an event for a specific event registration.
- publishEvent(String, Collection<EventRegistration>, Object, int) - Method in interface com.hazelcast.spi.EventService
-
Publishes an event for multiple event registrations.
- publishEvent(String, String, Object, int) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- publishEvent(String, EventRegistration, Object, int) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- publishEvent(String, Collection<EventRegistration>, Object, int) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- publishEvent(String, TopicEvent) - Method in class com.hazelcast.topic.impl.TopicService
-
- publishMapEvent(Address, String, EntryEventType, int) - Method in interface com.hazelcast.map.impl.MapEventPublisher
-
- publishMultiMapEvent(String, EntryEventType, int) - Method in class com.hazelcast.multimap.impl.MultiMapEventsPublisher
-
- publishMultiMapEvent(String, EntryEventType, int) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- PublishOperation - Class in com.hazelcast.topic.impl
-
- PublishOperation() - Constructor for class com.hazelcast.topic.impl.PublishOperation
-
- PublishOperation(String, Data) - Constructor for class com.hazelcast.topic.impl.PublishOperation
-
- publishReplicatedMessage(ReplicationMessage) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicationPublisher
-
- publishReplicationEvent(String, ReplicationEventObject) - Method in class com.hazelcast.wan.impl.WanNoDelayReplication
-
- publishReplicationEvent(String, ReplicationEventObject) - Method in interface com.hazelcast.wan.WanReplicationPublisher
-
- publishRequest(TextCommand) - Method in class com.hazelcast.nio.ascii.SocketTextReader
-
- PublishRequest - Class in com.hazelcast.topic.impl.client
-
- PublishRequest() - Constructor for class com.hazelcast.topic.impl.client.PublishRequest
-
- PublishRequest(String, Data) - Constructor for class com.hazelcast.topic.impl.client.PublishRequest
-
- publishTime - Variable in class com.hazelcast.topic.impl.TopicEvent
-
- publishWanReplicationRemove(String, Data, long) - Method in interface com.hazelcast.map.impl.MapEventPublisher
-
- publishWanReplicationUpdate(String, EntryView) - Method in interface com.hazelcast.map.impl.MapEventPublisher
-
- purgeStaleEntries() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Removes any stale entries whose keys have been finalized.
- PurgeTxBackupOperation - Class in com.hazelcast.transaction.impl
-
- PurgeTxBackupOperation() - Constructor for class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- PurgeTxBackupOperation(String) - Constructor for class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- push(BufferObjectDataOutput) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- push(BufferObjectDataOutput) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- put(String, String, Object) - Method in interface com.hazelcast.ascii.TextCommandService
-
- put(String, String, Object, int) - Method in interface com.hazelcast.ascii.TextCommandService
-
- put(String, String, Object) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- put(String, String, Object, int) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- put(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
put operation with custom expiry policy.
- put(Data, Object, ExpiryPolicy, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- PUT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- PUT - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- put(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- put(Data, Object, ExpiryPolicy, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Associates the specified value with the specified key in this cache,
returning an existing value if one existed.
- put(LockStoreImpl) - Method in class com.hazelcast.concurrent.lock.LockStoreContainer
-
- put(K, V) - Method in interface com.hazelcast.core.BaseMap
-
Associates the specified value with the specified key in this map
If the map previously contained a mapping for
the key, the old value is replaced by the specified value.
- put(K, V) - Method in interface com.hazelcast.core.BaseMultiMap
-
Stores a key-value pair in the multimap.
- put(K, V) - Method in interface com.hazelcast.core.IMap
-
Associates the specified value with the specified key in this map
If the map previously contained a mapping for
the key, the old value is replaced by the specified value.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
-
Puts an entry into this map with a given ttl (time to live) value.
- put(K, V) - Method in interface com.hazelcast.core.MultiMap
-
Stores a key-value pair in the multimap.
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.ReplicatedMap
-
Associates a given value to the specified key and replicates it to the
cluster.
- put(K, V) - Method in interface com.hazelcast.core.TransactionalMap
-
- put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalMap
-
- put(K, V) - Method in interface com.hazelcast.core.TransactionalMultiMap
-
Stores a key-value pair in the multimap.
- put(Map.Entry<Data, Object>) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- put(Data, Object, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- PUT - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- PUT - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- put(Data, Data) - Method in class com.hazelcast.map.impl.NearCache
-
- put(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- put(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- put(Data, Object, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- put(Map.Entry<Data, Object>) - Method in interface com.hazelcast.map.impl.RecordStore
-
- put(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- put(Object, Object, long, TimeUnit) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- PUT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- PUT - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- put(K, V) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- put(K, V) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- put(byte) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- put(int, byte) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- put(byte[]) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- put(byte[], int, int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- put(ByteBuffer) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- put(String, Object) - Method in class com.hazelcast.osgi.OSGiScriptEngine
-
- put(String, Object) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- put(E) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- put(Object, Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- put(Object, Object, long, TimeUnit) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- put(Object, Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- put(Object, Object, long, TimeUnit) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- put(K, V) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- put(K, V, long, TimeUnit) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- put(int, Data) - Method in interface com.hazelcast.storage.Storage
-
- put(K, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Maps the specified key to the specified value in this table.
- PUT_ALL - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- PUT_ALL - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- PUT_ALL_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- PUT_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- PUT_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- PUT_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- PUT_IF_ABSENT - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- PUT_IF_ABSENT - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- PUT_IF_ABSENT - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- PUT_TRANSIENT - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- PUT_TTL - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- putAll(Map<? extends K, ? extends V>, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
putAll operation with custom expiry policy.
- putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- putAll(Map<? extends K, ? extends V>) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Copies all of the mappings from the specified map to this one.
- PutAllBackupOperation - Class in com.hazelcast.map.impl.operation
-
- PutAllBackupOperation(String, List<Map.Entry<Data, Data>>, List<RecordInfo>) - Constructor for class com.hazelcast.map.impl.operation.PutAllBackupOperation
-
- PutAllBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PutAllBackupOperation
-
- PutAllOperation - Class in com.hazelcast.map.impl.operation
-
- PutAllOperation(String, MapEntrySet) - Constructor for class com.hazelcast.map.impl.operation.PutAllOperation
-
- PutAllOperation(String, MapEntrySet, boolean) - Constructor for class com.hazelcast.map.impl.operation.PutAllOperation
-
- PutAllOperation() - Constructor for class com.hazelcast.map.impl.operation.PutAllOperation
-
- putAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in the cache.
- putAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in the cache using a
custom expiry policy.
- putAsync(K, V) - Method in interface com.hazelcast.core.IMap
-
Asynchronously puts the given key and value.
- putAsync(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
-
Asynchronously puts the given key and value into this map with a given ttl (time to live) value.
- putAsync(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- putAsync(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- putBackup(Data, Object) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- putBackup(Data, Object, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- putBackup(Data, Object) - Method in interface com.hazelcast.map.impl.RecordStore
-
- putBackup(Data, Object, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- PutBackupOperation - Class in com.hazelcast.map.impl.operation
-
- PutBackupOperation(String, Data, Data, RecordInfo) - Constructor for class com.hazelcast.map.impl.operation.PutBackupOperation
-
- PutBackupOperation(String, Data, Data, RecordInfo, boolean) - Constructor for class com.hazelcast.map.impl.operation.PutBackupOperation
-
- PutBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PutBackupOperation
-
- PutBackupOperation - Class in com.hazelcast.multimap.impl.operations
-
- PutBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.PutBackupOperation
-
- PutBackupOperation(String, Data, Data, long, int) - Constructor for class com.hazelcast.multimap.impl.operations.PutBackupOperation
-
- putChar(int, char) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putChar(char) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putDouble(int, double) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putDouble(double) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putFloat(int, float) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putFloat(float) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putFromLoad(Data, Object) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- putFromLoad(Data, Object, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- putFromLoad(Data, Object) - Method in interface com.hazelcast.map.impl.RecordStore
-
Puts key-value pair to map which is the result of a load from map store operation.
- putFromLoad(Data, Object, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
Puts key-value pair to map which is the result of a load from map store operation.
- PutFromLoadAllBackupOperation - Class in com.hazelcast.map.impl.operation
-
Runs on backups.
- PutFromLoadAllBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
-
- PutFromLoadAllBackupOperation(String, List<Data>) - Constructor for class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
-
- PutFromLoadAllOperation - Class in com.hazelcast.map.impl.operation
-
- PutFromLoadAllOperation() - Constructor for class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- PutFromLoadAllOperation(String, List<Data>) - Constructor for class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- putIfAbsent(String, String, Object, int) - Method in interface com.hazelcast.ascii.TextCommandService
-
- putIfAbsent(String, String, Object, int) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- putIfAbsent(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
putIfAbsent operation with custom expiry policy.
- putIfAbsent(Data, Object, ExpiryPolicy, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- putIfAbsent(Data, Object, ExpiryPolicy, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- putIfAbsent(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- putIfAbsent(Data, Object, ExpiryPolicy, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Removes the mapping for a key from this cache if it is present.
- putIfAbsent(K, V) - Method in interface com.hazelcast.core.BaseMap
-
If the specified key is not already associated
with a value, associate it with the given value.
- putIfAbsent(K, V) - Method in interface com.hazelcast.core.IMap
-
If the specified key is not already associated
with a value, associate it with the given value.
- putIfAbsent(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
-
Puts an entry into this map with a given ttl (time to live) value
if the specified key is not already associated with a value.
- putIfAbsent(K, V) - Method in interface com.hazelcast.core.TransactionalMap
-
- putIfAbsent(Data, Object, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- putIfAbsent(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- putIfAbsent(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- putIfAbsent(Data, Object, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- putIfAbsent(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- putIfAbsent(K, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- putIfAbsentAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in the cache if not already exist.
- putIfAbsentAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously associates the specified value with the specified key in the cache if not already exist,
using a custom expiry policy.
- putIfAbsentInternal(Data, Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- PutIfAbsentMapMergePolicy - Class in com.hazelcast.map.merge
-
PutIfAbsentMapMergePolicy causes the merging entry to be merged from source to destination map
if it does not exist in the destination map.
- PutIfAbsentMapMergePolicy() - Constructor for class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
-
- PutIfAbsentOperation - Class in com.hazelcast.map.impl.operation
-
- PutIfAbsentOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-
- PutIfAbsentOperation() - Constructor for class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-
- putInt(int, int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putInt(int) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putInternal(Data, Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- putInternal(Data, Data, long, TimeUnit) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- putInternal(Data, Data, int) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- putInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- putLocalCacheStats(String, LocalCacheStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- putLocalExecutorStats(String, LocalExecutorStatsImpl) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- putLocalMapStats(String, LocalMapStatsImpl) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- putLocalMultiMapStats(String, LocalMultiMapStatsImpl) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- putLocalQueueStats(String, LocalQueueStatsImpl) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- putLocalTopicStats(String, LocalTopicStatsImpl) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- putLong(int, long) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putLong(long) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putManagedExecutor(String, SerializableManagedExecutorBean) - Method in class com.hazelcast.management.SerializableMXBeans
-
- putNearCache(String, Data, Data) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- PutOperation - Class in com.hazelcast.map.impl.operation
-
- PutOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.operation.PutOperation
-
- PutOperation() - Constructor for class com.hazelcast.map.impl.operation.PutOperation
-
- PutOperation - Class in com.hazelcast.multimap.impl.operations
-
- PutOperation() - Constructor for class com.hazelcast.multimap.impl.operations.PutOperation
-
- PutOperation(String, Data, long, Data, int) - Constructor for class com.hazelcast.multimap.impl.operations.PutOperation
-
- putRecord(Data, Record) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- putRecord(Data, Record) - Method in interface com.hazelcast.map.impl.RecordStore
-
Puts a data key and a record value to record-store.
- PutRequest - Class in com.hazelcast.multimap.impl.client
-
- PutRequest() - Constructor for class com.hazelcast.multimap.impl.client.PutRequest
-
- PutRequest(String, Data, Data, int, long) - Constructor for class com.hazelcast.multimap.impl.client.PutRequest
-
- putShort(int, short) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putShort(short) - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- putTransient(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
-
Same as #put(K, V, long, TimeUnit)
but MapStore, if defined,
will not be called to store/persist the entry.
- putTransient(Data, Object, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- putTransient(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- putTransient(Data, Object, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- PutTransientOperation - Class in com.hazelcast.map.impl.operation
-
- PutTransientOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.operation.PutTransientOperation
-
- PutTransientOperation() - Constructor for class com.hazelcast.map.impl.operation.PutTransientOperation
-
- PYTHON - Static variable in class com.hazelcast.client.ClientTypes
-
PYTHON client protocol id
- randomPartitionKey() - Method in interface com.hazelcast.core.PartitionService
-
Generates a random partition key.
- randomPartitionKey() - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- RandomPicker - Class in com.hazelcast.util
-
User: ahmetmircik
Date: 10/7/13
Time: 12:27 PM
- rawIterator() - Method in class com.hazelcast.util.QueryResultSet
-
- ReachedMaxSizeException - Exception in com.hazelcast.map.impl.mapstore.writebehind
-
Exception thrown when a BoundedArrayWriteBehindQueue
rejects to accept an offer.
- ReachedMaxSizeException(String) - Constructor for exception com.hazelcast.map.impl.mapstore.writebehind.ReachedMaxSizeException
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheAddEntryListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheContainsKeyRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheCreateConfigRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheDestroyRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetConfigRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheGetRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheIterateRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheListenerRegistrationRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheManagementConfigRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientCreateRequest
-
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientDestroyRequest
-
- read(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.CollectionAddAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.CollectionAddRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.CollectionCompareAndRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.CollectionContainsRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.CollectionRemoveListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.CollectionRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.CollectionRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.ListAddAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.ListAddRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.ListGetRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.ListIndexOfRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.ListRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.ListSetRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.ListSubRequest
-
- read(PortableReader) - Method in class com.hazelcast.collection.client.TxnCollectionRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.AbstractAlterRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.ApplyRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.AtomicLongRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.CompareAndSetRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.AbstractAlterRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.ApplyRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.CompareAndSetRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.ContainsRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.ModifyRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.countdownlatch.client.AwaitRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.countdownlatch.client.CountDownRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.countdownlatch.client.GetCountRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.AbstractUnlockRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.AwaitRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.BeforeAwaitRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.GetLockCountRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.GetRemainingLeaseRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.lock.client.SignalRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.semaphore.client.AcquireRequest
-
- read(PortableReader) - Method in class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.CancellationRequest
-
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.IsShutdownRequest
-
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.ShutdownRequest
-
- read(PortableReader) - Method in class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddEntryListenerSqlRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapContainsKeyRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapEvictRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapGetEntryViewRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapIsLockedRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapLoadAllKeysRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapLockRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapReplaceIfSameRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapTryPutRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapUnlockRequest
-
- read(PortableReader) - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- read(PortableReader) - Method in class com.hazelcast.mapreduce.impl.client.ClientCancellationRequest
-
- read(PortableReader) - Method in class com.hazelcast.mapreduce.impl.client.ClientJobProcessInformationRequest
-
- read(PortableReader) - Method in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.AddEntryListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.CountRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.GetAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.KeyBasedContainsRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapAllPartitionRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapIsLockedRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapKeyBasedRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapLockRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.MultiMapUnlockRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.PutRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.RemoveAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.RemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapGetRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-
- read(PortableReader) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapValueCountRequest
-
- read(ByteBuffer) - Method in class com.hazelcast.nio.ascii.SocketTextReader
-
- read(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- read(byte[]) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
-
Converts given byte array to object
- read(ByteBuffer) - Method in class com.hazelcast.nio.serialization.ClassDefinitionSerializer
-
Reads ClassDefinition from a buffer.
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.BooleanSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ByteSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.CharArraySerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.CharSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.DoubleArraySerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.DoubleSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.FloatArraySerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.FloatSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.IntegerArraySerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.IntegerSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.LongArraySerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.LongSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ShortArraySerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ShortSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.StringSerializer
-
- read(byte[]) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.BigDecimalSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.BigIntegerSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.ClassSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.DateSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.EnumSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.Externalizer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.ObjectSerializer
-
- read() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- read(byte[]) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- read(byte[], int, int) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.serializers.ArrayListSerializerHook.ArrayListStreamSerializer
-
- read(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.serializers.LinkedListSerializerHook.LinkedListStreamSerializer
-
- read(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
-
Reads object from objectDataInputStream
- read(ByteBuffer) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- read(ByteBuffer) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
- read(ByteBuffer) - Method in interface com.hazelcast.nio.tcp.SocketReader
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.AddAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.AddListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.CompareAndRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.ContainsRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.DrainRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.OfferRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.QueueRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.RemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.TxnOfferRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.TxnPeekRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.TxnPollRequest
-
- read(PortableReader) - Method in class com.hazelcast.queue.impl.client.TxnSizeRequest
-
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapAddEntryListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsKeyRequest
-
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapContainsValueRequest
-
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapGetRequest
-
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutAllRequest
-
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapPutTtlRequest
-
- read(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ClientReplicatedMapRemoveRequest
-
- read(PortableReader) - Method in class com.hazelcast.topic.impl.client.AddMessageListenerRequest
-
- read(PortableReader) - Method in class com.hazelcast.topic.impl.client.PublishRequest
-
- read(PortableReader) - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-
- read(PortableReader) - Method in class com.hazelcast.transaction.client.CommitTransactionRequest
-
- read(PortableReader) - Method in class com.hazelcast.transaction.client.CreateTransactionRequest
-
- read(PortableReader) - Method in class com.hazelcast.transaction.client.RecoverTransactionRequest
-
- readAttribute(Map.Entry) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
-
- readAttributeValue(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
-
- readBackupData(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- readBackupData(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
Called when
MapConfig.isReadBackupData()
is
true
from
MapProxySupport.getInternal(com.hazelcast.nio.serialization.Data)
Returns corresponding value for key as
Data
.
- readBoolean(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- readBoolean(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readBoolean(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readBoolean() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readBoolean(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readByte(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- readByte(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readByte(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readByte() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readByte(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readByteArray(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
-
- readByteArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readByteArray(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readByteArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readByteArray() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readByteArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readChar(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
-
- readChar(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- readChar(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readChar(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readChar() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readChar(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readCharArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readCharArray(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readCharArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readCharArray() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readCharArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readCharB(byte[], int) - Static method in class com.hazelcast.nio.Bits
-
- readCharL(byte[], int) - Static method in class com.hazelcast.nio.Bits
-
- readData(ObjectDataInput) - Method in class com.hazelcast.ascii.memcache.MemcacheEntry
-
- readData(ObjectDataInput) - Method in class com.hazelcast.ascii.rest.RestValue
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.HazelcastExpiryPolicy
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheClearResponse
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheEventSet
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.CacheStatisticsImpl
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheClearOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
-
- readData(ObjectDataInput) - Method in class com.hazelcast.client.impl.client.ClientResponse
-
- readData(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.OperationFactoryWrapper
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.client.ClientMembershipEvent
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.client.MemberAttributeChange
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.BindMessage
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.ConfigCheck
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.JoinMessage
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.JoinRequest
-
- readData(ObjectDataInput) - Method in class com.hazelcast.cluster.MemberInfo
-
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionContainer
-
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionEvent
-
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionEventFilter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionItem
-
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.TxCollectionItem
-
- readData(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionTransactionLog
-
- readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.InternalLockNamespace
-
- readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- readData(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.CacheConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.config.NearCacheConfig
-
- readData(ObjectDataInput) - Method in class com.hazelcast.console.ConsoleApp.Echo
-
- readData(ObjectDataInput) - Method in class com.hazelcast.core.MemberAttributeEvent
-
- readData(ObjectDataInput) - Method in class com.hazelcast.core.MigrationEvent
-
- readData(ObjectDataInput) - Method in class com.hazelcast.core.PartitionAwareKey
-
- readData(ObjectDataInput) - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.instance.MemberImpl
-
- readData(ObjectDataInput) - Method in class com.hazelcast.management.MapConfigAdapter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.EntryEventData
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.EntryEventFilter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapEntrySet
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapEventData
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapKeySet
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.MapValueCollection
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddIndexOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ClearOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ContainsValueOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EntrySetOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictAllOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.IsEmptyOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapFlushOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapGetAllOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapKeySetOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapLoadAllOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapPutAllOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapValuesOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.SizeOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.QueryEventFilter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.QueryResult
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.VersionedValue
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.HigherHitsMapMergePolicy
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.LatestUpdateMapMergePolicy
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.PassThroughMergePolicy
-
- readData(ObjectDataInput) - Method in class com.hazelcast.map.merge.PutIfAbsentMapMergePolicy
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.AcceptAllSupplier
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.AvgTuple
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.KeyPredicateSupplier
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.PredicateSupplier
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.CombinerResultList
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.HashMapAdapter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentResult
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- readData(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.MultiMapEventFilter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.EntrySetResponse
-
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- readData(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- readData(ObjectDataInput) - Method in class com.hazelcast.nio.Address
-
- readData() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
-
Reads fields from the input stream
- readData() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- readData(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.client.PartitionsResponse
-
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.MigrationInfo
-
- readData(ObjectDataInput) - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.impl.QueryResultEntryImpl
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.PagingPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.PredicateBuilder
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.AndPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.BetweenPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.EqualPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.GreaterLessPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.InPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.LikePredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.NotPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.OrPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.Predicates.RegexPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.SqlPredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.query.TruePredicate
-
- readData(ObjectDataInput) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- readData(ObjectDataInput) - Method in class com.hazelcast.queue.impl.QueueEvent
-
- readData(ObjectDataInput) - Method in class com.hazelcast.queue.impl.QueueEventFilter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.queue.impl.QueueItem
-
- readData(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.QueueTransactionLog
-
- readData(ObjectDataInput) - Method in class com.hazelcast.queue.impl.TxQueueItem
-
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.messages.MultiReplicationMessage
-
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation.MemberMapPair
-
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- readData(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.record.VectorClockTimestamp
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.DefaultObjectNamespace
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.EventServiceImpl.EmptyFilter
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.EventServiceImpl.EventPacket
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.EventServiceImpl.Registration
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.NormalResponse
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation.PartitionResponse
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.Response
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.impl.SerializableCollection
-
- readData(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
-
- readData(ObjectDataInput) - Method in class com.hazelcast.topic.impl.TopicEvent
-
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.SerializableXID
-
- readData(ObjectDataInput) - Method in class com.hazelcast.transaction.TransactionOptions
-
- readData(ObjectDataInput) - Method in class com.hazelcast.util.QueryResultSet
-
- readData(ObjectDataInput) - Method in class com.hazelcast.wan.WanReplicationEvent
-
- readDataInner(ObjectDataInput) - Method in class com.hazelcast.map.impl.client.AbstractTxnMapRequest
-
- readDataInner(ObjectDataInput) - Method in class com.hazelcast.map.impl.client.TxnMapRequest
-
- readDataInner(ObjectDataInput) - Method in class com.hazelcast.map.impl.client.TxnMapRequestWithSQLQuery
-
- readDouble(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- readDouble(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readDouble(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readDouble() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readDouble(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readDoubleArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readDoubleArray(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readDoubleArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readDoubleArray() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readDoubleArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readFloat(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- readFloat(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readFloat(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readFloat() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readFloat(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readFloatArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readFloatArray(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readFloatArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readFloatArray() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readFloatArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.DeleteCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.ErrorCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.GetCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.IncrementCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.SetCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.SimpleCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.StatsCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.TouchCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.memcache.VersionCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.NoOpCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.rest.HttpDeleteCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.rest.HttpGetCommand
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.ascii.rest.HttpPostCommand
-
POST /path HTTP/1.0
User-Agent: HTTPTool/1.0
Content-TextCommandType: application/x-www-form-urlencoded
Content-Length: 45
byte[45]
- readFrom(DataInput) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.nio.Packet
-
- readFrom(ByteBuffer) - Method in class com.hazelcast.nio.serialization.DataAdapter
-
- readFrom(ByteBuffer) - Method in interface com.hazelcast.nio.SocketReadable
-
- readFrom(DataInput) - Static method in enum com.hazelcast.partition.MigrationEndpoint
-
- readFully(byte[]) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readFully(byte[], int, int) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readInt(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
-
- readInt(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- readInt(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readInt(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readInt() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readInt(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readIntArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readIntArray(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readIntArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readIntArray() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readIntArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readIntB(byte[], int) - Static method in class com.hazelcast.nio.Bits
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.client.impl.operations.PostJoinClientOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.FinalizeJoinOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.JoinCheckOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.JoinRequestOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MemberAttributeChangedOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MemberRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.PrepareMergeOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionAddAllBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionAddAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionAddBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionAddOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionClearBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionCompareAndRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionContainsOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionRemoveBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.CollectionTransactionRollbackOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListAddAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListAddOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListGetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListIndexOfOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListSetBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListSetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.list.ListSubOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.set.SetReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionPrepareOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionReserveAddOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionRollbackOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionTxnAddOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.management.operation.GetMapConfigOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.management.operation.ScriptExecutorOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.management.operation.ThreadDumpOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.management.operation.UpdateManagementCenterUrlOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.management.operation.UpdateMapConfigOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.GetAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.InvalidateNearCacheOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.NearCacheKeySetInvalidationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.QueryOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.QueryPartitionOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapMigrationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.MigrationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.AddAllBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.ClearBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.ContainsOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.DrainBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.DrainOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.OfferBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.PollBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.QueueReplicationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.RemoveBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.QueueTransactionRollbackOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnOfferBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnPeekOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnPollBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnPrepareBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnPrepareOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnReservePollBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnRollbackBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.AbstractOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.AbstractNamedOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.EventServiceImpl.DeregistrationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.EventServiceImpl.PostJoinRegistrationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.EventServiceImpl.RegistrationOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.EventServiceImpl.SendEventOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.IsStillExecutingOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl.DistributedObjectDestroyOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl.PostJoinProxyOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.impl.TraceableIsStillExecutingOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.topic.impl.PublishOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.BeginTxBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.RecoverTxnOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- readInternal(ObjectDataInput) - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- readIntHeader(int, ByteOrder) - Method in interface com.hazelcast.nio.serialization.Data
-
Reads an integer header from given offset using given ByteOrder.
- readIntHeader(int, ByteOrder) - Method in class com.hazelcast.nio.serialization.DefaultData
-
- readIntL(byte[], int) - Static method in class com.hazelcast.nio.Bits
-
- readLine() - Method in interface com.hazelcast.console.LineReader
-
- readLine() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
Deprecated.
- readLock - Variable in class com.hazelcast.query.impl.BaseIndexStore
-
- readLong(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
-
- readLong(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- readLong(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readLong(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readLong() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readLong(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readLongArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readLongArray(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readLongArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readLongArray() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readLongArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readLongB(byte[], int) - Static method in class com.hazelcast.nio.Bits
-
- readLongL(byte[], int) - Static method in class com.hazelcast.nio.Bits
-
- readLongString(DataInput) - Static method in class com.hazelcast.nio.IOUtil
-
- readObject(ObjectDataInput) - Static method in class com.hazelcast.nio.IOUtil
-
- readObject() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readObject() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readObject(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- readObject(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- ReadonlyOperation - Interface in com.hazelcast.spi
-
Read-only operations are not retried during migration.
- readPacket(ByteBuffer) - Method in class com.hazelcast.nio.tcp.DefaultPacketReader
-
- readPacket(ByteBuffer) - Method in interface com.hazelcast.nio.tcp.PacketReader
-
- readPortable(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-
- readPortable(PortableReader) - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- readPortable(PortableReader) - Method in class com.hazelcast.client.impl.client.DistributedObjectInfo
-
- readPortable(PortableReader) - Method in class com.hazelcast.client.impl.client.GenericError
-
- readPortable(PortableReader) - Method in class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- readPortable(PortableReader) - Method in class com.hazelcast.multimap.impl.client.PortableEntrySetResponse
-
- readPortable(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readPortable(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readPortable(PortableReader) - Method in interface com.hazelcast.nio.serialization.Portable
-
Read portable fields using PortableReader
- readPortable(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntrySet
-
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapGetResponse
-
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeySet
-
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableEntryEvent
-
- readPortable(PortableReader) - Method in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapValueCollection
-
- readPortable(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
-
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableCollection
-
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableDistributedObjectEvent
-
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableEntryEvent
-
- readPortable(PortableReader) - Method in class com.hazelcast.spi.impl.PortableItemEvent
-
- readPortable(PortableReader) - Method in class com.hazelcast.topic.impl.client.PortableMessage
-
- readPortableArray(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readPortableArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readPortableArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readPortableHeader(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- readPortableInner(PortableReader) - Method in class com.hazelcast.map.impl.client.MapQueryRequest
-
- readPortableInner(PortableReader) - Method in class com.hazelcast.map.impl.client.MapSQLQueryRequest
-
- readPortableInternal(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
-
- readPortableInternal(PortableReader) - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- ReadRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- ReadRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-
- ReadRequest(String) - Constructor for class com.hazelcast.concurrent.atomiclong.client.ReadRequest
-
- ReadRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- ReadRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-
- ReadRequest(String) - Constructor for class com.hazelcast.concurrent.atomicreference.client.ReadRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.ClusterPropsRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.ConsoleCommandRequest
-
- readResponse(JsonObject) - Method in interface com.hazelcast.management.request.ConsoleRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.ExecuteScriptRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.GetLogsRequest
-
Deprecated.
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.GetMapEntryRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.GetMemberSystemPropertiesRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.GetSystemWarningsRequest
-
Deprecated.
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.MapConfigRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.MemberConfigRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.RunGcRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.ShutdownMemberRequest
-
- readResponse(JsonObject) - Method in class com.hazelcast.management.request.ThreadDumpRequest
-
- readShort(byte[], int, boolean) - Static method in class com.hazelcast.nio.Bits
-
- readShort(int) - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- readShort(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readShort(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readShort() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readShort(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readShortArray() - Method in interface com.hazelcast.nio.ObjectDataInput
-
- readShortArray(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readShortArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readShortArray() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readShortArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readShortB(byte[], int) - Static method in class com.hazelcast.nio.Bits
-
- readShortL(byte[], int) - Static method in class com.hazelcast.nio.Bits
-
- readThroughCache(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- readThroughRecord(Data, long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- readUnsignedByte() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readUnsignedShort() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readUTF(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
-
- readUTF(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
-
- readUTF() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- readUTF(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
-
- readUTF(DataInput, byte[]) - Static method in class com.hazelcast.nio.UTFEncoderDecoder
-
- readUTF0(DataInput, byte[]) - Method in class com.hazelcast.nio.UTFEncoderDecoder
-
- reArrange(Collection<MemberGroup>, InternalPartition[]) - Method in interface com.hazelcast.partition.impl.PartitionStateGenerator
-
Rearranges the partition layout.
- reArrange(Collection<MemberGroup>, InternalPartition[]) - Method in class com.hazelcast.partition.impl.PartitionStateGeneratorImpl
-
- record - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- Record<V> - Interface in com.hazelcast.map.impl.record
-
- RECORD - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- RecordFactory<T> - Interface in com.hazelcast.map.impl.record
-
TODO need a better name than RecordFactory!
- RecordInfo - Class in com.hazelcast.map.impl.record
-
Record info.
- RecordInfo() - Constructor for class com.hazelcast.map.impl.record.RecordInfo
-
- RecordInfo(RecordInfo) - Constructor for class com.hazelcast.map.impl.record.RecordInfo
-
- recordLoaded - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- RecordReplicationInfo - Class in com.hazelcast.map.impl.record
-
- RecordReplicationInfo(Data, Data, RecordInfo) - Constructor for class com.hazelcast.map.impl.record.RecordReplicationInfo
-
- RecordReplicationInfo() - Constructor for class com.hazelcast.map.impl.record.RecordReplicationInfo
-
- records - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- Records - Class in com.hazelcast.map.impl.record
-
Contains various factory & helper methods for a
Record
object.
- RecordStatistics - Class in com.hazelcast.map.impl.record
-
TODO empty statistics.
- RecordStatistics() - Constructor for class com.hazelcast.map.impl.record.RecordStatistics
-
- recordStore - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- RecordStore - Interface in com.hazelcast.map.impl
-
Defines a record-store.
- recordToData(R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- recordToData(CacheRecord) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- recordToValue(R) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- recordToValue(CacheRecord) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- RECOVER - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- recover() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- recover(int) - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- RECOVER_ALL - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- RECOVER_TIMEOUT - Static variable in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- RecoverAllTransactionsRequest - Class in com.hazelcast.transaction.client
-
- RecoverAllTransactionsRequest() - Constructor for class com.hazelcast.transaction.client.RecoverAllTransactionsRequest
-
- recoverClientTransaction(SerializableXID, boolean) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- RecoveredTransaction - Class in com.hazelcast.transaction.impl
-
- RecoveredTransaction() - Constructor for class com.hazelcast.transaction.impl.RecoveredTransaction
-
- recoverLocal() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- RecoverTransactionRequest - Class in com.hazelcast.transaction.client
-
- RecoverTransactionRequest() - Constructor for class com.hazelcast.transaction.client.RecoverTransactionRequest
-
- RecoverTransactionRequest(SerializableXID, boolean) - Constructor for class com.hazelcast.transaction.client.RecoverTransactionRequest
-
- RecoverTxnOperation - Class in com.hazelcast.transaction.impl
-
- RecoverTxnOperation() - Constructor for class com.hazelcast.transaction.impl.RecoverTxnOperation
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.cache.impl.client.CacheClearRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.cache.impl.client.CacheGetAllRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.cache.impl.client.CacheLoadAllRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.cache.impl.client.CacheSizeRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.client.AllPartitionsClientRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.impl.client.MultiPartitionClientRequest
-
- reduce(Map<Address, Object>) - Method in class com.hazelcast.client.impl.client.MultiTargetClientRequest
-
- reduce(int) - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- reduce(int) - Method in class com.hazelcast.jmx.SemaphoreMBean
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapAddIndexRequest
-
- reduce(Map<Address, Object>) - Method in class com.hazelcast.map.impl.client.MapAddInterceptorRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapClearRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapContainsValueRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapEntrySetRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapEvictAllRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapExecuteOnAllKeysRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeysRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapExecuteWithPredicateRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapFlushRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapGetAllRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapIsEmptyRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapKeySetRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapLoadGivenKeysRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapPutAllRequest
-
- reduce(Map<Address, Object>) - Method in class com.hazelcast.map.impl.client.MapRemoveInterceptorRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapSizeRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.map.impl.client.MapValuesRequest
-
- reduce(ValueIn) - Method in class com.hazelcast.mapreduce.Reducer
-
This method is called to supply values to be reduced into a final reduced result.
The reduce method might be called multiple times so the eventually reduces value
needs to be hold internally in a member state of the Reducer.
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.ClearRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.ContainsRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.EntrySetRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.KeySetRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.SizeRequest
-
- reduce(Map<Integer, Object>) - Method in class com.hazelcast.multimap.impl.client.ValuesRequest
-
- REDUCE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- REDUCE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- ReduceBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- ReduceBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-
- ReduceBackupOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-
- ReduceOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- ReduceOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- ReduceOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- reducePermits(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- reducePermits(int) - Method in interface com.hazelcast.core.ISemaphore
-
Shrinks the number of available permits by the indicated
reduction.
- reducer(ReducerFactory<Key, Value, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- reducer(ReducerFactory<Key, Value, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-
- reducer(ReducerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
-
- Reducer<ValueIn,ValueOut> - Class in com.hazelcast.mapreduce
-
The abstract Reducer class is used to build reducers for the
Job
.
Reducers may be distributed inside of the cluster but there is always only one Reducer
per key.
- Reducer() - Constructor for class com.hazelcast.mapreduce.Reducer
-
- reducer(ReducerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
-
- REDUCER_CHUNK_MESSAGE - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- REDUCER_LAST_CHUNK_MESSAGE - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- ReduceRequest - Class in com.hazelcast.concurrent.semaphore.client
-
- ReduceRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-
- ReduceRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.ReduceRequest
-
- reducerFactory - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-
- reducerFactory - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- ReducerFactory<KeyIn,ValueIn,ValueOut> - Interface in com.hazelcast.mapreduce
-
A ReducerFactory implementation is used to build
Reducer
instances per key.
An implementation needs to be serializable by Hazelcast since it might be distributed
inside the cluster to do parallel calculations of reducing step.
- ReducerTask<Key,Chunk> - Class in com.hazelcast.mapreduce.impl.task
-
This task implementation executes the reducing phase.
- ReducerTask(String, String, JobSupervisor) - Constructor for class com.hazelcast.mapreduce.impl.task.ReducerTask
-
- reducerTasks - Variable in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- REDUCING_FINISHED_MESSAGE - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- ReducingFinishedNotification - Class in com.hazelcast.mapreduce.impl.notification
-
This notification class is used to signal the
JobSupervisor
owner node that a reducer has finished the reducing step for the defined partitionId.
- ReducingFinishedNotification() - Constructor for class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-
- ReducingFinishedNotification(Address, String, String, int) - Constructor for class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-
- ReducingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
-
This interface describes a reducing mapreduce Job.
For further information
Job
.
- ReducingSubmittableJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
-
This interface describes a submittable mapreduce Job.
For further information
Job
.
- ReferenceWrapper - Class in com.hazelcast.concurrent.atomicreference
-
- ReferenceWrapper() - Constructor for class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
-
- ReflectionHelper - Class in com.hazelcast.query.impl
-
Scans your classpath, indexes the metadata, allows you to query it on runtime.
- regex(String, String) - Static method in class com.hazelcast.query.Predicates
-
- register(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- register(HazelcastMBean) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- register(Class, Serializer) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- register(Class, Serializer) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- register(Selector, int, Object) - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- register(Selector, int, Object) - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
- register(String, int, int, ExecutorType) - Method in interface com.hazelcast.spi.ExecutionService
-
- register(String, int, int, ExecutorType) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- registerCacheEntryListener(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- registerCacheObject(Object, String, String, boolean) - Static method in class com.hazelcast.cache.impl.MXBeanUtil
-
Registers the provided CacheMXBean
or
CacheStatisticsMXBean
implementations if not registered yet.
- registerClassDefinition(ClassDefinition) - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- registerCleaner(ReplicatedRecordStore) - Method in interface com.hazelcast.replicatedmap.impl.CleanerRegistrator
-
- registerConnection(Address, Connection) - Method in interface com.hazelcast.nio.ConnectionManager
-
- registerConnection(Address, Connection) - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- registerEndpoint(ClientEndpoint) - Method in interface com.hazelcast.client.ClientEndpointManager
-
Registers an endpoint with this ClientEndpointManager.
- registerEndpoint(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- registerEngineExtension(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- registerEngineMimeType(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- registerEngineName(String, ScriptEngineFactory) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
- registerExpiredAwaitOp(AwaitOperation) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- registerGlobal(Serializer) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- registerGlobal(Serializer) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- registerJobSupervisorCancellation(String, String, Address) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- registerListener(String, CacheEventListener) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- registerListener(String, CacheEventListener) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- registerListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
-
Registers a listener on all cluster nodes.
- registerListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
-
Registers a listener on all cluster nodes.
- registerListener(String, String, Object) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- registerListener(String, String, EventFilter, Object) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- registerListeners(CacheConfig<K, V>, ICache<K, V>) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- registerLocalListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
-
Registers a local only listener.
- registerLocalListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
-
Registers a local only listener.
- registerLocalListener(String, String, Object) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- registerLocalListener(String, String, EventFilter, Object) - Method in class com.hazelcast.spi.impl.EventServiceImpl
-
- registerLockStoreConstructor(String, ConstructorFunction<ObjectNamespace, LockStoreInfo>) - Method in interface com.hazelcast.concurrent.lock.LockService
-
- registerLockStoreConstructor(String, ConstructorFunction<ObjectNamespace, LockStoreInfo>) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- registerMapCombineTask(MapCombineTask<KeyIn, ValueIn, KeyOut, ValueOut, Chunk>) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- registerReducerEventInterests(int, Set<Address>) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- registerReducerTask(ReducerTask<Key, Chunk>) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- registerSignalKey(ConditionKey) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- registerTrackableJob(TrackableJobFuture<V>) - Method in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- registrationId - Variable in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- rejectExecution() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- rejoin() - Method in class com.hazelcast.instance.Node
-
- release(int, String) - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- release() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- release(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- release() - Method in interface com.hazelcast.core.ISemaphore
-
Releases a permit, increasing the number of available permits by
one.
- release(int) - Method in interface com.hazelcast.core.ISemaphore
-
Releases the given number of permits, increasing the number of
available permits by that amount.
- release(int) - Method in class com.hazelcast.jmx.SemaphoreMBean
-
- RELEASE_BACKUP_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- RELEASE_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- ReleaseBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- ReleaseBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-
- ReleaseBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-
- ReleaseOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- ReleaseOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- ReleaseOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- releaseReadLock() - Method in class com.hazelcast.query.impl.BaseIndexStore
-
- ReleaseRequest - Class in com.hazelcast.concurrent.semaphore.client
-
- ReleaseRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-
- ReleaseRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.ReleaseRequest
-
- releaseWriteLock() - Method in class com.hazelcast.query.impl.BaseIndexStore
-
- reloadManagers() - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
This method is the only one that is visible and not part of the ScriptEngineManager class.
- reloadOwnedPartitions() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- reloadOwnedPartitions() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- remaining() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- REMAINING_CAPACITY - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- REMAINING_CAPACITY - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- RemainingCapacityOperation - Class in com.hazelcast.queue.impl.operations
-
Returns the remaining capacity of the queue based on config max-size
- RemainingCapacityOperation() - Constructor for class com.hazelcast.queue.impl.operations.RemainingCapacityOperation
-
- RemainingCapacityOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.RemainingCapacityOperation
-
- RemainingCapacityRequest - Class in com.hazelcast.queue.impl.client
-
Request for remaining capacity of Queue.
- RemainingCapacityRequest() - Constructor for class com.hazelcast.queue.impl.client.RemainingCapacityRequest
-
- RemainingCapacityRequest(String) - Constructor for class com.hazelcast.queue.impl.client.RemainingCapacityRequest
-
- RemoteMapReduceException - Exception in com.hazelcast.mapreduce
-
This exception class is used to show stacktraces of multiple failed
remote operations at once.
- RemoteMapReduceException(String, List<Exception>) - Constructor for exception com.hazelcast.mapreduce.RemoteMapReduceException
-
- RemotePropagatable<T extends RemotePropagatable> - Interface in com.hazelcast.spi.impl
-
- RemoteService - Interface in com.hazelcast.spi
-
An interface that can be implemented by SPI-Services to give them the ability to create proxies to
distributed objects.
- remove(Data, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- remove(Data, Object, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- remove() - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- REMOVE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- remove() - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- REMOVE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- remove(K) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- remove(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- remove(Data, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Removes the mapping for a key from this cache if it is present.
- remove(Data, Object, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Atomically removes the mapping for a key only if currently mapped to the
given value.
- remove(Object) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- remove(Data) - Method in class com.hazelcast.collection.CollectionContainer
-
- remove(int) - Method in class com.hazelcast.collection.list.ListContainer
-
- remove(int) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- remove(E) - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- remove(Object) - Method in interface com.hazelcast.core.BaseMap
-
Removes the mapping for a key from this map if it is present.
- remove(Object, Object) - Method in interface com.hazelcast.core.BaseMap
-
Removes the entry for a key only if currently mapped to a given value.
- remove(Object, Object) - Method in interface com.hazelcast.core.BaseMultiMap
-
Removes the given key value pair from the multimap.
- remove(Object) - Method in interface com.hazelcast.core.BaseMultiMap
-
Removes all the entries with the given key.
- remove(Object) - Method in interface com.hazelcast.core.IMap
-
Removes the mapping for a key from this map if it is present.
- remove(Object, Object) - Method in interface com.hazelcast.core.IMap
-
Removes the entry for a key only if currently mapped to a given value.
- remove(Object, Object) - Method in interface com.hazelcast.core.MultiMap
-
Removes the given key value pair from the multimap.
- remove(Object) - Method in interface com.hazelcast.core.MultiMap
-
Removes all the entries with the given key.
- remove(E) - Method in interface com.hazelcast.core.TransactionalList
-
Add item from transactional list
- remove(Object) - Method in interface com.hazelcast.core.TransactionalMap
-
- remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMap
-
- remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMultiMap
-
Removes the given key value pair from the multimap.
- remove(Object) - Method in interface com.hazelcast.core.TransactionalMultiMap
-
Removes all the entries with the given key.
- remove(E) - Method in interface com.hazelcast.core.TransactionalSet
-
Add item from transactional set
- remove(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- remove(Data, Object) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- REMOVE - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- REMOVE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- remove(K, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-
- remove(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- remove(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-
- remove(String) - Method in class com.hazelcast.map.impl.NearCacheProvider
-
- remove(Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- remove(Object, Object) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- remove(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- remove(Data, Object) - Method in interface com.hazelcast.map.impl.RecordStore
-
- remove(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- remove(Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- remove(Data, boolean) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- remove(Object, Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- remove(Object) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- remove(boolean) - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- remove(Object, Object) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- remove(Object) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- remove() - Method in class com.hazelcast.queue.impl.proxy.QueueIterator
-
- remove(Object) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- remove() - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- remove(Data) - Method in class com.hazelcast.queue.impl.QueueContainer
-
iterates all items, checks equality with data
This method does not trigger store load.
- REMOVE - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- REMOVE - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- REMOVE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- remove(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- remove(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- remove(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- remove(int, REF) - Method in interface com.hazelcast.storage.Storage
-
- remove(Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Removes the key (and its corresponding value) from this map.
- remove(Object, Object) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- REMOVE_ALL - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- REMOVE_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- REMOVE_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- REMOVE_ALL_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- REMOVE_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- REMOVE_ALL_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- REMOVE_ALL_LISTENERS - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- REMOVE_BACKUP - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- REMOVE_BACKUP - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- REMOVE_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- REMOVE_ENTRY_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- REMOVE_ENTRY_LISTENER - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- REMOVE_ENTRY_LISTENER - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- REMOVE_IF_SAME - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- REMOVE_INDEX - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- REMOVE_INDEX_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- REMOVE_INTERCEPTOR - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- REMOVE_INVALIDATION_LISTENER - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- REMOVE_LISTENER - Static variable in class com.hazelcast.client.impl.client.ClientPortableHook
-
- REMOVE_LISTENER - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- REMOVE_LISTENER - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- REMOVE_LISTENER - Static variable in class com.hazelcast.topic.impl.TopicPortableHook
-
- removeAddress(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- removeAll(Set<Data>) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- removeAll(Set<? extends K>) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- removeAll() - Method in class com.hazelcast.cache.impl.CacheProxy
-
- removeAll(Set<Data>) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
records of keys will be deleted one by one and will publish a REMOVE event
for each key.
- removeAll(Collection<?>) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- removeAll(Collection) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-
Directly removes keys from map store as in write-through mode.
- removeAll(Collection) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-
Removes keys from map store.
- removeAll(Collection<E>) - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Removes all items in collection from queue.
- removeAll() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
Removes and returns all items in this queue.
- removeAll(Collection<?>) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- RemoveAllBackupOperation - Class in com.hazelcast.multimap.impl.operations
-
- RemoveAllBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
-
- RemoveAllBackupOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
-
- removeAllInternal(Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- RemoveAllListeners - Class in com.hazelcast.client.impl.client
-
When a connection does not respond to heart-beat we switch the listeners to another endpoint
If somehow connection starts to respond heart-beat we need to signal the endpoint to remove the listeners
- RemoveAllListeners() - Constructor for class com.hazelcast.client.impl.client.RemoveAllListeners
-
- RemoveAllOperation - Class in com.hazelcast.multimap.impl.operations
-
- RemoveAllOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-
- RemoveAllOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-
- RemoveAllRequest - Class in com.hazelcast.multimap.impl.client
-
- RemoveAllRequest() - Constructor for class com.hazelcast.multimap.impl.client.RemoveAllRequest
-
- RemoveAllRequest(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.client.RemoveAllRequest
-
- removeAsync(K) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the mapping for a key from this cache if it is present.
- removeAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously removes the mapping for a key only if it is currently mapped to the
given value.
- removeAsync(K) - Method in interface com.hazelcast.core.IMap
-
Asynchronously removes the given key.
- removeAsync(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- removeAttribute(String) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- removeAttribute(String) - Method in interface com.hazelcast.core.Member
-
Removes a key-value pair attribute for this member if given key was
previously assigned as an attribute.
If key wasn't assigned to a value this method does nothing.
- removeAttribute(String) - Method in class com.hazelcast.instance.MemberImpl
-
- removeAwait(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- removeBackup(long) - Method in class com.hazelcast.collection.CollectionContainer
-
- removeBackup(Data) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- removeBackup(K, long) - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-
- removeBackup(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- removeBackup(Data, long) - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-
- removeBackup(Data) - Method in interface com.hazelcast.map.impl.RecordStore
-
- removeBackup(long) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- RemoveBackupOperation - Class in com.hazelcast.map.impl.operation
-
- RemoveBackupOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- RemoveBackupOperation(String, Data, boolean) - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- RemoveBackupOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- RemoveBackupOperation - Class in com.hazelcast.multimap.impl.operations
-
- RemoveBackupOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-
- RemoveBackupOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-
- RemoveBackupOperation - Class in com.hazelcast.queue.impl.operations
-
Remove backup of the Queue item.
- RemoveBackupOperation() - Constructor for class com.hazelcast.queue.impl.operations.RemoveBackupOperation
-
- RemoveBackupOperation(String, long) - Constructor for class com.hazelcast.queue.impl.operations.RemoveBackupOperation
-
- removeCacheConfigFromLocal(String) - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
Removes the local copy of the cache configuration if one exists.
- removeCacheConfigFromLocal(String) - Method in class com.hazelcast.cache.impl.HazelcastServerCacheManager
-
- removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- removeCacheEntryListenerConfiguration(CacheEntryListenerConfiguration<K, V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Remove a configuration for a CacheEntryListener
.
- removeClientListener(String) - Method in class com.hazelcast.client.impl.ClientServiceProxy
-
- removeClientListener(String) - Method in interface com.hazelcast.core.ClientService
-
Removes a ClientListener.
- removeDistributedObjectListener(String) - Method in interface com.hazelcast.core.HazelcastInstance
-
Removes the specified Distributed Object listener.
- removeDistributedObjectListener(String) - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- removeDistributedObjectListener(String) - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- RemoveDistributedObjectListenerRequest - Class in com.hazelcast.client.impl.client
-
Client request to add a distributed object listener to a remote node.
- RemoveDistributedObjectListenerRequest() - Constructor for class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-
- RemoveDistributedObjectListenerRequest(String) - Constructor for class com.hazelcast.client.impl.client.RemoveDistributedObjectListenerRequest
-
- removeEndpoint(ClientEndpoint) - Method in interface com.hazelcast.client.ClientEndpointManager
-
Removes an endpoint from this ClientEndpointManager.
- removeEndpoint(ClientEndpoint, boolean) - Method in interface com.hazelcast.client.ClientEndpointManager
-
Removes an endpoint and optionally closes it immediately.
- removeEndpoint(ClientEndpoint) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- removeEndpoint(ClientEndpoint, boolean) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- removeEndpoint(Address) - Method in interface com.hazelcast.nio.IOService
-
- removeEndpoint(Address) - Method in class com.hazelcast.nio.NodeIOService
-
- removeEndpoints(String) - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- removeEntryIndex(Data) - Method in interface com.hazelcast.query.impl.Index
-
- removeEntryIndex(Data) - Method in class com.hazelcast.query.impl.IndexImpl
-
- removeEntryIndex(Data) - Method in class com.hazelcast.query.impl.IndexService
-
- removeEntryListener(String) - Method in interface com.hazelcast.core.IMap
-
Removes the specified entry listener
Returns silently if there is no such listener added before.
- removeEntryListener(String) - Method in interface com.hazelcast.core.MultiMap
-
Removes the specified entry listener
Returns silently if there is no such listener added before.
- removeEntryListener(String) - Method in interface com.hazelcast.core.ReplicatedMap
-
Removes the specified entry listener
Returns silently if there is no such listener added before.
- removeEntryListener(String) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- removeEntryListener(String) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- removeEntryListener(String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- removeEntryListenerInternal(String) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- removeEntryListenerInternal(String) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- RemoveEntryListenerRequest - Class in com.hazelcast.multimap.impl.client
-
- RemoveEntryListenerRequest() - Constructor for class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- RemoveEntryListenerRequest(String, String) - Constructor for class com.hazelcast.multimap.impl.client.RemoveEntryListenerRequest
-
- removeEventListener(String, String) - Method in interface com.hazelcast.map.impl.MapServiceContextEventListenerSupport
-
- removeEventListener(String, String) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- removeEvictableRecords(RecordStore, int, MapConfig, boolean) - Method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- removeFirst() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
removes head of the queue.
- removeIfSameInternal(Data, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- RemoveIfSameOperation - Class in com.hazelcast.map.impl.operation
-
- RemoveIfSameOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-
- RemoveIfSameOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-
- removeIndex(Comparable, Data) - Method in interface com.hazelcast.query.impl.IndexStore
-
- removeIndex(Comparable, Data) - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- removeIndex(Comparable, Data) - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- removeInterceptor(String) - Method in interface com.hazelcast.core.IMap
-
Removes the given interceptor for this map.
- removeInterceptor(String) - Method in class com.hazelcast.map.impl.MapContainer
-
- removeInterceptor(String, String) - Method in interface com.hazelcast.map.impl.MapServiceContextInterceptorSupport
-
- removeInterceptor(String) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- RemoveInterceptorOperation - Class in com.hazelcast.map.impl.operation
-
- RemoveInterceptorOperation(String, String) - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- RemoveInterceptorOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- RemoveInterceptorOperationFactory - Class in com.hazelcast.map.impl.operation
-
- RemoveInterceptorOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperationFactory
-
- RemoveInterceptorOperationFactory(String, String) - Constructor for class com.hazelcast.map.impl.operation.RemoveInterceptorOperationFactory
-
- removeInternal(Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- removeInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- removeInternal(Data) - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- removeInternal(Data, Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- removeItemListener(String) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- removeItemListener(String) - Method in interface com.hazelcast.core.ICollection
-
Removes the specified item listener.
- removeItemListener(String, String) - Method in class com.hazelcast.queue.impl.QueueService
-
- removeLifecycleListener(String) - Method in interface com.hazelcast.core.LifecycleService
-
Remove lifecycle listener
- removeLifecycleListener(String) - Method in class com.hazelcast.instance.LifecycleServiceImpl
-
- removeLifecycleListener(String) - Method in class com.hazelcast.instance.TerminatedLifecycleService
-
- removeListener(String, String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- RemoveListenerRequest - Class in com.hazelcast.queue.impl.client
-
Remove listener request belong to the Queue item.
- RemoveListenerRequest() - Constructor for class com.hazelcast.queue.impl.client.RemoveListenerRequest
-
- RemoveListenerRequest(String, String) - Constructor for class com.hazelcast.queue.impl.client.RemoveListenerRequest
-
- removeLogListener(LogListener) - Method in interface com.hazelcast.logging.LoggingService
-
- removeLogListener(LogListener) - Method in class com.hazelcast.logging.LoggingServiceImpl
-
- removeManagedTransaction(Xid) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- removeMember(Member) - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- removeMember(Member) - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-
- removeMember(Member) - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- removeMembershipListener(String) - Method in class com.hazelcast.cluster.impl.ClusterProxy
-
- removeMembershipListener(String) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- removeMembershipListener(String) - Method in interface com.hazelcast.core.Cluster
-
Removes the specified MembershipListener.
- removeMessageListener(String) - Method in interface com.hazelcast.core.ITopic
-
Stops receiving messages for the given message listener.
- removeMessageListener(String) - Method in class com.hazelcast.topic.impl.TopicProxy
-
- removeMessageListener(String, String) - Method in class com.hazelcast.topic.impl.TopicService
-
- RemoveMessageListenerRequest - Class in com.hazelcast.topic.impl.client
-
- RemoveMessageListenerRequest() - Constructor for class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- RemoveMessageListenerRequest(String, String) - Constructor for class com.hazelcast.topic.impl.client.RemoveMessageListenerRequest
-
- removeMigrationListener(String) - Method in interface com.hazelcast.core.PartitionService
-
Removes a MigrationListener.
- removeMigrationListener(String) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- removeMigrationListener(String) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- removeMigrationListener(String) - Method in class com.hazelcast.partition.PartitionServiceProxy
-
- removeMulticastListener(MulticastListener) - Method in class com.hazelcast.cluster.impl.MulticastService
-
- removeNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- removeNotificationListener(NotificationListener) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- removeNumber(int) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- RemoveOperation - Class in com.hazelcast.map.impl.operation
-
- RemoveOperation(String, Data) - Constructor for class com.hazelcast.map.impl.operation.RemoveOperation
-
- RemoveOperation() - Constructor for class com.hazelcast.map.impl.operation.RemoveOperation
-
- RemoveOperation - Class in com.hazelcast.multimap.impl.operations
-
- RemoveOperation() - Constructor for class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- RemoveOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- RemoveOperation - Class in com.hazelcast.queue.impl.operations
-
Remove operation for the Queue.
- RemoveOperation() - Constructor for class com.hazelcast.queue.impl.operations.RemoveOperation
-
- RemoveOperation(String, Data) - Constructor for class com.hazelcast.queue.impl.operations.RemoveOperation
-
- removeOwnershipMapping(String) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- removeProxyListener(String) - Method in class com.hazelcast.spi.impl.ProxyServiceImpl
-
- removeProxyListener(String) - Method in interface com.hazelcast.spi.ProxyService
-
- removeRecord(Data) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- removeRecord(Data) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Removes the record for a key.
- removeReference(int) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- RemoveRequest - Class in com.hazelcast.multimap.impl.client
-
- RemoveRequest() - Constructor for class com.hazelcast.multimap.impl.client.RemoveRequest
-
- RemoveRequest(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.client.RemoveRequest
-
- RemoveRequest - Class in com.hazelcast.queue.impl.client
-
Remove Request for the Queue.
- RemoveRequest() - Constructor for class com.hazelcast.queue.impl.client.RemoveRequest
-
- RemoveRequest(String, Data) - Constructor for class com.hazelcast.queue.impl.client.RemoveRequest
-
- removeSignalKey(ConditionKey) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- removeThreadId() - Static method in class com.hazelcast.util.ThreadUtil
-
- removeTombstone(Object) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- removeTombstone(Object) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- removeTransactionContext(String) - Method in interface com.hazelcast.client.ClientEndpoint
-
- removeTransactionContext(String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- removeTransactionLog(Object) - Method in interface com.hazelcast.transaction.impl.TransactionSupport
-
- removeWhiteSpace(byte[]) - Static method in class com.hazelcast.util.Base64
-
remove WhiteSpace from MIME containing encoded Base64
data.
- REPL_CLEAR_MESSAGE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- REPL_MULTI_UPDATE_MESSAGE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- REPL_UPDATE_MESSAGE - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- replace(String, String, Object) - Method in interface com.hazelcast.ascii.TextCommandService
-
- replace(String, String, Object) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- replace(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
replace operation with custom expiry policy.
- replace(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
replace operation with custom expiry policy.
- replace(Data, Object, ExpiryPolicy, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- replace(Data, Object, Object, ExpiryPolicy, String) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- REPLACE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- REPLACE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- replace(K, V, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- replace(K, V) - Method in class com.hazelcast.cache.impl.CacheProxy
-
- replace(Data, Object, ExpiryPolicy, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Atomically replaces the entry for a key only if currently mapped to some
value.
- replace(Data, Object, Object, ExpiryPolicy, String) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Atomically replaces the entry for a key only if currently mapped to a
given value.
- replace(K, V) - Method in interface com.hazelcast.core.BaseMap
-
Replaces the entry for a key only if currently mapped to some value.
- replace(K, V, V) - Method in interface com.hazelcast.core.BaseMap
-
Replaces the entry for a key only if currently mapped to a given value.
- replace(K, V, V) - Method in interface com.hazelcast.core.IMap
-
Replaces the entry for a key only if currently mapped to a given value.
- replace(K, V) - Method in interface com.hazelcast.core.IMap
-
Replaces the entry for a key only if currently mapped to some value.
- replace(K, V) - Method in interface com.hazelcast.core.TransactionalMap
-
- replace(K, V, V) - Method in interface com.hazelcast.core.TransactionalMap
-
- replace(Data, Object) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- replace(Data, Object, Object) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- REPLACE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- replace(K, V, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- replace(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- replace(Data, Object) - Method in interface com.hazelcast.map.impl.RecordStore
-
- replace(Data, Object, Object) - Method in interface com.hazelcast.map.impl.RecordStore
-
- replace(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- replace(Object, Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- replace(K, V, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- replace(K, V) - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
- REPLACE_IF_SAME - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- replaceAsync(K, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the entry for a key.
- replaceAsync(K, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the entry for a key only if it is currently mapped to some
value.
- replaceAsync(K, V, V) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the entry for a key only if it is currently mapped to a
given value.
- replaceAsync(K, V, V, ExpiryPolicy) - Method in interface com.hazelcast.cache.ICache
-
Asynchronously replaces the entry for a key only if it is currently mapped to a
given value using custom expiry policy.
- replaceIfSameInternal(Data, Object, Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- ReplaceIfSameOperation - Class in com.hazelcast.map.impl.operation
-
- ReplaceIfSameOperation(String, Data, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-
- ReplaceIfSameOperation() - Constructor for class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-
- replaceInternal(Data, Data) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- ReplaceOperation - Class in com.hazelcast.map.impl.operation
-
- ReplaceOperation(String, Data, Data) - Constructor for class com.hazelcast.map.impl.operation.ReplaceOperation
-
- ReplaceOperation() - Constructor for class com.hazelcast.map.impl.operation.ReplaceOperation
-
- REPLICA_SYNC_RETRY_DELAY - Static variable in interface com.hazelcast.partition.InternalPartitionService
-
- replicaChanged(PartitionReplicaChangeEvent) - Method in interface com.hazelcast.partition.impl.PartitionListener
-
- ReplicaErrorLogger - Class in com.hazelcast.partition
-
- replicaIndex - Variable in class com.hazelcast.spi.InvocationBuilder
-
- ReplicaSyncRequest - Class in com.hazelcast.partition.impl
-
- ReplicaSyncRequest() - Constructor for class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- ReplicaSyncRequest(int, int) - Constructor for class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- ReplicaSyncResponse - Class in com.hazelcast.partition.impl
-
- ReplicaSyncResponse() - Constructor for class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- ReplicaSyncResponse(List<Operation>, long[]) - Constructor for class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- ReplicaSyncRetryResponse - Class in com.hazelcast.partition.impl
-
- ReplicaSyncRetryResponse() - Constructor for class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- replicate(MultiReplicationMessage) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicationPublisher
-
- replicate(ReplicationMessage) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicationPublisher
-
- replicate(ReplicationMessage) - Method in interface com.hazelcast.replicatedmap.impl.ReplicationChannel
-
- replicate(MultiReplicationMessage) - Method in interface com.hazelcast.replicatedmap.impl.ReplicationChannel
-
- REPLICATED_MAP_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- REPLICATED_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- ReplicatedEntryEventFilter - Class in com.hazelcast.replicatedmap.impl.record
-
Basic filter implementation for selecting interesting events on the server
- ReplicatedEntryEventFilter(Object) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedEntryEventFilter
-
- ReplicatedMap<K,V> - Interface in com.hazelcast.core
-
A ReplicatedMap is a map like data structure with non-strong consistency
(so-called eventually consistent) and values are locally stored on every
node of the cluster.
- ReplicatedMapClearOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
- ReplicatedMapClearOperation() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- ReplicatedMapClearOperation(String, boolean) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- ReplicatedMapConfig - Class in com.hazelcast.config
-
- ReplicatedMapConfig() - Constructor for class com.hazelcast.config.ReplicatedMapConfig
-
- ReplicatedMapConfig(ReplicatedMapConfig) - Constructor for class com.hazelcast.config.ReplicatedMapConfig
-
- ReplicatedMapDataSerializerHook - Class in com.hazelcast.replicatedmap.impl.operation
-
This class contains all the ID hooks for IdentifiedDataSerializable classes used inside the replicated map.
- ReplicatedMapDataSerializerHook() - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- ReplicatedMapEntrySet<K,V> - Class in com.hazelcast.replicatedmap.impl.client
-
An implementation of a portable implementing entry set for client results on entrySet requests
- ReplicatedMapEntrySet(Set<Map.Entry<K, V>>) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapEntrySet
-
- ReplicatedMapEvictionProcessor - Class in com.hazelcast.replicatedmap.impl
-
Actual eviction processor implementation to remove values to evict values from the replicated map
- ReplicatedMapEvictionProcessor(NodeEngine, ReplicatedMapService, String) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapEvictionProcessor
-
- ReplicatedMapGetResponse - Class in com.hazelcast.replicatedmap.impl.client
-
Response class for client replicated map get requests
- ReplicatedMapInitChunkOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
Class for requesting an initial chunk of data from another node to pre-provision newly joining members
- ReplicatedMapInitChunkOperation(String, Member) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- ReplicatedMapInitChunkOperation(String, Member, ReplicatedRecord[], int, boolean) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- ReplicatedMapKeySet - Class in com.hazelcast.replicatedmap.impl.client
-
Class to implement a replicated map keySet result
- ReplicatedMapKeySet(Set) - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapKeySet
-
- ReplicatedMapMBean - Class in com.hazelcast.jmx
-
- ReplicatedMapMBean(ReplicatedMapProxy, ManagementService) - Constructor for class com.hazelcast.jmx.ReplicatedMapMBean
-
- ReplicatedMapPermission - Class in com.hazelcast.security.permission
-
- ReplicatedMapPermission(String, String...) - Constructor for class com.hazelcast.security.permission.ReplicatedMapPermission
-
- ReplicatedMapPortableEntryEvent - Class in com.hazelcast.replicatedmap.impl.client
-
Class to redirect entry listener events on the members to the listening client
- ReplicatedMapPortableHook - Class in com.hazelcast.replicatedmap.impl.client
-
This class registers all Portable serializers that are needed for communication between nodes and clients
- ReplicatedMapPortableHook() - Constructor for class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- ReplicatedMapPostJoinOperation - Class in com.hazelcast.replicatedmap.impl.operation
-
The replicated map post join operation to execute on remote nodes
- ReplicatedMapPostJoinOperation(ReplicatedMapPostJoinOperation.MemberMapPair[], int) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
- ReplicatedMapPostJoinOperation.MemberMapPair - Class in com.hazelcast.replicatedmap.impl.operation
-
A mapping for replicated map names and the assigned provisioning member
- ReplicatedMapPostJoinOperation.MemberMapPair(Member, String) - Constructor for class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation.MemberMapPair
-
- ReplicatedMapProxy<K,V> - Class in com.hazelcast.replicatedmap.impl
-
The internal
ReplicatedMap
implementation proxying the requests to the underlying
- ReplicatedMapService - Class in com.hazelcast.replicatedmap.impl
-
This is the main service implementation to handle replication and manages the backing
ReplicatedRecordStore
s that actually hold the data
- ReplicatedMapService(NodeEngine) - Constructor for class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- ReplicatedMapValueCollection - Class in com.hazelcast.replicatedmap.impl.client
-
Class implementing a replicated map value collection result
- ReplicatedMessageListener - Interface in com.hazelcast.replicatedmap.impl
-
Simple listener interface used by the ReplicatedMapService
- ReplicatedQueryEventFilter - Class in com.hazelcast.replicatedmap.impl.record
-
This class is used to transfer a predicate as an remote operation and filter values matching the predicate
- ReplicatedQueryEventFilter(Object, Predicate) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedQueryEventFilter
-
- ReplicatedRecord<K,V> - Class in com.hazelcast.replicatedmap.impl.record
-
A ReplicatedRecord is the actual data holding entity.
- ReplicatedRecord() - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- ReplicatedRecord(K, V, VectorClockTimestamp, int, long) - Constructor for class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- ReplicatedRecordStore - Interface in com.hazelcast.replicatedmap.impl.record
-
This interface describes a common record store for replicated maps and their actual records
- ReplicateTxOperation - Class in com.hazelcast.transaction.impl
-
- ReplicateTxOperation() - Constructor for class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- ReplicateTxOperation(List<TransactionLog>, String, String, long, long) - Constructor for class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- REPLICATION - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- REPLICATION - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- ReplicationChannel - Interface in com.hazelcast.replicatedmap.impl
-
This interface represents a channel to send replication messages to
- ReplicationEventObject - Interface in com.hazelcast.wan
-
Marker interface for WAN replication messages
- ReplicationMessage<K,V> - Class in com.hazelcast.replicatedmap.impl.messages
-
This replication message is used for sending over a replication event to another node
- ReplicationMessage() - Constructor for class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- ReplicationMessage(String, K, V, VectorClockTimestamp, Member, int, long) - Constructor for class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- ReplicationPublisher<K,V> - Class in com.hazelcast.replicatedmap.impl.record
-
This class implements the actual replication logic for replicated map
- ReplicationSupportingService - Interface in com.hazelcast.spi
-
An interface that can be implemented by SPI services to give them the ability to listen to
Replication Events.
- REQUEST_MEMBERID_ASSIGNMENT - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- REQUEST_PARTITION_MAPPING - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- REQUEST_PARTITION_PROCESSED - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- REQUEST_PARTITION_REDUCING - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- REQUEST_PARTITION_RESULT - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- REQUEST_TYPE_CLUSTER_PROPERTIES - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_CLUSTER_STATE - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_CONSOLE_COMMAND - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_EVICT_LOCAL_MAP - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_EXECUTE_SCRIPT - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_GET_THREAD_DUMP - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_LOG_VERSION_MISMATCH - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_LOGS - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_MAP_CONFIG - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_MAP_ENTRY - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_MEMBER_CONFIG - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_MEMBER_SHUTDOWN - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_MEMBER_SYSTEM_PROPERTIES - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_RUN_GC - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- REQUEST_TYPE_SYSTEM_WARNINGS - Static variable in class com.hazelcast.management.request.ConsoleRequestConstants
-
- requestChunk() - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-
- RequestMemberIdAssignment - Class in com.hazelcast.mapreduce.impl.operation
-
This operation is used to do some kind of partitionId based processing on non partition based implementations
of
KeyValueSource
(not implementing
PartitionIdAware
)
which can happen for custom data sources like distributed filesystems that are up to the end user on how to
manage the distribution.
- RequestMemberIdAssignment() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-
- RequestMemberIdAssignment(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-
- RequestPartitionMapping - Class in com.hazelcast.mapreduce.impl.operation
-
This operation requests a new partition to process by the requester on the job owning node
- RequestPartitionMapping() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-
- RequestPartitionMapping(String, String) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-
- RequestPartitionProcessed - Class in com.hazelcast.mapreduce.impl.operation
-
This operation tells the job owner to mark a partition as cully processed
- RequestPartitionProcessed() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-
- RequestPartitionProcessed(String, String, int, JobPartitionState.State) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-
- RequestPartitionReducing - Class in com.hazelcast.mapreduce.impl.operation
-
This operation tells the job owner to start reducing phase of the defined partition on the first
occurrence of a full emitted chunk
- RequestPartitionReducing() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-
- RequestPartitionReducing(String, String, int) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-
- RequestPartitionResult - Class in com.hazelcast.mapreduce.impl.operation
-
This class is used to store the requested result of all kinds of processing operations.
By default it holds a basic result state and maybe the partitionId it was operated otherwise
it's value is defined as -1
- RequestPartitionResult() - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- RequestPartitionResult(RequestPartitionResult.ResultState, int) - Constructor for class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- RequestPartitionResult.ResultState - Enum in com.hazelcast.mapreduce.impl.operation
-
This enum is used to define the basic state of an operations result
- RES_100 - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- RES_200 - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- RES_204 - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- RES_400 - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- RES_403 - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- RES_404 - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- RES_500 - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- RES_503 - Static variable in class com.hazelcast.ascii.rest.HttpCommand
-
- reserveAdd(String, Data) - Method in class com.hazelcast.collection.CollectionContainer
-
- reserveAddBackup(long, String) - Method in class com.hazelcast.collection.CollectionContainer
-
- reserveRemove(long, Data, String) - Method in class com.hazelcast.collection.CollectionContainer
-
- reserveRemoveBackup(long, String) - Method in class com.hazelcast.collection.CollectionContainer
-
- reset() - Method in class com.hazelcast.cache.impl.CacheService
-
- reset() - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- reset() - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- reset() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- reset() - Method in interface com.hazelcast.cluster.Joiner
-
- reset() - Method in class com.hazelcast.collection.CollectionService
-
- reset() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- reset() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- reset() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- reset() - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- reset() - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- reset() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- reset() - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- reset() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- reset() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- reset() - Method in class com.hazelcast.map.impl.MapService
-
- reset() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- reset() - Method in interface com.hazelcast.map.impl.mapstore.MapDataStore
-
- reset() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- reset() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughStore
-
- reset() - Method in interface com.hazelcast.map.impl.RecordStore
-
- reset() - Method in interface com.hazelcast.map.impl.SizeEstimator
-
- reset() - Method in class com.hazelcast.mapreduce.Combiner
-
This method is called always after a chunk of data is retrieved.
- reset() - Method in class com.hazelcast.mapreduce.impl.ListKeyValueSource
-
- reset() - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- reset() - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- reset() - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- reset() - Method in class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- reset() - Method in class com.hazelcast.mapreduce.KeyValueSource
-
This method need to reset all internal state as it would be a new instance at all.
- reset() - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- reset() - Method in interface com.hazelcast.nio.BufferObjectDataInput
-
- reset() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- reset() - Method in class com.hazelcast.nio.serialization.DataAdapter
-
- reset() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- reset() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionMonitor
-
- reset() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- reset() - Static method in class com.hazelcast.query.impl.ReflectionHelper
-
- reset() - Method in class com.hazelcast.query.PagingPredicate
-
resets for reuse
- reset() - Method in class com.hazelcast.queue.impl.QueueService
-
- reset() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- reset() - Method in interface com.hazelcast.spi.ManagedService
-
reset this ManagedService back to initial state.
- reset() - Method in class com.hazelcast.topic.impl.TopicService
-
- reset() - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- resetPartitionState() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- response - Variable in class com.hazelcast.ascii.rest.HttpCommand
-
- response - Variable in class com.hazelcast.collection.CollectionOperation
-
- response - Variable in class com.hazelcast.concurrent.atomiclong.operations.AbstractAlterOperation
-
- response - Variable in class com.hazelcast.concurrent.atomicreference.operations.AbstractAlterOperation
-
- response - Variable in class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-
- response - Variable in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- response - Variable in class com.hazelcast.queue.impl.operations.QueueOperation
-
- Response - Class in com.hazelcast.spi.impl
-
- Response() - Constructor for class com.hazelcast.spi.impl.Response
-
- Response(long, boolean) - Constructor for class com.hazelcast.spi.impl.Response
-
- ResponseAlreadySentException - Exception in com.hazelcast.spi.exception
-
A HazelcastException indicating that there is some kind of system error causing a response to be send
multiple times for some operation.
- ResponseAlreadySentException() - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
-
- ResponseAlreadySentException(String) - Constructor for exception com.hazelcast.spi.exception.ResponseAlreadySentException
-
- ResponseHandler - Interface in com.hazelcast.spi
-
- ResponseHandlerFactory - Class in com.hazelcast.spi.impl
-
- ResponseQueueFactory - Class in com.hazelcast.util
-
Factory for creating response queues.
- REST_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- restart() - Method in interface com.hazelcast.nio.ConnectionManager
-
- restart() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- RestValue - Class in com.hazelcast.ascii.rest
-
- RestValue() - Constructor for class com.hazelcast.ascii.rest.RestValue
-
- RestValue(byte[], byte[]) - Constructor for class com.hazelcast.ascii.rest.RestValue
-
- result - Variable in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- result - Variable in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- resultDeserialized - Variable in class com.hazelcast.spi.InvocationBuilder
-
- resultUpdater - Variable in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- resumeMigration() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- resumeMigration() - Method in interface com.hazelcast.partition.InternalPartitionService
-
- retainAll(Collection<?>) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- retainAll(Collection<?>) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- rethrow(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
-
- rethrow(Throwable, Class<T>) - Static method in class com.hazelcast.util.ExceptionUtil
-
- RETHROW_EVERYTHING - Static variable in class com.hazelcast.util.FutureUtil
-
Just rethrows all exceptions
- RETHROW_EXECUTION_EXCEPTION - Static variable in class com.hazelcast.util.FutureUtil
-
- RETHROW_TRANSACTION_EXCEPTION - Static variable in class com.hazelcast.util.FutureUtil
-
Handler for transaction specific rethrown of exceptions.
- rethrowAllowedTypeFirst(Throwable, Class<T>) - Static method in class com.hazelcast.util.ExceptionUtil
-
This rethrow the exception providing an allowed Exception in first priority, even it is a Runtime exception
- rethrowAllowInterrupted(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
-
- RetryableException - Interface in com.hazelcast.spi.exception
-
Marker interface for exceptions to indicate that an operation can be retried.
- RetryableHazelcastException - Exception in com.hazelcast.spi.exception
-
A 'marker' exception that indicates that an operation can be retried.
- RetryableHazelcastException() - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-
- RetryableHazelcastException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-
- RetryableHazelcastException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-
- RetryableHazelcastException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableHazelcastException
-
- RetryableIOException - Exception in com.hazelcast.spi.exception
-
A
IOException
indicating that there was a IO failure, but it can be retried.
- RetryableIOException() - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-
- RetryableIOException(String) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-
- RetryableIOException(String, Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-
- RetryableIOException(Throwable) - Constructor for exception com.hazelcast.spi.exception.RetryableIOException
-
- RetryableRequest - Interface in com.hazelcast.client.impl.client
-
- retryWithDifferentReplicationNode(Member) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicationPublisher
-
- RETURN - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- RETURN_END - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- returnsResponse() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- returnsResponse() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- returnsResponse() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- returnsResponse() - Method in class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-
- returnsResponse() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- returnsResponse() - Method in class com.hazelcast.client.impl.operations.PostJoinClientOperation
-
- returnsResponse() - Method in class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-
- returnsResponse() - Method in class com.hazelcast.cluster.impl.operations.JoinCheckOperation
-
- returnsResponse() - Method in class com.hazelcast.cluster.impl.operations.MasterClaimOperation
-
- returnsResponse() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-
- returnsResponse() - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
-
- returnsResponse() - Method in class com.hazelcast.cluster.impl.operations.PrepareMergeOperation
-
- returnsResponse() - Method in class com.hazelcast.collection.CollectionOperation
-
- returnsResponse() - Method in class com.hazelcast.collection.CollectionTransactionRollbackOperation
-
- returnsResponse() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBaseOperation
-
- returnsResponse() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBaseOperation
-
- returnsResponse() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- returnsResponse() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- returnsResponse() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-
- returnsResponse() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
-
- returnsResponse() - Method in class com.hazelcast.management.operation.GetMapConfigOperation
-
- returnsResponse() - Method in class com.hazelcast.management.operation.ScriptExecutorOperation
-
- returnsResponse() - Method in class com.hazelcast.management.operation.ThreadDumpOperation
-
- returnsResponse() - Method in class com.hazelcast.management.operation.UpdateManagementCenterUrlOperation
-
- returnsResponse() - Method in class com.hazelcast.management.operation.UpdateMapConfigOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.AbstractMapOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.InvalidateNearCacheOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.NearCacheKeySetInvalidationOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- returnsResponse() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- returnsResponse() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-
- returnsResponse() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-
- returnsResponse() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessingOperation
-
- returnsResponse() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- returnsResponse() - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.AssignPartitions
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.HasOngoingMigration
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.MigrationRequestOperation
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- returnsResponse() - Method in class com.hazelcast.partition.impl.SafeStateCheckOperation
-
- returnsResponse() - Method in class com.hazelcast.queue.impl.operations.QueueOperation
-
- returnsResponse() - Method in class com.hazelcast.queue.impl.tx.QueueTransactionRollbackOperation
-
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.AbstractReplicatedMapOperation
-
- returnsResponse() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.AbstractOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.EventServiceImpl.DeregistrationOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.EventServiceImpl.PostJoinRegistrationOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.EventServiceImpl.RegistrationOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.EventServiceImpl.SendEventOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.IsStillExecutingOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl.DistributedObjectDestroyOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl.PostJoinProxyOperation
-
- returnsResponse() - Method in interface com.hazelcast.spi.impl.RemotePropagatable
-
- returnsResponse() - Method in class com.hazelcast.spi.impl.TraceableIsStillExecutingOperation
-
- returnsResponse() - Method in class com.hazelcast.spi.Operation
-
- returnsResponse() - Method in class com.hazelcast.topic.impl.PublishOperation
-
- returnsResponse() - Method in class com.hazelcast.transaction.impl.BeginTxBackupOperation
-
- returnsResponse() - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
-
- returnsResponse() - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- returnsResponse() - Method in class com.hazelcast.transaction.impl.RecoverTxnOperation
-
- returnsResponse() - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- returnsResponse() - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- returnValue - Variable in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-
- returnWithDeadline(Collection<Future>, long, TimeUnit) - Static method in class com.hazelcast.util.FutureUtil
-
- returnWithDeadline(Collection<Future>, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
-
- returnWithDeadline(Collection<Future>, long, TimeUnit, long, TimeUnit) - Static method in class com.hazelcast.util.FutureUtil
-
- returnWithDeadline(Collection<Future>, long, TimeUnit, long, TimeUnit, FutureUtil.ExceptionHandler) - Static method in class com.hazelcast.util.FutureUtil
-
- rewind() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- rollback(NodeEngine) - Method in class com.hazelcast.collection.txn.CollectionTransactionLog
-
- rollback(NodeEngine) - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
-
- rollback(NodeEngine) - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- rollback(NodeEngine) - Method in class com.hazelcast.queue.impl.tx.QueueTransactionLog
-
- ROLLBACK - Static variable in class com.hazelcast.transaction.client.ClientTxnPortableHook
-
- rollback() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- rollback(NodeEngine) - Method in interface com.hazelcast.transaction.impl.TransactionLog
-
- rollback(Xid) - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- rollbackAdd(long) - Method in class com.hazelcast.collection.CollectionContainer
-
- rollbackAddBackup(long) - Method in class com.hazelcast.collection.CollectionContainer
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.collection.CollectionService
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.map.impl.MapService
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- rollbackMigration(PartitionMigrationEvent) - Method in class com.hazelcast.queue.impl.QueueService
-
- rollbackMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
-
- rollbackRemove(long) - Method in class com.hazelcast.collection.CollectionContainer
-
- rollbackRemoveBackup(long) - Method in class com.hazelcast.collection.CollectionContainer
-
- rollbackTransaction(String) - Method in class com.hazelcast.collection.CollectionContainer
-
- rollbackTransaction(String) - Method in class com.hazelcast.collection.CollectionService
-
- rollbackTransaction(String) - Method in class com.hazelcast.map.impl.MapService
-
- rollbackTransaction(String) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- rollbackTransaction(String) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- rollbackTransaction(String) - Method in class com.hazelcast.queue.impl.QueueService
-
- rollbackTransaction(String) - Method in interface com.hazelcast.spi.TransactionalService
-
- rollbackTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
-
Rollback of the current transaction.
- RollbackTransactionRequest - Class in com.hazelcast.transaction.client
-
- RollbackTransactionRequest() - Constructor for class com.hazelcast.transaction.client.RollbackTransactionRequest
-
- RollbackTxBackupOperation - Class in com.hazelcast.transaction.impl
-
- RollbackTxBackupOperation() - Constructor for class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- RollbackTxBackupOperation(String) - Constructor for class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- RUBY - Static variable in class com.hazelcast.client.ClientTypes
-
RUBY client protocol id
- run() - Method in class com.hazelcast.cache.impl.operation.CacheBackupEntryProcessorOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheClearBackupOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheContainsKeyOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheCreateConfigOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheDestroyOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetConfigOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheGetOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheKeyIteratorOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheListenerRegistrationOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheManagementConfigOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutAllBackupOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutBackupOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllBackupOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveBackupOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheReplicationOperation
-
- run() - Method in class com.hazelcast.cache.impl.operation.CacheSizeOperation
-
- run() - Method in class com.hazelcast.client.impl.ClientHeartbeatMonitor
-
- run() - Method in class com.hazelcast.client.impl.operations.ClientDisconnectionOperation
-
- run() - Method in class com.hazelcast.client.impl.operations.ClientReAuthOperation
-
- run() - Method in class com.hazelcast.client.impl.operations.PostJoinClientOperation
-
- run() - Method in class com.hazelcast.cluster.impl.MulticastService
-
- run() - Method in class com.hazelcast.cluster.impl.operations.AuthenticationFailureOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.AuthorizationOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.ConfigMismatchOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.FinalizeJoinOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.GroupMismatchOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.HeartbeatOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.JoinCheckOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.JoinRequestOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.MasterClaimOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.MasterConfirmationOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.MemberAttributeChangedOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.MemberRemoveOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.MergeClustersOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.PrepareMergeOperation
-
- run() - Method in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-
- run() - Method in class com.hazelcast.collection.CollectionAddAllBackupOperation
-
- run() - Method in class com.hazelcast.collection.CollectionAddAllOperation
-
- run() - Method in class com.hazelcast.collection.CollectionAddBackupOperation
-
- run() - Method in class com.hazelcast.collection.CollectionAddOperation
-
- run() - Method in class com.hazelcast.collection.CollectionClearBackupOperation
-
- run() - Method in class com.hazelcast.collection.CollectionClearOperation
-
- run() - Method in class com.hazelcast.collection.CollectionCompareAndRemoveOperation
-
- run() - Method in class com.hazelcast.collection.CollectionContainsOperation
-
- run() - Method in class com.hazelcast.collection.CollectionGetAllOperation
-
- run() - Method in class com.hazelcast.collection.CollectionIsEmptyOperation
-
- run() - Method in class com.hazelcast.collection.CollectionRemoveBackupOperation
-
- run() - Method in class com.hazelcast.collection.CollectionRemoveOperation
-
- run() - Method in class com.hazelcast.collection.CollectionReplicationOperation
-
- run() - Method in class com.hazelcast.collection.CollectionSizeOperation
-
- run() - Method in class com.hazelcast.collection.CollectionTransactionRollbackOperation
-
- run() - Method in class com.hazelcast.collection.list.ListAddAllOperation
-
- run() - Method in class com.hazelcast.collection.list.ListAddOperation
-
- run() - Method in class com.hazelcast.collection.list.ListGetOperation
-
- run() - Method in class com.hazelcast.collection.list.ListIndexOfOperation
-
- run() - Method in class com.hazelcast.collection.list.ListRemoveOperation
-
- run() - Method in class com.hazelcast.collection.list.ListSetBackupOperation
-
- run() - Method in class com.hazelcast.collection.list.ListSetOperation
-
- run() - Method in class com.hazelcast.collection.list.ListSubOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionPrepareBackupOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionPrepareOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionReserveAddOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionReserveRemoveOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionRollbackBackupOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionRollbackOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionTxnAddBackupOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionTxnAddOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveBackupOperation
-
- run() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddAndGetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AddBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterAndGetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AlterOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.ApplyOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongReplicationOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.CompareAndSetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAddOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndAlterOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetAndSetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.GetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterAndGetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AlterOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.ApplyOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceReplicationOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.ContainsOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndAlterOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetAndSetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.GetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.IsNullOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownLatchReplicationOperation
-
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.GetCountOperation
-
- run() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.AwaitBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.GetLockCountOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.GetRemainingLeaseTimeOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.IsLockedOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.LockBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.LockReplicationOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockIfLeaseExpiredOperation
-
- run() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.AvailableOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.DeadMemberBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.InitBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseBackupOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- run() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-
- run() - Method in class com.hazelcast.executor.impl.operations.CancellationOperation
-
- run() - Method in class com.hazelcast.executor.impl.operations.ShutdownOperation
-
- run() - Method in class com.hazelcast.instance.Node.NodeShutdownHookThread
-
- run() - Method in class com.hazelcast.management.operation.GetMapConfigOperation
-
- run() - Method in class com.hazelcast.management.operation.ScriptExecutorOperation
-
- run() - Method in class com.hazelcast.management.operation.ThreadDumpOperation
-
- run() - Method in class com.hazelcast.management.operation.UpdateManagementCenterUrlOperation
-
- run() - Method in class com.hazelcast.management.operation.UpdateMapConfigOperation
-
- run() - Method in class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
-
- run() - Method in class com.hazelcast.map.impl.operation.AddIndexOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.ClearBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.ContainsValueOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.EvictAllBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.GetOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.InvalidateNearCacheOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.LoadAllOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MapEntrySetOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MapFlushOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MapIsEmptyOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MapKeySetOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MapReplicationOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MapSizeOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MapValuesOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.NearCacheKeySetInvalidationOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PartitionCheckIfLoadedOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PostJoinMapOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PutOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.QueryOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.QueryPartitionOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.RemoveBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.SetOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- run() - Method in class com.hazelcast.map.impl.operation.WanOriginatedDeleteOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
-
- run() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.CancelJobSupervisorOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.FireNotificationOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.GetResultOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.KeysAssignmentOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.KeyValueJobOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.NotifyRemoteExceptionOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.PostPonePartitionProcessing
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.ProcessStatsUpdateOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.RequestMemberIdAssignment
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionMapping
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionProcessed
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionReducing
-
- run() - Method in class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- run() - Method in class com.hazelcast.mapreduce.impl.task.ReducerTask
-
- run() - Method in class com.hazelcast.multimap.impl.operations.ClearBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.EntrySetOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.KeySetOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.MultiMapMigrationOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.PutBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.RemoveBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.SizeOperation
-
- run() - Method in class com.hazelcast.multimap.impl.operations.ValuesOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
-
- run() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-
- run() - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- run() - Method in class com.hazelcast.nio.tcp.SocketAcceptor
-
- run() - Method in class com.hazelcast.nio.tcp.SocketConnector
-
- run() - Method in class com.hazelcast.nio.tcp.WriteHandler
-
- run() - Method in class com.hazelcast.partition.impl.AssignPartitions
-
- run() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-
- run() - Method in class com.hazelcast.partition.impl.HasOngoingMigration
-
- run() - Method in class com.hazelcast.partition.impl.IsReplicaVersionSync
-
- run() - Method in class com.hazelcast.partition.impl.MigrationOperation
-
- run() - Method in class com.hazelcast.partition.impl.MigrationRequestOperation
-
- run() - Method in class com.hazelcast.partition.impl.PartitionStateOperation
-
- run() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- run() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- run() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- run() - Method in class com.hazelcast.partition.impl.SafeStateCheckOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.AddAllBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.CheckAndEvictOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.ClearBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.ClearOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.ContainsOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.DrainBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.DrainOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.IsEmptyOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.IteratorOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.OfferBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.PeekOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.PollBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.QueueReplicationOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.RemainingCapacityOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.RemoveBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
-
- run() - Method in class com.hazelcast.queue.impl.operations.SizeOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.QueueTransactionRollbackOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnOfferBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnPeekOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnPollBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnPrepareBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnPrepareOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnReservePollBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnRollbackBackupOperation
-
- run() - Method in class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapClearOperation
-
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapInitChunkOperation
-
- run() - Method in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapPostJoinOperation
-
- run() - Method in class com.hazelcast.spi.impl.EventServiceImpl.DeregistrationOperation
-
- run() - Method in class com.hazelcast.spi.impl.EventServiceImpl.PostJoinRegistrationOperation
-
- run() - Method in class com.hazelcast.spi.impl.EventServiceImpl.RegistrationOperation
-
- run() - Method in class com.hazelcast.spi.impl.EventServiceImpl.SendEventOperation
-
- run() - Method in class com.hazelcast.spi.impl.IsStillExecutingOperation
-
- run() - Method in class com.hazelcast.spi.impl.PartitionIteratingOperation
-
- run() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl.DistributedObjectDestroyOperation
-
- run() - Method in class com.hazelcast.spi.impl.ProxyServiceImpl.PostJoinProxyOperation
-
- run() - Method in class com.hazelcast.spi.impl.TraceableIsStillExecutingOperation
-
- run() - Method in class com.hazelcast.spi.Operation
-
- run() - Method in class com.hazelcast.topic.impl.PublishOperation
-
- run() - Method in class com.hazelcast.transaction.impl.BeginTxBackupOperation
-
- run() - Method in class com.hazelcast.transaction.impl.BroadcastTxRollbackOperation
-
- run() - Method in class com.hazelcast.transaction.impl.PurgeTxBackupOperation
-
- run() - Method in class com.hazelcast.transaction.impl.RecoverTxnOperation
-
- run() - Method in class com.hazelcast.transaction.impl.ReplicateTxOperation
-
- run() - Method in class com.hazelcast.transaction.impl.RollbackTxBackupOperation
-
- run() - Method in class com.hazelcast.util.executor.CompletableFutureTask
-
- run() - Method in class com.hazelcast.util.executor.HazelcastManagedThread
-
Manages the thread lifecycle and can be overridden to customize if needed.
- run() - Method in class com.hazelcast.util.HealthMonitor
-
- run() - Method in class com.hazelcast.wan.impl.WanNoDelayReplication
-
- RunGcRequest - Class in com.hazelcast.management.request
-
Request for invoking Garbage Collection on the node.
- RunGcRequest() - Constructor for class com.hazelcast.management.request.RunGcRequest
-
- RunnableAdapter<V> - Class in com.hazelcast.executor.impl
-
- RunnableAdapter() - Constructor for class com.hazelcast.executor.impl.RunnableAdapter
-
- RunnableAdapter(Runnable) - Constructor for class com.hazelcast.executor.impl.RunnableAdapter
-
- runOperationOnCallingThread(Operation) - Method in interface com.hazelcast.spi.OperationService
-
Runs operation in calling thread.
- runParallel(Collection<Integer>) - Method in class com.hazelcast.map.impl.operation.QueryOperation
-
- runParallelForPaging(Collection<Integer>) - Method in class com.hazelcast.map.impl.operation.QueryOperation
-
- RuntimeInterruptedException - Exception in com.hazelcast.core
-
- RuntimeInterruptedException() - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
-
- RuntimeInterruptedException(String) - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
-
- runUnderLifecycleLock(Runnable) - Method in class com.hazelcast.instance.LifecycleServiceImpl
-
- SafeStateCheckOperation - Class in com.hazelcast.partition.impl
-
Checks whether a node is safe or not.
- SafeStateCheckOperation() - Constructor for class com.hazelcast.partition.impl.SafeStateCheckOperation
-
- saveEntryIndex(QueryableEntry) - Method in interface com.hazelcast.query.impl.Index
-
- saveEntryIndex(QueryableEntry) - Method in class com.hazelcast.query.impl.IndexImpl
-
- saveEntryIndex(QueryableEntry) - Method in class com.hazelcast.query.impl.IndexService
-
- schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-
- schedule(String, Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-
- schedule(Runnable, long, TimeUnit) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- schedule(String, Runnable, long, TimeUnit) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- schedule(long, K, V) - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
Schedules (or reschedules) the execution of given entry.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-
- scheduleAtFixedRate(String, Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- scheduleAtFixedRate(String, Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- SCHEDULED_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the scheduled executor.
- ScheduledEntry<K,V> - Class in com.hazelcast.util.scheduler
-
Entry wrapper with schedule time information to be used in SecondsBasedEntryTaskScheduler.
- ScheduledEntry(K, V, long, int) - Constructor for class com.hazelcast.util.scheduler.ScheduledEntry
-
- ScheduledEntry(K, V, long, int, long) - Constructor for class com.hazelcast.util.scheduler.ScheduledEntry
-
- ScheduledEntryProcessor<K,V> - Interface in com.hazelcast.util.scheduler
-
- scheduleEviction(ObjectNamespace, Data, int, long) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- scheduleEviction(String, long) - Method in class com.hazelcast.queue.impl.QueueService
-
- ScheduleType - Enum in com.hazelcast.util.scheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-
- scheduleWithFixedDelay(String, Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- scheduleWithFixedDelay(String, Runnable, long, long, TimeUnit) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- ScriptEngineManagerContext - Class in com.hazelcast.management
-
- ScriptExecutorOperation - Class in com.hazelcast.management.operation
-
Operation to execute script on the node.
- ScriptExecutorOperation() - Constructor for class com.hazelcast.management.operation.ScriptExecutorOperation
-
- ScriptExecutorOperation(String, String, Map<String, Object>) - Constructor for class com.hazelcast.management.operation.ScriptExecutorOperation
-
- searchForOtherClusters() - Method in class com.hazelcast.cluster.impl.MulticastJoiner
-
- searchForOtherClusters() - Method in class com.hazelcast.cluster.impl.TcpIpJoiner
-
- searchForOtherClusters() - Method in interface com.hazelcast.cluster.Joiner
-
- second - Variable in class com.hazelcast.query.Predicates.LikePredicate
-
- SecureCallable<V> - Interface in com.hazelcast.security
-
A secure callable that runs in a sandbox.
- SecureRequest - Interface in com.hazelcast.client.impl.client
-
- SecurityConfig - Class in com.hazelcast.config
-
Contains configuration for Security
- SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
-
- securityContext - Variable in class com.hazelcast.instance.Node
-
- SecurityContext - Interface in com.hazelcast.security
-
- SecurityInterceptor - Interface in com.hazelcast.security
-
This interface allows to intercept requests which produced by an API call like map.put, queue.offer ...
- SecurityInterceptorConfig - Class in com.hazelcast.config
-
- SecurityInterceptorConfig() - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-
- SecurityInterceptorConfig(String) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-
- SecurityInterceptorConfig(SecurityInterceptor) - Constructor for class com.hazelcast.config.SecurityInterceptorConfig
-
- segments - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- select(Member) - Method in interface com.hazelcast.core.MemberSelector
-
Decides for the given member to be part of an operation or not.
- SelectionHandler - Interface in com.hazelcast.nio.tcp
-
- selector - Variable in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- selectorQueue - Variable in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- SEMAPHORE_DEAD_MEMBER_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- SEMAPHORE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- SEMAPHORE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- SEMAPHORE_REPLICATION_OPERATION - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- SemaphoreBackupAwareOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- SemaphoreBackupAwareOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-
- SemaphoreBackupAwareOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupAwareOperation
-
- SemaphoreBackupOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- SemaphoreBackupOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
-
- SemaphoreBackupOperation(String, int, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreBackupOperation
-
- SemaphoreConfig - Class in com.hazelcast.config
-
- SemaphoreConfig() - Constructor for class com.hazelcast.config.SemaphoreConfig
-
- SemaphoreConfig(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfig
-
Creates a SemaphoreConfig by cloning another one.
- SemaphoreConfigReadOnly - Class in com.hazelcast.config
-
Contains configuration for Semaphore(read only)
- SemaphoreConfigReadOnly(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfigReadOnly
-
- SemaphoreDataSerializerHook - Class in com.hazelcast.concurrent.semaphore
-
- SemaphoreDataSerializerHook() - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreDataSerializerHook
-
- SemaphoreDeadMemberOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- SemaphoreDeadMemberOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- SemaphoreDeadMemberOperation(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- SemaphoreMBean - Class in com.hazelcast.jmx
-
- SemaphoreMBean(ISemaphore, ManagementService) - Constructor for class com.hazelcast.jmx.SemaphoreMBean
-
- SemaphoreOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- SemaphoreOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-
- SemaphoreOperation(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreOperation
-
- SemaphorePermission - Class in com.hazelcast.security.permission
-
- SemaphorePermission(String, String...) - Constructor for class com.hazelcast.security.permission.SemaphorePermission
-
- SemaphorePortableHook - Class in com.hazelcast.concurrent.semaphore.client
-
- SemaphorePortableHook() - Constructor for class com.hazelcast.concurrent.semaphore.client.SemaphorePortableHook
-
- SemaphoreProxy - Class in com.hazelcast.concurrent.semaphore
-
- SemaphoreProxy(String, SemaphoreService, NodeEngine) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- SemaphoreReplicationOperation - Class in com.hazelcast.concurrent.semaphore.operations
-
- SemaphoreReplicationOperation() - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-
- SemaphoreReplicationOperation(Map<String, Permit>) - Constructor for class com.hazelcast.concurrent.semaphore.operations.SemaphoreReplicationOperation
-
- SemaphoreRequest - Class in com.hazelcast.concurrent.semaphore.client
-
- SemaphoreRequest() - Constructor for class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- SemaphoreRequest(String, int) - Constructor for class com.hazelcast.concurrent.semaphore.client.SemaphoreRequest
-
- SemaphoreService - Class in com.hazelcast.concurrent.semaphore
-
- SemaphoreService(NodeEngine) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- SemaphoreWaitNotifyKey - Class in com.hazelcast.concurrent.semaphore
-
- SemaphoreWaitNotifyKey(String, String) - Constructor for class com.hazelcast.concurrent.semaphore.SemaphoreWaitNotifyKey
-
- send(JoinMessage) - Method in class com.hazelcast.cluster.impl.MulticastService
-
- send(Address, Operation) - Method in class com.hazelcast.management.ManagementCenterService
-
- send(Packet, Connection) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- send(Packet, Address) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
Retries sending packet maximum 5 times until connection to target becomes available.
- send(Operation, Address) - Method in interface com.hazelcast.spi.OperationService
-
Executes an operation remotely.
- send(Response, Address) - Method in interface com.hazelcast.spi.OperationService
-
Sends a response to a remote machine.
- send200() - Method in class com.hazelcast.ascii.rest.HttpCommand
-
- send204() - Method in class com.hazelcast.ascii.rest.HttpCommand
-
- send400() - Method in class com.hazelcast.ascii.rest.HttpCommand
-
- SEND_STATS - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- sendEvent(Object, int) - Method in interface com.hazelcast.client.ClientEndpoint
-
- sendEvent(Object, int) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- sendJoinRequest(Address, boolean) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- sendMasterQuestion(Address) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- sendNotification(Notification) - Method in class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- sendNotification(Address, MapReduceNotification) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- sendResponse(TextCommand) - Method in interface com.hazelcast.ascii.TextCommandService
-
- sendResponse(TextCommand) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- sendResponse(Object, int) - Method in interface com.hazelcast.client.ClientEndpoint
-
- sendResponse(Object, int) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- sendResponse(ClientEndpointImpl, Object, int, boolean, boolean) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- sendResponse(TextCommand) - Method in class com.hazelcast.nio.ascii.SocketTextReader
-
- sendResponse(Object) - Method in interface com.hazelcast.spi.ResponseHandler
-
- sendShutdownMessage() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- SerializableClientEndPoint - Class in com.hazelcast.management
-
- SerializableClientEndPoint() - Constructor for class com.hazelcast.management.SerializableClientEndPoint
-
- SerializableClientEndPoint(Client) - Constructor for class com.hazelcast.management.SerializableClientEndPoint
-
- SerializableCollection - Class in com.hazelcast.spi.impl
-
- SerializableCollection() - Constructor for class com.hazelcast.spi.impl.SerializableCollection
-
- SerializableCollection(Collection<Data>) - Constructor for class com.hazelcast.spi.impl.SerializableCollection
-
- SerializableCollection(Data...) - Constructor for class com.hazelcast.spi.impl.SerializableCollection
-
- SerializableConnectionManagerBean - Class in com.hazelcast.management
-
- SerializableConnectionManagerBean() - Constructor for class com.hazelcast.management.SerializableConnectionManagerBean
-
- SerializableConnectionManagerBean(ConnectionManager) - Constructor for class com.hazelcast.management.SerializableConnectionManagerBean
-
- SerializableEventServiceBean - Class in com.hazelcast.management
-
- SerializableEventServiceBean() - Constructor for class com.hazelcast.management.SerializableEventServiceBean
-
- SerializableEventServiceBean(EventService) - Constructor for class com.hazelcast.management.SerializableEventServiceBean
-
- SerializableManagedExecutorBean - Class in com.hazelcast.management
-
- SerializableManagedExecutorBean() - Constructor for class com.hazelcast.management.SerializableManagedExecutorBean
-
- SerializableManagedExecutorBean(ManagedExecutorService) - Constructor for class com.hazelcast.management.SerializableManagedExecutorBean
-
- SerializableMXBeans - Class in com.hazelcast.management
-
Holder class for serializable service beans.
- SerializableMXBeans() - Constructor for class com.hazelcast.management.SerializableMXBeans
-
- SerializableOperationServiceBean - Class in com.hazelcast.management
-
- SerializableOperationServiceBean() - Constructor for class com.hazelcast.management.SerializableOperationServiceBean
-
- SerializableOperationServiceBean(OperationService) - Constructor for class com.hazelcast.management.SerializableOperationServiceBean
-
- SerializablePartitionServiceBean - Class in com.hazelcast.management
-
- SerializablePartitionServiceBean() - Constructor for class com.hazelcast.management.SerializablePartitionServiceBean
-
- SerializablePartitionServiceBean(InternalPartitionService, HazelcastInstanceImpl) - Constructor for class com.hazelcast.management.SerializablePartitionServiceBean
-
- SerializableProxyServiceBean - Class in com.hazelcast.management
-
- SerializableProxyServiceBean() - Constructor for class com.hazelcast.management.SerializableProxyServiceBean
-
- SerializableProxyServiceBean(ProxyService) - Constructor for class com.hazelcast.management.SerializableProxyServiceBean
-
- SerializableXID - Class in com.hazelcast.transaction.impl
-
- SerializableXID() - Constructor for class com.hazelcast.transaction.impl.SerializableXID
-
- SerializableXID(int, byte[], byte[]) - Constructor for class com.hazelcast.transaction.impl.SerializableXID
-
- SerializationConfig - Class in com.hazelcast.config
-
- SerializationConfig() - Constructor for class com.hazelcast.config.SerializationConfig
-
- SerializationConstants - Class in com.hazelcast.nio.serialization
-
- serializationService - Variable in class com.hazelcast.cache.impl.CacheRecordStore
-
- serializationService - Variable in class com.hazelcast.cache.impl.record.CacheRecordFactory
-
- serializationService - Variable in class com.hazelcast.client.impl.client.ClientRequest
-
- SerializationService - Interface in com.hazelcast.nio.serialization
-
- SerializationServiceBuilder - Interface in com.hazelcast.nio.serialization
-
- SerializationServiceImpl - Class in com.hazelcast.nio.serialization
-
- Serializer - Interface in com.hazelcast.nio.serialization
-
- SerializerConfig - Class in com.hazelcast.config
-
Contains the serialization configuration for a particular class.
- SerializerConfig() - Constructor for class com.hazelcast.config.SerializerConfig
-
- serializerFor(Class) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- serializerFor(int) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- SerializerHook<T> - Interface in com.hazelcast.nio.serialization
-
- SERVER_ERROR - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- service - Variable in class com.hazelcast.client.impl.client.ClientRequest
-
- SERVICE_NAME - Static variable in interface com.hazelcast.cache.impl.ICacheService
-
Service name
- SERVICE_NAME - Static variable in class com.hazelcast.client.impl.ClientEngineImpl
-
Service Name of clientEngine to be used in requests
- SERVICE_NAME - Static variable in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- SERVICE_NAME - Static variable in class com.hazelcast.collection.list.ListService
-
- SERVICE_NAME - Static variable in class com.hazelcast.collection.set.SetService
-
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
The name of this service.s
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
The name of the AtomicReferenceService.
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
The service name of this CountDownLatchService.
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- SERVICE_NAME - Static variable in interface com.hazelcast.concurrent.lock.LockService
-
- SERVICE_NAME - Static variable in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- SERVICE_NAME - Static variable in class com.hazelcast.executor.impl.DistributedExecutorService
-
- SERVICE_NAME - Static variable in class com.hazelcast.map.impl.MapService
-
Service name of map service used
to register ServiceManager.registerService(java.lang.String, java.lang.Object)
- SERVICE_NAME - Static variable in class com.hazelcast.mapreduce.impl.MapReduceService
-
The service name to retrieve an instance of the MapReduceService
- SERVICE_NAME - Static variable in class com.hazelcast.multimap.impl.MultiMapService
-
- SERVICE_NAME - Static variable in interface com.hazelcast.partition.InternalPartitionService
-
- SERVICE_NAME - Static variable in class com.hazelcast.queue.impl.QueueService
-
Service name.
- SERVICE_NAME - Static variable in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
Public constant for the internal service name of the ReplicatedMapService
- SERVICE_NAME - Static variable in class com.hazelcast.topic.impl.TopicService
-
- SERVICE_NAME - Static variable in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- SERVICE_NAME - Static variable in interface com.hazelcast.wan.WanReplicationService
-
The service identifier
- ServiceConfig - Class in com.hazelcast.config
-
- ServiceConfig() - Constructor for class com.hazelcast.config.ServiceConfig
-
- ServiceConfigurationParser<T> - Interface in com.hazelcast.spi
-
A hook into the parsing system.
- ServiceInfo - Class in com.hazelcast.spi
-
Contains the name of the service and the actual service.
- ServiceInfo(String, Object) - Constructor for class com.hazelcast.spi.ServiceInfo
-
- ServiceLoader - Class in com.hazelcast.util
-
Support class for loading Hazelcast services and hooks based on the Java ServiceLoader specification
but changed in the fact of classloaders to test for given services to work in multi classloader
environments like application or OSGi servers
- serviceName - Variable in class com.hazelcast.collection.client.CollectionRequest
-
- serviceName() - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- serviceName() - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- serviceName - Variable in class com.hazelcast.spi.InvocationBuilder
-
- ServicesConfig - Class in com.hazelcast.config
-
- ServicesConfig() - Constructor for class com.hazelcast.config.ServicesConfig
-
- set(int, long, Data) - Method in class com.hazelcast.collection.list.ListContainer
-
- set(int, E) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- set(long) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- set(long) - Method in class com.hazelcast.concurrent.atomiclong.LongWrapper
-
- SET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- set(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- set(Data) - Method in class com.hazelcast.concurrent.atomicreference.ReferenceWrapper
-
- set(K, V) - Method in interface com.hazelcast.core.BaseMap
-
Associates the specified value with the specified key in this map
If the map previously contained a mapping for
the key, the old value is replaced by the specified value.
- set(long) - Method in interface com.hazelcast.core.IAtomicLong
-
Atomically sets the given value.
- set(E) - Method in interface com.hazelcast.core.IAtomicReference
-
Atomically sets the given value.
- set(K, V) - Method in interface com.hazelcast.core.IMap
-
Puts an entry into this map.
- set(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
-
Puts an entry into this map with a given ttl (time to live) value.
- set(K, V) - Method in interface com.hazelcast.core.TransactionalMap
-
- set(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
-
- set(Data, Object, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- SET - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- set(K, V) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- set(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- set(Data, Object, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- set(Object, Object) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- SET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- SET - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- SET_ADAPTER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- SET_AND_GET - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- SET_BACKUP - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- SET_BACKUP - Static variable in class com.hazelcast.concurrent.atomicreference.AtomicReferenceDataSerializerHook
-
- SET_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- SET_COUNT_OPERATION - Static variable in class com.hazelcast.concurrent.countdownlatch.CountDownLatchDataSerializerHook
-
- SET_OPERATION - Static variable in class com.hazelcast.concurrent.atomiclong.AtomicLongDataSerializerHook
-
- SET_REPLICATION - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- setAccessKey(String) - Method in class com.hazelcast.config.AwsConfig
-
Sets the access key to access AWS.
- setActions(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
-
- setActive(boolean) - Method in class com.hazelcast.instance.Node
-
- setActiveConnectionCount(int) - Method in class com.hazelcast.management.SerializableConnectionManagerBean
-
- setActivePartitionCount(int) - Method in class com.hazelcast.management.SerializablePartitionServiceBean
-
- SetAdapter<E> - Class in com.hazelcast.mapreduce.aggregation.impl
-
A simple adapter class to serialize values of a
Set
using
Hazelcast serialization support.
- SetAdapter() - Constructor for class com.hazelcast.mapreduce.aggregation.impl.SetAdapter
-
- setAddress(String) - Method in class com.hazelcast.management.SerializableClientEndPoint
-
- setAddress(String) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- setAddress(String[]) - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- setAlgorithm(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- setAllocatorType(NativeMemoryConfig.MemoryAllocatorType) - Method in class com.hazelcast.config.NativeMemoryConfig
-
- setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Unsafe is not public api of java.
- setAllowUnsafe(boolean) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setAllowUnsafe(boolean) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setAndGet(E) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- setAndGet(E) - Method in interface com.hazelcast.core.IAtomicReference
-
Deprecated.
will be removed from Hazelcast 3.4 since it doesn't really serve a purpose.
- SetAndGetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- SetAndGetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- SetAndGetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetAndGetOperation
-
- setAsAsync() - Method in class com.hazelcast.map.impl.client.MapGetRequest
-
- setAsAsync() - Method in class com.hazelcast.map.impl.client.MapPutRequest
-
- setAsAsync() - Method in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- setAsMaster() - Method in class com.hazelcast.instance.Node
-
- setAsSubmitToKey() - Method in class com.hazelcast.map.impl.client.MapExecuteOnKeyRequest
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
-
Number of asynchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.ListConfigReadOnly
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfig
-
Number of asynchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfig
-
Sets the number of asynchronous backups.
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
-
- setAsyncBackupCount(int) - Method in class com.hazelcast.config.SetConfigReadOnly
-
- setAsyncFillup(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- setAttribute(String) - Method in class com.hazelcast.config.MapIndexConfig
-
Sets the attribute that is going to be indexed.
- setAttribute(String) - Method in class com.hazelcast.config.MapIndexConfigReadOnly
-
- setAttribute(Attribute) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- setAttribute(String) - Method in class com.hazelcast.query.PredicateBuilder
-
- setAttributes(Map<String, Object>) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setAttributes(Map<String, Object>) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setAttributes(AttributeList) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- setAveAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.JoinConfig
-
- setBackup(long, long, Data) - Method in class com.hazelcast.collection.list.ListContainer
-
- setBackupCount(int) - Method in class com.hazelcast.config.CacheConfig
-
Number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setBackupCount(int) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setBackupCount(int) - Method in class com.hazelcast.config.CollectionConfig
-
- setBackupCount(int) - Method in class com.hazelcast.config.ListConfigReadOnly
-
- setBackupCount(int) - Method in class com.hazelcast.config.MapConfig
-
Number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
-
- setBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setBackupCount(int) - Method in class com.hazelcast.config.QueueConfig
-
- setBackupCount(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- setBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfig
-
Sets the number of synchronous backups.
- setBackupCount(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
-
- setBackupCount(int) - Method in class com.hazelcast.config.SetConfigReadOnly
-
- setBackupCount(int) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- setBackupCount(int) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setBackupEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- setBackupEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setBackupEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setBackupItemCount(int) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- SetBackupOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- SetBackupOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-
- SetBackupOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetBackupOperation
-
- SetBackupOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- SetBackupOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-
- SetBackupOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetBackupOperation
-
- setBeans(SerializableMXBeans) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfig
-
- setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setBindings(Bindings, int) - Method in class com.hazelcast.osgi.OSGiScriptEngine
-
- setBindings(Bindings) - Method in class com.hazelcast.osgi.OSGiScriptEngineManager
-
Follows the same behavior of @link javax.script.ScriptEngineManager#setBindings(Bindings)
This means that the same bindings are applied to all the underlying managers.
- setBit(byte, int) - Static method in class com.hazelcast.nio.Bits
-
Sets n-th bit of the byte value
- setBit(int, int) - Static method in class com.hazelcast.nio.Bits
-
Sets n-th bit of the integer value
- setBooleanAttribute(String, boolean) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setBooleanAttribute(String, boolean) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setBooleanAttribute(String, boolean) - Method in interface com.hazelcast.core.Member
-
Defines a key-value pair boolean attribute for this member available
to other cluster members.
- setBooleanAttribute(String, boolean) - Method in class com.hazelcast.instance.MemberImpl
-
- setByteAttribute(String, byte) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setByteAttribute(String, byte) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setByteAttribute(String, byte) - Method in interface com.hazelcast.core.Member
-
Defines a key-value pair byte attribute for this member available
to other cluster members.
- setByteAttribute(String, byte) - Method in class com.hazelcast.instance.MemberImpl
-
- setByteOrder(ByteOrder) - Method in class com.hazelcast.config.SerializationConfig
-
Not that configuring use native byte order as enabled will override the byte order set by this method.
- setByteOrder(ByteOrder) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setByteOrder(ByteOrder) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setBytes(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setCacheConfigs(Map<String, CacheSimpleConfig>) - Method in class com.hazelcast.config.Config
-
- setCachedValue(Object) - Method in interface com.hazelcast.map.impl.record.Record
-
- setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- setCacheEntryEventFilterFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-
- setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- setCacheEntryListenerFactory(String) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-
- setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setCacheEntryListeners(List<CacheSimpleEntryListenerConfig>) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setCacheLoaderFactory(Factory<? extends CacheLoader<K, V>>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the CacheLoader
factory.
- setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setCacheLoaderFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
-
- setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setCacheWriterFactory(Factory<? extends CacheWriter<? super K, ? super V>>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the CacheWriter
factory.
- setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setCacheWriterFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setCallback(Callback<Object>) - Method in class com.hazelcast.spi.InvocationBuilder
-
- setCallerAddress(Operation, Address) - Static method in class com.hazelcast.spi.OperationAccessor
-
- setCallerUuid(String) - Method in class com.hazelcast.spi.Operation
-
- setCallerUuid(String) - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- setCallId(int) - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- setCallId(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
-
- setCallTimeout(long) - Method in class com.hazelcast.spi.InvocationBuilder
-
- setCallTimeout(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
-
- setCheckClassDefErrors(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
When enabled, serialization system will check class definitions error at start and throw an Serialization
Exception with error definition.
- setCheckClassDefErrors(boolean) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setCheckClassDefErrors(boolean) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setChunkSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
-
- setChunkSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-
- setClass(Class<? extends Serializer>) - Method in class com.hazelcast.config.SerializerConfig
-
- setClassDefinitions(Set<ClassDefinition>) - Method in class com.hazelcast.config.SerializationConfig
-
- setClassLoader(ClassLoader) - Method in class com.hazelcast.config.Config
-
Sets the class-loader to be used during de-serialization
and as context class-loader of Hazelcast internal threads.
- setClassLoader(ClassLoader) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setClassLoader(ClassLoader) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setClassName(String) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- setClassName(String) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-
- setClassName(String) - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- setClassName(String) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
-
- setClassName(String) - Method in class com.hazelcast.config.ListenerConfig
-
Sets the class name of the EventListener.
- setClassName(String) - Method in class com.hazelcast.config.ListenerConfigReadOnly
-
- setClassName(String) - Method in class com.hazelcast.config.LoginModuleConfig
-
- setClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the name for the MapStore implementation class
- setClassName(String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setClassName(String) - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
-
- setClassName(String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-
- setClassName(String) - Method in class com.hazelcast.config.SecurityInterceptorConfig
-
- setClassName(String) - Method in class com.hazelcast.config.SerializerConfig
-
- setClassName(String) - Method in class com.hazelcast.config.ServiceConfig
-
- setClassName(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
- setClassVersion(int, int, int) - Method in interface com.hazelcast.nio.serialization.PortableContext
-
- setClientConnectionCount(int) - Method in class com.hazelcast.management.SerializableConnectionManagerBean
-
- setClientEngine(ClientEngineImpl) - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- setClientHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- setClientLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.SecurityConfig
-
- setClientPermissionConfigs(Set<PermissionConfig>) - Method in class com.hazelcast.config.SecurityConfig
-
- setClientPolicyConfig(PermissionPolicyConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- setClients(Collection<SerializableClientEndPoint>) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- setClientThreadId(long) - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-
- setClientType(String) - Method in class com.hazelcast.management.SerializableClientEndPoint
-
- setClusterName(String) - Method in class com.hazelcast.monitor.TimedMemberState
-
- setCmdGet(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setCmdSet(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setCmdTouch(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- SetCommand - Class in com.hazelcast.ascii.memcache
-
- SetCommand(TextCommandConstants.TextCommandType, String, int, int, int, boolean) - Constructor for class com.hazelcast.ascii.memcache.SetCommand
-
- SetCommandParser - Class in com.hazelcast.ascii.memcache
-
- SetCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.memcache.SetCommandParser
-
- SetCommandProcessor - Class in com.hazelcast.ascii.memcache
-
- SetCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.ascii.memcache.SetCommandProcessor
-
- setCommittedHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setCommittedNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfig
-
- setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-
- setCompletedTaskCount(long) - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.AbstractCacheRequest
-
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheEntryProcessorRequest
-
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheGetAndRemoveRequest
-
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CachePutRequest
-
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheRemoveRequest
-
- setCompletionId(Integer) - Method in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- setCompletionId(int) - Method in class com.hazelcast.cache.impl.operation.AbstractMutatingCacheOperation
-
- setCompletionId(int) - Method in interface com.hazelcast.cache.impl.operation.MutableOperation
-
- setConcurrencyLevel(int) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- SetConfig - Class in com.hazelcast.config
-
Contains the configuration for an
ISet
.
- SetConfig() - Constructor for class com.hazelcast.config.SetConfig
-
- SetConfig(SetConfig) - Constructor for class com.hazelcast.config.SetConfig
-
- setConfig(SerializationConfig) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setConfig(SerializationConfig) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setConfig(QueueConfig, NodeEngine, QueueService) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- setConfigObject(Object) - Method in class com.hazelcast.config.ServiceConfig
-
- SetConfigReadOnly - Class in com.hazelcast.config
-
Contains configuration for Set(read only)
- SetConfigReadOnly(SetConfig) - Constructor for class com.hazelcast.config.SetConfigReadOnly
-
- setConfigurationFile(File) - Method in class com.hazelcast.config.Config
-
- setConfigurationUrl(URL) - Method in class com.hazelcast.config.Config
-
- setConn(Connection) - Method in class com.hazelcast.nio.Packet
-
Sets the Connection this Packet is send with.
- setConnection(Operation, Connection) - Static method in class com.hazelcast.spi.OperationAccessor
-
- setConnectionCount(int) - Method in class com.hazelcast.management.SerializableConnectionManagerBean
-
- setConnectionManagerBean(SerializableConnectionManagerBean) - Method in class com.hazelcast.management.SerializableMXBeans
-
- setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.AwsConfig
-
Sets the connect timeout in seconds.
- setConnectionTimeoutSeconds(int) - Method in class com.hazelcast.config.TcpIpConfig
-
Sets the connection timeout.
- SetContainer - Class in com.hazelcast.collection.set
-
- SetContainer() - Constructor for class com.hazelcast.collection.set.SetContainer
-
- SetContainer(String, NodeEngine) - Constructor for class com.hazelcast.collection.set.SetContainer
-
- setContentType(byte[]) - Method in class com.hazelcast.ascii.rest.RestValue
-
- setContext(ScriptContext) - Method in class com.hazelcast.osgi.OSGiScriptEngine
-
- setContextClassLoader(ClassLoader) - Method in class com.hazelcast.util.executor.HazelcastManagedThread
-
- setCost(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setCount(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- setCount(String, int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- setCountDirect(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- setCountDirect(String, int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- SetCountOperation - Class in com.hazelcast.concurrent.countdownlatch.operations
-
- SetCountOperation() - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- SetCountOperation(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- SetCountRequest - Class in com.hazelcast.concurrent.countdownlatch.client
-
- SetCountRequest() - Constructor for class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- SetCountRequest(String, int) - Constructor for class com.hazelcast.concurrent.countdownlatch.client.SetCountRequest
-
- setCreationTime(long) - Method in interface com.hazelcast.map.impl.record.Record
-
- setCreationTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- setCreationTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setCurrConnections(int) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setData(Data) - Method in class com.hazelcast.nio.serialization.DataAdapter
-
- setData(byte[]) - Method in class com.hazelcast.nio.serialization.DefaultData
-
- setData(Data) - Method in class com.hazelcast.queue.impl.QueueItem
-
- setDataSerializableFactories(Map<Integer, DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- setDataSerializableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
-
- setDecrHits(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setDecrMisses(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setDeleteHits(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setDeleteMisses(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setDirtyEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setDistributedObjectListener(String) - Method in interface com.hazelcast.client.ClientEndpoint
-
- setDistributedObjectListener(String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- setDone() - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- setDoubleAttribute(String, double) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setDoubleAttribute(String, double) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setDoubleAttribute(String, double) - Method in interface com.hazelcast.core.Member
-
Defines a key-value pair double attribute for this member available
to other cluster members.
- setDoubleAttribute(String, double) - Method in class com.hazelcast.instance.MemberImpl
-
- setDurability(int) - Method in class com.hazelcast.transaction.TransactionOptions
-
Sets the transaction durability.
- setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfig
-
- setEmptyQueueTtl(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- setEnableCompression(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Enables compression when default java serialization is used.
- setEnableCompression(boolean) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setEnableCompression(boolean) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setEnabled(boolean) - Method in class com.hazelcast.config.AwsConfig
-
Enables or disables the aws join mechanism.
- setEnabled(boolean) - Method in class com.hazelcast.config.InterfacesConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.ManagementCenterConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfig
-
Enables and disables this configuration
- setEnabled(boolean) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setEnabled(boolean) - Method in class com.hazelcast.config.MulticastConfig
-
Enables or disables the multicast discovery mechanism
- setEnabled(boolean) - Method in class com.hazelcast.config.NativeMemoryConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.PartitionGroupConfig
-
Enables or disables this PartitionGroupConfig.
- setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-
- setEnabled(boolean) - Method in class com.hazelcast.config.SecurityConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.ServiceConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Enables and disables this configuration
- setEnabled(boolean) - Method in class com.hazelcast.config.SSLConfig
-
Enables and disables this configuration
- setEnabled(boolean) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- setEnabled(boolean) - Method in class com.hazelcast.config.TcpIpConfig
-
Enables or disables the Tcp/Ip join mechanism.
- setEnableDefaults(boolean) - Method in class com.hazelcast.config.ServicesConfig
-
- setEnableSharedObject(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
Enables shared object when default java serialization is used.
- setEnableSharedObject(boolean) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setEnableSharedObject(boolean) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setEndpoint(ClientEndpoint) - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- setEndPoint(Address) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- setEndpoint(Address) - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- setEndpoint(String) - Method in class com.hazelcast.security.AbstractCredentials
-
- setEndpoint(String) - Method in interface com.hazelcast.security.Credentials
-
Sets IP address of endpoint.
- setEndpoints(Set<String>) - Method in class com.hazelcast.config.PermissionConfig
-
- setEndpoints(List<String>) - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfig
-
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfig
-
- setEntryListenerConfigs(List<EntryListenerConfig>) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setEntryView(EntryView) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- setError(Throwable) - Method in class com.hazelcast.util.executor.DelegatingFuture
-
- setEventObject(ReplicationEventObject) - Method in class com.hazelcast.wan.WanReplicationEvent
-
- setEventQueueCapacity(int) - Method in class com.hazelcast.management.SerializableEventServiceBean
-
- setEventQueueSize(int) - Method in class com.hazelcast.management.SerializableEventServiceBean
-
- setEventServiceBean(SerializableEventServiceBean) - Method in class com.hazelcast.management.SerializableMXBeans
-
- setEventThreadCount(int) - Method in class com.hazelcast.management.SerializableEventServiceBean
-
- setEvictionCriteriaNumber(long) - Method in interface com.hazelcast.map.impl.record.Record
-
- setEvictionCriteriaNumber(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- setEvictionCriteriaNumber(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setEvictionOperator(EvictionOperator) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
Used for testing purposes.
- setEvictionPercentage(int) - Method in class com.hazelcast.config.CacheConfig
-
- setEvictionPercentage(int) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setEvictionPercentage(int) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfig
-
When max.
- setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheConfig
-
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfig
-
- setEvictionPolicy(EvictionPolicy) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setEvictionPolicy(String) - Method in class com.hazelcast.config.NearCacheConfig
-
- setEvictionPolicy(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setEvictionThresholdPercentage(int) - Method in class com.hazelcast.config.CacheConfig
-
- setEvictionThresholdPercentage(int) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setEvictionThresholdPercentage(int) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setExecutedOperationCount(long) - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- setExecutorConfigs(Map<String, ExecutorConfig>) - Method in class com.hazelcast.config.Config
-
- setExecutorName(String) - Method in class com.hazelcast.spi.InvocationBuilder
-
Sets the executor name.
- setExecutorName(String) - Method in class com.hazelcast.spi.Operation
-
- setExpirationTime(long) - Method in class com.hazelcast.cache.impl.record.AbstractCacheRecord
-
- setExpirationTime(long) - Method in interface com.hazelcast.cache.impl.record.Expirable
-
Sets the expiration time in milliseconds.
- setExpirationTime(long) - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- setExpirationTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setExpiryPolicyFactory(Factory<? extends ExpiryPolicy>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set the Factory
for the ExpiryPolicy
.
- setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setExpiryPolicyFactory(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the name for the MapStoreFactory implementation class
- setFactoryClassName(String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfig
-
- setFactoryClassName(String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-
- setFactoryClassName(String) - Method in class com.hazelcast.config.SSLConfig
-
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the map store factory implementation object
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfig
-
- setFactoryImplementation(QueueStoreFactory) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-
- setFactoryImplementation(Object) - Method in class com.hazelcast.config.SSLConfig
-
- setFloatAttribute(String, float) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setFloatAttribute(String, float) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setFloatAttribute(String, float) - Method in interface com.hazelcast.core.Member
-
Defines a key-value pair float attribute for this member available
to other cluster members.
- setFloatAttribute(String, float) - Method in class com.hazelcast.instance.MemberImpl
-
- setFreeNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setFreePhysical(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setGcStats(LocalGCStats) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setGetHits(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setGetMisses(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
-
- setGlobalOrderingEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
-
- setGlobalSerializerConfig(GlobalSerializerConfig) - Method in class com.hazelcast.config.SerializationConfig
-
- setGroupConfig(GroupConfig) - Method in class com.hazelcast.config.Config
-
- setGroupName(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- setGroupPassword(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- setGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.config.PartitionGroupConfig
-
Sets the MemberGroupType.
- setHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher
-
- setHasRunningCleanup(boolean) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- setHazelcast(HazelcastInstance) - Method in class com.hazelcast.console.ConsoleApp
-
- setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.core.HazelcastInstanceAware
-
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.instance.MemberImpl
-
- setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setHeader(int) - Method in class com.hazelcast.nio.Packet
-
- setHeader(byte[]) - Method in class com.hazelcast.nio.serialization.DefaultData
-
- setHeapCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setHits(int) - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- setHits(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setHits(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- setHits(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setHits(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- setHostHeader(String) - Method in class com.hazelcast.config.AwsConfig
-
Sets the host header; the address the EC2 API can be found.
- setImplementation(ICredentialsFactory) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfig
-
- setImplementation(EntryListener) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-
- setImplementation(EventListener) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-
- setImplementation(ByteArraySerializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- setImplementation(StreamSerializer) - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfig
-
- setImplementation(ItemListener) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
-
- setImplementation(EventListener) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
-
- setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfig
-
Sets the EventListener implementation.
- setImplementation(EventListener) - Method in class com.hazelcast.config.ListenerConfigReadOnly
-
- setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the map store implementation object
- setImplementation(Object) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setImplementation(IPermissionPolicy) - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- setImplementation(SecurityInterceptor) - Method in class com.hazelcast.config.SecurityInterceptorConfig
-
- setImplementation(Serializer) - Method in class com.hazelcast.config.SerializerConfig
-
Sets the serializer implementation instance.
- setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
- setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
-
- setIncludeValue(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-
- setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfig
-
- setIncludeValue(boolean) - Method in class com.hazelcast.config.ItemListenerConfigReadOnly
-
- setIncrHits(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setIncrMisses(long) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setInitialized() - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets initial load mode
LAZY: Default load mode where load is async
EAGER: load mode where load is blocked till all partitions are loaded
- setInitialLoadMode(MapStoreConfig.InitialLoadMode) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setInitialOutputBufferSize(int) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setInitialOutputBufferSize(int) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setInitialPermits(int) - Method in class com.hazelcast.config.SemaphoreConfig
-
Sets the initial number of permits.
- setInitialPermits(int) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfig
-
Data type that will be used for storing records.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfig
-
Binary type that will be used for storing records.
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfig
-
- setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfig
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setInMemoryFormat(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setInMemoryFormat(InMemoryFormat) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- setInstanceName(String) - Method in class com.hazelcast.config.Config
-
- setInstanceNames(Set<String>) - Method in class com.hazelcast.monitor.TimedMemberState
-
- setIntAttribute(String, int) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setIntAttribute(String, int) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setIntAttribute(String, int) - Method in interface com.hazelcast.core.Member
-
Defines a key-value pair int attribute for this member available
to other cluster members.
- setIntAttribute(String, int) - Method in class com.hazelcast.instance.MemberImpl
-
- setInterfaces(Collection<String>) - Method in class com.hazelcast.config.InterfacesConfig
-
Adds a collection of interfaces.
- setInterfaces(Collection<String>) - Method in class com.hazelcast.config.MemberGroupConfig
-
Sets the interfaces that are part of a group.
- setInterfaces(InterfacesConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfig
-
- setInvalidateOnChange(boolean) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setInvocationTime(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
-
- setItemId(long) - Method in class com.hazelcast.queue.impl.QueueItem
-
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.CollectionConfig
-
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.ListConfigReadOnly
-
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfig
-
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- setItemListenerConfigs(List<ItemListenerConfig>) - Method in class com.hazelcast.config.SetConfigReadOnly
-
- setIterationCount(int) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- setIterationType(IterationType) - Method in class com.hazelcast.query.PagingPredicate
-
- setJobTrackerConfigs(Map<String, JobTrackerConfig>) - Method in class com.hazelcast.config.Config
-
- setJoin(JoinConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setJoined() - Method in class com.hazelcast.instance.Node
-
- setKey(byte[]) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- setKey(K) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setKey(Data) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setKeyType(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- SetKeyValueSource<V> - Class in com.hazelcast.mapreduce.impl
-
- SetKeyValueSource() - Constructor for class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- SetKeyValueSource(String) - Constructor for class com.hazelcast.mapreduce.impl.SetKeyValueSource
-
- setLastAccessTime(long) - Method in interface com.hazelcast.map.impl.record.Record
-
- setLastAccessTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- setLastAccessTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setLastAccessTime(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- setLastAccessTime(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setLastCleanupTime(long) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- setLastCleanupTimeCopy(long) - Method in class com.hazelcast.map.impl.PartitionContainer
-
- setLastStoredTime(long) - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- setLastStoredTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setLastUpdateTime(long) - Method in interface com.hazelcast.map.impl.record.Record
-
- setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- setLastUpdateTime(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setLastUpdateTime(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- setLastUpdateTime(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setLicenseKey(String) - Method in class com.hazelcast.config.Config
-
- setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.config.Config
-
- setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.Config
-
- setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- setListenerRegistration(String, String, String) - Method in interface com.hazelcast.client.ClientEndpoint
-
- setListenerRegistration(String, String, String) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- setLoaded(boolean) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- setLoaded(boolean) - Method in interface com.hazelcast.map.impl.RecordStore
-
- setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
-
- setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
-
- setLocalMemoryStats(LocalMemoryStats) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- setLocalUpdatePolicy(NearCacheConfig.LocalUpdatePolicy) - Method in class com.hazelcast.config.NearCacheConfig
-
- setLockedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- setLockedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setLoginContext(LoginContext) - Method in interface com.hazelcast.client.ClientEndpoint
-
- setLoginContext(LoginContext) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- setLongAttribute(String, long) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setLongAttribute(String, long) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setLongAttribute(String, long) - Method in interface com.hazelcast.core.Member
-
Defines a key-value pair long attribute for this member available
to other cluster members.
- setLongAttribute(String, long) - Method in class com.hazelcast.instance.MemberImpl
-
- setMajorCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- setMajorTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- setManagedContext(ManagedContext) - Method in class com.hazelcast.config.Config
-
- setManagedContext(ManagedContext) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setManagedContext(ManagedContext) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
-
- setManagementEnabled(CacheConfig, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- setManagementEnabled(CacheConfig, String, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setManagementEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets whether management is enabled on a cache.
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setManagementEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfig
-
- setManagerPrefix(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setMapConfigs(Map<String, MapConfig>) - Method in class com.hazelcast.config.Config
-
- setMapIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.MapConfig
-
- setMapIndexConfigs(List<MapIndexConfig>) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setMapName(String) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- setMapName(String) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- setMapName(String) - Method in class com.hazelcast.replicatedmap.impl.client.AbstractReplicatedMapClientRequest
-
- setMapServiceContext(MapServiceContext) - Method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- setMapServiceContext(MapServiceContext) - Method in class com.hazelcast.map.impl.MapService
-
- setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfig
-
Sets the mapStore configuration
- setMapStoreConfig(MapStoreConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setMaster(Boolean) - Method in class com.hazelcast.monitor.TimedMemberState
-
- setMaster(Address) - Method in class com.hazelcast.partition.MigrationInfo
-
- setMasterAddress(Address) - Method in class com.hazelcast.instance.Node
-
- SetMasterOperation - Class in com.hazelcast.cluster.impl.operations
-
- SetMasterOperation() - Constructor for class com.hazelcast.cluster.impl.operations.SetMasterOperation
-
- SetMasterOperation(Address) - Constructor for class com.hazelcast.cluster.impl.operations.SetMasterOperation
-
- setMasterTime(long) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- setMasterUuid(String) - Method in class com.hazelcast.partition.MigrationInfo
-
- setMaxAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- setMaxHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfig
-
Maximum number of seconds for each entry to stay idle in the map.
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
-
- setMaxIdleSeconds(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setMaximumPoolSize(int) - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- setMaxNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setMaxSize(int) - Method in class com.hazelcast.config.CollectionConfig
-
- setMaxSize(int) - Method in class com.hazelcast.config.ListConfigReadOnly
-
- setMaxSize(int) - Method in class com.hazelcast.config.NearCacheConfig
-
- setMaxSize(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setMaxSize(int) - Method in class com.hazelcast.config.QueueConfig
-
- setMaxSize(int) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- setMaxSize(int) - Method in class com.hazelcast.config.SetConfigReadOnly
-
- setMaxSizeChecker(MaxSizeChecker) - Method in class com.hazelcast.map.impl.eviction.EvictionOperator
-
- setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfig
-
- setMaxSizeConfig(MaxSizeConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfig
-
- setMaxSizePolicy(MaxSizeConfig.MaxSizePolicy) - Method in class com.hazelcast.config.MaxSizeConfigReadOnly
-
- setMaxThreadSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
-
- setMaxThreadSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-
- SetMBean - Class in com.hazelcast.jmx
-
- SetMBean(ISet, ManagementService) - Constructor for class com.hazelcast.jmx.SetMBean
-
- setMemberAttributeConfig(MemberAttributeConfig) - Method in class com.hazelcast.config.Config
-
- setMemberCredentialsConfig(CredentialsFactoryConfig) - Method in class com.hazelcast.config.SecurityConfig
-
- setMemberGroupConfigs(Collection<MemberGroupConfig>) - Method in class com.hazelcast.config.PartitionGroupConfig
-
Adds a MemberGroupConfig.
- setMemberList(List<String>) - Method in class com.hazelcast.monitor.TimedMemberState
-
- setMemberLoginModuleConfigs(List<LoginModuleConfig>) - Method in class com.hazelcast.config.SecurityConfig
-
- setMembers(List<String>) - Method in class com.hazelcast.config.TcpIpConfig
-
Sets the well known members.
- setMemberState(MemberStateImpl) - Method in class com.hazelcast.monitor.TimedMemberState
-
- setMergePolicy(String) - Method in class com.hazelcast.config.MapConfig
-
- setMergePolicy(String) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setMergePolicy(String) - Method in class com.hazelcast.config.WanReplicationRef
-
- setMergePolicy(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
-
- setMergePolicy(MapMergePolicy) - Method in class com.hazelcast.map.impl.wan.MapReplicationUpdate
-
- setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfig
-
- setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfigReadOnly
-
- setMetadataSpacePercentage(float) - Method in class com.hazelcast.config.NativeMemoryConfig
-
- setMinAge(long) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- setMinBlockSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
-
- setMinEvictionCheckMillis(long) - Method in class com.hazelcast.config.MapConfig
-
Sets the minimum time in millis which should pass before asking if a partition of this map is evictable or not.
- setMinEvictionCheckMillis(long) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setMinorCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- setMinorTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- setMonitor(TcpIpConnectionMonitor) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- setMulticastConfig(MulticastConfig) - Method in class com.hazelcast.config.JoinConfig
-
- setMulticastGroup(String) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the multicast-group.
- setMulticastPort(int) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the multicast port.
- setMulticastTimeoutSeconds(int) - Method in class com.hazelcast.config.MulticastConfig
-
Specifies the time in seconds that a node should wait for a valid multicast response from another node running
in the network before declaring itself as master node and creating its own cluster.
- setMulticastTimeToLive(int) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the time to live for the multicast package; a value between 0..255.
- setMultiMapConfigs(Map<String, MultiMapConfig>) - Method in class com.hazelcast.config.Config
-
- setName(String) - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- setName(String) - Method in class com.hazelcast.config.CacheConfig
-
- setName(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setName(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.CollectionConfig
-
- setName(String) - Method in class com.hazelcast.config.ExecutorConfig
-
- setName(String) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.GroupConfig
-
Sets the group name of the group.
- setName(String) - Method in class com.hazelcast.config.JobTrackerConfig
-
- setName(String) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.ListConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.MapConfig
-
- setName(String) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.MultiMapConfig
-
- setName(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.NearCacheConfig
-
- setName(String) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.PermissionConfig
-
- setName(String) - Method in class com.hazelcast.config.QueueConfig
-
- setName(String) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- setName(String) - Method in class com.hazelcast.config.SemaphoreConfig
-
Sets the name of the semaphore.
- setName(String) - Method in class com.hazelcast.config.SemaphoreConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.ServiceConfig
-
- setName(String) - Method in class com.hazelcast.config.SetConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.TopicConfig
-
Sets the name of the topic.
- setName(String) - Method in class com.hazelcast.config.TopicConfigReadOnly
-
- setName(String) - Method in class com.hazelcast.config.WanReplicationConfig
-
- setName(String) - Method in class com.hazelcast.config.WanReplicationRef
-
- setName(String) - Method in class com.hazelcast.config.WanReplicationRefReadOnly
-
- setName(String) - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- setNativeMemoryConfig(NativeMemoryConfig) - Method in class com.hazelcast.config.Config
-
- setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.CacheConfig
-
- setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfig
-
- setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setNearCacheSizeEstimator(SizeEstimator) - Method in class com.hazelcast.map.impl.NearCache
-
- setNearCacheStats(NearCacheStatsImpl) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
-
- setNextRecordId(long) - Method in class com.hazelcast.multimap.impl.operations.MultiMapResponse
-
- setNode(Node) - Method in class com.hazelcast.spi.impl.BinaryOperationFactory
-
- setNode(Node) - Method in interface com.hazelcast.spi.NodeAware
-
- setNodeEngine(NodeEngine) - Method in class com.hazelcast.spi.Operation
-
- setObject(Object) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-
- setObjectName(Map<String, String>) - Method in class com.hazelcast.jmx.HazelcastMBean
-
- setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- setOldValueRequired(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-
- SetOperation - Class in com.hazelcast.concurrent.atomiclong.operations
-
- SetOperation() - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-
- SetOperation(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.operations.SetOperation
-
- SetOperation - Class in com.hazelcast.concurrent.atomicreference.operations
-
- SetOperation() - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- SetOperation(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.operations.SetOperation
-
- SetOperation - Class in com.hazelcast.map.impl.operation
-
- SetOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.operation.SetOperation
-
- SetOperation() - Constructor for class com.hazelcast.map.impl.operation.SetOperation
-
- setOperationExecutorQueueSize(int) - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- SetOperations - Interface in com.hazelcast.multimap.impl.operations
-
- setOperationService(OperationService) - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- setOperationServiceBean(SerializableOperationServiceBean) - Method in class com.hazelcast.management.SerializableMXBeans
-
- setOperationThreadCount(long) - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- setOptimizeQueries(boolean) - Method in class com.hazelcast.config.MapConfig
-
- setOptimizeQueries(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setOrdered(boolean) - Method in class com.hazelcast.config.MapIndexConfig
-
Configures the index to be ordered or not ordered.
- setOrdered(boolean) - Method in class com.hazelcast.config.MapIndexConfigReadOnly
-
- setOutboundPortDefinitions(Collection<String>) - Method in class com.hazelcast.config.NetworkConfig
-
- setOutboundPorts(Collection<Integer>) - Method in class com.hazelcast.config.NetworkConfig
-
- setOutOfMemoryHandler(OutOfMemoryHandler) - Static method in class com.hazelcast.core.Hazelcast
-
Sets OutOfMemoryHandler to be used when an OutOfMemoryError
is caught by Hazelcast threads.
- setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setOwnedEntryCount(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- setOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- setOwnedEntryMemoryCost(long) - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- setOwnedItemCount(int) - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- setOwnerConnection(boolean) - Method in class com.hazelcast.client.impl.client.AuthenticationRequest
-
- setOwnerUuid(String) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
-
- setOwnerUuid(String) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- setOwnerUuid(String) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- setOwnerUuid(String) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- setPageSize(int) - Method in class com.hazelcast.config.NativeMemoryConfig
-
- setPagingPredicateAnchor(PagingPredicate, Map.Entry) - Static method in class com.hazelcast.query.PagingPredicateAccessor
-
- setPartitionCount(int) - Method in class com.hazelcast.management.SerializablePartitionServiceBean
-
- setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
-
- setPartitionHash(int) - Method in class com.hazelcast.nio.serialization.DefaultData
-
- setPartitionId(int) - Method in class com.hazelcast.mapreduce.impl.MapKeyValueSource
-
- setPartitionId(int) - Method in class com.hazelcast.mapreduce.impl.MultiMapKeyValueSource
-
- setPartitionId(int) - Method in class com.hazelcast.mapreduce.impl.task.DefaultContext
-
- setPartitionId(int) - Method in interface com.hazelcast.mapreduce.PartitionIdAware
-
Sets the partition id the implementing instance is executed against
- setPartitionId(int) - Method in class com.hazelcast.spi.Operation
-
- setPartitionIds(Collection<Integer>) - Method in class com.hazelcast.map.impl.QueryResult
-
- setPartitioningStrategy(PartitioningStrategy) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setPartitioningStrategy(PartitioningStrategy) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- setPartitioningStrategyClass(String) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
-
- setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfig
-
- setPartitioningStrategyConfig(PartitioningStrategyConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setPartitionReplicaVersions(int, long[], int) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- setPartitionReplicaVersions(int, long[], int) - Method in interface com.hazelcast.partition.InternalPartitionService
-
- setPartitions(InternalPartition[], Map<Address, Integer>) - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- setPartitionServiceBean(SerializablePartitionServiceBean) - Method in class com.hazelcast.management.SerializableMXBeans
-
- setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- setPartitionStrategy(PartitioningStrategy) - Method in class com.hazelcast.config.PartitioningStrategyConfigReadOnly
-
- setPassword(String) - Method in class com.hazelcast.config.GroupConfig
-
Sets the password for the group.
- setPassword(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- setPassword(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- SetPermission - Class in com.hazelcast.security.permission
-
- SetPermission(String, String...) - Constructor for class com.hazelcast.security.permission.SetPermission
-
- setPollOperation(boolean) - Method in class com.hazelcast.queue.impl.TxQueueItem
-
- setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfig
-
- setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
-
- setPoolSize(int) - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- setPort(int) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the port the Hazelcast member is going to try to bind on.
- setPortableFactories(Map<Integer, PortableFactory>) - Method in class com.hazelcast.config.SerializationConfig
-
- setPortableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
-
- setPortableVersion(int) - Method in class com.hazelcast.config.SerializationConfig
-
- setPortAutoIncrement(boolean) - Method in class com.hazelcast.config.NetworkConfig
-
Sets if a Hazelcast member is allowed to find a free port by incrementing the port number when it encounters
an occupied port.
- setPortCount(int) - Method in class com.hazelcast.config.NetworkConfig
-
The maxmim number of ports to try.
- setPreReplicationHook(PreReplicationHook) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicationPublisher
-
- setPreReplicationHook(PreReplicationHook) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- setPrincipal(String) - Method in class com.hazelcast.config.PermissionConfig
-
- setPrincipal(String) - Method in class com.hazelcast.security.AbstractCredentials
-
- setProperties(Properties) - Method in class com.hazelcast.config.Config
-
- setProperties(Properties) - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.LoginModuleConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setProperties(Properties) - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-
- setProperties(Properties) - Method in class com.hazelcast.config.ServiceConfig
-
- setProperties(Properties) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Sets the properties.
- setProperties(Properties) - Method in class com.hazelcast.config.SSLConfig
-
Sets the properties.
- setProperties(Properties) - Method in class com.hazelcast.config.XmlConfigBuilder
-
Sets the used properties.
- setProperty(String, String) - Method in class com.hazelcast.config.Config
-
- setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfig
-
- setProperty(String, String) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfig
-
- setProperty(String, String) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-
- setProperty(String, String) - Method in class com.hazelcast.config.SocketInterceptorConfig
-
Sets a property.
- setProperty(String, String) - Method in class com.hazelcast.config.SSLConfig
-
Sets a property.
- setProxyCount(int) - Method in class com.hazelcast.management.SerializableProxyServiceBean
-
- SetProxyImpl<E> - Class in com.hazelcast.collection.set
-
- SetProxyImpl(String, NodeEngine, SetService) - Constructor for class com.hazelcast.collection.set.SetProxyImpl
-
- setProxyServiceBean(SerializableProxyServiceBean) - Method in class com.hazelcast.management.SerializableMXBeans
-
- setPublicAddress(String) - Method in class com.hazelcast.config.NetworkConfig
-
- setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfig
-
- setQueueCapacity(int) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
-
- setQueueConfigs(Map<String, QueueConfig>) - Method in class com.hazelcast.config.Config
-
- setQueueSize(int) - Method in class com.hazelcast.config.JobTrackerConfig
-
- setQueueSize(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-
- setQueueSize(int) - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfig
-
- setQueueStoreConfig(QueueStoreConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfig
-
- setReadBackupData(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setReadThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set if read-through caching should be used.
- setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setReadThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setRecord(Data, CacheRecord) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- setRecord(Data, CacheRecord) - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Associates the specified record with the specified key.
- setRecordId(long) - Method in class com.hazelcast.multimap.impl.MultiMapRecord
-
- setRegion(String) - Method in class com.hazelcast.config.AwsConfig
-
Sets the region where the EC2 instances running the Hazelcast members will be running.
- setRegistrationId(String) - Method in class com.hazelcast.client.impl.client.BaseClientRemoveListenerRequest
-
- setRemainingQueueCapacity(int) - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- setRemoteOperationCount(int) - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- setRemoteResponseHandler(NodeEngine, RemotePropagatable) - Static method in class com.hazelcast.spi.impl.ResponseHandlerFactory
-
- setRemoveOperation(boolean) - Method in class com.hazelcast.collection.TxCollectionItem
-
- setRemoveTime(long) - Method in class com.hazelcast.map.impl.wan.MapReplicationRemove
-
- setReplicaIndex(int) - Method in class com.hazelcast.spi.InvocationBuilder
-
Sets the replicaIndex
- setReplicaIndex(int) - Method in class com.hazelcast.spi.Operation
-
- setReplicatedMapConfigs(Map<String, ReplicatedMapConfig>) - Method in class com.hazelcast.config.Config
-
- setReplicationDelayMillis(long) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- setReplicationImpl(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- setReplicationImplObject(Object) - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- SetReplicationOperation - Class in com.hazelcast.collection.set
-
- SetReplicationOperation() - Constructor for class com.hazelcast.collection.set.SetReplicationOperation
-
- SetReplicationOperation(Map<String, CollectionContainer>, int, int) - Constructor for class com.hazelcast.collection.set.SetReplicationOperation
-
- setReplicatorExecutorService(ScheduledExecutorService) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- SetRequest - Class in com.hazelcast.concurrent.atomiclong.client
-
- SetRequest() - Constructor for class com.hazelcast.concurrent.atomiclong.client.SetRequest
-
- SetRequest(String, long) - Constructor for class com.hazelcast.concurrent.atomiclong.client.SetRequest
-
- SetRequest - Class in com.hazelcast.concurrent.atomicreference.client
-
- SetRequest() - Constructor for class com.hazelcast.concurrent.atomicreference.client.SetRequest
-
- SetRequest(String, Data) - Constructor for class com.hazelcast.concurrent.atomicreference.client.SetRequest
-
- setRequiredMember(String) - Method in class com.hazelcast.config.TcpIpConfig
-
Sets the required member.
- setResponse(byte[]) - Method in class com.hazelcast.ascii.memcache.DeleteCommand
-
- setResponse(byte[]) - Method in class com.hazelcast.ascii.memcache.IncrementCommand
-
- setResponse(byte[]) - Method in class com.hazelcast.ascii.memcache.SetCommand
-
- setResponse(byte[]) - Method in class com.hazelcast.ascii.memcache.SimpleCommand
-
- setResponse(Stats) - Method in class com.hazelcast.ascii.memcache.StatsCommand
-
- setResponse(byte[]) - Method in class com.hazelcast.ascii.memcache.TouchCommand
-
- setResponse(byte[]) - Method in class com.hazelcast.ascii.rest.HttpCommand
-
- setResponse(byte[], byte[]) - Method in class com.hazelcast.ascii.rest.HttpCommand
-
HTTP/1.0 200 OK
Date: Fri, 31 Dec 1999 23:59:59 GMT
Content-TextCommandType: text/html
Content-Length: 1354
- setResponseHandler(ResponseHandler) - Method in interface com.hazelcast.spi.impl.RemotePropagatable
-
- setResponseHandler(ResponseHandler) - Method in class com.hazelcast.spi.Operation
-
- setResponseQueueSize(int) - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- setResult(Object) - Method in class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- setResult(Object) - Method in class com.hazelcast.spi.impl.AbstractCompletableFuture
-
- setResultDeserialized(boolean) - Method in class com.hazelcast.spi.InvocationBuilder
-
Sets the automatic deserialized option for the result.
- setRetryCount(int) - Method in class com.hazelcast.config.JobTrackerConfig
-
- setRetryCount(int) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-
- setReuseAddress(boolean) - Method in class com.hazelcast.config.NetworkConfig
-
Sets the reuse address.
- setRollbackOnly() - Method in interface com.hazelcast.transaction.impl.Transaction
-
- setRunnable(Runnable) - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- setRunningOperationsCount(int) - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- setRuntimeProps(Map<String, Long>) - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- setSalt(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- setScopeId(String) - Method in class com.hazelcast.nio.Address
-
- setScriptEngineManager(ScriptEngineManager) - Static method in class com.hazelcast.management.ScriptEngineManagerContext
-
- setSecretKey(String) - Method in class com.hazelcast.config.AwsConfig
-
Sets the secret key to access AWS.
- setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
-
- setSecurityGroupName(String) - Method in class com.hazelcast.config.AwsConfig
-
Sets the security group name.
- setSecurityInterceptorConfigs(List<SecurityInterceptorConfig>) - Method in class com.hazelcast.config.SecurityConfig
-
- setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.Config
-
- setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.config.Config
-
- setSerializationService(SerializationService) - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
-
- setService(Object) - Method in class com.hazelcast.client.impl.client.ClientRequest
-
- SetService - Class in com.hazelcast.collection.set
-
- SetService(NodeEngine) - Constructor for class com.hazelcast.collection.set.SetService
-
- setService(MapService) - Method in class com.hazelcast.map.impl.DefaultMapServiceContext
-
- setService(MapService) - Method in interface com.hazelcast.map.impl.MapServiceContext
-
- setService(Object) - Method in class com.hazelcast.spi.Operation
-
- setServiceConfigs(Collection<ServiceConfig>) - Method in class com.hazelcast.config.ServicesConfig
-
- setServiceImpl(Object) - Method in class com.hazelcast.config.ServiceConfig
-
- setServiceName(String) - Method in class com.hazelcast.collection.client.CollectionAddListenerRequest
-
- setServiceName(String) - Method in class com.hazelcast.collection.client.CollectionRequest
-
- setServiceName(String) - Method in class com.hazelcast.spi.Operation
-
- setServiceName(String) - Method in class com.hazelcast.wan.WanReplicationEvent
-
- setServicesConfig(ServicesConfig) - Method in class com.hazelcast.config.Config
-
- setSetConfigs(Map<String, SetConfig>) - Method in class com.hazelcast.config.Config
-
- setShortAttribute(String, short) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setShortAttribute(String, short) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setShortAttribute(String, short) - Method in interface com.hazelcast.core.Member
-
Defines a key-value pair short attribute for this member available
to other cluster members.
- setShortAttribute(String, short) - Method in class com.hazelcast.instance.MemberImpl
-
- setSingleConnection() - Method in class com.hazelcast.client.impl.client.ClientRequest
-
mark this request as SingleConnection
- setSize(int) - Method in class com.hazelcast.config.MaxSizeConfig
-
- setSize(int) - Method in class com.hazelcast.config.MaxSizeConfigReadOnly
-
- setSize(MemorySize) - Method in class com.hazelcast.config.NativeMemoryConfig
-
- setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setStartTime(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
-
- setStartTime(long) - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- setStatistics(RecordStatistics) - Method in interface com.hazelcast.map.impl.record.Record
-
- setStatistics(RecordStatistics) - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- setStatisticsEnabled(CacheConfig, String, boolean) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- setStatisticsEnabled(CacheConfig, String, boolean) - Method in interface com.hazelcast.cache.impl.ICacheService
-
- setStatisticsEnabled(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets whether statistics gathering is enabled on a cache.
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.CollectionConfig
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfig
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ListConfigReadOnly
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfig
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfig
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfig
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.QueueConfigReadOnly
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.ReplicatedMapConfig
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.SetConfigReadOnly
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
-
- setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
-
- setStats(LocalQueueStatsImpl) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- setStatus(int) - Method in class com.hazelcast.nio.serialization.DataAdapter
-
- setStoreByValue(boolean) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setStoreByValue(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set if a configured cache should use store-by-value or store-by-reference
semantics.
- setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfig
-
- setStoreImplementation(QueueStore) - Method in class com.hazelcast.config.QueueStoreConfigReadOnly
-
- setStringAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfig
-
- setStringAttribute(String, String) - Method in class com.hazelcast.config.MemberAttributeConfigReadOnly
-
- setStringAttribute(String, String) - Method in interface com.hazelcast.core.Member
-
Defines a key-value pair string attribute for this member available
to other cluster members.
- setStringAttribute(String, String) - Method in class com.hazelcast.instance.MemberImpl
-
- setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.NetworkConfig
-
- setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
-
Deprecated.
- setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfig
-
- setSynchronous(boolean) - Method in class com.hazelcast.config.CacheSimpleEntryListenerConfigReadOnly
-
- setTagKey(String) - Method in class com.hazelcast.config.AwsConfig
-
Sets the tag key.
- setTagValue(String) - Method in class com.hazelcast.config.AwsConfig
-
Sets the tag value.
- setTargetAddress(Address) - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- setTargetAddress(Address) - Method in interface com.hazelcast.cluster.Joiner
-
- setTargetClusterConfigs(List<WanTargetClusterConfig>) - Method in class com.hazelcast.config.WanReplicationConfig
-
- setTcpIpConfig(TcpIpConfig) - Method in class com.hazelcast.config.JoinConfig
-
- setTerminated(boolean) - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- setThisMember(MemberImpl) - Method in class com.hazelcast.logging.LoggingServiceImpl
-
- setThreadId(long) - Method in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- setThreadId(long) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
-
- setThreadId(long) - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- setThreadId(long) - Method in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- setThreadId(long) - Static method in class com.hazelcast.util.ThreadUtil
-
- setThreads(int) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setTime(long) - Method in class com.hazelcast.monitor.TimedMemberState
-
- setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
-
Sets the timeout.
- setTimeoutMillis(long) - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfig
-
Maximum number of seconds for each entry to stay in the map.
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfig
-
- setTimeToLiveSeconds(int) - Method in class com.hazelcast.config.NearCacheConfigReadOnly
-
- setTopicConfigs(Map<String, TopicConfig>) - Method in class com.hazelcast.config.Config
-
- setTopologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.config.JobTrackerConfig
-
- setTopologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
-
- setTotalConnections(int) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setTotalPhysical(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setTransactionContext(TransactionContext) - Method in interface com.hazelcast.client.ClientEndpoint
-
- setTransactionContext(TransactionContext) - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- setTransactionId(String) - Method in class com.hazelcast.collection.TxCollectionItem
-
- setTransactionId(String) - Method in class com.hazelcast.queue.impl.TxQueueItem
-
- setTransactionTimeout(int) - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- setTransactionType(TransactionOptions.TransactionType) - Method in class com.hazelcast.transaction.TransactionOptions
-
- setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.MulticastConfig
-
Sets the trusted interfaces.
- setTryCount(int) - Method in class com.hazelcast.cluster.impl.JoinRequest
-
- setTryCount(int) - Method in class com.hazelcast.spi.InvocationBuilder
-
Sets the try count; the number of times this operation can be retried.
- setTryPauseMillis(long) - Method in class com.hazelcast.spi.InvocationBuilder
-
Sets the pause time in millis.
- setTtl(long) - Method in interface com.hazelcast.map.impl.record.Record
-
- setTtl(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- setTtl(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setTxLogs(List<TransactionLog>) - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- setTxnId(String) - Method in class com.hazelcast.transaction.client.BaseTransactionRequest
-
- setTxnId(String) - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
-
- setType(int) - Method in class com.hazelcast.nio.serialization.DefaultData
-
- setType(ConnectionType) - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- setTypeClass(Class) - Method in class com.hazelcast.config.SerializerConfig
-
- setTypeClassName(String) - Method in class com.hazelcast.config.SerializerConfig
-
This method is called only if typeClass is not set.
- setTypes(Class<K>, Class<V>) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setTypes(Class<K>, Class<V>) - Method in interface com.hazelcast.config.CacheConfiguration
-
Sets the expected type of keys and values for a Cache
configured with this Configuration
.
- setUnknownCount(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- setUnknownTime(long) - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- setUpdateInterval(int) - Method in class com.hazelcast.config.ManagementCenterConfig
-
- setUptime(int) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setUriString(String) - Method in class com.hazelcast.config.CacheConfig
-
- setUriString(String) - Method in class com.hazelcast.config.CacheConfigReadOnly
-
- setUrl(String) - Method in class com.hazelcast.config.ManagementCenterConfig
-
- setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
-
- setUsedHeap(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setUsedNativeMemory(long) - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- setUseNativeByteOrder(boolean) - Method in class com.hazelcast.config.SerializationConfig
-
- setUseNativeByteOrder(boolean) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setUseNativeByteOrder(boolean) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setUserContext(ConcurrentMap<String, Object>) - Method in class com.hazelcast.config.Config
-
- setUsername(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- setUuid(String) - Method in class com.hazelcast.management.SerializableClientEndPoint
-
- setValidateTarget(boolean) - Method in class com.hazelcast.spi.Operation
-
- setValue(MemcacheEntry, boolean) - Method in class com.hazelcast.ascii.memcache.GetCommand
-
- setValue(byte[]) - Method in class com.hazelcast.ascii.rest.RestValue
-
- setValue(V) - Method in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- setValue(Object) - Method in class com.hazelcast.cache.impl.record.CacheObjectRecord
-
- setValue(V) - Method in interface com.hazelcast.cache.impl.record.CacheRecord
-
- setValue(Data) - Method in class com.hazelcast.collection.CollectionItem
-
- setValue(V) - Method in class com.hazelcast.map.impl.MapEntrySimple
-
- setValue(Record<Data>, Object) - Method in class com.hazelcast.map.impl.record.DataRecordFactory
-
- setValue(Record<Data>, Object) - Method in class com.hazelcast.map.impl.record.NativeRecordFactory
-
- setValue(Record<Object>, Object) - Method in class com.hazelcast.map.impl.record.ObjectRecordFactory
-
- setValue(V) - Method in interface com.hazelcast.map.impl.record.Record
-
- setValue(Record<T>, Object) - Method in interface com.hazelcast.map.impl.record.RecordFactory
-
- setValue(V) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setValue(Object) - Method in class com.hazelcast.query.impl.QueryEntry
-
- setValue(V, int, long) - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- setValue(V) - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfig
-
- setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfig
-
- setValueCollectionType(String) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setValueCollectionType(MultiMapConfig.ValueCollectionType) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
-
- setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setValueType(String) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setVersion(long) - Method in interface com.hazelcast.map.impl.record.Record
-
- setVersion(long) - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- setVersion(long) - Method in class com.hazelcast.map.impl.SimpleEntryView
-
- setVersion(long) - Method in interface com.hazelcast.map.impl.tx.MapTxnOperation
-
- setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- setVersion(long) - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- setVersion(int) - Method in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- setVersion(int) - Method in interface com.hazelcast.nio.serialization.SerializationServiceBuilder
-
- setWaitingRequests(int) - Method in class com.hazelcast.ascii.memcache.Stats
-
- setWaitTimeout(long) - Method in class com.hazelcast.spi.Operation
-
- setWanReplicationConfigs(Map<String, WanReplicationConfig>) - Method in class com.hazelcast.config.Config
-
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfig
-
- setWanReplicationRef(WanReplicationRef) - Method in class com.hazelcast.config.MapConfigReadOnly
-
- setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the number of operations to be included in each batch processing round.
- setWriteBatchSize(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setWriteBehindProcessor(WriteBehindProcessor) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- setWriteBehindQueue(WriteBehindQueue<DelayedEntry>) - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindStore
-
- setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
-
Sets the number of seconds to delay before writing (storing) the dirty records
Default value is
0.
- setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
-
- setWriteThrough(boolean) - Method in interface com.hazelcast.config.CacheConfiguration
-
Set if write-through caching should be used.
- setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfig
-
- setWriteThrough(boolean) - Method in class com.hazelcast.config.CacheSimpleConfigReadOnly
-
- setXid(SerializableXID) - Method in class com.hazelcast.transaction.impl.RecoveredTransaction
-
- severe(String) - Method in class com.hazelcast.logging.AbstractLogger
-
- severe(Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-
- severe(String, Throwable) - Method in class com.hazelcast.logging.AbstractLogger
-
- severe(String) - Method in interface com.hazelcast.logging.ILogger
-
- severe(Throwable) - Method in interface com.hazelcast.logging.ILogger
-
- severe(String, Throwable) - Method in interface com.hazelcast.logging.ILogger
-
Logs message with associated throwable information at
Level.SEVERE
.
- SharedService - Interface in com.hazelcast.spi
-
A shared service (not clear what the difference is between shared and unshared though).
- SHORT_ARRAY_BASE_OFFSET - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- SHORT_ARRAY_INDEX_SCALE - Static variable in class com.hazelcast.nio.UnsafeHelper
-
- SHORT_SIZE_IN_BYTES - Static variable in class com.hazelcast.nio.Bits
-
Short size in bytes
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheClearOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheEntryProcessorOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheGetAndReplaceOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheLoadAllOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CachePutIfAbsentOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CachePutOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveAllOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.cache.impl.operation.CacheReplaceOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.CollectionAddAllOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.CollectionAddOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.CollectionClearOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.CollectionCompareAndRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.CollectionRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.list.ListRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.list.ListSetOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.txn.CollectionPrepareOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.txn.CollectionRollbackOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.txn.CollectionTxnAddOperation
-
- shouldBackup() - Method in class com.hazelcast.collection.txn.CollectionTxnRemoveOperation
-
- shouldBackup - Variable in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.atomiclong.operations.AtomicLongBackupAwareOperation
-
- shouldBackup - Variable in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.atomicreference.operations.AtomicReferenceBackupAwareOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.atomicreference.operations.CompareAndSetOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.countdownlatch.operations.SetCountOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.LocalLockCleanupOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.SignalOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.DrainOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.InitOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.ReduceOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- shouldBackup() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.operation.WanOriginatedDeleteOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- shouldBackup() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.ClearOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.PutOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.RemoveAllOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.operations.RemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- shouldBackup() - Method in class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.operations.ClearOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.operations.DrainOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.tx.TxnPrepareOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- shouldBackup() - Method in class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- shouldBackup() - Method in interface com.hazelcast.spi.BackupAwareOperation
-
Checks if a backup needs to be made.
- shouldBePositive(long, String) - Static method in class com.hazelcast.util.ValidationUtil
-
- shouldConnectTo(Address) - Method in interface com.hazelcast.nio.IOService
-
- shouldConnectTo(Address) - Method in class com.hazelcast.nio.NodeIOService
-
- shouldNotify() - Method in class com.hazelcast.concurrent.countdownlatch.operations.CountDownOperation
-
- shouldNotify() - Method in class com.hazelcast.concurrent.lock.operations.BeforeAwaitOperation
-
- shouldNotify() - Method in class com.hazelcast.concurrent.lock.operations.UnlockOperation
-
- shouldNotify() - Method in class com.hazelcast.concurrent.semaphore.operations.ReleaseOperation
-
- shouldNotify() - Method in class com.hazelcast.concurrent.semaphore.operations.SemaphoreDeadMemberOperation
-
- shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- shouldNotify() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- shouldNotify() - Method in class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- shouldNotify() - Method in class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.operations.AddAllOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.operations.ClearOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.operations.CompareAndRemoveOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.operations.DrainOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.operations.RemoveOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- shouldNotify() - Method in class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- shouldNotify() - Method in interface com.hazelcast.spi.Notifier
-
- shouldReply() - Method in class com.hazelcast.ascii.AbstractTextCommand
-
- shouldReply() - Method in class com.hazelcast.ascii.memcache.DeleteCommand
-
- shouldReply() - Method in class com.hazelcast.ascii.memcache.IncrementCommand
-
- shouldReply() - Method in class com.hazelcast.ascii.memcache.SetCommand
-
- shouldReply() - Method in class com.hazelcast.ascii.memcache.TouchCommand
-
- shouldReply() - Method in class com.hazelcast.ascii.rest.HttpCommand
-
- shouldReply() - Method in interface com.hazelcast.ascii.TextCommand
-
- shouldReply() - Method in class com.hazelcast.cluster.impl.BindMessage
-
- shouldWait(String) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- shouldWait() - Method in class com.hazelcast.concurrent.countdownlatch.operations.AwaitOperation
-
- shouldWait() - Method in class com.hazelcast.concurrent.lock.operations.AwaitOperation
-
- shouldWait() - Method in class com.hazelcast.concurrent.lock.operations.LockOperation
-
- shouldWait() - Method in class com.hazelcast.concurrent.semaphore.operations.AcquireOperation
-
- shouldWait() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- shouldWait() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- shouldWait() - Method in class com.hazelcast.map.impl.operation.GetOperation
-
- shouldWait() - Method in class com.hazelcast.map.impl.operation.LockAwareOperation
-
- shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-
- shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnSetOperation
-
- shouldWait() - Method in class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- shouldWait() - Method in class com.hazelcast.multimap.impl.operations.ContainsEntryOperation
-
- shouldWait() - Method in class com.hazelcast.multimap.impl.operations.CountOperation
-
- shouldWait() - Method in class com.hazelcast.multimap.impl.operations.GetAllOperation
-
- shouldWait() - Method in class com.hazelcast.multimap.impl.operations.MultiMapBackupAwareOperation
-
- shouldWait() - Method in class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-
- shouldWait() - Method in class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- shouldWait() - Method in class com.hazelcast.queue.impl.operations.OfferOperation
-
- shouldWait() - Method in class com.hazelcast.queue.impl.operations.PollOperation
-
- shouldWait() - Method in class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- shouldWait() - Method in class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- shouldWait() - Method in interface com.hazelcast.spi.WaitSupport
-
- shutdown(boolean) - Method in class com.hazelcast.cache.impl.CacheService
-
- shutdown(boolean) - Method in class com.hazelcast.client.impl.ClientEngineImpl
-
- shutdown(boolean) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- shutdown(boolean) - Method in class com.hazelcast.collection.CollectionService
-
- shutdown(boolean) - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongService
-
- shutdown(boolean) - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceService
-
- shutdown(boolean) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchService
-
- shutdown(boolean) - Method in class com.hazelcast.concurrent.idgen.IdGeneratorService
-
- shutdown(boolean) - Method in class com.hazelcast.concurrent.lock.LockServiceImpl
-
- shutdown(boolean) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreService
-
- shutdown() - Method in interface com.hazelcast.core.HazelcastInstance
-
Shuts down this HazelcastInstance.
- shutdown() - Method in interface com.hazelcast.core.LifecycleService
-
gracefully shutdowns HazelcastInstance.
- shutdown(boolean) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- shutdown() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- shutdown() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- shutdown() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- shutdown() - Method in class com.hazelcast.instance.LifecycleServiceImpl
-
- shutdown(boolean) - Method in class com.hazelcast.instance.Node
-
- shutdown() - Method in class com.hazelcast.instance.TerminatedLifecycleService
-
- shutdown() - Method in class com.hazelcast.jmx.InstanceMBean
-
- shutdown() - Method in class com.hazelcast.management.ManagementCenterService
-
- shutdown(boolean) - Method in class com.hazelcast.map.impl.MapService
-
- shutdown(boolean) - Method in class com.hazelcast.mapreduce.impl.MapReduceService
-
- shutdown(boolean) - Method in class com.hazelcast.multimap.impl.MultiMapService
-
- shutdown() - Method in interface com.hazelcast.nio.ConnectionManager
-
- shutdown() - Method in class com.hazelcast.nio.tcp.AbstractIOSelector
-
- shutdown() - Method in interface com.hazelcast.nio.tcp.IOSelector
-
- shutdown() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- shutdown() - Method in class com.hazelcast.nio.tcp.WriteHandler
-
- shutdown(boolean) - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- shutdown(boolean) - Method in class com.hazelcast.queue.impl.QueueService
-
- shutdown(boolean) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapService
-
- shutdown() - Method in class com.hazelcast.spi.impl.BasicOperationScheduler
-
- shutdown() - Method in interface com.hazelcast.spi.impl.InternalOperationService
-
Shuts down this InternalOperationService.
- shutdown(boolean) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- shutdown(boolean) - Method in interface com.hazelcast.spi.ManagedService
-
Shuts down this ManagedService.
- shutdown(boolean) - Method in class com.hazelcast.topic.impl.TopicService
-
- shutdown(boolean) - Method in class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- shutdown() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- shutdown() - Method in class com.hazelcast.util.executor.StripedExecutor
-
Shuts down this StripedExecutor.
- shutdown() - Method in class com.hazelcast.util.VersionCheck
-
- shutdown() - Method in class com.hazelcast.wan.impl.WanNoDelayReplication
-
- shutdown() - Method in class com.hazelcast.wan.impl.WanReplicationServiceImpl
-
- shutdown() - Method in interface com.hazelcast.wan.WanReplicationEndpoint
-
Closes the endpoint, it's internal connections and shuts down other internal states
- shutdown() - Method in interface com.hazelcast.wan.WanReplicationService
-
Starts the shutdown process of the WAN replication service
- SHUTDOWN_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-
- shutdownAll() - Static method in class com.hazelcast.core.Hazelcast
-
Shuts down all running Hazelcast Instances on this JVM.
- shutdownAll() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-
- shutdownAll() - Static method in class com.hazelcast.jmx.ManagementService
-
- shutdownExecutor(String) - Method in class com.hazelcast.executor.impl.DistributedExecutorService
-
- shutdownExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
-
- shutdownExecutor(String) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- shutdownHazelcastInstance() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCachingProvider
-
- SHUTDOWNHOOK_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- ShutdownMemberRequest - Class in com.hazelcast.management.request
-
Request for shutting down the member.
- ShutdownMemberRequest() - Constructor for class com.hazelcast.management.request.ShutdownMemberRequest
-
- shutdownNodeByFiringEvents(Node, boolean) - Static method in class com.hazelcast.instance.NodeShutdownHelper
-
Shutdowns a node by firing lifecycle events.
- shutdownNow() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- shutdownNow() - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- ShutdownOperation - Class in com.hazelcast.executor.impl.operations
-
- ShutdownOperation() - Constructor for class com.hazelcast.executor.impl.operations.ShutdownOperation
-
- ShutdownOperation(String) - Constructor for class com.hazelcast.executor.impl.operations.ShutdownOperation
-
- ShutdownRequest - Class in com.hazelcast.executor.impl.client
-
- ShutdownRequest() - Constructor for class com.hazelcast.executor.impl.client.ShutdownRequest
-
- ShutdownRequest(String) - Constructor for class com.hazelcast.executor.impl.client.ShutdownRequest
-
- SIGNAL - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- SIGNAL_BACKUP - Static variable in class com.hazelcast.concurrent.lock.LockDataSerializerHook
-
- SignalBackupOperation - Class in com.hazelcast.concurrent.lock.operations
-
- SignalBackupOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
-
- SignalBackupOperation(ObjectNamespace, Data, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.operations.SignalBackupOperation
-
- SignalOperation - Class in com.hazelcast.concurrent.lock.operations
-
- SignalOperation() - Constructor for class com.hazelcast.concurrent.lock.operations.SignalOperation
-
- SignalOperation(ObjectNamespace, Data, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.operations.SignalOperation
-
- SignalRequest - Class in com.hazelcast.concurrent.lock.client
-
- SignalRequest() - Constructor for class com.hazelcast.concurrent.lock.client.SignalRequest
-
- SignalRequest(ObjectNamespace, String, long, String, boolean) - Constructor for class com.hazelcast.concurrent.lock.client.SignalRequest
-
- SimpleCommand - Class in com.hazelcast.ascii.memcache
-
- SimpleCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.memcache.SimpleCommand
-
- SimpleCommandParser - Class in com.hazelcast.ascii.memcache
-
- SimpleCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.memcache.SimpleCommandParser
-
- SimpleCommandProcessor - Class in com.hazelcast.ascii.memcache
-
- SimpleCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.ascii.memcache.SimpleCommandProcessor
-
- SimpleEntryView<K,V> - Class in com.hazelcast.map.impl
-
SimpleEntryView is an implementation of
EntryView
and also it is writable.
- SimpleEntryView(K, V) - Constructor for class com.hazelcast.map.impl.SimpleEntryView
-
- SimpleEntryView() - Constructor for class com.hazelcast.map.impl.SimpleEntryView
-
- SingleExecutorThreadFactory - Class in com.hazelcast.util.executor
-
- SingleExecutorThreadFactory(ThreadGroup, ClassLoader, String) - Constructor for class com.hazelcast.util.executor.SingleExecutorThreadFactory
-
- SingleMemberGroup - Class in com.hazelcast.partition.membergroup
-
- SingleMemberGroup() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- SingleMemberGroup(Member) - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- SingleMemberGroupFactory - Class in com.hazelcast.partition.membergroup
-
- SingleMemberGroupFactory() - Constructor for class com.hazelcast.partition.membergroup.SingleMemberGroupFactory
-
- SingleResultSet - Class in com.hazelcast.query.impl
-
Multiple result set for Predicates.
- SingleResultSet(ConcurrentMap<Data, QueryableEntry>) - Constructor for class com.hazelcast.query.impl.SingleResultSet
-
- size(String) - Method in interface com.hazelcast.ascii.TextCommandService
-
Returns the size of the distributed queue instance with the specified name
- size(String) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- size() - Method in interface com.hazelcast.cache.ICache
-
Total entry count.
- size() - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- SIZE - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- SIZE - Static variable in class com.hazelcast.cache.impl.CachePortableHook
-
- size() - Method in interface com.hazelcast.cache.impl.ICacheRecordStore
-
Calculates the entry size of this store which reflects the partition size of the cache.
- size() - Method in interface com.hazelcast.client.ClientEndpointManager
-
Returns the current number of endpoints.
- size() - Method in class com.hazelcast.client.impl.ClientEndpointManagerImpl
-
- size() - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- size() - Method in class com.hazelcast.collection.CollectionContainer
-
- size() - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- size() - Method in interface com.hazelcast.core.BaseMap
-
Returns the number of entries in this map.
- size() - Method in interface com.hazelcast.core.BaseMultiMap
-
Returns the number of key-value pairs in the multimap.
- size() - Method in interface com.hazelcast.core.BaseQueue
-
Returns the number of elements in this collection.
- size() - Method in interface com.hazelcast.core.MultiMap
-
Returns the number of key-value pairs in the multimap.
- size() - Method in interface com.hazelcast.core.TransactionalList
-
Returns the size of the list
- size() - Method in interface com.hazelcast.core.TransactionalMap
-
- size() - Method in interface com.hazelcast.core.TransactionalMultiMap
-
Returns the number of key-value pairs in the multimap.
- size() - Method in interface com.hazelcast.core.TransactionalQueue
-
Returns the number of elements in this collection.
- size() - Method in interface com.hazelcast.core.TransactionalSet
-
Returns the size of the set
- size() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
Size may not give precise size at a specific moment
due to the expiration logic.
- SIZE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- size() - Method in interface com.hazelcast.map.impl.mapstore.writebehind.WriteBehindQueue
-
- size() - Method in class com.hazelcast.map.impl.NearCache
-
- size() - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- size() - Method in interface com.hazelcast.map.impl.RecordStore
-
- size() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- size() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- SIZE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- SIZE - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- size() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- size() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- size() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- size() - Method in class com.hazelcast.nio.Packet
-
Returns an estimation of the packet, including its payload, in bytes.
- size() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- size() - Method in interface com.hazelcast.partition.membergroup.MemberGroup
-
- size() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- size() - Method in class com.hazelcast.query.impl.AndResultSet
-
- size() - Method in class com.hazelcast.query.impl.MultiResultSet
-
- size() - Method in class com.hazelcast.query.impl.OrResultSet
-
- size() - Method in class com.hazelcast.query.impl.SingleResultSet
-
- size() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- SIZE - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- SIZE - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- size() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- SIZE - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- size() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- size() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- size() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- size() - Method in class com.hazelcast.spi.impl.SerializableCollection
-
- size() - Method in interface com.hazelcast.storage.DataRef
-
- size() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns the number of key-value mappings in this map.
- size() - Method in class com.hazelcast.util.QueryResultSet
-
- size() - Method in interface com.hazelcast.util.scheduler.EntryTaskScheduler
-
- size() - Method in class com.hazelcast.util.SortedQueryResultSet
-
- SIZE_FACTORY - Static variable in class com.hazelcast.cache.impl.CacheDataSerializerHook
-
- SizeEstimator<T> - Interface in com.hazelcast.map.impl
-
Size estimator general contract.
- SizeEstimators - Class in com.hazelcast.map.impl
-
Static factory methods for corresponding size estimators.
- sizeInternal() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- SizeOperation - Class in com.hazelcast.multimap.impl.operations
-
- SizeOperation() - Constructor for class com.hazelcast.multimap.impl.operations.SizeOperation
-
- SizeOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.SizeOperation
-
- SizeOperation - Class in com.hazelcast.queue.impl.operations
-
Notify size of the queue.
- SizeOperation() - Constructor for class com.hazelcast.queue.impl.operations.SizeOperation
-
- SizeOperation(String) - Constructor for class com.hazelcast.queue.impl.operations.SizeOperation
-
- SizeOperationFactory - Class in com.hazelcast.map.impl.operation
-
- SizeOperationFactory() - Constructor for class com.hazelcast.map.impl.operation.SizeOperationFactory
-
- SizeOperationFactory(String) - Constructor for class com.hazelcast.map.impl.operation.SizeOperationFactory
-
- SizeRequest - Class in com.hazelcast.multimap.impl.client
-
- SizeRequest() - Constructor for class com.hazelcast.multimap.impl.client.SizeRequest
-
- SizeRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.SizeRequest
-
- SizeRequest - Class in com.hazelcast.queue.impl.client
-
Request for size of the Queue.
- SizeRequest() - Constructor for class com.hazelcast.queue.impl.client.SizeRequest
-
- SizeRequest(String) - Constructor for class com.hazelcast.queue.impl.client.SizeRequest
-
- skip(long) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- skipBytes(int) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
-
- Slf4jFactory - Class in com.hazelcast.logging
-
- Slf4jFactory() - Constructor for class com.hazelcast.logging.Slf4jFactory
-
- slice() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- sneakyThrow(Throwable) - Static method in class com.hazelcast.util.ExceptionUtil
-
- socket() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- socket() - Method in interface com.hazelcast.nio.tcp.SocketChannelWrapper
-
- SOCKET_CLIENT_BIND - Variable in class com.hazelcast.instance.GroupProperties
-
- SOCKET_CLIENT_BIND_ANY - Variable in class com.hazelcast.instance.GroupProperties
-
- SOCKET_KEEP_ALIVE - Variable in class com.hazelcast.instance.GroupProperties
-
- SOCKET_LINGER_SECONDS - Variable in class com.hazelcast.instance.GroupProperties
-
- SOCKET_NO_DELAY - Variable in class com.hazelcast.instance.GroupProperties
-
- SOCKET_RECEIVE_BUFFER_SIZE - Variable in class com.hazelcast.instance.GroupProperties
-
- SOCKET_SEND_BUFFER_SIZE - Variable in class com.hazelcast.instance.GroupProperties
-
- SOCKET_SERVER_BIND_ANY - Variable in class com.hazelcast.instance.GroupProperties
-
- SocketAcceptor - Class in com.hazelcast.nio.tcp
-
- SocketAcceptor(ServerSocketChannel, TcpIpConnectionManager) - Constructor for class com.hazelcast.nio.tcp.SocketAcceptor
-
- socketChannel - Variable in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- SocketChannelWrapper - Interface in com.hazelcast.nio.tcp
-
- SocketChannelWrapperFactory - Interface in com.hazelcast.nio.tcp
-
- SocketConnector - Class in com.hazelcast.nio.tcp
-
- SocketConnector(TcpIpConnectionManager, Address, boolean) - Constructor for class com.hazelcast.nio.tcp.SocketConnector
-
- SocketInterceptor - Interface in com.hazelcast.nio
-
An interface that provides the ability to intercept the creation of sockets.
- SocketInterceptorConfig - Class in com.hazelcast.config
-
Contains the configuration for interceptor socket
- SocketInterceptorConfig() - Constructor for class com.hazelcast.config.SocketInterceptorConfig
-
- SocketReadable - Interface in com.hazelcast.nio
-
Represents something where data can be read from.
- SocketReader - Interface in com.hazelcast.nio.tcp
-
- SocketTextReader - Class in com.hazelcast.nio.ascii
-
- SocketTextReader(TcpIpConnection) - Constructor for class com.hazelcast.nio.ascii.SocketTextReader
-
- SocketTextWriter - Class in com.hazelcast.nio.ascii
-
- SocketTextWriter(TcpIpConnection) - Constructor for class com.hazelcast.nio.ascii.SocketTextWriter
-
- SocketWritable - Interface in com.hazelcast.nio
-
Represents something that can be written to a
Connection
.
- SocketWriter<T extends SocketWritable> - Interface in com.hazelcast.nio.tcp
-
- SortedIndexStore - Class in com.hazelcast.query.impl
-
Store indexes rankly.
- SortedIndexStore() - Constructor for class com.hazelcast.query.impl.SortedIndexStore
-
- SortedQueryResultSet - Class in com.hazelcast.util
-
Collection class for results of query operations
- SortedQueryResultSet(Comparator, IterationType, int) - Constructor for class com.hazelcast.util.SortedQueryResultSet
-
- SortingUtil - Class in com.hazelcast.util
-
Utility class for generating Comparators to be used in sort methods specific to hazelcast classes.
- SPACE - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- SPI_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- SPI_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- SpiDataSerializerHook - Class in com.hazelcast.spi.impl
-
- SpiDataSerializerHook() - Constructor for class com.hazelcast.spi.impl.SpiDataSerializerHook
-
- SpiPortableHook - Class in com.hazelcast.spi.impl
-
- SpiPortableHook() - Constructor for class com.hazelcast.spi.impl.SpiPortableHook
-
- SplitBrainHandlerService - Interface in com.hazelcast.spi
-
An interface that can be implemented by SPI services that want to be able to resolve a split brain.
- SQL_QUERY - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- SqlPredicate - Class in com.hazelcast.query
-
This class contains methods related to conversion of sql query to predicate.
- SqlPredicate(String) - Constructor for class com.hazelcast.query.SqlPredicate
-
- SqlPredicate() - Constructor for class com.hazelcast.query.SqlPredicate
-
- SSLConfig - Class in com.hazelcast.config
-
SSL configuration
- SSLConfig() - Constructor for class com.hazelcast.config.SSLConfig
-
- SSLContextFactory - Interface in com.hazelcast.nio.ssl
-
- StandardLoggerFactory - Class in com.hazelcast.logging
-
- StandardLoggerFactory() - Constructor for class com.hazelcast.logging.StandardLoggerFactory
-
- start - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- start() - Method in class com.hazelcast.client.impl.ClientHeartbeatMonitor
-
- start(String[]) - Method in class com.hazelcast.console.ConsoleApp
-
- start() - Method in class com.hazelcast.instance.Node
-
- start() - Method in class com.hazelcast.management.ManagementCenterService
-
- start() - Method in class com.hazelcast.map.impl.eviction.ExpirationManager
-
- start() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
-
- start() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
-
- start() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
-
- start() - Method in interface com.hazelcast.nio.ConnectionManager
-
- start() - Method in interface com.hazelcast.nio.tcp.IOSelector
-
- start() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- start(BundleContext) - Method in class com.hazelcast.osgi.Activator
-
- start() - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- start(Xid, int) - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- START_PROCESSING_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- startAwaiting(Data, String, String, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- startClusterMerge(Address) - Method in class com.hazelcast.cluster.impl.AbstractJoiner
-
- startExecution(long) - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- startPending() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- startProcessing() - Method in class com.hazelcast.partition.MigrationInfo
-
- StartProcessingJobOperation<K> - Class in com.hazelcast.mapreduce.impl.operation
-
This operation is used to start the actual processing after all node prepared to execute the map reduce job
- StartProcessingJobOperation() - Constructor for class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- StartProcessingJobOperation(String, String, Collection<K>, KeyPredicate<K>) - Constructor for class com.hazelcast.mapreduce.impl.operation.StartProcessingJobOperation
-
- StartServer - Class in com.hazelcast.core.server
-
Starts a Hazelcast server
- startTasks(MappingPhase) - Method in class com.hazelcast.mapreduce.impl.task.JobSupervisor
-
- startTime - Variable in class com.hazelcast.map.impl.client.MapPutRequest
-
- startTime - Variable in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- STAT_NOT_AVAILABLE - Static variable in interface com.hazelcast.monitor.LocalInstanceStats
-
Fill a stat value with this if it's not available
- state - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- stateChange(Address, int, JobPartitionState.State, JobProcessInformationImpl, JobTaskConfiguration) - Static method in class com.hazelcast.mapreduce.impl.MapReduceUtil
-
- stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
-
Called when instance's state changes.
- statistics - Variable in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- statistics - Variable in class com.hazelcast.cache.impl.AbstractCacheService
-
- statistics - Variable in class com.hazelcast.map.impl.record.RecordInfo
-
- Stats - Class in com.hazelcast.ascii.memcache
-
- Stats() - Constructor for class com.hazelcast.ascii.memcache.Stats
-
- StatsCommand - Class in com.hazelcast.ascii.memcache
-
- StatsCommand() - Constructor for class com.hazelcast.ascii.memcache.StatsCommand
-
- StatsCommandProcessor - Class in com.hazelcast.ascii.memcache
-
- StatsCommandProcessor(TextCommandService) - Constructor for class com.hazelcast.ascii.memcache.StatsCommandProcessor
-
- stop() - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- stop() - Method in class com.hazelcast.cluster.impl.MulticastService
-
- stop() - Method in class com.hazelcast.console.ConsoleApp
-
- stop() - Method in interface com.hazelcast.map.impl.mapstore.MapStoreManager
-
- stop() - Method in class com.hazelcast.map.impl.mapstore.writebehind.WriteBehindManager
-
- stop() - Method in class com.hazelcast.map.impl.mapstore.writethrough.WriteThroughManager
-
- stop(BundleContext) - Method in class com.hazelcast.osgi.Activator
-
- Storage<REF extends DataRef> - Interface in com.hazelcast.storage
-
Plain storage interface for off-heap, disk etc access.
- storageEquals(Object) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- store(K, V) - Method in interface com.hazelcast.core.MapStore
-
Stores the key-value pair.
- store(K, V) - Method in class com.hazelcast.core.MapStoreAdapter
-
Stores the key-value pair.
- store(Long, T) - Method in interface com.hazelcast.core.QueueStore
-
Stores the key-value pair.
- store(Object, Object) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- store() - Method in class com.hazelcast.map.impl.record.RecordStatistics
-
- store(Long, Data) - Method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- storeAll(Map<K, V>) - Method in interface com.hazelcast.core.MapStore
-
Stores multiple entries.
- storeAll(Map<K, V>) - Method in class com.hazelcast.core.MapStoreAdapter
-
Stores multiple entries.
- storeAll(Map<Long, T>) - Method in interface com.hazelcast.core.QueueStore
-
Stores multiple entries.
- storeAll(Map) - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- storeAll(Map<Long, Data>) - Method in class com.hazelcast.queue.impl.QueueStoreWrapper
-
- STORED - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- StoreEvent<E> - Class in com.hazelcast.map.impl.mapstore.writebehind
-
For internal usage only.
- StoreListener<E> - Interface in com.hazelcast.map.impl.mapstore.writebehind
-
(For internal usage only.)
Listener's main contract
which are called before and after store operations.
- StoreWorker - Class in com.hazelcast.map.impl.mapstore.writebehind
-
Used to process store operations in another thread.
- StoreWorker(MapContainer, WriteBehindProcessor) - Constructor for class com.hazelcast.map.impl.mapstore.writebehind.StoreWorker
-
- StreamSerializer<T> - Interface in com.hazelcast.nio.serialization
-
A base class for custom serialization.
- StringAndPartitionAwarePartitioningStrategy - Class in com.hazelcast.partition.strategy
-
- StringPartitioningStrategy - Class in com.hazelcast.partition.strategy
-
- StringPartitioningStrategy() - Constructor for class com.hazelcast.partition.strategy.StringPartitioningStrategy
-
- stringToBytes(String) - Static method in class com.hazelcast.util.StringUtil
-
- StringUtil - Class in com.hazelcast.util
-
Utility class for Strings.
- StripedExecutor - Class in com.hazelcast.util.executor
-
The StripedExecutor internally uses a stripe of queues and each queue has its own private worker-thread.
- StripedExecutor(ILogger, String, ThreadGroup, int, int) - Constructor for class com.hazelcast.util.executor.StripedExecutor
-
- StripedRunnable - Interface in com.hazelcast.util.executor
-
Striped Runnable is used in StripedExecutor.
- sub(int, int) - Method in class com.hazelcast.collection.list.ListContainer
-
- subList(int, int) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- submit(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to a randomly selected member and returns a Future
representing that task.
- submit(Runnable, ExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to a random member.
- submit(Runnable, MemberSelector, ExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to a randomly selected members.
- submit(Callable<T>, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to a random member.
- submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to a randomly selected member.
- submit(Callable<T>, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submit(Runnable, MemberSelector, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submit(Callable<T>, MemberSelector, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submit(Runnable) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submit(Runnable, T) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submit(Callable<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submit(Runnable, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submit(Callable<T>, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submit() - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- submit(Collator<Map.Entry<Key, List<Value>>, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- submit() - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-
- submit(Collator<Map.Entry<Key, List<Value>>, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-
- submit() - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-
- submit(Collator<Map.Entry<Key, Value>, ValueOut>) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-
- submit(Collator) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-
- submit() - Method in interface com.hazelcast.mapreduce.MappingJob
-
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes
- submit(Collator<Map.Entry<KeyIn, List<ValueIn>>, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
-
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the
collator before returning the final result.
- submit() - Method in interface com.hazelcast.mapreduce.ReducingJob
-
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes
- submit(Collator<Map.Entry<KeyIn, List<ValueIn>>, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
-
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the
collator before returning the final result.
- submit() - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
-
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes
- submit(Collator<Map.Entry<KeyIn, ValueIn>, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
-
Submits the task to Hazelcast and executes the defined mapper and reducer on all cluster nodes and executes the
collator before returning the final result.
- submit(String, Runnable) - Method in interface com.hazelcast.spi.ExecutionService
-
- submit(String, Callable<T>) - Method in interface com.hazelcast.spi.ExecutionService
-
- submit(String, Runnable) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- submit(String, Callable<T>) - Method in class com.hazelcast.spi.impl.ExecutionServiceImpl
-
- submit(Callable<T>) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- submit(Runnable, T) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- submit(Runnable) - Method in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- submitToAllMembers(Callable<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to all cluster members and returns
map of Member-Future pairs representing pending completion of the task on each member
- submitToAllMembers(Runnable, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the all cluster members.
- submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the all cluster members.
- submitToAllMembers(Callable<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToAllMembers(Runnable, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToAllMembers(Callable<T>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToKey(K, EntryProcessor, ExecutionCallback) - Method in interface com.hazelcast.core.IMap
-
Applies the user defined EntryProcessor to the entry mapped by the key with
specified ExecutionCallback to listen event status and returns immediately.
- submitToKey(K, EntryProcessor) - Method in interface com.hazelcast.core.IMap
-
Applies the user defined EntryProcessor to the entry mapped by the key.
- submitToKey(K, EntryProcessor, ExecutionCallback) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- submitToKey(K, EntryProcessor) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- submitToKeyOwner(Callable<T>, Object) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to owner of the specified key and returns a Future
representing that task.
- submitToKeyOwner(Runnable, Object, ExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to owner of the specified key.
- submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to owner of the specified key.
- submitToKeyOwner(Callable<T>, Object) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToKeyOwner(Runnable, Object, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToKeyOwner(Callable<T>, Object, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMember(Callable<T>, Member) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to specified member and returns a Future
representing that task.
- submitToMember(Runnable, Member, ExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the specified member.
- submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the specified member.
- submitToMember(Callable<T>, Member) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMember(Runnable, Member, ExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMember(Callable<T>, Member, ExecutionCallback<T>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMembers(Callable<T>, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to given members and returns
map of Member-Future pairs representing pending completion of the task on each member
- submitToMembers(Callable<T>, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to selected members and returns
map of Member-Future pairs representing pending completion of the task on each member
- submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the specified members.
- submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the selected members.
- submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the specified members.
- submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in interface com.hazelcast.core.IExecutorService
-
Submits task to the selected members.
- submitToMembers(Callable<T>, MemberSelector) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMembers(Runnable, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMembers(Callable<T>, MemberSelector, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMembers(Callable<T>, Collection<Member>) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMembers(Runnable, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- submitToMembers(Callable<T>, Collection<Member>, MultiExecutionCallback) - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- success - Variable in class com.hazelcast.partition.impl.BaseMigrationOperation
-
- Supplier<KeyIn,ValueIn,ValueOut> - Class in com.hazelcast.mapreduce.aggregation
-
The Supplier interface is used to supply values from input data structures like
IMap
or
MultiMap
to an
aggregation.
- Supplier() - Constructor for class com.hazelcast.mapreduce.aggregation.Supplier
-
- SUPPLIER_CONSUMING_MAPPER - Static variable in class com.hazelcast.mapreduce.aggregation.impl.AggregationsDataSerializerHook
-
- SymmetricEncryptionConfig - Class in com.hazelcast.config
-
Contains configuration for symmetric encryption
- SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
-
- SYNC_DELAY_MS - Static variable in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- SYNC_FREQUENCY - Static variable in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- SYSTEM_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
-
Name of the system executor.
- SYSTEM_LOG_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- systemLogger - Variable in class com.hazelcast.instance.DefaultNodeExtension
-
- take() - Method in interface com.hazelcast.core.BaseQueue
-
Retrieves and removes the head of this queue, waiting if necessary
until an element becomes available.
- take() - Method in interface com.hazelcast.core.TransactionalQueue
-
Retrieves and removes the head of this queue, waiting if necessary
until an element becomes available.
- take() - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- take() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxy
-
- takeReadLock() - Method in class com.hazelcast.query.impl.BaseIndexStore
-
- takeWriteLock() - Method in class com.hazelcast.query.impl.BaseIndexStore
-
- target - Variable in class com.hazelcast.spi.InvocationBuilder
-
- TARGET_CALLABLE_REQUEST - Static variable in class com.hazelcast.executor.impl.ExecutorPortableHook
-
- TargetCallableRequest - Class in com.hazelcast.executor.impl.client
-
This class is used for sending the task to a particular target
- TargetCallableRequest() - Constructor for class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- TargetCallableRequest(String, String, Callable, Address) - Constructor for class com.hazelcast.executor.impl.client.TargetCallableRequest
-
- TargetClientRequest - Class in com.hazelcast.client.impl.client
-
- TargetClientRequest() - Constructor for class com.hazelcast.client.impl.client.TargetClientRequest
-
- TargetDisconnectedException - Exception in com.hazelcast.spi.exception
-
- TargetDisconnectedException() - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
-
- TargetDisconnectedException(Address) - Constructor for exception com.hazelcast.spi.exception.TargetDisconnectedException
-
- TargetNotMemberException - Exception in com.hazelcast.spi.exception
-
- TargetNotMemberException(String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
-
- TargetNotMemberException(Address, int, String, String) - Constructor for exception com.hazelcast.spi.exception.TargetNotMemberException
-
- TCKMBeanServerBuilder - Class in com.hazelcast.cache.impl
-
An MBeanServer builder required by TCK tests.
- TCKMBeanServerBuilder() - Constructor for class com.hazelcast.cache.impl.TCKMBeanServerBuilder
-
- TCKMBeanServerBuilder.RIMBeanServerDelegate - Class in com.hazelcast.cache.impl
-
- TCKMBeanServerBuilder.RIMBeanServerDelegate(MBeanServerDelegate) - Constructor for class com.hazelcast.cache.impl.TCKMBeanServerBuilder.RIMBeanServerDelegate
-
- TcpIpConfig - Class in com.hazelcast.config
-
Contains the configuration for the Tcp/Ip join mechanism.
- TcpIpConfig() - Constructor for class com.hazelcast.config.TcpIpConfig
-
- TcpIpConnection - Class in com.hazelcast.nio.tcp
-
- TcpIpConnection(TcpIpConnectionManager, IOSelector, IOSelector, int, SocketChannelWrapper) - Constructor for class com.hazelcast.nio.tcp.TcpIpConnection
-
- TcpIpConnectionManager - Class in com.hazelcast.nio.tcp
-
- TcpIpConnectionManager(IOService, ServerSocketChannel) - Constructor for class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- TcpIpConnectionMonitor - Class in com.hazelcast.nio.tcp
-
- TcpIpConnectionMonitor(TcpIpConnectionManager, Address) - Constructor for class com.hazelcast.nio.tcp.TcpIpConnectionMonitor
-
- TcpIpJoiner - Class in com.hazelcast.cluster.impl
-
- TcpIpJoiner(Node) - Constructor for class com.hazelcast.cluster.impl.TcpIpJoiner
-
- terminate() - Method in interface com.hazelcast.core.LifecycleService
-
terminate HazelcastInstance ungracefully.
- terminate() - Method in class com.hazelcast.instance.LifecycleServiceImpl
-
- terminate() - Method in class com.hazelcast.instance.TerminatedLifecycleService
-
- terminateAll() - Static method in class com.hazelcast.instance.HazelcastInstanceFactory
-
- TerminatedLifecycleService - Class in com.hazelcast.instance
-
- TerminatedLifecycleService() - Constructor for class com.hazelcast.instance.TerminatedLifecycleService
-
- TERMINATION_TIMEOUT_SECONDS - Static variable in class com.hazelcast.spi.impl.BasicOperationScheduler
-
- TEXT - Static variable in class com.hazelcast.nio.Protocols
-
Protocol that is used by Memcache And Http
- TextCommand - Interface in com.hazelcast.ascii
-
- TextCommandConstants - Class in com.hazelcast.ascii
-
- TextCommandConstants.TextCommandType - Enum in com.hazelcast.ascii
-
- TextCommandProcessor<T> - Interface in com.hazelcast.ascii
-
- textCommandService - Variable in class com.hazelcast.ascii.AbstractTextCommandProcessor
-
- TextCommandService - Interface in com.hazelcast.ascii
-
- textCommandService - Variable in class com.hazelcast.instance.Node
-
- TextCommandServiceImpl - Class in com.hazelcast.ascii
-
- TextCommandServiceImpl(Node) - Constructor for class com.hazelcast.ascii.TextCommandServiceImpl
-
- THIS_ATTRIBUTE_NAME - Static variable in class com.hazelcast.query.QueryConstants
-
Attribute name of the "this".
- thisAddress - Variable in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- thisMember - Variable in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- THREAD_ID_GENERATOR - Static variable in class com.hazelcast.util.executor.StripedExecutor
-
- ThreadDumpGenerator - Class in com.hazelcast.management
-
Generates thread dumps.
- ThreadDumpOperation - Class in com.hazelcast.management.operation
-
Operation for generating thread dumps.
- ThreadDumpOperation() - Constructor for class com.hazelcast.management.operation.ThreadDumpOperation
-
- ThreadDumpOperation(boolean) - Constructor for class com.hazelcast.management.operation.ThreadDumpOperation
-
- ThreadDumpRequest - Class in com.hazelcast.management.request
-
Request for generating thread dumps.
- ThreadDumpRequest() - Constructor for class com.hazelcast.management.request.ThreadDumpRequest
-
- ThreadDumpRequest(boolean) - Constructor for class com.hazelcast.management.request.ThreadDumpRequest
-
- threadGroup - Variable in class com.hazelcast.instance.Node
-
- threadGroup - Variable in class com.hazelcast.util.executor.AbstractExecutorThreadFactory
-
- threadId - Variable in class com.hazelcast.concurrent.lock.client.AbstractIsLockedRequest
-
- threadId - Variable in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- threadId - Variable in class com.hazelcast.map.impl.client.MapDeleteRequest
-
- threadId - Variable in class com.hazelcast.map.impl.client.MapPutRequest
-
- threadId - Variable in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- threadId - Variable in class com.hazelcast.map.impl.client.MapRemoveRequest
-
- threadId - Variable in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- threadId - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- threadId - Variable in class com.hazelcast.multimap.impl.operations.MultiMapKeyBasedOperation
-
- ThreadMonitoringService - Class in com.hazelcast.management
-
Service for monitoring threads.
- ThreadMonitoringService(ThreadGroup) - Constructor for class com.hazelcast.management.ThreadMonitoringService
-
- ThreadUtil - Class in com.hazelcast.util
-
Utility class to manipulate and query thread id
- throwExceptionIfNegative(int) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- throwExceptionIfNull(Object) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- throwExceptionIfNull(Object) - Method in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- throwNotActiveException() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- throwNotActiveException() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- TIME - Static variable in class com.hazelcast.util.executor.CachedExecutorServiceDelegate
-
- TimedMemberState - Class in com.hazelcast.monitor
-
- TimedMemberState() - Constructor for class com.hazelcast.monitor.TimedMemberState
-
- TimedMemberStateFactory - Interface in com.hazelcast.management
-
- timeout - Variable in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- timeout - Variable in class com.hazelcast.map.impl.client.MapTryRemoveRequest
-
- timeoutMillis - Variable in class com.hazelcast.queue.impl.client.QueueRequest
-
- TimeoutRunnable - Interface in com.hazelcast.util.executor
-
Interface for runnable with timeout value
- toArray() - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- toArray(T[]) - Method in class com.hazelcast.collection.AbstractCollectionProxyImpl
-
- toArray() - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- toArray(T[]) - Method in class com.hazelcast.collection.list.ListProxyImpl
-
- toArray() - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- toArray(T[]) - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- toByteArray(Object) - Method in interface com.hazelcast.ascii.TextCommandService
-
- toByteArray(Object) - Method in class com.hazelcast.ascii.TextCommandServiceImpl
-
- toByteArray() - Method in interface com.hazelcast.nio.ObjectDataOutput
-
- toByteArray() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
-
- toByteArray(ObjectDataOutput) - Method in class com.hazelcast.query.impl.AndResultSet
-
- toBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
-
- toData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- toData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- toData(Object) - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- toData(Object) - Method in class com.hazelcast.cache.impl.ClusterWideIterator
-
- toData(Object) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-
- toData(Object) - Method in class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-
- toData(Object) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- toData(Object) - Method in interface com.hazelcast.nio.IOService
-
- toData(Object) - Method in class com.hazelcast.nio.NodeIOService
-
- toData(Object) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- toData(Object, PartitioningStrategy) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- toData(Object) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- toData(Object, PartitioningStrategy) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- toData(Object) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- toData(Object) - Method in interface com.hazelcast.spi.NodeEngine
-
- toEventData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- toGigaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
-
- toHeapData(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- toHeapData(Object) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- toJson() - Method in interface com.hazelcast.management.JsonSerializable
-
- toJson() - Method in class com.hazelcast.management.ManagementCenterIdentifier
-
- toJson() - Method in class com.hazelcast.management.MapConfigAdapter
-
- toJson() - Method in class com.hazelcast.management.request.ClusterPropsRequest
-
- toJson() - Method in class com.hazelcast.management.request.ConsoleCommandRequest
-
- toJson() - Method in class com.hazelcast.management.request.ExecuteScriptRequest
-
- toJson() - Method in class com.hazelcast.management.request.GetLogsRequest
-
Deprecated.
- toJson() - Method in class com.hazelcast.management.request.GetMapEntryRequest
-
- toJson() - Method in class com.hazelcast.management.request.GetMemberSystemPropertiesRequest
-
- toJson() - Method in class com.hazelcast.management.request.GetSystemWarningsRequest
-
Deprecated.
- toJson() - Method in class com.hazelcast.management.request.MapConfigRequest
-
- toJson() - Method in class com.hazelcast.management.request.MemberConfigRequest
-
- toJson() - Method in class com.hazelcast.management.request.RunGcRequest
-
- toJson() - Method in class com.hazelcast.management.request.ShutdownMemberRequest
-
- toJson() - Method in class com.hazelcast.management.request.ThreadDumpRequest
-
- toJson() - Method in class com.hazelcast.management.SerializableClientEndPoint
-
- toJson() - Method in class com.hazelcast.management.SerializableConnectionManagerBean
-
- toJson() - Method in class com.hazelcast.management.SerializableEventServiceBean
-
- toJson() - Method in class com.hazelcast.management.SerializableManagedExecutorBean
-
- toJson() - Method in class com.hazelcast.management.SerializableMXBeans
-
- toJson() - Method in class com.hazelcast.management.SerializableOperationServiceBean
-
- toJson() - Method in class com.hazelcast.management.SerializablePartitionServiceBean
-
- toJson() - Method in class com.hazelcast.management.SerializableProxyServiceBean
-
- toJson() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.LocalExecutorStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.LocalTopicStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- toJson() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- toJson() - Method in class com.hazelcast.monitor.TimedMemberState
-
- toKiloBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
-
- toMegaBytes(long) - Method in enum com.hazelcast.memory.MemoryUnit
-
- toNewBuffer() - Method in class com.hazelcast.ascii.memcache.MemcacheEntry
-
- toObject(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheService
-
- toObject(Object) - Method in class com.hazelcast.cache.impl.AbstractClusterWideIterator
-
- toObject(Object) - Method in class com.hazelcast.cache.impl.ClusterWideIterator
-
- toObject(Object) - Method in class com.hazelcast.map.impl.mapstore.AbstractMapDataStore
-
- toObject(Object) - Method in class com.hazelcast.multimap.impl.operations.MultiMapOperation
-
- toObject(Data) - Method in interface com.hazelcast.nio.IOService
-
- toObject(Data) - Method in class com.hazelcast.nio.NodeIOService
-
- toObject() - Method in interface com.hazelcast.nio.serialization.PortableAdapter
-
- toObject(Object) - Method in interface com.hazelcast.nio.serialization.SerializationService
-
- toObject(Object) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
-
- toObject(Object) - Method in class com.hazelcast.spi.impl.NodeEngineImpl
-
- toObject(Object) - Method in interface com.hazelcast.spi.NodeEngine
-
- TOPIC_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- TOPIC_EVENT - Static variable in class com.hazelcast.topic.impl.TopicDataSerializerHook
-
- TOPIC_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
-
- TopicConfig - Class in com.hazelcast.config
-
Contains the configuration for a
ITopic
.
- TopicConfig() - Constructor for class com.hazelcast.config.TopicConfig
-
Creates a TopicConfig.
- TopicConfig(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfig
-
- TopicConfigReadOnly - Class in com.hazelcast.config
-
Configuration for topic(Read only)
- TopicConfigReadOnly(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfigReadOnly
-
- TopicDataSerializerHook - Class in com.hazelcast.topic.impl
-
- TopicDataSerializerHook() - Constructor for class com.hazelcast.topic.impl.TopicDataSerializerHook
-
- TopicEvent - Class in com.hazelcast.topic.impl
-
- TopicEvent() - Constructor for class com.hazelcast.topic.impl.TopicEvent
-
- TopicEvent(String, Data, Address) - Constructor for class com.hazelcast.topic.impl.TopicEvent
-
- TopicMBean - Class in com.hazelcast.jmx
-
- TopicMBean(ITopic, ManagementService) - Constructor for class com.hazelcast.jmx.TopicMBean
-
- TopicPermission - Class in com.hazelcast.security.permission
-
- TopicPermission(String, String...) - Constructor for class com.hazelcast.security.permission.TopicPermission
-
- TopicPortableHook - Class in com.hazelcast.topic.impl
-
- TopicPortableHook() - Constructor for class com.hazelcast.topic.impl.TopicPortableHook
-
- TopicProxy<E> - Class in com.hazelcast.topic.impl
-
- TopicProxy(String, NodeEngine, TopicService) - Constructor for class com.hazelcast.topic.impl.TopicProxy
-
- TopicService - Class in com.hazelcast.topic.impl
-
- TopicService() - Constructor for class com.hazelcast.topic.impl.TopicService
-
- TopologyChangedException - Exception in com.hazelcast.mapreduce
-
- TopologyChangedException() - Constructor for exception com.hazelcast.mapreduce.TopologyChangedException
-
Creates a new instance of the TopologyChangedException
- TopologyChangedException(String) - Constructor for exception com.hazelcast.mapreduce.TopologyChangedException
-
Creates a new instance of the TopologyChangedException
- topologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.MappingJobImpl
-
- topologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingJobImpl
-
- topologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.mapreduce.impl.AbstractJob.ReducingSubmittableJobImpl
-
- topologyChangedStrategy - Variable in class com.hazelcast.mapreduce.impl.AbstractJob
-
- topologyChangedStrategy(TopologyChangedStrategy) - Method in class com.hazelcast.mapreduce.impl.AbstractJob
-
- topologyChangedStrategy - Variable in class com.hazelcast.mapreduce.impl.client.ClientMapReduceRequest
-
- topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.Job
-
Defines the strategy to handle topology changes while executing the map reduce job.
- topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.MappingJob
-
Defines the strategy to handle topology changes while executing the map reduce job.
- topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.ReducingJob
-
Defines the strategy to handle topology changes while executing the map reduce job.
- topologyChangedStrategy(TopologyChangedStrategy) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
-
Defines the strategy to handle topology changes while executing the map reduce job.
- TopologyChangedStrategy - Enum in com.hazelcast.mapreduce
-
This enum class is used to define how a map reduce job behaves
if the job owner recognizes a topology changed event.
When members are leaving the cluster it might happen to loose
processed data chunks that were already send to the reducers
on the leaving node.
In addition to that on any topology change there is a redistribution
of the member assigned partitions which means that a map job might
have a problem to finish it's currently processed partition.
The default behavior is immediately cancelling the running task and
throwing an
TopologyChangedException
but it is possible
to submit the same job configuration again if
JobTracker.getTrackableJob(String)
returns null for the requested job id.
- toPrettyString() - Method in class com.hazelcast.memory.MemorySize
-
Returns a pretty format String representation of this memory size.
- toPrettyString(long) - Static method in class com.hazelcast.memory.MemorySize
-
Utility method to create a pretty format representation of given value in bytes.
- toPrettyString(long, MemoryUnit) - Static method in class com.hazelcast.memory.MemorySize
-
Utility method to create a pretty format representation of given value in given unit.
- toRecord(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- toString() - Method in class com.hazelcast.ascii.AbstractTextCommand
-
- toString() - Method in class com.hazelcast.ascii.memcache.DeleteCommand
-
- toString() - Method in class com.hazelcast.ascii.memcache.EndCommand
-
- toString() - Method in class com.hazelcast.ascii.memcache.ErrorCommand
-
- toString() - Method in class com.hazelcast.ascii.memcache.GetCommand
-
- toString() - Method in class com.hazelcast.ascii.memcache.MemcacheEntry
-
- toString() - Method in class com.hazelcast.ascii.memcache.PartialGetCommand
-
- toString() - Method in class com.hazelcast.ascii.memcache.SetCommand
-
- toString() - Method in class com.hazelcast.ascii.memcache.SimpleCommand
-
- toString() - Method in class com.hazelcast.ascii.memcache.StatsCommand
-
- toString() - Method in class com.hazelcast.ascii.NoOpCommand
-
- toString() - Method in class com.hazelcast.ascii.rest.HttpCommand
-
- toString() - Method in class com.hazelcast.ascii.rest.RestValue
-
- toString() - Method in class com.hazelcast.cache.HazelcastCachingProvider
-
- toString() - Method in class com.hazelcast.cache.impl.AbstractHazelcastCacheManager
-
- toString() - Method in class com.hazelcast.cache.impl.CacheEntryEventImpl
-
- toString() - Method in class com.hazelcast.cache.impl.CacheEventDataImpl
-
- toString() - Method in class com.hazelcast.cache.impl.CacheKeyIteratorResult
-
- toString() - Method in class com.hazelcast.cache.impl.HazelcastServerCachingProvider
-
- toString() - Method in class com.hazelcast.cache.impl.operation.CacheGetAllOperation
-
- toString() - Method in class com.hazelcast.client.impl.client.ClientPrincipal
-
- toString() - Method in class com.hazelcast.client.impl.client.ClientResponse
-
- toString() - Method in class com.hazelcast.client.impl.client.GenericError
-
- toString() - Method in class com.hazelcast.client.impl.ClientEndpointImpl
-
- toString() - Method in class com.hazelcast.cluster.impl.BindMessage
-
- toString() - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- toString() - Method in class com.hazelcast.cluster.impl.JoinMessage
-
- toString() - Method in class com.hazelcast.cluster.impl.JoinRequest
-
- toString() - Method in class com.hazelcast.cluster.impl.operations.JoinRequestOperation
-
- toString() - Method in class com.hazelcast.cluster.impl.operations.MasterDiscoveryOperation
-
- toString() - Method in class com.hazelcast.cluster.impl.operations.MemberInfoUpdateOperation
-
- toString() - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
-
- toString() - Method in class com.hazelcast.cluster.impl.operations.SetMasterOperation
-
- toString() - Method in class com.hazelcast.cluster.MemberInfo
-
- toString() - Method in class com.hazelcast.collection.txn.CollectionTransactionLog
-
- toString() - Method in class com.hazelcast.concurrent.atomiclong.AtomicLongProxy
-
- toString() - Method in class com.hazelcast.concurrent.atomicreference.AtomicReferenceProxy
-
- toString() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchInfo
-
- toString() - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- toString() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- toString() - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- toString() - Method in class com.hazelcast.concurrent.lock.LockWaitNotifyKey
-
- toString() - Method in class com.hazelcast.concurrent.semaphore.Permit
-
- toString() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- toString() - Method in class com.hazelcast.config.AwsConfig
-
- toString() - Method in class com.hazelcast.config.CacheConfig
-
- toString() - Method in class com.hazelcast.config.Config
-
- toString() - Method in class com.hazelcast.config.CredentialsFactoryConfig
-
- toString() - Method in class com.hazelcast.config.EntryListenerConfig
-
- toString() - Method in class com.hazelcast.config.ExecutorConfig
-
- toString() - Method in class com.hazelcast.config.GlobalSerializerConfig
-
- toString() - Method in class com.hazelcast.config.GroupConfig
-
- toString() - Method in class com.hazelcast.config.InterfacesConfig
-
- toString() - Method in class com.hazelcast.config.ItemListenerConfig
-
- toString() - Method in class com.hazelcast.config.JoinConfig
-
- toString() - Method in class com.hazelcast.config.ListenerConfig
-
- toString() - Method in class com.hazelcast.config.LoginModuleConfig
-
- toString() - Method in class com.hazelcast.config.ManagementCenterConfig
-
- toString() - Method in class com.hazelcast.config.MapConfig
-
- toString() - Method in class com.hazelcast.config.MapIndexConfig
-
- toString() - Method in class com.hazelcast.config.MapStoreConfig
-
- toString() - Method in class com.hazelcast.config.MaxSizeConfig
-
- toString() - Method in class com.hazelcast.config.MemberGroupConfig
-
- toString() - Method in class com.hazelcast.config.MulticastConfig
-
- toString() - Method in class com.hazelcast.config.MultiMapConfig
-
- toString() - Method in class com.hazelcast.config.NativeMemoryConfig
-
- toString() - Method in class com.hazelcast.config.NearCacheConfig
-
- toString() - Method in class com.hazelcast.config.NetworkConfig
-
- toString() - Method in class com.hazelcast.config.PartitionGroupConfig
-
- toString() - Method in class com.hazelcast.config.PartitioningStrategyConfig
-
- toString() - Method in class com.hazelcast.config.PermissionConfig
-
- toString() - Method in class com.hazelcast.config.PermissionPolicyConfig
-
- toString() - Method in class com.hazelcast.config.QueueConfig
-
- toString() - Method in class com.hazelcast.config.QueueStoreConfig
-
- toString() - Method in class com.hazelcast.config.SecurityConfig
-
- toString() - Method in class com.hazelcast.config.SemaphoreConfig
-
- toString() - Method in class com.hazelcast.config.SerializationConfig
-
- toString() - Method in class com.hazelcast.config.SerializerConfig
-
- toString() - Method in class com.hazelcast.config.ServiceConfig
-
- toString() - Method in class com.hazelcast.config.ServicesConfig
-
- toString() - Method in class com.hazelcast.config.SocketInterceptorConfig
-
- toString() - Method in class com.hazelcast.config.SSLConfig
-
- toString() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
-
- toString() - Method in class com.hazelcast.config.TcpIpConfig
-
- toString() - Method in class com.hazelcast.config.TopicConfig
-
- toString() - Method in class com.hazelcast.config.WanReplicationConfig
-
- toString() - Method in class com.hazelcast.config.WanReplicationRef
-
- toString() - Method in class com.hazelcast.config.WanTargetClusterConfig
-
- toString() - Method in class com.hazelcast.core.AbstractIMapEvent
-
- toString() - Method in class com.hazelcast.core.DistributedObjectEvent
-
- toString() - Method in class com.hazelcast.core.EntryEvent
-
- toString() - Method in class com.hazelcast.core.InitialMembershipEvent
-
- toString() - Method in class com.hazelcast.core.ItemEvent
-
- toString() - Method in class com.hazelcast.core.LifecycleEvent
-
- toString() - Method in class com.hazelcast.core.MapEvent
-
- toString() - Method in class com.hazelcast.core.MembershipEvent
-
- toString() - Method in class com.hazelcast.core.MigrationEvent
-
- toString() - Method in class com.hazelcast.core.PartitionAwareKey
-
- toString() - Method in class com.hazelcast.executor.impl.client.PartitionCallableRequest
-
- toString() - Method in class com.hazelcast.executor.impl.ExecutorServiceProxy
-
- toString() - Method in class com.hazelcast.executor.impl.RunnableAdapter
-
- toString() - Method in class com.hazelcast.instance.BuildInfo
-
- toString() - Method in class com.hazelcast.instance.GroupProperties.GroupProperty
-
- toString() - Method in class com.hazelcast.instance.HazelcastInstanceImpl
-
- toString() - Method in class com.hazelcast.instance.HazelcastInstanceProxy
-
- toString() - Method in class com.hazelcast.instance.MemberImpl
-
- toString() - Method in class com.hazelcast.instance.Node
-
- toString() - Method in class com.hazelcast.management.MonitoredThread
-
- toString() - Method in class com.hazelcast.management.ThreadMonitoringService
-
- toString() - Method in class com.hazelcast.map.impl.EntryEventData
-
- toString() - Method in class com.hazelcast.map.impl.MapEventData
-
- toString() - Method in class com.hazelcast.map.impl.mapstore.writebehind.DelayedEntry
-
- toString() - Method in class com.hazelcast.map.impl.MapStoreWrapper
-
- toString() - Method in class com.hazelcast.map.impl.operation.AddInterceptorOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.BasePutOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.BaseRemoveOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.ClearBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.ClearExpiredOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.ClearOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.ContainsKeyOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.DeleteOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.EntryBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.EntryOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.EvictAllBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.EvictAllOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.EvictOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.GetAllOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.GetEntryViewOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.GetOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.InvalidateNearCacheOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.MergeOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.MultipleEntryBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.MultipleEntryOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.NearCacheKeySetInvalidationOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PartitionWideEntryWithPredicateOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PutAllBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PutAllOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PutBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllBackupOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PutFromLoadAllOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PutIfAbsentOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PutOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.PutTransientOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.RemoveIfSameOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.RemoveInterceptorOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.RemoveOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.ReplaceIfSameOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.ReplaceOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.SetOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.TryPutOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- toString() - Method in class com.hazelcast.map.impl.operation.WanOriginatedDeleteOperation
-
- toString() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- toString() - Method in class com.hazelcast.map.impl.record.RecordInfo
-
- toString() - Method in class com.hazelcast.map.impl.record.RecordReplicationInfo
-
- toString() - Method in class com.hazelcast.map.impl.tx.MapTransactionLog
-
- toString() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- toString() - Method in class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-
- toString() - Method in class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- toString() - Method in class com.hazelcast.mapreduce.impl.notification.IntermediateChunkNotification
-
- toString() - Method in class com.hazelcast.mapreduce.impl.notification.LastChunkNotification
-
- toString() - Method in class com.hazelcast.mapreduce.impl.notification.MapReduceNotification
-
- toString() - Method in class com.hazelcast.mapreduce.impl.notification.MemberAwareMapReduceNotification
-
- toString() - Method in class com.hazelcast.mapreduce.impl.notification.ReducingFinishedNotification
-
- toString() - Method in class com.hazelcast.mapreduce.impl.operation.RequestPartitionResult
-
- toString() - Method in class com.hazelcast.mapreduce.impl.task.JobPartitionStateImpl
-
- toString() - Method in class com.hazelcast.mapreduce.impl.task.JobProcessInformationImpl
-
- toString() - Method in class com.hazelcast.memory.MemorySize
-
- toString() - Method in class com.hazelcast.monitor.impl.LocalCacheStatsImpl
-
- toString() - Method in class com.hazelcast.monitor.impl.LocalGCStatsImpl
-
- toString() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- toString() - Method in class com.hazelcast.monitor.impl.LocalMemoryStatsImpl
-
- toString() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- toString() - Method in class com.hazelcast.monitor.impl.MemberStateImpl
-
- toString() - Method in class com.hazelcast.monitor.impl.NearCacheStatsImpl
-
- toString() - Method in class com.hazelcast.monitor.TimedMemberState
-
- toString() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- toString() - Method in class com.hazelcast.multimap.impl.txn.MultiMapTransactionLog
-
- toString() - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- toString() - Method in class com.hazelcast.nio.Address
-
- toString() - Method in class com.hazelcast.nio.DynamicByteBuffer
-
- toString() - Method in class com.hazelcast.nio.Packet
-
- toString() - Method in class com.hazelcast.nio.serialization.DefaultData
-
- toString() - Method in class com.hazelcast.nio.tcp.DefaultSocketChannelWrapper
-
- toString() - Method in class com.hazelcast.nio.tcp.TcpIpConnection
-
- toString() - Method in class com.hazelcast.nio.tcp.TcpIpConnectionManager
-
- toString() - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-
- toString() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-
- toString() - Method in class com.hazelcast.partition.impl.InternalPartitionServiceImpl
-
- toString() - Method in class com.hazelcast.partition.impl.MigrationOperation
-
- toString() - Method in class com.hazelcast.partition.impl.PartitionReplicaChangeEvent
-
- toString() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- toString() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- toString() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- toString() - Method in class com.hazelcast.partition.membergroup.DefaultMemberGroup
-
- toString() - Method in class com.hazelcast.partition.membergroup.SingleMemberGroup
-
- toString() - Method in class com.hazelcast.partition.MigrationInfo
-
- toString() - Method in class com.hazelcast.partition.PartitionInfo
-
- toString() - Method in class com.hazelcast.partition.PartitionRuntimeState
-
- toString() - Method in class com.hazelcast.partition.PartitionServiceProxy.PartitionProxy
-
- toString() - Method in class com.hazelcast.query.impl.SortedIndexStore
-
- toString() - Method in class com.hazelcast.query.impl.UnsortedIndexStore
-
- toString() - Method in class com.hazelcast.query.PredicateBuilder
-
- toString() - Method in class com.hazelcast.query.Predicates.AndPredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.BetweenPredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.EqualPredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.GreaterLessPredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.ILikePredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.InPredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.LikePredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.NotEqualPredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.NotPredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.OrPredicate
-
- toString() - Method in class com.hazelcast.query.Predicates.RegexPredicate
-
- toString() - Method in class com.hazelcast.query.SqlPredicate
-
- toString() - Method in class com.hazelcast.queue.impl.proxy.QueueProxyImpl
-
- toString() - Method in class com.hazelcast.queue.impl.tx.TransactionalQueueProxy
-
- toString() - Method in class com.hazelcast.replicatedmap.impl.messages.ReplicationMessage
-
- toString() - Method in class com.hazelcast.replicatedmap.impl.record.ReplicatedRecord
-
- toString() - Method in class com.hazelcast.replicatedmap.impl.record.VectorClockTimestamp
-
- toString() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- toString() - Method in class com.hazelcast.security.permission.AllPermissions.AllPermissionsCollection
-
- toString() - Method in class com.hazelcast.security.permission.AllPermissions
-
- toString() - Method in class com.hazelcast.security.permission.ClusterPermissionCollection
-
- toString() - Method in class com.hazelcast.security.permission.DenyAllPermissionCollection
-
- toString() - Method in class com.hazelcast.security.UsernamePasswordCredentials
-
- toString() - Method in class com.hazelcast.spi.AbstractDistributedObject
-
- toString() - Method in class com.hazelcast.spi.DefaultObjectNamespace
-
- toString() - Method in class com.hazelcast.spi.impl.BasicOperationScheduler
-
- toString() - Method in class com.hazelcast.spi.impl.DistributedObjectEventPacket
-
- toString() - Method in class com.hazelcast.spi.impl.EventServiceImpl.EventPacket
-
- toString() - Method in class com.hazelcast.spi.impl.EventServiceImpl.Registration
-
- toString() - Method in class com.hazelcast.spi.impl.NormalResponse
-
- toString() - Method in class com.hazelcast.spi.PartitionMigrationEvent
-
- toString() - Method in class com.hazelcast.spi.PartitionReplicationEvent
-
- toString() - Method in class com.hazelcast.spi.ServiceInfo
-
- toString() - Method in class com.hazelcast.topic.impl.TopicEvent
-
- toString() - Method in class com.hazelcast.transaction.impl.SerializableXID
-
- toString() - Method in class com.hazelcast.transaction.impl.XAResourceImpl
-
- toString() - Method in class com.hazelcast.transaction.TransactionOptions
-
- toString() - Method in class com.hazelcast.util.AddressUtil.AddressHolder
-
- toString() - Method in class com.hazelcast.util.AddressUtil.AddressMatcher
-
- toString() - Method in class com.hazelcast.util.executor.NamedThreadPoolExecutor
-
- toString() - Method in class com.hazelcast.util.QueryResultSet
-
- toString() - Method in class com.hazelcast.util.scheduler.ScheduledEntry
-
- toStringAndClear(ByteBuffer) - Static method in class com.hazelcast.nio.ascii.SocketTextReader
-
- total() - Method in class com.hazelcast.monitor.impl.LocalMapStatsImpl
-
- total() - Method in class com.hazelcast.monitor.impl.LocalQueueStatsImpl
-
- total() - Method in class com.hazelcast.monitor.impl.LocalReplicatedMapStatsImpl
-
- total() - Method in interface com.hazelcast.monitor.LocalMapStats
-
Returns the total number of total operations
- TotalOrderedTopicProxy - Class in com.hazelcast.topic.impl
-
- TotalOrderedTopicProxy(String, NodeEngine, TopicService) - Constructor for class com.hazelcast.topic.impl.TotalOrderedTopicProxy
-
- totalPhysicalMemory() - Static method in class com.hazelcast.memory.MemoryStatsSupport
-
- TouchCommand - Class in com.hazelcast.ascii.memcache
-
User: sancar
Date: 3/8/13
Time: 1:54 PM
- TouchCommand(TextCommandConstants.TextCommandType, String, int, boolean) - Constructor for class com.hazelcast.ascii.memcache.TouchCommand
-
- TouchCommandParser - Class in com.hazelcast.ascii.memcache
-
User: sancar
Date: 3/8/13
Time: 1:52 PM
- TouchCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.memcache.TouchCommandParser
-
- TouchCommandProcessor - Class in com.hazelcast.ascii.memcache
-
User: sancar
Date: 3/8/13
Time: 2:03 PM
- TouchCommandProcessor(TextCommandServiceImpl) - Constructor for class com.hazelcast.ascii.memcache.TouchCommandProcessor
-
- TOUCHED - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- toValue(Object) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- TraceableIsStillExecutingOperation - Class in com.hazelcast.spi.impl
-
- TraceableIsStillExecutingOperation(String, Object) - Constructor for class com.hazelcast.spi.impl.TraceableIsStillExecutingOperation
-
- TraceableOperation - Interface in com.hazelcast.spi
-
Operation which has a traceable identifier
- TrackableJob<V> - Interface in com.hazelcast.mapreduce
-
This interface describes a trackable job.
- TrackableJobFuture<V> - Class in com.hazelcast.mapreduce.impl.task
-
This is the node based implementation of the job's reactive
ICompletableFuture
and is returned to the users codebase.
- TrackableJobFuture(String, String, JobTracker, NodeEngine, Collator) - Constructor for class com.hazelcast.mapreduce.impl.task.TrackableJobFuture
-
- trackableJobs - Variable in class com.hazelcast.mapreduce.impl.AbstractJobTracker
-
- TRACKED_JOB_OPERATION - Static variable in class com.hazelcast.mapreduce.impl.MapReduceDataSerializerHook
-
- Transaction - Interface in com.hazelcast.transaction.impl
-
- Transaction.State - Enum in com.hazelcast.transaction.impl
-
- TRANSACTION_ROLLBACK - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TransactionAccessor - Class in com.hazelcast.transaction.impl
-
- TransactionalList<E> - Interface in com.hazelcast.core
-
Transactional implementation of
IList
.
- TransactionalListProxy<E> - Class in com.hazelcast.collection.txn
-
- TransactionalListProxy(String, TransactionSupport, NodeEngine, ListService) - Constructor for class com.hazelcast.collection.txn.TransactionalListProxy
-
- TransactionalMap<K,V> - Interface in com.hazelcast.core
-
Transactional implementation of
BaseMap
.
- TransactionalMapProxy - Class in com.hazelcast.map.impl.tx
-
- TransactionalMapProxy(String, MapService, NodeEngine, TransactionSupport) - Constructor for class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- TransactionalMapProxySupport - Class in com.hazelcast.map.impl.tx
-
- TransactionalMapProxySupport(String, MapService, NodeEngine, TransactionSupport) - Constructor for class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- TransactionalMultiMap<K,V> - Interface in com.hazelcast.core
-
- TransactionalMultiMapProxy<K,V> - Class in com.hazelcast.multimap.impl.txn
-
- TransactionalMultiMapProxy(NodeEngine, MultiMapService, String, TransactionSupport) - Constructor for class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- TransactionalMultiMapProxySupport - Class in com.hazelcast.multimap.impl.txn
-
- TransactionalMultiMapProxySupport(NodeEngine, MultiMapService, String, TransactionSupport) - Constructor for class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- TransactionalObject - Interface in com.hazelcast.transaction
-
Marker interface for all transactional distributed objects.
- TransactionalQueue<E> - Interface in com.hazelcast.core
-
- TransactionalQueueProxy<E> - Class in com.hazelcast.queue.impl.tx
-
Provides proxy for the Transactional Queue.
- TransactionalQueueProxy(NodeEngine, QueueService, String, TransactionSupport) - Constructor for class com.hazelcast.queue.impl.tx.TransactionalQueueProxy
-
- TransactionalQueueProxySupport - Class in com.hazelcast.queue.impl.tx
-
Provides support for proxy of the Transactional Queue.
- TransactionalQueueProxySupport(NodeEngine, QueueService, String, TransactionSupport) - Constructor for class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- TransactionalService - Interface in com.hazelcast.spi
-
An interface that can be implemented by SPI services that want to deal with transactions.
- TransactionalSet<E> - Interface in com.hazelcast.core
-
Transactional implementation of
ISet
.
- TransactionalSetProxy<E> - Class in com.hazelcast.collection.txn
-
- TransactionalSetProxy(String, TransactionSupport, NodeEngine, SetService) - Constructor for class com.hazelcast.collection.txn.TransactionalSetProxy
-
- TransactionalTask<T> - Interface in com.hazelcast.transaction
-
Contains the logic that is going to be executed within a transaction.
- TransactionalTaskContext - Interface in com.hazelcast.transaction
-
Provides a context to access transactional data-structures like the
TransactionalMap
.
- TransactionContext - Interface in com.hazelcast.transaction
-
Provides a context to do transactional operations; so beginning/committing transactions, but also retrieving
transactional data-structures like the
TransactionalMap
.
- TransactionException - Exception in com.hazelcast.transaction
-
A
HazelcastException
that is thrown when something goes wrong while dealing with transactions and transactional
data-structures.
- TransactionException() - Constructor for exception com.hazelcast.transaction.TransactionException
-
- TransactionException(String) - Constructor for exception com.hazelcast.transaction.TransactionException
-
- TransactionException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
-
- TransactionException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionException
-
- TransactionLog - Interface in com.hazelcast.transaction.impl
-
- TransactionManagerService - Interface in com.hazelcast.transaction
-
- TransactionManagerServiceImpl - Class in com.hazelcast.transaction.impl
-
- TransactionManagerServiceImpl(NodeEngineImpl) - Constructor for class com.hazelcast.transaction.impl.TransactionManagerServiceImpl
-
- TransactionNotActiveException - Exception in com.hazelcast.transaction
-
A
HazelcastException
thrown when an a transactional operation is executed without an active transaction.
- TransactionNotActiveException() - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
-
- TransactionNotActiveException(String) - Constructor for exception com.hazelcast.transaction.TransactionNotActiveException
-
- TransactionOptions - Class in com.hazelcast.transaction
-
Contains the configuration for a Hazelcast transaction.
- TransactionOptions() - Constructor for class com.hazelcast.transaction.TransactionOptions
-
Creates a new default configured TransactionsOptions.
- TransactionOptions.TransactionType - Enum in com.hazelcast.transaction
-
The type of transaction.
- TransactionPermission - Class in com.hazelcast.security.permission
-
- TransactionPermission() - Constructor for class com.hazelcast.security.permission.TransactionPermission
-
- TransactionSupport - Interface in com.hazelcast.transaction.impl
-
- TransactionTimedOutException - Exception in com.hazelcast.transaction
-
Thrown when a transaction has timed out.
- TransactionTimedOutException() - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
-
- TransactionTimedOutException(String) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
-
- TransactionTimedOutException(String, Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
-
- TransactionTimedOutException(Throwable) - Constructor for exception com.hazelcast.transaction.TransactionTimedOutException
-
- TRANSFERABLE_PROCESS_INFORMATION - Static variable in class com.hazelcast.mapreduce.impl.MapReducePortableHook
-
- TransferableJobProcessInformation - Class in com.hazelcast.mapreduce.impl.task
-
This implementation of
JobProcessInformation
is used to
transmit the currently processed number of records and the partition states to a requesting
client.
- TransferableJobProcessInformation() - Constructor for class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- TransferableJobProcessInformation(JobPartitionState[], int) - Constructor for class com.hazelcast.mapreduce.impl.task.TransferableJobProcessInformation
-
- TruePredicate - Class in com.hazelcast.query
-
- TruePredicate() - Constructor for class com.hazelcast.query.TruePredicate
-
- TRY_PUT - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- TRY_REMOVE - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- tryAcquire() - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- tryAcquire(int) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- tryAcquire(long, TimeUnit) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- tryAcquire(int, long, TimeUnit) - Method in class com.hazelcast.concurrent.semaphore.SemaphoreProxy
-
- tryAcquire() - Method in interface com.hazelcast.core.ISemaphore
-
Acquires a permit, if one is available and returns immediately,
with the value true
,
reducing the number of available permits by one.
- tryAcquire(int) - Method in interface com.hazelcast.core.ISemaphore
-
Acquires the given number of permits, if they are available, and
returns immediately, with the value true
,
reducing the number of available permits by the given amount.
- tryAcquire(long, TimeUnit) - Method in interface com.hazelcast.core.ISemaphore
-
Acquires a permit from this semaphore, if one becomes available
within the given waiting time and the current thread has not
been
interrupted.
- tryAcquire(int, long, TimeUnit) - Method in interface com.hazelcast.core.ISemaphore
-
Acquires the given number of permits, if they are available and
returns immediately, with the value true
,
reducing the number of available permits by the given amount.
- tryCloseConnections(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
Tries to close server socket and connections to other HazelcastInstances.
- tryCloseConnections(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher.Helper
-
- tryCount - Variable in class com.hazelcast.spi.InvocationBuilder
-
- tryLock() - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- tryLock(long, TimeUnit) - Method in class com.hazelcast.concurrent.lock.LockProxy
-
- tryLock(NodeEngine, Data) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-
- tryLock(NodeEngine, Data, long, TimeUnit) - Method in class com.hazelcast.concurrent.lock.LockProxySupport
-
- tryLock() - Method in interface com.hazelcast.core.ILock
- tryLock(long, TimeUnit) - Method in interface com.hazelcast.core.ILock
- tryLock(K) - Method in interface com.hazelcast.core.IMap
-
Tries to acquire the lock for the specified key.
- tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
-
Tries to acquire the lock for the specified key.
- tryLock(K) - Method in interface com.hazelcast.core.MultiMap
-
Tries to acquire the lock for the specified key.
- tryLock(K, long, TimeUnit) - Method in interface com.hazelcast.core.MultiMap
-
Tries to acquire the lock for the specified key.
- tryLock(K) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- tryLock(K, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- tryLock(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- tryLock(K, long, TimeUnit) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- tryPauseMillis - Variable in class com.hazelcast.spi.InvocationBuilder
-
- tryPut(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
-
Tries to put the given key, value into this map within specified
timeout value.
- tryPut(Data, Object, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- tryPut(K, V, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- tryPut(Data, Object, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- TryPutOperation - Class in com.hazelcast.map.impl.operation
-
- TryPutOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.operation.TryPutOperation
-
- TryPutOperation() - Constructor for class com.hazelcast.map.impl.operation.TryPutOperation
-
- tryRemove(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
-
Tries to remove the entry with the given key from this map
within specified timeout value.
- tryRemove(K, long, TimeUnit) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- TryRemoveOperation - Class in com.hazelcast.map.impl.operation
-
- TryRemoveOperation(String, Data, long) - Constructor for class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- TryRemoveOperation() - Constructor for class com.hazelcast.map.impl.operation.TryRemoveOperation
-
- trySetCount(int) - Method in class com.hazelcast.concurrent.countdownlatch.CountDownLatchProxy
-
- trySetCount(int) - Method in interface com.hazelcast.core.ICountDownLatch
-
Sets the count to the given value if the current count is zero.
- tryShutdown(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
Tries to shutdown HazelcastInstance forcefully;
including closing sockets and connections, stopping threads etc.
- tryShutdown(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher.Helper
-
- tryStopThreads(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
-
Tries to stop internal Hazelcast threads (such as service thread, IO threads, executor threads).
- tryStopThreads(HazelcastInstance) - Static method in class com.hazelcast.instance.OutOfMemoryErrorDispatcher.Helper
-
- ttl - Variable in class com.hazelcast.concurrent.lock.client.AbstractLockRequest
-
- ttl - Variable in class com.hazelcast.map.impl.client.MapPutRequest
-
- ttl - Variable in class com.hazelcast.map.impl.operation.KeyBasedMapOperation
-
- ttl - Variable in class com.hazelcast.map.impl.record.RecordInfo
-
- ttlToExpirePolicy(long) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- tx - Variable in class com.hazelcast.collection.txn.AbstractTransactionalCollectionProxy
-
- tx - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- tx - Variable in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- tx - Variable in class com.hazelcast.queue.impl.tx.TransactionalQueueProxySupport
-
- TX_COLLECTION_ITEM - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- TX_QUEUE_ITEM - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TX_ROLLBACK - Static variable in class com.hazelcast.collection.CollectionDataSerializerHook
-
- TxCollectionItem - Class in com.hazelcast.collection
-
- TxCollectionItem() - Constructor for class com.hazelcast.collection.TxCollectionItem
-
- TxCollectionItem(CollectionItem) - Constructor for class com.hazelcast.collection.TxCollectionItem
-
- TxCollectionItem(long, Data, String, boolean) - Constructor for class com.hazelcast.collection.TxCollectionItem
-
- txMap - Variable in class com.hazelcast.collection.CollectionContainer
-
- txMapSize() - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TXN_COMMIT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_COMMIT_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_GENERATE_RECORD_ID - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_LIST_ADD - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- TXN_LIST_REMOVE - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- TXN_LIST_SIZE - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- TXN_LOCK_AND_GET - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_MM_GET - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- TXN_MM_PUT - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- TXN_MM_REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- TXN_MM_REMOVEALL - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- TXN_MM_SIZE - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- TXN_MM_VALUE_COUNT - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- TXN_OFFER - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_OFFER - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- TXN_OFFER_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_PEEK - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_PEEK - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- TXN_POLL - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_POLL - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- TXN_POLL_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_PREPARE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_PREPARE - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_PREPARE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_PREPARE_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_PUT - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_PUT_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_REMOVE - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_REMOVE_ALL - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_REMOVE_ALL_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_REMOVE_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_REQUEST - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- TXN_REQUEST_WITH_SQL_QUERY - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- TXN_RESERVE_OFFER - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_RESERVE_OFFER_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_RESERVE_POLL - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_RESERVE_POLL_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_ROLLBACK - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_ROLLBACK - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_ROLLBACK_BACKUP - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- TXN_ROLLBACK_BACKUP - Static variable in class com.hazelcast.queue.impl.QueueDataSerializerHook
-
- TXN_SET_ADD - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- TXN_SET_REMOVE - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- TXN_SET_SIZE - Static variable in class com.hazelcast.collection.CollectionPortableHook
-
- TXN_SIZE - Static variable in class com.hazelcast.queue.impl.QueuePortableHook
-
- TxnCollectionRequest - Class in com.hazelcast.collection.client
-
- TxnCollectionRequest() - Constructor for class com.hazelcast.collection.client.TxnCollectionRequest
-
- TxnCollectionRequest(String) - Constructor for class com.hazelcast.collection.client.TxnCollectionRequest
-
- TxnCollectionRequest(String, Data) - Constructor for class com.hazelcast.collection.client.TxnCollectionRequest
-
- TxnCommitBackupOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnCommitBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
-
- TxnCommitBackupOperation(String, Data, List<Operation>, String, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnCommitBackupOperation
-
- txnCommitOffer(long, Data, boolean) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnCommitOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnCommitOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- TxnCommitOperation(String, Data, long, List<Operation>) - Constructor for class com.hazelcast.multimap.impl.txn.TxnCommitOperation
-
- txnCommitPoll(long) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- txnCommitPollBackup(long) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnDeleteOperation - Class in com.hazelcast.map.impl.tx
-
Transactional delete operation
- TxnDeleteOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- TxnDeleteOperation(String, Data, long) - Constructor for class com.hazelcast.map.impl.tx.TxnDeleteOperation
-
- txnEnsureReserve(long) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnGenerateRecordIdOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnGenerateRecordIdOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
-
- TxnGenerateRecordIdOperation(String, Data) - Constructor for class com.hazelcast.multimap.impl.txn.TxnGenerateRecordIdOperation
-
- txnId - Variable in class com.hazelcast.transaction.client.BaseTransactionRequest
-
- TxnListAddRequest - Class in com.hazelcast.collection.client
-
- TxnListAddRequest() - Constructor for class com.hazelcast.collection.client.TxnListAddRequest
-
- TxnListAddRequest(String, Data) - Constructor for class com.hazelcast.collection.client.TxnListAddRequest
-
- TxnListRemoveRequest - Class in com.hazelcast.collection.client
-
- TxnListRemoveRequest() - Constructor for class com.hazelcast.collection.client.TxnListRemoveRequest
-
- TxnListRemoveRequest(String, Data) - Constructor for class com.hazelcast.collection.client.TxnListRemoveRequest
-
- TxnListSizeRequest - Class in com.hazelcast.collection.client
-
- TxnListSizeRequest() - Constructor for class com.hazelcast.collection.client.TxnListSizeRequest
-
- TxnListSizeRequest(String) - Constructor for class com.hazelcast.collection.client.TxnListSizeRequest
-
- txnLock(Data, String, long, long) - Method in interface com.hazelcast.concurrent.lock.LockStore
-
- txnLock(Data, String, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreImpl
-
- txnLock(Data, String, long, long) - Method in class com.hazelcast.concurrent.lock.LockStoreProxy
-
- txnLock(Data, String, long, long) - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- txnLock(Data, String, long, long) - Method in interface com.hazelcast.map.impl.RecordStore
-
- txnLock(Data, String, long, long) - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- TxnLockAndGetOperation - Class in com.hazelcast.map.impl.tx
-
Transactional lock and get operation.
- TxnLockAndGetOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-
- TxnLockAndGetOperation(String, Data, long, long, String) - Constructor for class com.hazelcast.map.impl.tx.TxnLockAndGetOperation
-
- TxnLockAndGetOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnLockAndGetOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-
- TxnLockAndGetOperation(String, Data, long, long, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnLockAndGetOperation
-
- TxnMapRequest - Class in com.hazelcast.map.impl.client
-
- TxnMapRequest() - Constructor for class com.hazelcast.map.impl.client.TxnMapRequest
-
- TxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType) - Constructor for class com.hazelcast.map.impl.client.TxnMapRequest
-
- TxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data) - Constructor for class com.hazelcast.map.impl.client.TxnMapRequest
-
- TxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data) - Constructor for class com.hazelcast.map.impl.client.TxnMapRequest
-
- TxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data, long, TimeUnit) - Constructor for class com.hazelcast.map.impl.client.TxnMapRequest
-
- TxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Data, Data, Data) - Constructor for class com.hazelcast.map.impl.client.TxnMapRequest
-
- TxnMapRequest(String, AbstractTxnMapRequest.TxnMapRequestType, Predicate) - Constructor for class com.hazelcast.map.impl.client.TxnMapRequest
-
- TxnMapRequestWithSQLQuery - Class in com.hazelcast.map.impl.client
-
User: sancar
Date: 9/18/13
Time: 2:22 PM
- TxnMapRequestWithSQLQuery() - Constructor for class com.hazelcast.map.impl.client.TxnMapRequestWithSQLQuery
-
- TxnMapRequestWithSQLQuery(String, AbstractTxnMapRequest.TxnMapRequestType, String) - Constructor for class com.hazelcast.map.impl.client.TxnMapRequestWithSQLQuery
-
- TxnMultiMapGetRequest - Class in com.hazelcast.multimap.impl.client
-
- TxnMultiMapGetRequest() - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapGetRequest
-
- TxnMultiMapGetRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapGetRequest
-
- TxnMultiMapPutRequest - Class in com.hazelcast.multimap.impl.client
-
- TxnMultiMapPutRequest() - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-
- TxnMultiMapPutRequest(String, Data, Data) - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapPutRequest
-
- TxnMultiMapRemoveAllRequest - Class in com.hazelcast.multimap.impl.client
-
- TxnMultiMapRemoveAllRequest() - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-
- TxnMultiMapRemoveAllRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveAllRequest
-
- TxnMultiMapRemoveRequest - Class in com.hazelcast.multimap.impl.client
-
- TxnMultiMapRemoveRequest() - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-
- TxnMultiMapRemoveRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-
- TxnMultiMapRemoveRequest(String, Data, Data) - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapRemoveRequest
-
- TxnMultiMapRequest - Class in com.hazelcast.multimap.impl.client
-
- TxnMultiMapRequest() - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-
- TxnMultiMapRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapRequest
-
- TxnMultiMapSizeRequest - Class in com.hazelcast.multimap.impl.client
-
- TxnMultiMapSizeRequest() - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapSizeRequest
-
- TxnMultiMapSizeRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapSizeRequest
-
- TxnMultiMapValueCountRequest - Class in com.hazelcast.multimap.impl.client
-
- TxnMultiMapValueCountRequest() - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapValueCountRequest
-
- TxnMultiMapValueCountRequest(String, Data) - Constructor for class com.hazelcast.multimap.impl.client.TxnMultiMapValueCountRequest
-
- TxnOfferBackupOperation - Class in com.hazelcast.queue.impl.tx
-
Provides backup operation during transactional offer operation.
- TxnOfferBackupOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnOfferBackupOperation
-
- TxnOfferBackupOperation(String, long, Data) - Constructor for class com.hazelcast.queue.impl.tx.TxnOfferBackupOperation
-
- txnOfferBackupReserve(long, String) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnOfferOperation - Class in com.hazelcast.queue.impl.tx
-
Offer operation for the Transactional Queue.
- TxnOfferOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- TxnOfferOperation(String, long, Data) - Constructor for class com.hazelcast.queue.impl.tx.TxnOfferOperation
-
- TxnOfferRequest - Class in com.hazelcast.queue.impl.client
-
Request for transactional offer operation.
- TxnOfferRequest() - Constructor for class com.hazelcast.queue.impl.client.TxnOfferRequest
-
- TxnOfferRequest(String, long, Data) - Constructor for class com.hazelcast.queue.impl.client.TxnOfferRequest
-
- txnOfferReserve(String) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- txnPeek(long, String) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnPeekOperation - Class in com.hazelcast.queue.impl.tx
-
Peek operation for the transactional queue.
- TxnPeekOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnPeekOperation
-
- TxnPeekOperation(String, long, long, String) - Constructor for class com.hazelcast.queue.impl.tx.TxnPeekOperation
-
- TxnPeekRequest - Class in com.hazelcast.queue.impl.client
-
Request for transactional peek operation.
- TxnPeekRequest() - Constructor for class com.hazelcast.queue.impl.client.TxnPeekRequest
-
- TxnPeekRequest(String, long) - Constructor for class com.hazelcast.queue.impl.client.TxnPeekRequest
-
- TxnPollBackupOperation - Class in com.hazelcast.queue.impl.tx
-
Provides backup operation during transactional poll operation.
- TxnPollBackupOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnPollBackupOperation
-
- TxnPollBackupOperation(String, long) - Constructor for class com.hazelcast.queue.impl.tx.TxnPollBackupOperation
-
- txnPollBackupReserve(long, String) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnPollOperation - Class in com.hazelcast.queue.impl.tx
-
Poll operation for the transactional queue.
- TxnPollOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- TxnPollOperation(String, long) - Constructor for class com.hazelcast.queue.impl.tx.TxnPollOperation
-
- TxnPollRequest - Class in com.hazelcast.queue.impl.client
-
Request for transactional poll operation.
- TxnPollRequest() - Constructor for class com.hazelcast.queue.impl.client.TxnPollRequest
-
- TxnPollRequest(String, long) - Constructor for class com.hazelcast.queue.impl.client.TxnPollRequest
-
- txnPollReserve(long, String) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnPrepareBackupOperation - Class in com.hazelcast.map.impl.tx
-
An operation to prepare transaction by locking the key on key backup owner.
- TxnPrepareBackupOperation(String, Data, String, long) - Constructor for class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
-
- TxnPrepareBackupOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnPrepareBackupOperation
-
- TxnPrepareBackupOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnPrepareBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
-
- TxnPrepareBackupOperation(String, Data, String, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnPrepareBackupOperation
-
- TxnPrepareBackupOperation - Class in com.hazelcast.queue.impl.tx
-
Provides backup operation during transactional prepare operation.
- TxnPrepareBackupOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnPrepareBackupOperation
-
- TxnPrepareBackupOperation(String, long, boolean, String) - Constructor for class com.hazelcast.queue.impl.tx.TxnPrepareBackupOperation
-
- TxnPrepareOperation - Class in com.hazelcast.map.impl.tx
-
An operation to prepare transaction by locking the key on the key owner.
- TxnPrepareOperation(String, Data, String) - Constructor for class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- TxnPrepareOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnPrepareOperation
-
- TxnPrepareOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnPrepareOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- TxnPrepareOperation(String, Data, long, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnPrepareOperation
-
- TxnPrepareOperation - Class in com.hazelcast.queue.impl.tx
-
Prepare operation for the transactional queue.
- TxnPrepareOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnPrepareOperation
-
- TxnPrepareOperation(String, long, boolean, String) - Constructor for class com.hazelcast.queue.impl.tx.TxnPrepareOperation
-
- TxnPutBackupOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnPutBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
-
- TxnPutBackupOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.txn.TxnPutBackupOperation
-
- TxnPutOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnPutOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- TxnPutOperation(String, Data, Data, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnPutOperation
-
- TxnRemoveAllBackupOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnRemoveAllBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
-
- TxnRemoveAllBackupOperation(String, Data, Collection<Long>) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveAllBackupOperation
-
- TxnRemoveAllOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnRemoveAllOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- TxnRemoveAllOperation(String, Data, Collection<MultiMapRecord>) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveAllOperation
-
- TxnRemoveBackupOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnRemoveBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
-
- TxnRemoveBackupOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveBackupOperation
-
- TxnRemoveOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnRemoveOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- TxnRemoveOperation(String, Data, long, Data) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRemoveOperation
-
- TxnReserveOfferBackupOperation - Class in com.hazelcast.queue.impl.tx
-
Reserve offer backup operation for the transactional queue.
- TxnReserveOfferBackupOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnReserveOfferBackupOperation
-
- TxnReserveOfferBackupOperation(String, long, String) - Constructor for class com.hazelcast.queue.impl.tx.TxnReserveOfferBackupOperation
-
- TxnReserveOfferOperation - Class in com.hazelcast.queue.impl.tx
-
Reserve offer operation for the transactional queue.
- TxnReserveOfferOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- TxnReserveOfferOperation(String, long, int, String) - Constructor for class com.hazelcast.queue.impl.tx.TxnReserveOfferOperation
-
- TxnReservePollBackupOperation - Class in com.hazelcast.queue.impl.tx
-
Reserve poll backup operation for the transactional queue.
- TxnReservePollBackupOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnReservePollBackupOperation
-
- TxnReservePollBackupOperation(String, long, String) - Constructor for class com.hazelcast.queue.impl.tx.TxnReservePollBackupOperation
-
- TxnReservePollOperation - Class in com.hazelcast.queue.impl.tx
-
Reserve poll operation for the transactional queue.
- TxnReservePollOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- TxnReservePollOperation(String, long, long, String) - Constructor for class com.hazelcast.queue.impl.tx.TxnReservePollOperation
-
- TxnRollbackBackupOperation - Class in com.hazelcast.map.impl.tx
-
An operation to rollback transaction by unlocking the key on key backup owner.
- TxnRollbackBackupOperation(String, Data, String, long) - Constructor for class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
-
- TxnRollbackBackupOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnRollbackBackupOperation
-
- TxnRollbackBackupOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnRollbackBackupOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
-
- TxnRollbackBackupOperation(String, Data, String, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRollbackBackupOperation
-
- TxnRollbackBackupOperation - Class in com.hazelcast.queue.impl.tx
-
Provides backup operation during transactional rollback operation.
- TxnRollbackBackupOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnRollbackBackupOperation
-
- TxnRollbackBackupOperation(String, long, boolean) - Constructor for class com.hazelcast.queue.impl.tx.TxnRollbackBackupOperation
-
- txnRollbackOffer(long) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- txnRollbackOfferBackup(long) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnRollbackOperation - Class in com.hazelcast.map.impl.tx
-
An operation to rollback transaction by unlocking the key on key owner.
- TxnRollbackOperation(String, Data, String) - Constructor for class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- TxnRollbackOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnRollbackOperation
-
- TxnRollbackOperation - Class in com.hazelcast.multimap.impl.txn
-
- TxnRollbackOperation() - Constructor for class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-
- TxnRollbackOperation(String, Data, long) - Constructor for class com.hazelcast.multimap.impl.txn.TxnRollbackOperation
-
- TxnRollbackOperation - Class in com.hazelcast.queue.impl.tx
-
Rollback operation for the transactional queue.
- TxnRollbackOperation() - Constructor for class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- TxnRollbackOperation(String, long, boolean) - Constructor for class com.hazelcast.queue.impl.tx.TxnRollbackOperation
-
- txnRollbackPoll(long, boolean) - Method in class com.hazelcast.queue.impl.QueueContainer
-
- TxnSetAddRequest - Class in com.hazelcast.collection.client
-
- TxnSetAddRequest() - Constructor for class com.hazelcast.collection.client.TxnSetAddRequest
-
- TxnSetAddRequest(String, Data) - Constructor for class com.hazelcast.collection.client.TxnSetAddRequest
-
- TxnSetOperation - Class in com.hazelcast.map.impl.tx
-
An operation to unlock and set (key,value) on the partition .
- TxnSetOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnSetOperation
-
- TxnSetOperation(String, Data, Data, long) - Constructor for class com.hazelcast.map.impl.tx.TxnSetOperation
-
- TxnSetOperation(String, Data, Data, long, long) - Constructor for class com.hazelcast.map.impl.tx.TxnSetOperation
-
- TxnSetRemoveRequest - Class in com.hazelcast.collection.client
-
- TxnSetRemoveRequest() - Constructor for class com.hazelcast.collection.client.TxnSetRemoveRequest
-
- TxnSetRemoveRequest(String, Data) - Constructor for class com.hazelcast.collection.client.TxnSetRemoveRequest
-
- TxnSetSizeRequest - Class in com.hazelcast.collection.client
-
- TxnSetSizeRequest() - Constructor for class com.hazelcast.collection.client.TxnSetSizeRequest
-
- TxnSetSizeRequest(String) - Constructor for class com.hazelcast.collection.client.TxnSetSizeRequest
-
- TxnSizeRequest - Class in com.hazelcast.queue.impl.client
-
Request for size of the Transactional Queue.
- TxnSizeRequest() - Constructor for class com.hazelcast.queue.impl.client.TxnSizeRequest
-
- TxnSizeRequest(String) - Constructor for class com.hazelcast.queue.impl.client.TxnSizeRequest
-
- TxnUnlockBackupOperation - Class in com.hazelcast.map.impl.tx
-
An operation to unlock key on the backup owner.
- TxnUnlockBackupOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
-
- TxnUnlockBackupOperation(String, Data) - Constructor for class com.hazelcast.map.impl.tx.TxnUnlockBackupOperation
-
- TxnUnlockOperation - Class in com.hazelcast.map.impl.tx
-
An operation to unlock key on the partition owner.
- TxnUnlockOperation() - Constructor for class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- TxnUnlockOperation(String, Data, long) - Constructor for class com.hazelcast.map.impl.tx.TxnUnlockOperation
-
- TxnValueWrapper - Class in com.hazelcast.map.impl.tx
-
Wrapper for value objects with type information.
- TxnValueWrapper(Object, TxnValueWrapper.Type) - Constructor for class com.hazelcast.map.impl.tx.TxnValueWrapper
-
- TxQueueItem - Class in com.hazelcast.queue.impl
-
Transactional Queue Item.
- TxQueueItem() - Constructor for class com.hazelcast.queue.impl.TxQueueItem
-
- TxQueueItem(QueueItem) - Constructor for class com.hazelcast.queue.impl.TxQueueItem
-
- TxQueueItem(QueueContainer, long, Data) - Constructor for class com.hazelcast.queue.impl.TxQueueItem
-
- type - Variable in class com.hazelcast.ascii.AbstractTextCommand
-
- type - Variable in class com.hazelcast.ascii.TypeAwareCommandParser
-
- TypeAwareCommandParser - Class in com.hazelcast.ascii
-
- TypeAwareCommandParser(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.TypeAwareCommandParser
-
- validateConfiguredKeyType(Class<K>, K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates the key with key type.
- validateConfiguredTypes(CacheConfig, K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates that the configured key matches the provided key.
- validateConfiguredTypes(CacheConfig, K, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates the configured key and value types matches the provided key, value types.
- validateConfiguredTypes(CacheConfig, K, V, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates the configured key and value types matches the provided key, value types.
- validateConfiguredValueType(Class<V>, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates the value with value type.
- validateJoinMessage(JoinMessage) - Method in class com.hazelcast.cluster.impl.ClusterServiceImpl
-
- validateNotNull(K) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates that a key is not null.
- validateNotNull(K, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates that key, value pair are both not null.
- validateNotNull(K, V, V) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates that key and multi values are not null.
- validateNotNull(Set<? extends K>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Validates that none of the keys are null in set.
- validateNotNull(Map<? extends K, ? extends V>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
This validator ensures that no key or value is null in the provided map.
- validateResults(Map<Integer, Object>) - Static method in class com.hazelcast.cache.impl.CacheProxyUtil
-
Cache clear response validator, loop on results to validate that no exception exists on the result map.
- validatesTarget() - Method in class com.hazelcast.cluster.impl.operations.PostJoinOperation
-
- validatesTarget() - Method in class com.hazelcast.partition.impl.BaseMigrationOperation
-
- validatesTarget() - Method in class com.hazelcast.partition.impl.CheckReplicaVersion
-
- validatesTarget() - Method in class com.hazelcast.partition.impl.ReplicaSyncRequest
-
- validatesTarget() - Method in class com.hazelcast.partition.impl.ReplicaSyncResponse
-
- validatesTarget() - Method in class com.hazelcast.partition.impl.ReplicaSyncRetryResponse
-
- validatesTarget() - Method in class com.hazelcast.spi.Operation
-
- ValidationUtil - Class in com.hazelcast.util
-
A utility class for validating arguments and state.
- value - Variable in class com.hazelcast.cache.impl.CacheEntryProcessorEntry
-
- value - Variable in class com.hazelcast.cache.impl.client.CacheGetAndReplaceRequest
-
- value - Variable in class com.hazelcast.cache.impl.client.CachePutIfAbsentRequest
-
- value - Variable in class com.hazelcast.cache.impl.client.CachePutRequest
-
- value - Variable in class com.hazelcast.cache.impl.client.CacheReplaceRequest
-
- value - Variable in class com.hazelcast.cache.impl.record.CacheObjectRecord
-
- value - Variable in class com.hazelcast.collection.client.CollectionAddRequest
-
- value - Variable in class com.hazelcast.collection.CollectionAddOperation
-
- value - Variable in class com.hazelcast.collection.CollectionItem
-
- value - Variable in class com.hazelcast.core.EntryEvent
-
- value - Variable in class com.hazelcast.map.impl.client.MapPutRequest
-
- value - Variable in class com.hazelcast.map.impl.client.MapRemoveIfSameRequest
-
- value - Variable in class com.hazelcast.query.Predicates.EqualPredicate
-
- VALUE_SPACE - Static variable in class com.hazelcast.ascii.TextCommandConstants
-
- ValueCollectionFactory - Class in com.hazelcast.multimap.impl
-
Multi-map values are backed by collections which are created by static factory methods in this class.
- valueCount(K) - Method in interface com.hazelcast.core.BaseMultiMap
-
Returns number of values matching to given key in the multimap.
- valueCount(K) - Method in interface com.hazelcast.core.MultiMap
-
Returns number of values matching to given key in the multimap.
- valueCount(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
-
Returns number of values matching to given key in the multimap.
- valueCount(K) - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- valueCount(K) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxy
-
- valueCountInternal(Data) - Method in class com.hazelcast.multimap.impl.txn.TransactionalMultiMapProxySupport
-
- valueList - Variable in class com.hazelcast.collection.client.CollectionAddAllRequest
-
- valueList - Variable in class com.hazelcast.collection.CollectionAddAllOperation
-
- valueMap - Variable in class com.hazelcast.collection.CollectionAddAllBackupOperation
-
- valueMap - Variable in class com.hazelcast.collection.CollectionAddAllOperation
-
- valueMap - Variable in class com.hazelcast.map.impl.tx.TransactionalMapProxySupport
-
- valueOf(String) - Static method in enum com.hazelcast.ascii.TextCommandConstants.TextCommandType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.cache.impl.CacheEntryProcessorEntry.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.cache.impl.CacheEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.EvictionPolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.InMemoryFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.MaxSizeConfig.MaxSizePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.ClientType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.EntryEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.ItemEventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.map.impl.client.AbstractTxnMapRequest.TxnMapRequestType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.map.impl.operation.MapOperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.mapreduce.impl.operation.RequestPartitionResult.ResultState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.mapreduce.TopologyChangedStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.memory.MemoryUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.multimap.impl.operations.MultiMapOperationFactory.OperationFactoryType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.nio.ConnectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.nio.serialization.FieldType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.partition.MigrationEndpoint
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.query.impl.AttributeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.query.impl.ComparisonType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.spi.ExceptionAction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.transaction.impl.Transaction.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.Option
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.ReferenceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.util.executor.ExecutorType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.util.HealthMonitorLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.util.IterationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.hazelcast.util.scheduler.ScheduleType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.hazelcast.ascii.TextCommandConstants.TextCommandType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.cache.impl.CacheEntryProcessorEntry.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.cache.impl.CacheEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.EvictionPolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.InMemoryFormat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.LoginModuleConfig.LoginModuleUsage
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.MapStoreConfig.InitialLoadMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.MaxSizeConfig.MaxSizePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.MultiMapConfig.ValueCollectionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.NativeMemoryConfig.MemoryAllocatorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.NearCacheConfig.LocalUpdatePolicy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.PartitionGroupConfig.MemberGroupType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.config.PermissionConfig.PermissionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.ClientType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.DistributedObjectEvent.EventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.EntryEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface com.hazelcast.core.IMap
-
Returns a collection clone of the values contained in this map.
- values(Predicate) - Method in interface com.hazelcast.core.IMap
-
Queries the map based on the specified predicate and
returns the values of matching entries.
- values() - Static method in enum com.hazelcast.core.ItemEventType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.LifecycleEvent.LifecycleState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in interface com.hazelcast.core.MultiMap
-
Returns the collection of values in the multimap.
- values() - Method in interface com.hazelcast.core.ReplicatedMap
-
Returns a
Collection
view of the values contained in this map.
- values(Comparator<V>) - Method in interface com.hazelcast.core.ReplicatedMap
-
Returns a
Collection
view of the values contained in this map.
- values() - Method in interface com.hazelcast.core.TransactionalMap
-
- values(Predicate) - Method in interface com.hazelcast.core.TransactionalMap
-
- values(String) - Method in class com.hazelcast.jmx.MapMBean
-
- values() - Method in class com.hazelcast.jmx.ReplicatedMapMBean
-
- values() - Static method in enum com.hazelcast.map.impl.client.AbstractTxnMapRequest.TxnMapRequestType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES - Static variable in class com.hazelcast.map.impl.MapDataSerializerHook
-
- VALUES - Static variable in class com.hazelcast.map.impl.MapPortableHook
-
- values() - Static method in enum com.hazelcast.map.impl.operation.MapOperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- values(Predicate) - Method in class com.hazelcast.map.impl.proxy.MapProxyImpl
-
- values() - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- values(Predicate) - Method in class com.hazelcast.map.impl.tx.TransactionalMapProxy
-
- values() - Static method in enum com.hazelcast.mapreduce.impl.operation.RequestPartitionResult.ResultState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.mapreduce.TopologyChangedStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.memory.MemoryUnit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.hazelcast.multimap.impl.MultiMapContainer
-
- VALUES - Static variable in class com.hazelcast.multimap.impl.MultiMapDataSerializerHook
-
- VALUES - Static variable in class com.hazelcast.multimap.impl.MultiMapPortableHook
-
- values() - Method in class com.hazelcast.multimap.impl.ObjectMultiMapProxy
-
- values() - Static method in enum com.hazelcast.multimap.impl.operations.MultiMapOperationFactory.OperationFactoryType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.nio.ConnectionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.nio.serialization.FieldType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.partition.MigrationEndpoint
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.query.impl.AttributeType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.query.impl.ComparisonType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- values() - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- values(Comparator) - Method in class com.hazelcast.replicatedmap.impl.record.AbstractReplicatedRecordStore
-
- values() - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- values(Comparator) - Method in interface com.hazelcast.replicatedmap.impl.record.ReplicatedRecordStore
-
- values() - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- values(Comparator<V>) - Method in class com.hazelcast.replicatedmap.impl.ReplicatedMapProxy
-
- values() - Static method in enum com.hazelcast.spi.ExceptionAction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.transaction.impl.Transaction.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.Option
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.util.ConcurrentReferenceHashMap.ReferenceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.hazelcast.util.ConcurrentReferenceHashMap
-
Returns a
Collection
view of the values contained in this map.
- values() - Static method in enum com.hazelcast.util.executor.ExecutorType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.util.HealthMonitorLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.util.IterationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.hazelcast.util.scheduler.ScheduleType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES_COLLECTION - Static variable in class com.hazelcast.replicatedmap.impl.client.ReplicatedMapPortableHook
-
- valuesData() - Method in class com.hazelcast.map.impl.DefaultRecordStore
-
- valuesData() - Method in interface com.hazelcast.map.impl.RecordStore
-
- valuesInternal() - Method in class com.hazelcast.multimap.impl.MultiMapProxySupport
-
- ValuesOperation - Class in com.hazelcast.multimap.impl.operations
-
- ValuesOperation() - Constructor for class com.hazelcast.multimap.impl.operations.ValuesOperation
-
- ValuesOperation(String) - Constructor for class com.hazelcast.multimap.impl.operations.ValuesOperation
-
- ValuesRequest - Class in com.hazelcast.multimap.impl.client
-
- ValuesRequest() - Constructor for class com.hazelcast.multimap.impl.client.ValuesRequest
-
- ValuesRequest(String) - Constructor for class com.hazelcast.multimap.impl.client.ValuesRequest
-
- valueToData(T) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- valueToData(T) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- valueToRecord(T) - Method in class com.hazelcast.cache.impl.AbstractCacheRecordStore
-
- valueToRecord(T) - Method in class com.hazelcast.cache.impl.CacheRecordStore
-
- VECTOR - Static variable in class com.hazelcast.replicatedmap.impl.operation.ReplicatedMapDataSerializerHook
-
- VectorClockTimestamp - Class in com.hazelcast.replicatedmap.impl.record
-
A vector clock implementation based on hashcodes of the Hazelcast members UUID to solve conflicts on
replication updates
- VectorClockTimestamp() - Constructor for class com.hazelcast.replicatedmap.impl.record.VectorClockTimestamp
-
- verify() - Method in class com.hazelcast.config.JoinConfig
-
Verifies this JoinConfig is valid.
- version - Variable in class com.hazelcast.map.impl.record.RecordInfo
-
- VERSION - Static variable in class com.hazelcast.nio.Packet
-
- version - Variable in class com.hazelcast.nio.serialization.DefaultSerializationServiceBuilder
-
- VERSION_CHECK_ENABLED - Variable in class com.hazelcast.instance.GroupProperties
-
- VersionCheck - Class in com.hazelcast.util
-
Checks version of hazelcast with central server.
- VersionCheck() - Constructor for class com.hazelcast.util.VersionCheck
-
- VersionCommand - Class in com.hazelcast.ascii.memcache
-
- VersionCommand(TextCommandConstants.TextCommandType) - Constructor for class com.hazelcast.ascii.memcache.VersionCommand
-
- VersionCommandProcessor - Class in com.hazelcast.ascii.memcache
-
User: sancar
Date: 3/7/13
Time: 10:31 AM
- VersionCommandProcessor(TextCommandServiceImpl) - Constructor for class com.hazelcast.ascii.memcache.VersionCommandProcessor
-
- VersionedPortable - Interface in com.hazelcast.nio.serialization
-
VersionedPortable is an extension to
Portable
to support per class version instead of a global serialization version.
- VersionedValue - Class in com.hazelcast.map.impl.tx
-
Wrapper for
Data
value objects with version information.
- VersionedValue(Data, long) - Constructor for class com.hazelcast.map.impl.tx.VersionedValue
-
- VersionedValue() - Constructor for class com.hazelcast.map.impl.tx.VersionedValue
-