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

A

AbstractCredentials - Class in com.hazelcast.security
Abstract implementation of Credentials
AbstractCredentials() - Constructor for class com.hazelcast.security.AbstractCredentials
 
AbstractCredentials(String) - Constructor for class com.hazelcast.security.AbstractCredentials
 
AbstractDistributedObject<S extends RemoteService> - Class in com.hazelcast.spi
 
AbstractDistributedObject(NodeEngine, S) - Constructor for class com.hazelcast.spi.AbstractDistributedObject
 
AbstractHazelcastCacheRegionFactory - Class in com.hazelcast.hibernate
 
AbstractHazelcastCacheRegionFactory() - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
AbstractHazelcastCacheRegionFactory(Properties) - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
AbstractHazelcastCacheRegionFactory(HazelcastInstance) - Constructor for class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
AbstractJoiner - Class in com.hazelcast.cluster
 
AbstractJoiner(Node) - Constructor for class com.hazelcast.cluster.AbstractJoiner
 
AbstractOperation - Class in com.hazelcast.spi
 
AbstractOperation() - Constructor for class com.hazelcast.spi.AbstractOperation
 
AbstractWaitNotifyKey - Class in com.hazelcast.spi
 
AbstractWaitNotifyKey(String, String) - Constructor for class com.hazelcast.spi.AbstractWaitNotifyKey
 
AbstractXmlConfigHelper - Class in com.hazelcast.config
 
AbstractXmlConfigHelper() - Constructor for class com.hazelcast.config.AbstractXmlConfigHelper
 
AbstractXmlConfigHelper.IterableNodeList - Class in com.hazelcast.config
 
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
 
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.
add(E) - Method in interface com.hazelcast.core.IQueue
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
addAction(String) - Method in class com.hazelcast.config.PermissionConfig
 
addAddress(String...) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
addAddress(String...) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
addAll(Collection<? extends E>) - Method in interface com.hazelcast.core.IQueue
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
 
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
 
addCharArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addCharField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addClassDef(ClassDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
addClassDefinition(ClassDefinition) - Method in class com.hazelcast.config.SerializationConfig
 
addClassDefinition(ClassDefinition) - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
addClientListener(ClientListener) - Method in interface com.hazelcast.core.ClientService
 
addClientLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addClientPermissionConfig(PermissionConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactory(int, DataSerializableFactory) - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
addDataSerializableFactoryClass(int, String) - Method in class com.hazelcast.config.SerializationConfig
 
addDataSerializableFactoryClass(int, Class<? extends DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.HazelcastClient
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.HazelcastClientProxy
 
addDistributedObjectListener(DistributedObjectListener) - Method in class com.hazelcast.client.spi.ProxyManager
 
addDistributedObjectListener(DistributedObjectListener) - Method in interface com.hazelcast.core.HazelcastInstance
Adds a Distributed Object listener which will be notified when a new DistributedObject will be created or destroyed.
addDoubleArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addDoubleField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
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.
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
 
addExecutorConfig(ExecutorConfig) - Method in class com.hazelcast.config.Config
Adds a new ExecutorConfig by name
addFieldDef(FieldDefinition) - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
addFloatArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addFloatField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
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.
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.
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 interface com.hazelcast.core.ICollection
Adds an item listener for this collection.
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.CollectionConfig
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.ListConfigReadOnly
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfig
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.QueueConfigReadOnly
 
addItemListenerConfig(ItemListenerConfig) - Method in class com.hazelcast.config.SetConfigReadOnly
 
addJobTrackerConfig(JobTrackerConfig) - Method in class com.hazelcast.config.Config
 
addLifecycleListener(LifecycleListener) - Method in class com.hazelcast.client.LifecycleServiceImpl
 
addLifecycleListener(LifecycleListener) - Method in interface com.hazelcast.core.LifecycleService
Add listener object to listen lifecycle events.
addListConfig(ListConfig) - Method in class com.hazelcast.config.Config
 
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
addListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.Config
 
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.
addLongArrayField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addLongField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addMapConfig(MapConfig) - Method in class com.hazelcast.config.Config
 
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfig
 
addMapIndexConfig(MapIndexConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
 
addMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Adds a 'well known' member.
addMemberGroupConfig(MemberGroupConfig) - Method in class com.hazelcast.config.PartitionGroupConfig
Adds a MemberGroupConfig.
addMemberLoginModuleConfig(LoginModuleConfig) - Method in class com.hazelcast.config.SecurityConfig
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.cluster.ClusterProxy
 
addMembershipListener(MembershipListener) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
addMembershipListener(MembershipListener) - Method in interface com.hazelcast.core.Cluster
Adds MembershipListener to listen for membership updates.
addMessageListener(MessageListener<E>) - Method in interface com.hazelcast.core.ITopic
Subscribes to this topic.
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfig
 
addMessageListenerConfig(ListenerConfig) - Method in class com.hazelcast.config.TopicConfigReadOnly
 
addMigrationListener(MigrationListener) - Method in interface com.hazelcast.core.PartitionService
 
addMulticastListener(MulticastListener) - Method in class com.hazelcast.cluster.MulticastService
 
addMultiMapConfig(MultiMapConfig) - Method in class com.hazelcast.config.Config
 
addNearCacheConfig(String, NearCacheConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
addOutboundPort(int) - Method in class com.hazelcast.config.NetworkConfig
 
addOutboundPortDefinition(String) - Method in class com.hazelcast.config.NetworkConfig
 
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.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
 
addProxyFactoryConfig(ProxyFactoryConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
addProxyListener(DistributedObjectListener) - Method in interface com.hazelcast.spi.ProxyService
 
addQueueConfig(QueueConfig) - Method in class com.hazelcast.config.Config
 
ADDRESS - Static variable in class com.hazelcast.cluster.ClusterDataSerializerHook
 
address - Variable in class com.hazelcast.cluster.JoinMessage
 
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
 
addTargetClusterConfig(WanTargetClusterConfig) - Method in class com.hazelcast.config.WanReplicationConfig
 
addTopicConfig(TopicConfig) - Method in class com.hazelcast.config.Config
 
addTrustedInterface(String) - Method in class com.hazelcast.config.MulticastConfig
Adds a trusted interface.
addUTFField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
addWanReplicationConfig(WanReplicationConfig) - Method in class com.hazelcast.config.Config
 
afterPropertiesSet() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
afterResponse() - Method in class com.hazelcast.client.PartitionClientRequest
 
afterRun() - Method in class com.hazelcast.spi.AbstractOperation
 
afterRun() - Method in class com.hazelcast.spi.Operation
 
AllPartitionsClientRequest - Class in com.hazelcast.client
 
AllPartitionsClientRequest() - Constructor for class com.hazelcast.client.AllPartitionsClientRequest
 
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.
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.
and(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
 
and(Predicate, Predicate) - Static method in class com.hazelcast.query.Predicates
 
andThen(ExecutionCallback<V>) - Method in interface com.hazelcast.core.ICompletableFuture
 
andThen(ExecutionCallback<V>, Executor) - Method in interface com.hazelcast.core.ICompletableFuture
 
appendToken(StringBuilder, StringBuilder) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
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) - 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.web.SessionAttributePredicate
 
ArrayDataSerializableFactory - Class in com.hazelcast.nio.serialization
 
ArrayDataSerializableFactory(ConstructorFunction<Integer, IdentifiedDataSerializable>[]) - Constructor for class com.hazelcast.nio.serialization.ArrayDataSerializableFactory
 
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
 
asMap() - Method in interface com.hazelcast.hibernate.RegionCache
 
asReadOnly() - Method in class com.hazelcast.config.MemberAttributeConfig
 
ASYNC_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
 
asyncAddAndGet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
 
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 interface com.hazelcast.core.AsyncAtomicLong
 
asyncAlterAndGet(IFunction<E, E>) - Method in interface com.hazelcast.core.AsyncAtomicReference
 
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
A IAtomicLong that exposes its operations using a ICompletableFuture so it can be used in the reactive programming model approach.
AsyncAtomicReference<E> - Interface in com.hazelcast.core
A IAtomicReference that exposes its operations using a ICompletableFuture so it can be used in the reactive programming model approach.
asyncClear() - Method in interface com.hazelcast.core.AsyncAtomicReference
 
asyncCompareAndSet(long, long) - Method in interface com.hazelcast.core.AsyncAtomicLong
 
asyncCompareAndSet(E, E) - Method in interface com.hazelcast.core.AsyncAtomicReference
 
asyncContains(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
 
asyncDecrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
 
asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
 
asyncGet() - Method in interface com.hazelcast.core.AsyncAtomicReference
 
asyncGetAndAdd(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
 
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 interface com.hazelcast.core.AsyncAtomicLong
 
asyncGetAndSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
 
asyncGetAndSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
 
asyncIncrementAndGet() - Method in interface com.hazelcast.core.AsyncAtomicLong
 
asyncIsNull() - Method in interface com.hazelcast.core.AsyncAtomicReference
 
asyncSet(long) - Method in interface com.hazelcast.core.AsyncAtomicLong
 
asyncSet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
 
asyncSetAndGet(E) - Method in interface com.hazelcast.core.AsyncAtomicReference
 
ATOMIC_LONG_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
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
 
AtomicLongMBean - Class in com.hazelcast.jmx
 
AtomicLongMBean(IAtomicLong, ManagementService) - Constructor for class com.hazelcast.jmx.AtomicLongMBean
 
AtomicReferenceMBean - Class in com.hazelcast.jmx
 
AtomicReferenceMBean(IAtomicReference, ManagementService) - Constructor for class com.hazelcast.jmx.AtomicReferenceMBean
 
attribute - Variable in class com.hazelcast.query.PredicateBuilder
 
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
 
AUTH - Static variable in class com.hazelcast.client.ClientPortableHook
 
AuthenticationException - Exception in com.hazelcast.client
 
AuthenticationException() - Constructor for exception com.hazelcast.client.AuthenticationException
 
AuthenticationException(String) - Constructor for exception com.hazelcast.client.AuthenticationException
 
AuthenticationFailureOperation - Class in com.hazelcast.cluster
 
AuthenticationFailureOperation() - Constructor for class com.hazelcast.cluster.AuthenticationFailureOperation
 
AuthenticationRequest - Class in com.hazelcast.client
 
AuthenticationRequest() - Constructor for class com.hazelcast.client.AuthenticationRequest
 
AuthenticationRequest(Credentials) - Constructor for class com.hazelcast.client.AuthenticationRequest
 
AuthenticationRequest(Credentials, ClientPrincipal) - Constructor for class com.hazelcast.client.AuthenticationRequest
 
AuthorizationOperation - Class in com.hazelcast.cluster
 
AuthorizationOperation() - Constructor for class com.hazelcast.cluster.AuthorizationOperation
 
AuthorizationOperation(String, String) - Constructor for class com.hazelcast.cluster.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
 
availablePermits() - Method in interface com.hazelcast.core.ISemaphore
Returns the current number of permits currently available in this semaphore.
await() - Method in interface com.hazelcast.core.ICondition
await(long, TimeUnit) - Method in interface com.hazelcast.core.ICondition
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
 
awaitNanos(long) - Method in interface com.hazelcast.core.ICondition
awaitUninterruptibly() - Method in interface com.hazelcast.core.ICondition
awaitUntil(Date) - Method in interface com.hazelcast.core.ICondition
AwsConfig - Class in com.hazelcast.config
The AWSConfig contains the configuration for AWS join mechanism.
AwsConfig() - Constructor for class com.hazelcast.config.AwsConfig
 

B

BackupAwareOperation - Interface in com.hazelcast.spi
A BackupAwareOperation is an Operation to indicate then when a change is made, a BackupOperation is created to replicate the backup.
BackupCompletionCallback - Interface in com.hazelcast.spi
 
BackupOperation - Interface in com.hazelcast.spi
When an BackupAwareOperation makes a change, the backups need to be replicated to other members (depending on the configuration and if change really happened).
BaseClientRemoveListenerRequest - Class in com.hazelcast.client
 
BaseClientRemoveListenerRequest() - Constructor for class com.hazelcast.client.BaseClientRemoveListenerRequest
 
BaseClientRemoveListenerRequest(String, String) - Constructor for class com.hazelcast.client.BaseClientRemoveListenerRequest
 
BaseMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed maps.
BaseMultiMap<K,V> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed multi-maps.
BaseQueue<E> - Interface in com.hazelcast.core
Base interface for Hazelcast distributed queues.
beforeMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
 
beforeProcess() - Method in class com.hazelcast.client.PartitionClientRequest
 
beforeRun() - Method in class com.hazelcast.cluster.PostJoinOperation
 
beforeRun() - Method in class com.hazelcast.spi.AbstractOperation
 
beforeRun() - Method in class com.hazelcast.spi.Operation
 
beginCombine() - Method in class com.hazelcast.mapreduce.Combiner
This method is called before the first value is submitted to this Combiner instance.
beginReduce(KeyIn) - Method in class com.hazelcast.mapreduce.Reducer
This method is called before the first value is submitted to this Reducer instance.
beginTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Begins a transaction.
between(Comparable, Comparable) - Method in class com.hazelcast.query.EntryObject
 
between(String, Comparable, Comparable) - Static method in class com.hazelcast.query.Predicates
 
BinaryClassDefinitionProxy - Class in com.hazelcast.nio.serialization
 
BinaryClassDefinitionProxy(int, int, int, byte[]) - Constructor for class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
BindOperation - Class in com.hazelcast.cluster
 
BindOperation() - Constructor for class com.hazelcast.cluster.BindOperation
 
BindOperation(Address) - Constructor for class com.hazelcast.cluster.BindOperation
 
BindOperation(Address, Address, boolean) - Constructor for class com.hazelcast.cluster.BindOperation
 
bufferSize() - Method in class com.hazelcast.nio.serialization.Data
 
build() - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build(ClassLoader) - Method in class com.hazelcast.client.config.XmlClientConfigBuilder
 
build() - Method in interface com.hazelcast.config.ConfigBuilder
Builds Config object.
build() - Method in class com.hazelcast.config.XmlConfigBuilder
 
build() - Method in class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
build() - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
buildCollectionRegion(String, Properties, CacheDataDescription) - Method in class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
buildCollectionRegion(String, Properties, CacheDataDescription) - Method in class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
buildEntityRegion(String, Properties, CacheDataDescription) - Method in class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
buildEntityRegion(String, Properties, CacheDataDescription) - Method in class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
buildNumber - Variable in class com.hazelcast.cluster.JoinMessage
 
buildQueryResultsRegion(String, Properties) - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
buildTimestampsRegion(String, Properties) - Method in class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
buildTimestampsRegion(String, Properties) - Method in class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
byOrdinal(int) - Static method in enum com.hazelcast.mapreduce.JobPartitionState.State
Returns an processing state by its given ordinal
ByteArraySerializer<T> - Interface in com.hazelcast.nio.serialization
 

C

CacheEnvironment - Class in com.hazelcast.hibernate
 
call() - Method in class com.hazelcast.client.AuthenticationRequest
 
call() - Method in class com.hazelcast.client.ClientCreateRequest
 
call() - Method in class com.hazelcast.client.ClientDestroyRequest
 
call() - Method in class com.hazelcast.client.DistributedObjectListenerRequest
 
call() - Method in class com.hazelcast.client.RemoveDistributedObjectListenerRequest
 
CallableClientRequest - Class in com.hazelcast.client
 
CallableClientRequest() - Constructor for class com.hazelcast.client.CallableClientRequest
 
Callback<T> - Interface in com.hazelcast.spi
 
callback - Variable in class com.hazelcast.spi.InvocationBuilder
 
callId - Variable in class com.hazelcast.client.ClientRequest
 
callTimeout - Variable in class com.hazelcast.spi.InvocationBuilder
 
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
 
checkJoinInfo(Address) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
checkPermission(Subject, Permission) - Method in interface com.hazelcast.security.SecurityContext
Checks whether current Subject has been granted specified permission or not.
checkTrue(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
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.
ClassDefinition - Interface in com.hazelcast.nio.serialization
 
ClassDefinitionBuilder - Class in com.hazelcast.nio.serialization
 
ClassDefinitionBuilder(int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionBuilder
 
ClassDefinitionImpl - Class in com.hazelcast.nio.serialization
 
ClassDefinitionImpl() - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
ClassDefinitionImpl(int, int) - Constructor for class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
className - Variable in class com.hazelcast.config.ListenerConfig
 
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.
cleanNodeName(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
cleanNodeName(String) - Static method in class com.hazelcast.config.AbstractXmlConfigHelper
 
cleanResources(HazelcastClient) - Static method in class com.hazelcast.client.ClientOutOfMemoryHandler.ClientHelper
 
clear() - Method in class com.hazelcast.config.InterfacesConfig
clears all interfaces.
clear() - Method in class com.hazelcast.config.MemberGroupConfig
Removes all interfaces from the member group.
clear() - Method in class com.hazelcast.config.PartitionGroupConfig
Removes all the PartitionGroupConfig.MemberGroupType instances.
clear() - Method in class com.hazelcast.config.ServicesConfig
 
clear() - Method in class com.hazelcast.config.TcpIpConfig
Removes all members.
clear() - Method in interface com.hazelcast.core.IAtomicReference
Clears the current stored reference.
clear() - Method in interface com.hazelcast.core.IQueue
clear() - Method in interface com.hazelcast.core.MultiMap
Clears the multimap.
clear() - Method in interface com.hazelcast.hibernate.RegionCache
 
clear() - Method in class com.hazelcast.jmx.ListMBean
 
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.SetMBean
 
clear() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
clearPartitionReplica(int) - Method in interface com.hazelcast.spi.MigrationAwareService
 
Client - Interface in com.hazelcast.core
Client interface allows to get information about a connected clients socket address, type and uuid.
CLIENT_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
CLIENT_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
 
CLIENT_PING - Static variable in class com.hazelcast.client.ClientPortableHook
 
CLIENT_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
CLIENT_RESPONSE - Static variable in class com.hazelcast.client.ClientDataSerializerHook
 
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.
ClientClusterService - Interface in com.hazelcast.client.spi
 
ClientConfig - Class in com.hazelcast.client.config
 
ClientConfig() - Constructor for class com.hazelcast.client.config.ClientConfig
 
clientConnected(Client) - Method in interface com.hazelcast.core.ClientListener
Invoked when a new client is connected.
ClientContext - Class in com.hazelcast.client.spi
 
ClientCreateRequest - Class in com.hazelcast.client
 
ClientCreateRequest() - Constructor for class com.hazelcast.client.ClientCreateRequest
 
ClientCreateRequest(String, String) - Constructor for class com.hazelcast.client.ClientCreateRequest
 
ClientDataSerializerHook - Class in com.hazelcast.client
 
ClientDataSerializerHook() - Constructor for class com.hazelcast.client.ClientDataSerializerHook
 
ClientDestroyRequest - Class in com.hazelcast.client
 
ClientDestroyRequest() - Constructor for class com.hazelcast.client.ClientDestroyRequest
 
ClientDestroyRequest(String, String) - Constructor for class com.hazelcast.client.ClientDestroyRequest
 
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.
ClientDisconnectionOperation - Class in com.hazelcast.client
 
ClientDisconnectionOperation() - Constructor for class com.hazelcast.client.ClientDisconnectionOperation
 
ClientDisconnectionOperation(String) - Constructor for class com.hazelcast.client.ClientDisconnectionOperation
 
ClientEndpoint - Class in com.hazelcast.client
 
ClientEngine - Interface in com.hazelcast.client
 
clientEngine - Variable in class com.hazelcast.client.ClientRequest
 
ClientEngineImpl - Class in com.hazelcast.client
 
ClientEngineImpl(Node) - Constructor for class com.hazelcast.client.ClientEngineImpl
 
ClientEngineMBean - Class in com.hazelcast.jmx
 
ClientEngineMBean(HazelcastInstance, ClientEngine, ManagementService) - Constructor for class com.hazelcast.jmx.ClientEngineMBean
 
ClientExecutionService - Interface in com.hazelcast.client.spi
 
ClientImpl - Class in com.hazelcast.client
 
ClientImpl(String, InetSocketAddress) - Constructor for class com.hazelcast.client.ClientImpl
 
ClientInvocationService - Interface in com.hazelcast.client.spi
 
ClientListener - Interface in com.hazelcast.core
ClientListener allows to get notified when a Client is connected to or disconnected from cluster.
ClientNetworkConfig - Class in com.hazelcast.client.config
 
ClientNetworkConfig() - Constructor for class com.hazelcast.client.config.ClientNetworkConfig
 
ClientOutOfMemoryHandler - Class in com.hazelcast.client
To clear resources of the client upon OutOfMemory
ClientOutOfMemoryHandler() - Constructor for class com.hazelcast.client.ClientOutOfMemoryHandler
 
ClientOutOfMemoryHandler.ClientHelper - Class in com.hazelcast.client
 
ClientPartitionService - Interface in com.hazelcast.client.spi
 
ClientPortableFactory - Class in com.hazelcast.client
 
ClientPortableFactory() - Constructor for class com.hazelcast.client.ClientPortableFactory
 
ClientPortableHook - Class in com.hazelcast.client
 
ClientPortableHook() - Constructor for class com.hazelcast.client.ClientPortableHook
 
ClientPrincipal - Class in com.hazelcast.client
 
ClientPrincipal() - Constructor for class com.hazelcast.client.ClientPrincipal
 
ClientPrincipal(String, String) - Constructor for class com.hazelcast.client.ClientPrincipal
 
ClientProxy - Class in com.hazelcast.client.spi
 
ClientProxy(String, String, String) - Constructor for class com.hazelcast.client.spi.ClientProxy
 
ClientProxyFactory - Interface in com.hazelcast.client.spi
 
ClientReAuthOperation - Class in com.hazelcast.client
 
ClientReAuthOperation() - Constructor for class com.hazelcast.client.ClientReAuthOperation
 
ClientReAuthOperation(String, boolean) - Constructor for class com.hazelcast.client.ClientReAuthOperation
 
ClientRequest - Class in com.hazelcast.client
 
ClientRequest() - Constructor for class com.hazelcast.client.ClientRequest
 
ClientResponse - Class in com.hazelcast.client
 
ClientResponse() - Constructor for class com.hazelcast.client.ClientResponse
 
ClientResponse(Data, boolean, int) - Constructor for class com.hazelcast.client.ClientResponse
 
ClientResponse(Data, int, boolean) - Constructor for class com.hazelcast.client.ClientResponse
 
ClientSecurityConfig - Class in com.hazelcast.client.config
 
ClientSecurityConfig() - Constructor for class com.hazelcast.client.config.ClientSecurityConfig
 
ClientService - Interface in com.hazelcast.core
ClientService allows to query connected Clients and attach/detach ClientListeners to listen connection events.
ClientType - Enum in com.hazelcast.core
Type of a client.
ClientTypes - Class in com.hazelcast.client
 
clone() - Method in class com.hazelcast.monitor.TimedMemberState
 
close() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
close() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
Cluster - Interface in com.hazelcast.core
Hazelcast cluster interface.
ClusterDataSerializerHook - Class in com.hazelcast.cluster
 
ClusterDataSerializerHook() - Constructor for class com.hazelcast.cluster.ClusterDataSerializerHook
 
ClusterProxy - Class in com.hazelcast.cluster
 
ClusterProxy(ClusterServiceImpl) - Constructor for class com.hazelcast.cluster.ClusterProxy
 
ClusterService - Interface in com.hazelcast.cluster
 
ClusterServiceImpl - Class in com.hazelcast.cluster
 
ClusterServiceImpl(Node) - Constructor for class com.hazelcast.cluster.ClusterServiceImpl
 
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_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
COLLECTION_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
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
 
com.hazelcast.client - package com.hazelcast.client
This package contains the serverside client functionality
com.hazelcast.client.config - package com.hazelcast.client.config
 
com.hazelcast.client.spi - package com.hazelcast.client.spi
 
com.hazelcast.cluster - package com.hazelcast.cluster
 
com.hazelcast.config - package com.hazelcast.config
Provides classes for configuring HazelcastInstance.
com.hazelcast.core - package com.hazelcast.core
Provides core API interfaces/classes.
com.hazelcast.hibernate - package com.hazelcast.hibernate
 
com.hazelcast.hibernate.instance - package com.hazelcast.hibernate.instance
 
com.hazelcast.jmx - package com.hazelcast.jmx
Contains Hazelcast MBean classes.
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.monitor - package com.hazelcast.monitor
Contains Hazelcast statistics interfaces related to map, queue, topic, multimap, executor service etc.
com.hazelcast.nio.serialization - package com.hazelcast.nio.serialization
Contains interfaces/classes related to serialization; such as serializer interfaces, input/output streams.
com.hazelcast.query - package com.hazelcast.query
Contains interfaces/classes related to Hazelcast query and indexing support.
com.hazelcast.security - package com.hazelcast.security
Provides interfaces/classes for Hazelcast security implementation.
com.hazelcast.spi - package com.hazelcast.spi
Provides interfaces/classes for Hazelcast SPI.
com.hazelcast.spring.cache - package com.hazelcast.spring.cache
 
com.hazelcast.spring.context - package com.hazelcast.spring.context
 
com.hazelcast.spring.jpa - package com.hazelcast.spring.jpa
 
com.hazelcast.spring.mongodb - package com.hazelcast.spring.mongodb
 
com.hazelcast.transaction - package com.hazelcast.transaction
Provides interfaces/classes for Hazelcast transaction support.
com.hazelcast.web - package com.hazelcast.web
 
combine(KeyIn, 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<KeyIn,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<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Defines the CombinerFactory for this task.
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.
commitMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
 
commitTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Commits a transaction.
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
 
config - Variable in class com.hazelcast.cluster.AbstractJoiner
 
Config - Class in com.hazelcast.config
Contains all the configuration to start a HazelcastInstance.
Config() - Constructor for class com.hazelcast.config.Config
 
Config(String) - Constructor for class com.hazelcast.config.Config
 
CONFIG_CHECK - Static variable in class com.hazelcast.cluster.ClusterDataSerializerHook
 
CONFIG_FILE_PATH - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
CONFIG_FILE_PATH_LEGACY - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
ConfigBuilder - Interface in com.hazelcast.config
Interface for all config builders.
ConfigCheck - Class in com.hazelcast.cluster
 
ConfigCheck() - Constructor for class com.hazelcast.cluster.ConfigCheck
 
configCheck - Variable in class com.hazelcast.cluster.JoinMessage
 
ConfigLoader - Class in com.hazelcast.config
 
ConfigurableService<T> - Interface in com.hazelcast.spi
 
configure(Properties) - Method in interface com.hazelcast.hibernate.instance.IHazelcastInstanceLoader
 
configure(GroupConfig, Properties) - Method in interface com.hazelcast.security.ICredentialsFactory
Configures ICredentialsFactory.
configure(SecurityConfig, Properties) - Method in interface com.hazelcast.security.IPermissionPolicy
Configures IPermissionPolicy.
configure(T) - Method in interface com.hazelcast.spi.ConfigurableService
 
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.
connectAndSendJoinRequest(Collection<Address>) - Method in class com.hazelcast.cluster.AbstractJoiner
 
connectionAdded(Connection) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
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.ClusterServiceImpl
 
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 - 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_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
 
contains(E) - Method in interface com.hazelcast.core.IAtomicReference
Checks if the reference contains the value.
contains(Object) - Method in interface com.hazelcast.core.IQueue
contains(Object) - Method in interface com.hazelcast.hibernate.RegionCache
 
containsAll(Collection<?>) - Method in interface com.hazelcast.core.IQueue
containsEntry(K, V) - Method in interface com.hazelcast.core.MultiMap
Returns whether the multimap contains the given key-value pair.
containsKey(Object) - Method in interface com.hazelcast.core.BaseMap
Returns true if this map contains an entry for the specified key.
containsKey(Object) - Method in interface com.hazelcast.core.IMap
Returns true if this map contains an entry for the specified key.
containsKey(K) - Method in interface com.hazelcast.core.MultiMap
Returns whether the multimap contains an entry with the key.
containsKey(Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.containsKey(Object).
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.
Context<K,V> - Interface in com.hazelcast.mapreduce
The Context interface is used for emitting keys and values to the sample space of the MapReduce algorithm.
convert(Map.Entry, Comparable, Comparable) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
 
CoreService - Interface in com.hazelcast.spi
Marker interface for core Hazelcast services.
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
 
CountDownLatchMBean - Class in com.hazelcast.jmx
 
CountDownLatchMBean(ICountDownLatch, ManagementService) - Constructor for class com.hazelcast.jmx.CountDownLatchMBean
 
CPP - Static variable in class com.hazelcast.client.ClientTypes
 
create(int) - Method in class com.hazelcast.client.ClientPortableFactory
 
create(String) - Method in interface com.hazelcast.client.spi.ClientProxyFactory
 
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
 
create(int) - Method in interface com.hazelcast.nio.serialization.PortableFactory
 
CREATE_PROXY - Static variable in class com.hazelcast.client.ClientPortableHook
 
createClassDefinition(int, byte[]) - Method in interface com.hazelcast.nio.serialization.SerializationContext
 
createClientLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
Creates client LoginContext.
createDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
 
createFactory() - Method in class com.hazelcast.client.ClientDataSerializerHook
 
createFactory() - Method in class com.hazelcast.client.ClientPortableHook
 
createFactory() - Method in class com.hazelcast.cluster.ClusterDataSerializerHook
 
createFactory() - Method in interface com.hazelcast.nio.serialization.DataSerializerHook
 
createFactory() - Method in interface com.hazelcast.nio.serialization.PortableHook
 
createFactory() - Method in class com.hazelcast.web.WebDataSerializerHook
 
createInput(Data, SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
 
createInput(byte[], SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
 
createInstance(Properties) - Static method in class com.hazelcast.hibernate.instance.HazelcastInstanceFactory
 
createInstanceLoader(Properties) - Static method in class com.hazelcast.hibernate.instance.HazelcastInstanceFactory
 
createInvocationBuilder(String, Operation, int) - Method in class com.hazelcast.client.InvocationClientRequest
 
createInvocationBuilder(String, Operation, Address) - Method in class com.hazelcast.client.InvocationClientRequest
 
createInvocationBuilder(String, Operation, int) - Method in interface com.hazelcast.spi.OperationService
 
createInvocationBuilder(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
 
createMember(Address, String, String, Map<String, Object>) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
createMemberLoginContext(Credentials) - Method in interface com.hazelcast.security.SecurityContext
Creates member LoginContext.
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, ByteOrder) - Method in interface com.hazelcast.nio.serialization.SerializationService
 
createObjectDataInputStream(InputStream) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
createObjectDataInputStream(InputStream, ByteOrder) - 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, ByteOrder) - Method in interface com.hazelcast.nio.serialization.SerializationService
 
createObjectDataOutputStream(OutputStream) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
createObjectDataOutputStream(OutputStream, ByteOrder) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
createObjectName(String, String) - Method in class com.hazelcast.jmx.ManagementService
 
createOperation() - Method in class com.hazelcast.client.OperationFactoryWrapper
 
createOperation() - Method in interface com.hazelcast.spi.OperationFactory
Creates the operation.
createOperationFactory() - Method in class com.hazelcast.client.AllPartitionsClientRequest
 
createOperationFactory() - Method in class com.hazelcast.client.MultiPartitionClientRequest
 
createOperationFactory() - Method in class com.hazelcast.client.MultiTargetClientRequest
 
createOutput(int, SerializationService) - Method in interface com.hazelcast.nio.serialization.InputOutputFactory
 
createPortableReader(Data) - Method in interface com.hazelcast.nio.serialization.SerializationService
 
createPortableReader(Data) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
createSecureCallable(Subject, Callable<V>) - Method in interface com.hazelcast.security.SecurityContext
Creates secure callable that runs in a sandbox.
createSerializer() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Creates a new serializer for the serialization type
createTransactionalObject(String, TransactionSupport) - Method in interface com.hazelcast.spi.TransactionalService
 
Credentials - Interface in com.hazelcast.security
Credentials is a container object for endpoint (Members and Clients) security attributes.
CredentialsFactoryConfig - Class in com.hazelcast.config
 
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
 

D

DATA - Static variable in class com.hazelcast.cluster.ClusterDataSerializerHook
 
Data - Class in com.hazelcast.nio.serialization
 
Data() - Constructor for class com.hazelcast.nio.serialization.Data
 
Data(int, byte[]) - Constructor for class com.hazelcast.nio.serialization.Data
 
data - Variable in class com.hazelcast.nio.serialization.DataAdapter
 
DataAdapter - Class in com.hazelcast.nio.serialization
 
DataAdapter(Data) - Constructor for class com.hazelcast.nio.serialization.DataAdapter
 
DataAdapter(SerializationContext) - Constructor for class com.hazelcast.nio.serialization.DataAdapter
 
DataAdapter(Data, SerializationContext) - Constructor for class com.hazelcast.nio.serialization.DataAdapter
 
DataSerializable - Interface in com.hazelcast.nio.serialization
 
DataSerializableFactory - Interface in com.hazelcast.nio.serialization
 
DataSerializerHook - Interface in com.hazelcast.nio.serialization
 
decrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
Atomically decrements the current value by one.
decrementAndGet() - Method in class com.hazelcast.jmx.AtomicLongMBean
 
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
 
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
 
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
 
DEFAULT_ASYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
 
DEFAULT_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
 
DEFAULT_CALL_TIMEOUT - Static variable in class com.hazelcast.spi.InvocationBuilder
 
DEFAULT_CHUNK_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
 
DEFAULT_COMMUNICATE_STATS - Static variable in class com.hazelcast.config.JobTrackerConfig
 
DEFAULT_DESERIALIZE_RESULT - Static variable in class com.hazelcast.spi.InvocationBuilder
 
DEFAULT_EMPTY_QUEUE_TTL - Static variable in class com.hazelcast.config.QueueConfig
 
DEFAULT_ENABLED - Static variable in class com.hazelcast.config.MulticastConfig
 
DEFAULT_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
 
DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.MapConfig
 
DEFAULT_EVICTION_POLICY - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_GLOBAL_ORDERING_ENABLED - Static variable in class com.hazelcast.config.TopicConfig
 
DEFAULT_GROUP_NAME - Static variable in class com.hazelcast.config.GroupConfig
 
DEFAULT_GROUP_PASSWORD - Static variable in class com.hazelcast.config.GroupConfig
 
DEFAULT_IN_MEMORY_FORMAT - Static variable in class com.hazelcast.config.MapConfig
 
DEFAULT_MAP_MERGE_POLICY - Static variable in class com.hazelcast.config.MapConfig
 
DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.MapConfig
 
DEFAULT_MAX_IDLE_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.CollectionConfig
 
DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.MapConfig
 
DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_MAX_SIZE - Static variable in class com.hazelcast.config.QueueConfig
 
DEFAULT_MAX_THREAD_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
 
DEFAULT_MEMORY_FORMAT - Static variable in class com.hazelcast.config.NearCacheConfig
 
DEFAULT_MULTICAST_GROUP - Static variable in class com.hazelcast.config.MulticastConfig
 
DEFAULT_MULTICAST_PORT - Static variable in class com.hazelcast.config.MulticastConfig
 
DEFAULT_MULTICAST_TIMEOUT_SECONDS - Static variable in class com.hazelcast.config.MulticastConfig
 
DEFAULT_MULTICAST_TTL - Static variable in class com.hazelcast.config.MulticastConfig
 
DEFAULT_POOL_SIZE - Static variable in class com.hazelcast.config.ExecutorConfig
 
DEFAULT_PORT - Static variable in class com.hazelcast.config.NetworkConfig
 
DEFAULT_QUEUE_CAPACITY - Static variable in class com.hazelcast.config.ExecutorConfig
 
DEFAULT_QUEUE_SIZE - Static variable in class com.hazelcast.config.JobTrackerConfig
 
DEFAULT_REPLICA_INDEX - Static variable in class com.hazelcast.spi.InvocationBuilder
 
DEFAULT_RETRY_COUNT - Static variable in class com.hazelcast.config.JobTrackerConfig
 
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.CollectionConfig
 
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.MultiMapConfig
 
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.QueueConfig
 
DEFAULT_SYNC_BACKUP_COUNT - Static variable in class com.hazelcast.config.SemaphoreConfig
 
DEFAULT_TOPOLOGY_CHANGED_STRATEGY - Static variable in class com.hazelcast.config.JobTrackerConfig
 
DEFAULT_TRY_COUNT - Static variable in class com.hazelcast.spi.InvocationBuilder
 
DEFAULT_TRY_PAUSE_MILLIS - Static variable in class com.hazelcast.spi.InvocationBuilder
 
DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.MapConfig
 
DEFAULT_TTL_SECONDS - Static variable in class com.hazelcast.config.NearCacheConfig
 
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_WRITE_DELAY_SECONDS - Static variable in class com.hazelcast.config.MapStoreConfig
 
DefaultObjectNamespace - Class in com.hazelcast.spi
 
DefaultObjectNamespace() - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
 
DefaultObjectNamespace(String, String) - Constructor for class com.hazelcast.spi.DefaultObjectNamespace
 
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
 
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
 
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
Transactional implementation of IMap.delete(Object).
delete(Serializable) - Method in class com.hazelcast.spring.jpa.JPAMapStore
 
delete(Object) - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
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.spring.jpa.JPAMapStore
 
deleteAll(Collection) - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
deregisterAllListeners(String, String) - Method in interface com.hazelcast.spi.EventService
 
deregisterListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
 
destroy() - Method in class com.hazelcast.client.spi.ClientProxy
 
destroy() - Method in class com.hazelcast.client.spi.ProxyManager
 
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.jmx.ManagementService
 
destroy() - Method in class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
 
destroy() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
destroy() - Method in interface com.hazelcast.nio.serialization.Serializer
 
destroy() - Method in interface com.hazelcast.security.ICredentialsFactory
Destroys ICredentialsFactory.
destroy() - Method in interface com.hazelcast.security.IPermissionPolicy
Destroys IPermissionPolicy.
destroy() - Method in interface com.hazelcast.security.SecurityContext
Destroys SecurityContext and all security elements.
destroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
destroy() - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
destroy() - Method in class com.hazelcast.web.WebFilter
 
DESTROY_ENDPOINT_DELAY_MS - Static variable in class com.hazelcast.client.ClientEngineImpl
 
DESTROY_PROXY - Static variable in class com.hazelcast.client.ClientPortableHook
 
destroyDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
 
destroyDistributedObject(String) - Method in interface com.hazelcast.spi.RemoteService
 
dispatchEvent(ClientEndpoint, ClientListener) - Method in class com.hazelcast.client.ClientEngineImpl
 
dispatchEvent(MembershipEvent, MembershipListener) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
dispatchEvent(E, T) - Method in interface com.hazelcast.spi.EventPublishingService
 
DISTRIBUTED_OBJECT_INFO - Static variable in class com.hazelcast.client.ClientPortableHook
 
DistributedObject - Interface in com.hazelcast.core
Base interface for all distributed objects.
DistributedObjectAccessor - Class in com.hazelcast.spi
 
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
 
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
 
DistributedObjectInfo - Class in com.hazelcast.client
 
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
 
DistributedObjectListenerRequest() - Constructor for class com.hazelcast.client.DistributedObjectListenerRequest
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class com.hazelcast.web.WebFilter
 
doJoin(AtomicBoolean) - Method in class com.hazelcast.cluster.AbstractJoiner
 
doJoin(AtomicBoolean) - Method in class com.hazelcast.cluster.MulticastJoiner
 
doJoin(AtomicBoolean) - Method in class com.hazelcast.cluster.TcpIpJoiner
 
DOMAIN - Static variable in class com.hazelcast.jmx.ManagementService
 
domLevel3 - Variable in class com.hazelcast.config.AbstractXmlConfigHelper
 
done() - Method in class com.hazelcast.nio.serialization.DataAdapter
 
drain() - Method in class com.hazelcast.jmx.SemaphoreMBean
 
drainPermits() - Method in interface com.hazelcast.core.ISemaphore
Acquires and returns all permits that are immediately available.
drainTo(Collection<? super E>) - Method in interface com.hazelcast.core.IQueue
drainTo(Collection<? super E>, int) - Method in interface com.hazelcast.core.IQueue
DuplicateInstanceNameException - Exception in com.hazelcast.core
Thrown when a duplicate instance name is detected.
DuplicateInstanceNameException() - Constructor for exception com.hazelcast.core.DuplicateInstanceNameException
 
DuplicateInstanceNameException(String) - Constructor for exception com.hazelcast.core.DuplicateInstanceNameException
 

E

element() - Method in interface com.hazelcast.core.IQueue
element() - Method in class com.hazelcast.mapreduce.KeyValueSource
Returns the current index' element
emit(K, V) - Method in interface com.hazelcast.mapreduce.Context
Emits a key-value pair to the sample space.
end() - Method in interface com.hazelcast.client.spi.ResponseStream
 
endpoint - Variable in class com.hazelcast.client.ClientRequest
 
Endpoint - Interface in com.hazelcast.core
Endpoint represents a peer in the cluster.
ENDPOINT_REMOVE_DELAY_MS - Static variable in class com.hazelcast.client.ClientEngineImpl
 
EntryAdapter<K,V> - Class in com.hazelcast.core
Adapter for EntryListener.
EntryAdapter() - Constructor for class com.hazelcast.core.EntryAdapter
 
entryAdded(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryAdded(EntryEvent<K, V>) - Method in interface com.hazelcast.core.EntryListener
Invoked when an entry is added.
EntryEvent<K,V> - Class in com.hazelcast.core
Map Entry event.
EntryEvent(Object, Member, int, K, V) - Constructor for class com.hazelcast.core.EntryEvent
 
EntryEvent(Object, Member, int, K, V, V) - Constructor for class com.hazelcast.core.EntryEvent
 
entryEventType - Variable in class com.hazelcast.core.EntryEvent
 
EntryEventType - Enum in com.hazelcast.core
Type of entry event.
entryEvicted(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryEvicted(EntryEvent<K, V>) - Method in interface com.hazelcast.core.EntryListener
Invoked when an entry is evicted.
EntryListener<K,V> - Interface in com.hazelcast.core
Map Entry listener to get notified when a map entry is added, removed, updated or evicted.
EntryListenerConfig - Class in com.hazelcast.config
 
EntryListenerConfig() - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(String, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(EntryListener, boolean, boolean) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfig(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfig
 
EntryListenerConfigReadOnly - Class in com.hazelcast.config
 
EntryListenerConfigReadOnly(EntryListenerConfig) - Constructor for class com.hazelcast.config.EntryListenerConfigReadOnly
 
EntryObject - Class in com.hazelcast.query
 
EntryObject(PredicateBuilder) - Constructor for class com.hazelcast.query.EntryObject
 
entryRemoved(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryRemoved(EntryEvent<K, V>) - Method in interface com.hazelcast.core.EntryListener
Invoked when an entry is removed.
entrySet() - Method in interface com.hazelcast.core.IMap
Returns a Set clone of the mappings contained in this map.
entrySet(Predicate) - Method in interface com.hazelcast.core.IMap
Queries the map based on the specified predicate and returns the matching entries.
entrySet() - Method in interface com.hazelcast.core.MultiMap
Returns the set of key-value pairs in the multimap.
entrySet(String) - Method in class com.hazelcast.jmx.MapMBean
 
entryUpdated(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
 
entryUpdated(EntryEvent<K, V>) - Method in interface com.hazelcast.core.EntryListener
Invoked when an entry is updated.
EntryView<K,V> - Interface in com.hazelcast.core
EntryView represents a readonly view of a map entry.
equal(Comparable) - Method in class com.hazelcast.query.EntryObject
 
equal(String, Comparable) - Static method in class com.hazelcast.query.Predicates
 
equals(Object) - Method in class com.hazelcast.client.ClientPrincipal
 
equals(Object) - Method in class com.hazelcast.client.DistributedObjectInfo
 
equals(Object) - Method in class com.hazelcast.client.spi.ClientProxy
 
equals(Object) - Method in class com.hazelcast.cluster.MemberInfo
 
equals(Object) - Method in class com.hazelcast.config.GroupConfig
 
equals(Object) - Method in class com.hazelcast.config.MapConfig
 
equals(Object) - Method in class com.hazelcast.config.TopicConfig
 
equals(Object) - Method in class com.hazelcast.core.LifecycleEvent
 
equals(Object) - Method in class com.hazelcast.core.PartitionAwareKey
 
equals(Object) - Method in class com.hazelcast.monitor.TimedMemberState
 
equals(Object) - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
equals(Object) - Method in class com.hazelcast.nio.serialization.Data
 
equals(Object) - Method in class com.hazelcast.query.SqlPredicate
 
equals(Object) - Method in class com.hazelcast.security.AbstractCredentials
 
equals(Object) - Method in class com.hazelcast.spi.AbstractDistributedObject
 
equals(Object) - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
equals(Object) - Method in class com.hazelcast.spi.DefaultObjectNamespace
 
equals(Object) - Method in class com.hazelcast.spi.ServiceInfo
 
eval(Object) - Method in interface com.hazelcast.spi.EventFilter
 
evaluate(Key) - Method in interface com.hazelcast.mapreduce.KeyPredicate
This methods implementation contains the evaluation code whether to select a key or not.
EventFilter - Interface in com.hazelcast.spi
 
EventHandler<E> - Interface in com.hazelcast.client.spi
 
EventOperation - Interface in com.hazelcast.spi
 
EventPublishingService<E,T> - Interface in com.hazelcast.spi
 
EventRegistration - Interface in com.hazelcast.spi
The result of a Event Registration.
EventService - Interface in com.hazelcast.spi
 
EventServiceMBean - Class in com.hazelcast.jmx
 
EventServiceMBean(HazelcastInstance, EventService, ManagementService) - Constructor for class com.hazelcast.jmx.EventServiceMBean
 
evict(K) - Method in interface com.hazelcast.core.IMap
Evicts the specified key from this map.
evict(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
ExceptionAction - Enum in com.hazelcast.spi
 
execute(Runnable) - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
execute(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Executes task on a randomly selected member
execute(String, Runnable) - Method in interface com.hazelcast.spi.ExecutionService
 
execute(TransactionalTaskContext) - Method in interface com.hazelcast.transaction.TransactionalTask
Executes the transactional logic.
executeInternal(Runnable) - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
executeOnAllMembers(Runnable) - Method in interface com.hazelcast.core.IExecutorService
Executes task on all of known cluster members
executeOnEntries(EntryProcessor) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the all entries in the map.
executeOnEntries(EntryProcessor, Predicate) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entries in the map which satisfies provided predicate.
executeOnKey(K, EntryProcessor) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entry mapped by the key.
executeOnKeyOwner(Runnable, Object) - Method in interface com.hazelcast.core.IExecutorService
Executes task on owner of the specified key
executeOnKeys(Set<K>, EntryProcessor) - Method in interface com.hazelcast.core.IMap
Applies the user defined EntryProcessor to the entries mapped by the collection of keys.
executeOnMember(Runnable, Member) - Method in interface com.hazelcast.core.IExecutorService
Executes task on the specified member
executeOnMembers(Runnable, Collection<Member>) - Method in interface com.hazelcast.core.IExecutorService
Executes task on each of the specified members
executeOnMembers(Runnable, MemberSelector) - Method in interface com.hazelcast.core.IExecutorService
Executes task on each of the selected members
executeOperation(Operation) - Method in interface com.hazelcast.spi.OperationService
Executes operation in operation executor pool.
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.client.HazelcastClient
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.client.HazelcastClient
 
executeTransaction(TransactionalTask<T>) - Method in class com.hazelcast.client.HazelcastClientProxy
 
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in class com.hazelcast.client.HazelcastClientProxy
 
executeTransaction(TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
Executes given transactional task in current thread using default options and returns the result of the task.
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.core.HazelcastInstance
Executes given transactional task in current thread using given options and returns the result of the task.
executeTransaction(TransactionOptions, TransactionalTask<T>) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
ExecutionCallback<V> - Interface in com.hazelcast.core
ExecutionCallback allows to asynchronously get notified when the execution is completed, either successfully or with error.
ExecutionService - Interface in com.hazelcast.spi
A Service responsible for providing access to 'system' executors and customer executors.
ExecutionTracingService - Interface in com.hazelcast.spi
Service that keeps registry of operations' execution/lifecycle.
EXECUTOR_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
EXECUTOR_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
ExecutorConfig - Class in com.hazelcast.config
 
ExecutorConfig() - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(String) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(String, int) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfig(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfig
 
ExecutorConfigReadOnly - Class in com.hazelcast.config
 
ExecutorConfigReadOnly(ExecutorConfig) - Constructor for class com.hazelcast.config.ExecutorConfigReadOnly
 
executorName - Variable in class com.hazelcast.spi.InvocationBuilder
 
ExecutorServiceMBean - Class in com.hazelcast.jmx
 
ExecutorServiceMBean(IExecutorService, ManagementService) - Constructor for class com.hazelcast.jmx.ExecutorServiceMBean
 
EXPLICIT_VERSION_CHECK - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 

F

F_ID - Static variable in class com.hazelcast.cluster.ClusterDataSerializerHook
 
F_ID - Static variable in class com.hazelcast.web.WebDataSerializerHook
 
F_ID_OFFSET_WEBMODULE - Static variable in interface com.hazelcast.nio.serialization.DataSerializerHook
 
FACTORY_ID - Static variable in class com.hazelcast.nio.serialization.Data
 
FactoryIdHelper - Class in com.hazelcast.nio.serialization
 
failedJoiningToMaster(boolean, int) - Method in class com.hazelcast.cluster.AbstractJoiner
 
FieldDefinition - Interface in com.hazelcast.nio.serialization
 
FieldType - Enum in com.hazelcast.nio.serialization
 
FileSystemXmlConfig - Class in com.hazelcast.config
A Config which is which includes functionality for loading itself from a XML configuration file.
FileSystemXmlConfig(String) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on some Hazelcast xml file and uses the System.properties to resolve variables in the XML.
FileSystemXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on some Hazelcast xml file.
FileSystemXmlConfig(File) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast xml file and uses the System.properties to resolve variables in the XML.
FileSystemXmlConfig(File, Properties) - Constructor for class com.hazelcast.config.FileSystemXmlConfig
Creates a Config based on a Hazelcast xml file.
fillDataSerializableFactories(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillPortableFactories(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillProperties(Node, Properties) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
fillSerializers(Node, SerializationConfig) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
filter(Object) - Method in class com.hazelcast.client.PartitionClientRequest
 
filter(Object) - Method in class com.hazelcast.client.TargetClientRequest
 
filter(QueryContext) - Method in interface com.hazelcast.query.IndexAwarePredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.PagingPredicate
Used if inner predicate is instanceof IndexAwarePredicate for filtering
filter(QueryContext) - Method in class com.hazelcast.query.PredicateBuilder
 
filter(QueryContext) - Method in class com.hazelcast.query.Predicates.AndPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.Predicates.BetweenPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.Predicates.EqualPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.Predicates.GreaterLessPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.Predicates.InPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.Predicates.NotEqualPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.Predicates.OrPredicate
 
filter(QueryContext) - Method in class com.hazelcast.query.SqlPredicate
 
filterConfig - Variable in class com.hazelcast.web.WebFilter
 
finalizeChunk() - Method in class com.hazelcast.mapreduce.Combiner
Creates a chunk of ValueOut to be send to the Reducer for the according key.
finalizeCombine() - Method in class com.hazelcast.mapreduce.Combiner
This method is called after mapping phase is over.
finalized(Context<KeyOut, ValueOut>) - Method in interface com.hazelcast.mapreduce.LifecycleMapper
This method is called after the Mapper.map(Object, Object, Context) method is executed for every value and can be used to finalize the internal state of the mapper or to emit a special value.
finalized(Context<KeyOut, ValueOut>) - Method in class com.hazelcast.mapreduce.LifecycleMapperAdapter
This method is called after the Mapper.map(Object, Object, Context) method is executed for every value and can be used to finalize the internal state of the mapper or to emit a special value.
FinalizeJoinOperation - Class in com.hazelcast.cluster
 
FinalizeJoinOperation() - Constructor for class com.hazelcast.cluster.FinalizeJoinOperation
 
FinalizeJoinOperation(Collection<MemberInfo>, PostJoinOperation, long) - Constructor for class com.hazelcast.cluster.FinalizeJoinOperation
 
finalizeReduce() - Method in class com.hazelcast.mapreduce.Reducer
finalizeReduce is called as last step for a reducing phase per key and retrieved the final reduced result.
findExecutorConfig(String) - Method in class com.hazelcast.config.Config
 
findJobTrackerConfig(String) - Method in class com.hazelcast.config.Config
 
findListConfig(String) - Method in class com.hazelcast.config.Config
 
findMapConfig(String) - Method in class com.hazelcast.config.Config
 
findMultiMapConfig(String) - Method in class com.hazelcast.config.Config
 
findQueueConfig(String) - Method in class com.hazelcast.config.Config
 
findSemaphoreConfig(String) - Method in class com.hazelcast.config.Config
 
findSetConfig(String) - Method in class com.hazelcast.config.Config
 
findTopicConfig(String) - Method in class com.hazelcast.config.Config
 
fireLifecycleEvent(LifecycleEvent.LifecycleState) - Method in class com.hazelcast.client.LifecycleServiceImpl
 
flush() - Method in interface com.hazelcast.core.IMap
If this map has a MapStore this method flushes all the local dirty entries by calling MapStore.storeAll() and/or MapStore.deleteAll()
flush() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
forceUnlock() - Method in interface com.hazelcast.core.ILock
Releases the lock regardless of the lock owner.
forceUnlock(K) - Method in interface com.hazelcast.core.IMap
Releases the lock for the specified key regardless of the lock owner.
forceUnlock(K) - Method in interface com.hazelcast.core.MultiMap
Releases the lock for the specified key regardless of the lock owner.
fromList(IList<V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
A helper method to build a KeyValueSource implementation based on the specified IList.
The key returned by this KeyValueSource implementation is ALWAYS the name of the list itself, whereas the value are the entries of list one by one.
fromMap(IMap<K, V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
A helper method to build a KeyValueSource implementation based on the specified IMap
fromMultiMap(MultiMap<K, V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
A helper method to build a KeyValueSource implementation based on the specified MultiMap
fromSet(ISet<V>) - Static method in class com.hazelcast.mapreduce.KeyValueSource
A helper method to build a KeyValueSource implementation based on the specified ISet.
The key returned by this KeyValueSource implementation is ALWAYS the name of the set itself, whereas the value are the entries of set one by one.
fromStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 

G

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.ClientPortableHook
 
GenericError - Class in com.hazelcast.client
 
GenericError() - Constructor for class com.hazelcast.client.GenericError
 
GenericError(String, String, int) - Constructor for class com.hazelcast.client.GenericError
 
GenericError(String, String, String, int) - Constructor for class com.hazelcast.client.GenericError
 
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
Transactional implementation of IMap.get(Object).
get(K) - Method in interface com.hazelcast.core.TransactionalMultiMap
Returns the collection of values associated with the key.
get(Object) - Method in interface com.hazelcast.hibernate.RegionCache
 
get(String) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
get(int) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
get(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
 
get(int) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
 
get(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
get(int) - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
get(byte) - Static method in enum com.hazelcast.nio.serialization.FieldType
 
get(String) - Method in class com.hazelcast.query.EntryObject
 
get(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
get(Object, Class<T>) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
GET_DISTRIBUTED_OBJECT_INFO - Static variable in class com.hazelcast.client.ClientPortableHook
 
GET_PARTITIONS - Static variable in class com.hazelcast.client.ClientPortableHook
 
getAccessKey() - Method in class com.hazelcast.config.AwsConfig
Gets the access key to access AWS.
getActions() - Method in class com.hazelcast.config.PermissionConfig
 
getActiveConnectionCount() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
 
getActivePartitionCount() - Method in class com.hazelcast.jmx.PartitionServiceMBean
 
getAddress() - Method in class com.hazelcast.cluster.JoinMessage
 
getAddress() - Method in class com.hazelcast.cluster.MemberInfo
 
getAddress() - Method in interface com.hazelcast.monitor.MemberState
 
getAddresses() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
getAddresses() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getAlgorithm() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getAll(Set<K>) - Method in interface com.hazelcast.core.IMap
Returns the entries for the given keys.
getAllDistributedObjects() - Method in interface com.hazelcast.spi.ProxyService
 
getAllHazelcastClients() - Static method in class com.hazelcast.client.HazelcastClient
 
getAllHazelcastInstances() - Static method in class com.hazelcast.core.Hazelcast
Returns all active/running HazelcastInstances on this JVM.
getAllKeys() - Method in class com.hazelcast.mapreduce.KeyValueSource
If KeyValueSource.isAllKeysSupported() returns true a call to this method has to return all clusterwide available keys.
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().
getAnchor() - Method in class com.hazelcast.query.PagingPredicate
 
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
 
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.
getAndIncrement() - Method in interface com.hazelcast.core.IAtomicLong
Atomically increments the current value by one.
getAndIncrement() - Method in class com.hazelcast.jmx.AtomicLongMBean
 
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
 
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.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
 
getAsync(K) - Method in interface com.hazelcast.core.IMap
Asynchronously gets the given key.
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 interface com.hazelcast.spi.BackupAwareOperation
The asynchronous backup count.
getAsyncExecutor() - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
getAsyncExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getAtomicLong(String) - Method in class com.hazelcast.client.HazelcastClient
 
getAtomicLong(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getAtomicLong(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates cluster-wide atomic long.
getAtomicReference(String) - Method in class com.hazelcast.client.HazelcastClient
 
getAtomicReference(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getAtomicReference(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates cluster-wide atomic reference.
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
 
getAttributes() - Method in class com.hazelcast.cluster.JoinRequest
 
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(String[]) - Method in class com.hazelcast.jmx.HazelcastMBean
 
getAvailable() - Method in class com.hazelcast.jmx.SemaphoreMBean
 
getAvgAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the average age of the items in this member.
getAwsConfig() - Method in class com.hazelcast.config.JoinConfig
 
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 interface com.hazelcast.monitor.LocalMapStats
Returns the number of backups per entry.
getBackupEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of backup entries hold by this member.
getBackupEntryMemoryCost() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns memory cost (number of bytes) of backup entries in this member.
getBackupItemCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of backup items in this member.
getBackupOperation() - Method in interface com.hazelcast.spi.BackupAwareOperation
Creates the BackupOperation responsible for making the backup.
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.
getBuffer() - Method in class com.hazelcast.nio.serialization.Data
 
getBufferSize() - Method in class com.hazelcast.client.config.SocketOptions
 
getBuild() - Method in class com.hazelcast.jmx.InstanceMBean
 
getBuildNumber() - Method in class com.hazelcast.cluster.JoinMessage
 
getBuiltinDefinitions() - Method in class com.hazelcast.client.ClientPortableHook
 
getBuiltinDefinitions() - Method in interface com.hazelcast.nio.serialization.PortableHook
 
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.
getByteOrder() - Method in class com.hazelcast.config.SerializationConfig
 
getByteOrder() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
getByteOrder() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
getByType(int) - Static method in enum com.hazelcast.core.EntryEventType
 
getByType(int) - Static method in enum com.hazelcast.core.ItemEventType
 
getByValue(int) - Static method in enum com.hazelcast.transaction.TransactionOptions.TransactionType
 
getCache(String) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
getCacheNames() - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
getCallback() - Method in class com.hazelcast.spi.InvocationBuilder
 
getCallerAddress() - Method in class com.hazelcast.spi.Operation
 
getCallerUuid() - Method in class com.hazelcast.spi.Operation
 
getCallId() - Method in class com.hazelcast.client.ClientRequest
 
getCallId() - Method in class com.hazelcast.client.ClientResponse
 
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 interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of cancelled operations of the executor service
getChunkSize() - Method in class com.hazelcast.config.JobTrackerConfig
 
getClassDefinition() - Method in class com.hazelcast.nio.serialization.Data
 
getClassDefinitions() - Method in class com.hazelcast.config.SerializationConfig
 
getClassId() - Method in class com.hazelcast.client.AuthenticationRequest
 
getClassId() - Method in class com.hazelcast.client.ClientCreateRequest
 
getClassId() - Method in class com.hazelcast.client.ClientDestroyRequest
 
getClassId() - Method in class com.hazelcast.client.ClientPrincipal
 
getClassId() - Method in class com.hazelcast.client.DistributedObjectInfo
 
getClassId() - Method in class com.hazelcast.client.DistributedObjectListenerRequest
 
getClassId() - Method in class com.hazelcast.client.GenericError
 
getClassId() - Method in class com.hazelcast.client.GetDistributedObjectsRequest
 
getClassId() - Method in class com.hazelcast.client.RemoveDistributedObjectListenerRequest
 
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
 
getClassId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getClassLoader() - Method in class com.hazelcast.client.config.ClientConfig
 
getClassLoader() - Method in class com.hazelcast.config.Config
Returns the class-loader that will be used in serialization.
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.client.config.ProxyFactoryConfig
 
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.SerializerConfig
 
getClassName() - Method in class com.hazelcast.config.ServiceConfig
 
getClassName() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns the name of the SocketInterceptor implementation class
getClientClusterService() - Method in class com.hazelcast.client.HazelcastClient
 
getClientConfig() - Method in class com.hazelcast.client.HazelcastClient
 
getClientConfig() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getClientConfig() - Method in class com.hazelcast.client.spi.ClientContext
 
getClientEndpointCount() - Method in interface com.hazelcast.client.ClientEngine
 
getClientEndpointCount() - Method in class com.hazelcast.client.ClientEngineImpl
 
getClientEndpointCount() - Method in class com.hazelcast.jmx.ClientEngineMBean
 
getClientEngine() - Method in class com.hazelcast.client.ClientRequest
 
getClientEngineMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getClientExecutionService() - Method in class com.hazelcast.client.HazelcastClient
 
getClientExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getClientLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getClientPartitionService() - Method in class com.hazelcast.client.HazelcastClient
 
getClientPermissionConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getClientPolicyConfig() - Method in class com.hazelcast.config.SecurityConfig
 
getClients() - Method in class com.hazelcast.client.ClientEngineImpl
 
getClientService() - Method in class com.hazelcast.client.ClientEngineImpl
 
getClientService() - Method in class com.hazelcast.client.HazelcastClient
 
getClientService() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getClientService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the client service of this Hazelcast instance.
getClientType() - Method in class com.hazelcast.client.ClientEndpoint
 
getClientType() - Method in class com.hazelcast.client.ClientImpl
 
getClientType() - Method in interface com.hazelcast.core.Client
Returns type of this client
getCluster() - Method in class com.hazelcast.client.HazelcastClient
 
getCluster() - Method in class com.hazelcast.client.HazelcastClientProxy
 
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.
getClusterId() - Method in class com.hazelcast.config.ManagementCenterConfig
 
getClusterName() - Method in class com.hazelcast.monitor.TimedMemberState
 
getClusterProxy() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getClusterService() - Method in interface com.hazelcast.client.ClientEngine
 
getClusterService() - Method in class com.hazelcast.client.ClientEngineImpl
 
getClusterService() - Method in class com.hazelcast.client.spi.ClientContext
 
getClusterService() - Method in interface com.hazelcast.spi.NodeEngine
 
getClusterTime() - Method in interface com.hazelcast.client.spi.ClientClusterService
 
getClusterTime() - Method in class com.hazelcast.cluster.ClusterProxy
 
getClusterTime() - Method in interface com.hazelcast.cluster.ClusterService
 
getClusterTime() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getClusterTime() - Method in interface com.hazelcast.core.Cluster
Returns the cluster-wide time in milliseconds.
getClusterTime() - Method in class com.hazelcast.jmx.InstanceMBean
 
getClusterTimeFor(long) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getComparator() - Method in class com.hazelcast.query.PagingPredicate
 
getCompletableFuture() - Method in interface com.hazelcast.mapreduce.TrackableJob
Returns the ICompletableFuture to add callbacks or wait for the resulting value of the tracked job
getCompletedTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of completed operations of the executor service
getConfig() - Method in interface com.hazelcast.client.ClientEngine
 
getConfig() - Method in class com.hazelcast.client.ClientEngineImpl
 
getConfig() - Method in class com.hazelcast.client.HazelcastClient
 
getConfig() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getConfig() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the configuration of this Hazelcast instance.
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.TopicMBean
 
getConfig() - Method in interface com.hazelcast.spi.NodeEngine
 
getConfigCheck() - Method in class com.hazelcast.cluster.JoinMessage
 
getConfigClassLoader() - Method in interface com.hazelcast.spi.NodeEngine
 
getConfigFilePath(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
 
getConfigObject() - Method in class com.hazelcast.config.ServiceConfig
 
getConfigSource() - Method in class com.hazelcast.jmx.InstanceMBean
 
getConfigurationFile() - Method in class com.hazelcast.config.Config
 
getConfigurationMembers(Config) - Static method in class com.hazelcast.cluster.TcpIpJoiner
 
getConfigurationUrl() - Method in class com.hazelcast.config.Config
 
getConnectedClients() - Method in interface com.hazelcast.core.ClientService
Returns all connected clients to this member.
getConnection() - Method in class com.hazelcast.spi.Operation
 
getConnectionAttemptLimit() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
getConnectionAttemptLimit() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getConnectionAttemptPeriod() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
getConnectionAttemptPeriod() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getConnectionCount() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
 
getConnectionListener() - Method in class com.hazelcast.client.ClientEngineImpl
 
getConnectionManager() - Method in class com.hazelcast.client.HazelcastClient
 
getConnectionManager() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
 
getConnectionManagerMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getConnectionTimeout() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
getConnectionTimeout() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
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.TcpIpJoiner
 
getConnTimeoutSeconds() - Method in class com.hazelcast.cluster.TcpIpJoinerOverAWS
 
getContext() - Method in class com.hazelcast.client.spi.ClientProxy
 
getCost() - Method in interface com.hazelcast.core.EntryView
Returns the cost (in bytes) of the entry.
getCount() - Method in interface com.hazelcast.core.ICountDownLatch
Returns the current count.
getCount() - Method in class com.hazelcast.jmx.CountDownLatchMBean
 
getCountDownLatch(String) - Method in class com.hazelcast.client.HazelcastClient
 
getCountDownLatch(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getCountDownLatch(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates cluster-wide CountDownLatch.
getCreationTime() - Method in interface com.hazelcast.core.EntryView
Returns the creation time of the entry.
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
getCredentials() - Method in class com.hazelcast.client.config.ClientConfig
 
getCredentials() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCredentials() - Method in class com.hazelcast.cluster.JoinRequest
 
getCredentialsClassname() - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
getCredentialsFactory() - Method in interface com.hazelcast.security.SecurityContext
Returns current ICredentialsFactory.
getCrudRepository() - Method in class com.hazelcast.spring.jpa.JPAMapStore
 
getCurrentClientConnections() - Method in class com.hazelcast.jmx.ConnectionManagerMBean
 
getCurrentValue() - Method in class com.hazelcast.jmx.AtomicLongMBean
 
getData() - Method in class com.hazelcast.nio.serialization.DataAdapter
 
getDataSerializableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getDataSerializableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
getDefault() - Static method in class com.hazelcast.transaction.TransactionOptions
Creates a new TransactionOptions configured with default settings.
getDefaultAccessType() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
getDefaultCacheTimeoutInMillis() - Static method in class com.hazelcast.hibernate.CacheEnvironment
 
getDefaultScheduledExecutor() - Method in interface com.hazelcast.spi.ExecutionService
 
getDetails() - Method in class com.hazelcast.client.GenericError
 
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(String, Object) - Method in class com.hazelcast.client.HazelcastClient
Deprecated. 
getDistributedObject(String, String) - Method in class com.hazelcast.client.HazelcastClient
 
getDistributedObject(String, Object) - Method in class com.hazelcast.client.HazelcastClientProxy
Deprecated. 
getDistributedObject(String, String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getDistributedObject() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns DistributedObject instance
getDistributedObject(String, Object) - Method in interface com.hazelcast.core.HazelcastInstance
Deprecated. use HazelcastInstance.getDistributedObject(String, String) instead.
getDistributedObject(String, String) - Method in interface com.hazelcast.core.HazelcastInstance
 
getDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
 
getDistributedObjects() - Method in class com.hazelcast.client.HazelcastClient
 
getDistributedObjects() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getDistributedObjects() - Method in class com.hazelcast.client.spi.ProxyManager
 
getDistributedObjects() - Method in interface com.hazelcast.core.HazelcastInstance
Returns all DistributedObject's such as; queue, map, set, list, topic, lock, multimap.
getDistributedObjects(String) - Method in interface com.hazelcast.spi.ProxyService
 
GetDistributedObjectsRequest - Class in com.hazelcast.client
 
GetDistributedObjectsRequest() - Constructor for class com.hazelcast.client.GetDistributedObjectsRequest
 
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.
getDurability() - Method in class com.hazelcast.transaction.TransactionOptions
Gets the transaction durability.
getEmptyPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns number of null returning poll operations.
getEmptyQueueTtl() - Method in class com.hazelcast.config.QueueConfig
 
getEndpoint() - Method in class com.hazelcast.client.ClientRequest
 
getEndpoint() - Method in class com.hazelcast.security.AbstractCredentials
 
getEndpoint() - Method in interface com.hazelcast.security.Credentials
Returns IP address of endpoint.
getEndpoints() - Method in class com.hazelcast.config.PermissionConfig
 
getEndpoints() - Method in class com.hazelcast.config.WanTargetClusterConfig
 
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
 
getEntryView(K) - Method in interface com.hazelcast.core.IMap
Returns the EntryView for the specified key.
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 interface com.hazelcast.spi.EventService
 
getEventQueueSize() - Method in class com.hazelcast.jmx.EventServiceMBean
 
getEventQueueSize() - Method in interface com.hazelcast.spi.EventService
 
getEventService() - Method in interface com.hazelcast.client.ClientEngine
 
getEventService() - Method in class com.hazelcast.client.ClientEngineImpl
 
getEventService() - Method in interface com.hazelcast.spi.NodeEngine
 
getEventServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getEventThreadCount() - Method in class com.hazelcast.jmx.EventServiceMBean
 
getEventThreadCount() - Method in interface com.hazelcast.spi.EventService
 
getEventType() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns type of this event; one of DistributedObjectEvent.EventType.CREATED or DistributedObjectEvent.EventType.DESTROYED
getEventType() - Method in class com.hazelcast.core.EntryEvent
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
getEvictionPercentage() - Method in class com.hazelcast.config.MapConfig
 
getEvictionPolicy() - Method in class com.hazelcast.config.MapConfig
 
getEvictionPolicy() - Method in class com.hazelcast.config.NearCacheConfig
 
getExecutedCount() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
 
getExecutedOperationCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
 
getExecutedOperationCount() - Method in interface com.hazelcast.spi.OperationService
 
getExecutionService() - Method in class com.hazelcast.client.spi.ClientContext
 
getExecutionService() - Method in interface com.hazelcast.spi.NodeEngine
 
getExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
 
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
 
getExecutorPoolSize() - Method in class com.hazelcast.client.config.ClientConfig
 
getExecutorService(String) - Method in class com.hazelcast.client.HazelcastClient
 
getExecutorService(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getExecutorService(String) - Method in interface com.hazelcast.core.HazelcastInstance
Returns the distributed executor service for the given name.
getExpirationTime() - Method in interface com.hazelcast.core.EntryView
Returns the expiration time of the entry.
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
Returns the name of the com.hazelcast.nio.ssl.SSLContextFactory implementation class
getFactoryId() - Method in class com.hazelcast.client.AuthenticationRequest
 
getFactoryId() - Method in class com.hazelcast.client.ClientCreateRequest
 
getFactoryId() - Method in class com.hazelcast.client.ClientDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.client.ClientDestroyRequest
 
getFactoryId() - Method in class com.hazelcast.client.ClientPortableHook
 
getFactoryId() - Method in class com.hazelcast.client.ClientPrincipal
 
getFactoryId() - Method in class com.hazelcast.client.ClientResponse
 
getFactoryId() - Method in class com.hazelcast.client.DistributedObjectInfo
 
getFactoryId() - Method in class com.hazelcast.client.DistributedObjectListenerRequest
 
getFactoryId() - Method in class com.hazelcast.client.GenericError
 
getFactoryId() - Method in class com.hazelcast.client.GetDistributedObjectsRequest
 
getFactoryId() - Method in class com.hazelcast.client.RemoveDistributedObjectListenerRequest
 
getFactoryId() - Method in class com.hazelcast.cluster.ClusterDataSerializerHook
 
getFactoryId() - Method in class com.hazelcast.cluster.ConfigCheck
 
getFactoryId() - Method in class com.hazelcast.cluster.HeartbeatOperation
 
getFactoryId() - Method in interface com.hazelcast.nio.serialization.ClassDefinition
 
getFactoryId() - Method in class com.hazelcast.nio.serialization.Data
 
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
 
getFactoryId() - Method in interface com.hazelcast.nio.serialization.Portable
 
getFactoryId() - Method in interface com.hazelcast.nio.serialization.PortableHook
 
getFactoryId() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getFactoryId() - Method in class com.hazelcast.web.SessionAttributePredicate
 
getFactoryId() - Method in class com.hazelcast.web.WebDataSerializerHook
 
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
Returns the com.hazelcast.nio.ssl.SSLContextFactory implementation object
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.ClassDefinitionImpl
 
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
 
getFieldCount() - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
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.ClassDefinitionImpl
 
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.ClassDefinitionImpl
 
getFieldType(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
 
getFieldType(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
getFilter() - Method in interface com.hazelcast.spi.EventRegistration
 
getFlags() - Method in class com.hazelcast.query.Predicates.ILikePredicate
 
getFlags() - Method in class com.hazelcast.query.Predicates.LikePredicate
 
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.
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.
getGetOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of get operations
getGlobalSerializerConfig() - Method in class com.hazelcast.config.SerializationConfig
 
getGroupConfig() - Method in class com.hazelcast.client.config.ClientConfig
 
getGroupConfig() - Method in class com.hazelcast.config.Config
 
getGroupName() - Method in class com.hazelcast.config.WanTargetClusterConfig
 
getGroupName() - Method in class com.hazelcast.jmx.InstanceMBean
 
getGroupPassword() - Method in class com.hazelcast.config.WanTargetClusterConfig
 
getGroupProperties() - Method in interface com.hazelcast.spi.NodeEngine
 
getGroupType() - Method in class com.hazelcast.config.PartitionGroupConfig
Returns the MemberGroupType configured.
getHazelcastInstance() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
getHazelcastInstance(Session) - Static method in class com.hazelcast.hibernate.instance.HazelcastAccessor
Tries to extract HazelcastInstance from Session.
getHazelcastInstance(SessionFactory) - Static method in class com.hazelcast.hibernate.instance.HazelcastAccessor
Tries to extract HazelcastInstance from SessionFactory.
getHazelcastInstance(SessionFactoryImplementor) - Static method in class com.hazelcast.hibernate.instance.HazelcastAccessor
Tries to extract HazelcastInstance from SessionFactoryImplementor.
getHazelcastInstance() - Method in class com.hazelcast.jmx.InstanceMBean
 
getHazelcastInstance() - Method in interface com.hazelcast.spi.NodeEngine
 
getHazelcastInstanceByName(String) - Static method in class com.hazelcast.core.Hazelcast
Returns an existing HazelcastInstance with instanceName.
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 class com.hazelcast.nio.serialization.Data
 
getHits() - Method in interface com.hazelcast.core.EntryView
Returns number of hits of the entry.
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.
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.client.ClientResponse
 
getId() - Method in class com.hazelcast.client.spi.ClientProxy
Deprecated. 
getId() - Method in class com.hazelcast.cluster.ConfigCheck
 
getId() - Method in class com.hazelcast.cluster.HeartbeatOperation
 
getId() - Method in interface com.hazelcast.core.DistributedObject
Deprecated. use DistributedObject.getName() instead
getId() - Method in class com.hazelcast.nio.serialization.Data
 
getId() - Method in enum com.hazelcast.nio.serialization.FieldType
 
getId() - Method in interface com.hazelcast.nio.serialization.IdentifiedDataSerializable
 
getId() - Method in class com.hazelcast.spi.AbstractDistributedObject
Deprecated. 
getId() - Method in interface com.hazelcast.spi.EventRegistration
 
getId() - Method in class com.hazelcast.web.SessionAttributePredicate
 
getIdGenerator(String) - Method in class com.hazelcast.client.HazelcastClient
 
getIdGenerator(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getIdGenerator(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates cluster-wide unique IDs.
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.SerializerConfig
 
getImplementation() - Method in class com.hazelcast.config.SocketInterceptorConfig
Returns the SocketInterceptor implementation object
getIndex() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getIndex(QueryContext) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
 
getInetSocketAddress() - Method in interface com.hazelcast.core.Member
Deprecated. use Member.getSocketAddress() instead
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.MapConfig
 
getInMemoryFormat() - Method in class com.hazelcast.config.NearCacheConfig
 
getInstance(Properties) - Method in class com.hazelcast.web.WebFilter
 
getInstanceMBean() - Method in class com.hazelcast.jmx.ManagementService
 
getInstanceName() - Method in class com.hazelcast.config.Config
 
getInstanceName(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
 
getInstanceNames() - Method in class com.hazelcast.monitor.TimedMemberState
 
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.
getIntegerValue(String, String, int) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
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
 
getInvocationService() - Method in class com.hazelcast.client.HazelcastClient
 
getInvocationService() - Method in class com.hazelcast.client.spi.ClientContext
 
getInvocationTime() - Method in class com.hazelcast.spi.Operation
 
getIoExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getItem() - Method in class com.hazelcast.core.ItemEvent
Returns the item related to event.
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
 
getIterationCount() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getIterationType() - Method in class com.hazelcast.query.PagingPredicate
 
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
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.
getJobTracker(String) - Method in class com.hazelcast.client.HazelcastClient
 
getJobTracker(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getJobTracker(String) - Method in interface com.hazelcast.core.HazelcastInstance
Returns the job tracker instance with the specified name.
getJobTracker() - Method in interface com.hazelcast.mapreduce.TrackableJob
Returns the assigned JobTracker
getJobTrackerConfig(String) - Method in class com.hazelcast.config.Config
 
getJobTrackerConfigs() - Method in class com.hazelcast.config.Config
 
getJoin() - Method in class com.hazelcast.config.NetworkConfig
Returns the JoinConfig.
getKey() - Method in class com.hazelcast.client.KeyBasedClientRequest
 
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
Deprecated. use DistributedObject.getName() instead.
getKey() - Method in class com.hazelcast.core.MemberAttributeEvent
 
getKey() - Method in class com.hazelcast.core.PartitionAwareKey
 
getLastAccessTime() - Method in interface com.hazelcast.core.EntryView
Returns the last access time to the entry.
getLastAccessTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the last access (read) time of the locally owned entries.
getLastStoredTime() - Method in interface com.hazelcast.core.EntryView
Returns the last time value is flushed to mapstore.
getLastUpdateTime() - Method in interface com.hazelcast.core.EntryView
Returns the last time value is updated.
getLastUpdateTime() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the last update time of the locally owned entries.
getLicenseKey() - Method in class com.hazelcast.config.Config
 
getLifecycleService() - Method in class com.hazelcast.client.HazelcastClient
 
getLifecycleService() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getLifecycleService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the lifecycle service for this instance.
getLingerSeconds() - Method in class com.hazelcast.client.config.SocketOptions
 
getList(String) - Method in class com.hazelcast.client.HazelcastClient
 
getList(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getList(String) - Method in interface com.hazelcast.core.HazelcastInstance
Returns the distributed list instance with the specified name.
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
 
getListenerConfigs() - Method in class com.hazelcast.client.config.ClientConfig
 
getListenerConfigs() - Method in class com.hazelcast.config.Config
 
getLoadBalancer() - Method in class com.hazelcast.client.config.ClientConfig
 
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
 
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.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 class com.hazelcast.client.HazelcastClient
 
getLocalEndpoint() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getLocalEndpoint() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the local Endpoint which this HazelcastInstance is belongs to.
getLocalEventOperationCount() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalEventOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalEventOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
 
getLocalExecutorStats() - Method in interface com.hazelcast.core.IExecutorService
Returns local statistics related to this executor service.
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
 
getLocalHits() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalHits() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalLastAccessTime() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalLastAccessTime() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalLastUpdateTime() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalLastUpdateTime() - Method in class com.hazelcast.jmx.MultiMapMBean
 
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 interface com.hazelcast.monitor.MemberState
 
getLocalMaxAge() - Method in class com.hazelcast.jmx.QueueMBean
 
getLocalMaxGetLatency() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalMaxGetLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalMaxPutLatency() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalMaxPutLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalMember() - Method in interface com.hazelcast.client.ClientEngine
 
getLocalMember() - Method in class com.hazelcast.client.ClientEngineImpl
 
getLocalMember() - Method in class com.hazelcast.cluster.ClusterProxy
 
getLocalMember() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getLocalMember() - Method in interface com.hazelcast.core.Cluster
Returns this Hazelcast instance member
getLocalMember() - Method in interface com.hazelcast.spi.NodeEngine
 
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 interface com.hazelcast.monitor.MemberState
 
getLocalOfferOperationCount() - Method in class com.hazelcast.jmx.QueueMBean
 
getLocalOtherOperationCount() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalOtherOperationCount() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalOtherOperationsCount() - Method in class com.hazelcast.jmx.QueueMBean
 
getLocalOwnedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalOwnedEntryCount() - Method in class com.hazelcast.jmx.MultiMapMBean
 
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
 
getLocalQueueStats() - Method in interface com.hazelcast.core.IQueue
Returns LocalQueueStats for this queue.
getLocalQueueStats(String) - Method in interface com.hazelcast.monitor.MemberState
 
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
 
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 interface com.hazelcast.monitor.MemberState
 
getLocalTotalExecutionLatency() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
 
getLocalTotalGetLatency() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalTotalGetLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalTotalPutLatency() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalTotalPutLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalTotalRemoveLatency() - Method in class com.hazelcast.jmx.MapMBean
 
getLocalTotalRemoveLatency() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getLocalTotalStartLatency() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
 
getLock(String) - Method in class com.hazelcast.client.HazelcastClient
 
getLock(Object) - Method in class com.hazelcast.client.HazelcastClient
Deprecated. 
getLock(Object) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getLock(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
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
Deprecated. will be removed in Hazelcast 3.2. Use HazelcastInstance.getLock(String) instead.
getLockCount() - Method in interface com.hazelcast.core.ILock
Returns re-entrant lock hold count, regardless of lock ownership.
getLockedEntryCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of currently locked locally owned keys.
getLockObject() - Method in class com.hazelcast.jmx.LockMBean
 
getLockTimeoutInMillis(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
 
getLogger(Class) - Method in interface com.hazelcast.client.ClientEngine
 
getLogger(String) - Method in interface com.hazelcast.client.ClientEngine
 
getLogger(Class) - Method in class com.hazelcast.client.ClientEngineImpl
 
getLogger(String) - Method in class com.hazelcast.client.ClientEngineImpl
 
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 class com.hazelcast.client.HazelcastClient
 
getLoggingService() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getLoggingService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the logging service of this Hazelcast instance.
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.
getManagedContext() - Method in class com.hazelcast.client.config.ClientConfig
 
getManagedContext() - Method in class com.hazelcast.config.Config
 
getManagedContext() - Method in interface com.hazelcast.nio.serialization.SerializationContext
 
getManagedContext() - Method in interface com.hazelcast.nio.serialization.SerializationService
 
getManagedContext() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
getManagementCenterConfig() - Method in class com.hazelcast.config.Config
 
getMap(String) - Method in class com.hazelcast.client.HazelcastClient
 
getMap(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Returns the distributed map instance with the specified name.
getMap(String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
Returns the transactional distributed map instance with the specified name.
getMapConfig(String) - Method in class com.hazelcast.config.Config
 
getMapConfigs() - Method in class com.hazelcast.config.Config
 
getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfig
 
getMapIndexConfigs() - Method in class com.hazelcast.config.MapConfigReadOnly
 
getMapStoreConfig() - Method in class com.hazelcast.config.MapConfig
Returns the map store configuration
getMapStoreConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
 
getMaster() - Method in class com.hazelcast.monitor.TimedMemberState
 
getMasterAddress() - Method in interface com.hazelcast.client.ClientEngine
 
getMasterAddress() - Method in class com.hazelcast.client.ClientEngineImpl
 
getMasterAddress() - Method in interface com.hazelcast.client.spi.ClientClusterService
 
getMasterAddress() - Method in interface com.hazelcast.cluster.ClusterService
 
getMasterAddress() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getMasterAddress() - Method in class com.hazelcast.cluster.SetMasterOperation
 
getMasterAddress() - Method in class com.hazelcast.jmx.NodeMBean
 
getMasterAddress() - Method in interface com.hazelcast.spi.NodeEngine
 
getMaxAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the max age of the items in this member.
getMaxGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the maximum latency of get operations.
getMaxIdleSeconds() - Method in class com.hazelcast.config.MapConfig
 
getMaxIdleSeconds() - Method in class com.hazelcast.config.NearCacheConfig
 
getMaxOperationTimeout(HazelcastInstance) - Static method in class com.hazelcast.hibernate.HazelcastTimestamper
 
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 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
 
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
 
getMember(Address) - Method in interface com.hazelcast.client.spi.ClientClusterService
 
getMember(String) - Method in interface com.hazelcast.client.spi.ClientClusterService
 
getMember(Address) - Method in interface com.hazelcast.cluster.ClusterService
 
getMember(String) - Method in interface com.hazelcast.cluster.ClusterService
 
getMember(Address) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getMember(String) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getMember() - Method in class com.hazelcast.core.EntryEvent
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.spi.MembershipServiceEvent
Returns the removed or added member.
getMemberAttributeConfig() - Method in class com.hazelcast.config.Config
 
getMemberCount() - Method in class com.hazelcast.cluster.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
Returns an unmodifiable collection containing all MemberGroupConfig elements.
getMemberList() - Method in interface com.hazelcast.client.spi.ClientClusterService
 
getMemberList() - Method in interface com.hazelcast.cluster.ClusterService
 
getMemberList() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getMemberList() - Method in class com.hazelcast.monitor.TimedMemberState
 
getMemberLoginModuleConfigs() - Method in class com.hazelcast.config.SecurityConfig
 
getMembers() - Method in class com.hazelcast.cluster.ClusterProxy
 
getMembers() - Method in interface com.hazelcast.cluster.ClusterService
 
getMembers() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getMembers() - Method in class com.hazelcast.cluster.TcpIpJoiner
 
getMembers() - Method in class com.hazelcast.cluster.TcpIpJoinerOverAWS
 
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
Returns an immutable set of ordered members at the moment this InitialMembershipListener is registered.
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
 
getMemberState() - Method in class com.hazelcast.monitor.TimedMemberState
 
getMergePolicy() - Method in class com.hazelcast.config.MapConfig
 
getMergePolicy() - Method in class com.hazelcast.config.WanReplicationRef
 
getMessage() - Method in class com.hazelcast.client.GenericError
 
getMessage() - Method in class com.hazelcast.cluster.JoinRequestOperation
 
getMessage() - Method in exception com.hazelcast.core.MemberLeftException
 
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
getMigrationEndpoint() - Method in class com.hazelcast.spi.PartitionMigrationEvent
 
getMinAge() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the min age of the items in this member.
getMisses() - Method in interface com.hazelcast.monitor.NearCacheStats
Returns the number of misses of the locally owned entries.
getMongoTemplate() - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
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(String) - Method in class com.hazelcast.client.HazelcastClient
 
getMultiMap(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getMultiMap(String) - Method in interface com.hazelcast.core.HazelcastInstance
Returns the distributed multimap instance with the specified name.
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
 
getName() - Method in class com.hazelcast.client.BaseClientRemoveListenerRequest
 
getName() - Method in class com.hazelcast.client.DistributedObjectInfo
 
getName() - Method in class com.hazelcast.client.GenericError
 
getName() - Method in class com.hazelcast.client.HazelcastClient
 
getName() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getName() - Method in class com.hazelcast.client.spi.ClientProxy
 
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 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.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 interface com.hazelcast.core.DistributedObject
Returns the unique name for this DistributedObject.
getName() - Method in class com.hazelcast.core.EntryEvent
Returns the name of the map for this event.
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.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.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.SemaphoreMBean
 
getName() - Method in class com.hazelcast.jmx.SetMBean
 
getName() - Method in class com.hazelcast.jmx.TopicMBean
 
getName() - Method in interface com.hazelcast.mapreduce.TrackableJob
Returns the name of the underlying JobTracker
getName() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
getName() - Method in class com.hazelcast.spi.ServiceInfo
 
getName() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
getNameAsPartitionAwareData() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getNativeCache() - Method in class com.hazelcast.spring.cache.HazelcastCache
 
getNearCacheConfig(String) - Method in class com.hazelcast.client.config.ClientConfig
 
getNearCacheConfig() - Method in class com.hazelcast.config.MapConfig
 
getNearCacheConfig() - Method in class com.hazelcast.config.MapConfigReadOnly
 
getNearCacheConfigMap() - Method in class com.hazelcast.client.config.ClientConfig
 
getNearCacheStats() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns statistics related to the Near Cache.
getNestedClassDefinitions() - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
getNetworkConfig() - Method in class com.hazelcast.client.config.ClientConfig
 
getNetworkConfig() - Method in class com.hazelcast.config.Config
 
getNewOwner() - Method in class com.hazelcast.core.MigrationEvent
Returns the new owner of the migrating partition
getNodeEngine() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getNodeEngine() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
getNodeEngine() - Method in class com.hazelcast.spi.Operation
 
getNodeMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getNotifiedKey() - Method in interface com.hazelcast.spi.Notifier
 
getObjectId() - Method in class com.hazelcast.core.DistributedObjectEvent
Returns identifier of related DistributedObject
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 interface com.hazelcast.monitor.LocalQueueStats
Returns the number of offer/put/add operations.
getOffHeapStorage() - Method in interface com.hazelcast.spi.NodeEngine
 
getOldOwner() - Method in class com.hazelcast.core.MigrationEvent
Returns the old owner of the migrating partition
getOldValue() - Method in class com.hazelcast.core.EntryEvent
Returns the old value of the entry event
getOp() - Method in class com.hazelcast.spi.InvocationBuilder
 
getOperationExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getOperationExecutorQueueSize() - Method in interface com.hazelcast.spi.OperationService
 
getOperationService() - Method in interface com.hazelcast.spi.NodeEngine
 
getOperationServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getOperationThreadCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
 
getOperationThreadCount() - Method in interface com.hazelcast.spi.OperationService
 
getOperationType() - Method in class com.hazelcast.core.MemberAttributeEvent
 
getOrCreateHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
Gets or creates the HazelcastInstance with a certain name.
getOtherOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of Other Operations
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
 
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 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 interface com.hazelcast.monitor.LocalQueueStats
Returns the number of owned items in this member.
getOwner() - Method in interface com.hazelcast.core.Partition
Returns owner member of the partition.
getOwner() - Method in interface com.hazelcast.mapreduce.JobPartitionState
Returns the owner of this partition
getOwnerUuid() - Method in class com.hazelcast.client.ClientPrincipal
 
getPacketVersion() - Method in class com.hazelcast.cluster.JoinMessage
 
getPage() - Method in class com.hazelcast.query.PagingPredicate
 
getPageSize() - Method in class com.hazelcast.query.PagingPredicate
 
getPartition() - Method in class com.hazelcast.client.KeyBasedClientRequest
 
getPartition() - Method in class com.hazelcast.client.PartitionClientRequest
 
getPartition(int) - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartition(Object) - Method in interface com.hazelcast.core.PartitionService
Returns partition which given key belongs to.
getPartitionCount() - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartitionCount() - Method in class com.hazelcast.jmx.PartitionServiceMBean
 
getPartitionGroupConfig() - Method in class com.hazelcast.config.Config
 
getPartitionHash() - Method in class com.hazelcast.nio.serialization.Data
 
getPartitionId(Data) - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartitionId(Object) - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
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.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
 
getPartitioningStrategy() - Method in class com.hazelcast.config.PartitioningStrategyConfig
 
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 class com.hazelcast.client.spi.ClientProxy
 
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 object 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.spi.AbstractDistributedObject
 
getPartitionOwner(int) - Method in interface com.hazelcast.client.spi.ClientPartitionService
 
getPartitions() - Method in class com.hazelcast.client.MultiPartitionClientRequest
 
getPartitions() - Method in interface com.hazelcast.core.PartitionService
Returns all partitions.
getPartitions() - Method in interface com.hazelcast.monitor.MemberState
 
getPartitionService() - Method in interface com.hazelcast.client.ClientEngine
 
getPartitionService() - Method in class com.hazelcast.client.ClientEngineImpl
 
getPartitionService() - Method in class com.hazelcast.client.HazelcastClient
 
getPartitionService() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getPartitionService() - Method in class com.hazelcast.client.spi.ClientContext
 
getPartitionService() - Method in interface com.hazelcast.core.HazelcastInstance
Returns the partition service of this Hazelcast instance.
getPartitionService() - Method in interface com.hazelcast.spi.NodeEngine
 
getPartitionServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getPartitionStates() - Method in interface com.hazelcast.mapreduce.JobProcessInformation
Returns an array of JobPartitionStates holding information about the processing state (JobPartitionState.State) and the processing owner of this partition.
The index of the JobPartitionState inside of the array is the number of the processed partition if the KeyValueSource is PartitionIdAware or a randomly assigned id for the different members of the cluster.
getPassword() - Method in class com.hazelcast.config.GroupConfig
Gets the password to connec to to the group.
getPassword() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getPassword() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getPendingTaskCount() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the number of pending operations of the executor service
getPermissions(Subject, Class<? extends Permission>) - Method in interface com.hazelcast.security.IPermissionPolicy
Determines permissions of subject.
getPollOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of poll/take/remove operations.
getPoolSize() - Method in class com.hazelcast.config.ExecutorConfig
 
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.jmx.InstanceMBean
 
getPortableFactories() - Method in class com.hazelcast.config.SerializationConfig
 
getPortableFactoryClasses() - Method in class com.hazelcast.config.SerializationConfig
 
getPortableVersion() - Method in class com.hazelcast.config.SerializationConfig
 
getPortCount() - Method in class com.hazelcast.config.NetworkConfig
Returns the maximum number of ports allowed to try to bind on.
getPosition(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
 
getPosition(FieldDefinition) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
 
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.
getPredicate() - Method in class com.hazelcast.query.PagingPredicate
 
getPrincipal() - Method in class com.hazelcast.client.ClientEndpoint
 
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 interface com.hazelcast.spi.OperationService
 
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).
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.
getProxy(String, String) - Method in class com.hazelcast.client.spi.ProxyManager
 
getProxyCount() - Method in class com.hazelcast.jmx.ProxyServiceMBean
 
getProxyCount() - Method in interface com.hazelcast.spi.ProxyService
 
getProxyFactoryConfigs() - Method in class com.hazelcast.client.config.ClientConfig
 
getProxyService() - Method in interface com.hazelcast.client.ClientEngine
 
getProxyService() - Method in class com.hazelcast.client.ClientEngineImpl
 
getProxyService() - Method in interface com.hazelcast.spi.NodeEngine
 
getProxyServiceMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getPublicAddress() - Method in class com.hazelcast.config.NetworkConfig
 
getPublishingMember() - Method in class com.hazelcast.core.Message
Returns the member that published the message
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
getPutOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of put operations
getQueryExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getQueue(String) - Method in class com.hazelcast.client.HazelcastClient
 
getQueue(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getQueue(String) - Method in interface com.hazelcast.core.HazelcastInstance
Returns the distributed queue instance with the specified name.
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
 
getQueueSize() - Method in class com.hazelcast.config.JobTrackerConfig
 
getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfig
 
getQueueStoreConfig() - Method in class com.hazelcast.config.QueueConfigReadOnly
 
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
 
getReceiveOperationCount() - Method in interface com.hazelcast.monitor.LocalTopicStats
Returns the total number of received messages of this topic on this member
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.BaseClientRemoveListenerRequest
 
getRegistrations(String, String) - Method in interface com.hazelcast.spi.EventService
 
getRegistrationsAsArray(String, String) - Method in interface com.hazelcast.spi.EventService
 
getRejectedOfferOperationCount() - Method in interface com.hazelcast.monitor.LocalQueueStats
Returns the number of rejected offers.
getRemainingLeaseTime() - Method in interface com.hazelcast.core.ILock
Returns remaining lease time in milliseconds.
getRemoteOperationsCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
 
getRemoteOperationsCount() - Method in interface com.hazelcast.spi.OperationService
 
getRemoveOperationCount() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the number of Remove operations
getReplicaIndex() - Method in class com.hazelcast.client.PartitionClientRequest
 
getReplicaIndex() - Method in class com.hazelcast.spi.InvocationBuilder
 
getReplicaIndex() - Method in class com.hazelcast.spi.Operation
 
getReplicaIndex() - Method in class com.hazelcast.spi.PartitionReplicationEvent
 
getReplicationImpl() - Method in class com.hazelcast.config.WanTargetClusterConfig
 
getReplicationImplObject() - Method in class com.hazelcast.config.WanTargetClusterConfig
 
getRequiredMember() - Method in class com.hazelcast.config.TcpIpConfig
Gets the required member.
getRequiredPermission() - Method in class com.hazelcast.client.AuthenticationRequest
 
getRequiredPermission() - Method in class com.hazelcast.client.ClientCreateRequest
 
getRequiredPermission() - Method in class com.hazelcast.client.ClientDestroyRequest
 
getRequiredPermission() - Method in class com.hazelcast.client.DistributedObjectListenerRequest
 
getRequiredPermission() - Method in class com.hazelcast.client.GetDistributedObjectsRequest
 
getRequiredPermission() - Method in class com.hazelcast.client.RemoveDistributedObjectListenerRequest
 
getRequiredPermission() - Method in interface com.hazelcast.client.SecureRequest
 
getResponse() - Method in class com.hazelcast.client.ClientReAuthOperation
 
getResponse() - Method in class com.hazelcast.client.ClientResponse
 
getResponse() - Method in class com.hazelcast.cluster.AuthorizationOperation
 
getResponse() - Method in class com.hazelcast.cluster.JoinCheckOperation
 
getResponse() - Method in class com.hazelcast.cluster.PrepareMergeOperation
 
getResponse() - Method in class com.hazelcast.cluster.TcpIpJoiner.MasterClaim
 
getResponse() - Method in class com.hazelcast.spi.AbstractOperation
 
getResponse() - Method in class com.hazelcast.spi.Operation
 
getResponseHandler() - Method in class com.hazelcast.spi.Operation
 
getResponseQueueSize() - Method in class com.hazelcast.jmx.OperationServiceMBean
 
getResponseQueueSize() - Method in interface com.hazelcast.spi.OperationService
 
getRetryCount() - Method in class com.hazelcast.config.JobTrackerConfig
 
getRunningOperationsCount() - Method in class com.hazelcast.jmx.OperationServiceMBean
 
getRunningOperationsCount() - Method in interface com.hazelcast.spi.OperationService
 
getRuntimeProps() - Method in interface com.hazelcast.monitor.MemberState
 
getSafely() - Method in interface com.hazelcast.spi.InternalCompletableFuture
 
getSalt() - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
getScheduledExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
 
getScheduledExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
getSecretKey() - Method in class com.hazelcast.config.AwsConfig
Gets the secret key to access AWS.
getSecurityConfig() - Method in class com.hazelcast.client.config.ClientConfig
 
getSecurityConfig() - Method in class com.hazelcast.config.Config
 
getSecurityContext() - Method in interface com.hazelcast.client.ClientEngine
 
getSecurityContext() - Method in class com.hazelcast.client.ClientEngineImpl
 
getSecurityGroupName() - Method in class com.hazelcast.config.AwsConfig
Gets the security group name.
getSecurityToken() - Method in class com.hazelcast.config.ManagementCenterConfig
 
getSemaphore(String) - Method in class com.hazelcast.client.HazelcastClient
 
getSemaphore(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getSemaphore(String) - Method in interface com.hazelcast.core.HazelcastInstance
Creates cluster-wide semaphore.
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.
getSerializationConfig() - Method in class com.hazelcast.client.config.ClientConfig
 
getSerializationConfig() - Method in class com.hazelcast.config.Config
 
getSerializationContext() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
getSerializationContext() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
getSerializationContext() - Method in interface com.hazelcast.nio.serialization.SerializationService
 
getSerializationContext() - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
getSerializationService() - Method in interface com.hazelcast.client.ClientEngine
 
getSerializationService() - Method in class com.hazelcast.client.ClientEngineImpl
 
getSerializationService() - Method in class com.hazelcast.client.HazelcastClient
 
getSerializationService() - Method in class com.hazelcast.client.HazelcastClientProxy
 
getSerializationService() - Method in class com.hazelcast.client.spi.ClientContext
 
getSerializationService() - Method in interface com.hazelcast.spi.NodeEngine
 
getSerializationType() - Method in interface com.hazelcast.nio.serialization.SerializerHook
Returns the actual class type of the serialized object
getSerializerConfigs() - Method in class com.hazelcast.config.SerializationConfig
 
getService() - Method in class com.hazelcast.client.ClientRequest
 
getService() - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
getService() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
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
 
getServiceName() - Method in class com.hazelcast.client.AuthenticationRequest
 
getServiceName() - Method in class com.hazelcast.client.ClientCreateRequest
 
getServiceName() - Method in class com.hazelcast.client.ClientDestroyRequest
 
getServiceName() - Method in class com.hazelcast.client.ClientReAuthOperation
 
getServiceName() - Method in class com.hazelcast.client.ClientRequest
 
getServiceName() - Method in class com.hazelcast.client.DistributedObjectInfo
 
getServiceName() - Method in class com.hazelcast.client.DistributedObjectListenerRequest
 
getServiceName() - Method in class com.hazelcast.client.GetDistributedObjectsRequest
 
getServiceName() - Method in class com.hazelcast.client.RemoveDistributedObjectListenerRequest
 
getServiceName() - Method in class com.hazelcast.client.spi.ClientProxy
 
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.spi.AbstractDistributedObject
 
getServiceName() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
getServiceName() - Method in class com.hazelcast.spi.DefaultObjectNamespace
 
getServiceName() - Method in interface com.hazelcast.spi.EventOperation
 
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
 
getServicesConfig() - Method in class com.hazelcast.config.Config
 
getSet(String) - Method in class com.hazelcast.client.HazelcastClient
 
getSet(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getSet(String) - Method in interface com.hazelcast.core.HazelcastInstance
Returns the distributed set instance with the specified name.
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 interface com.hazelcast.spi.NodeEngine
 
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.
getSize() - Method in interface com.hazelcast.client.spi.ClientClusterService
 
getSize() - Method in interface com.hazelcast.cluster.ClusterService
 
getSize() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getSize() - Method in class com.hazelcast.config.MaxSizeConfig
 
getSize() - Method in class com.hazelcast.jmx.MapMBean
 
getSize() - Method in class com.hazelcast.jmx.MultiMapMBean
 
getSizeInMemory() - Method in interface com.hazelcast.hibernate.RegionCache
 
getSocketAddress() - Method in class com.hazelcast.client.ClientEndpoint
 
getSocketAddress() - Method in class com.hazelcast.client.ClientImpl
 
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.
getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
getSocketInterceptorConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getSocketInterceptorConfig() - Method in class com.hazelcast.config.NetworkConfig
Gets the SocketInterceptorConfig.
getSocketOptions() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
getSocketOptions() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
getSource() - Method in class com.hazelcast.core.EntryEvent
 
getSSLConfig() - Method in class com.hazelcast.client.config.ClientNetworkConfig
Returns the current SSLConfig.
getSSLConfig() - Method in class com.hazelcast.config.NetworkConfig
Returns the current SSLConfig.
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.AbstractJoiner
 
getStartTime() - Method in interface com.hazelcast.cluster.Joiner
 
getStartTime() - Method in class com.hazelcast.spi.Operation
 
getState() - Method in class com.hazelcast.core.LifecycleEvent
 
getState() - Method in interface com.hazelcast.mapreduce.JobPartitionState
Returns the current processing state of this partition
getStatus() - Method in class com.hazelcast.core.MigrationEvent
Returns the status of the migration: Started, completed or failed
getStoreImplementation() - Method in class com.hazelcast.config.QueueStoreConfig
 
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.
getSubject() - Method in class com.hazelcast.client.ClientEndpoint
 
getSubscriber() - Method in interface com.hazelcast.spi.EventRegistration
 
getSymmetricEncryptionConfig() - Method in class com.hazelcast.config.NetworkConfig
Gets the SymmetricEncryptionConfig.
getSyncBackupCount() - Method in class com.hazelcast.config.MultiMapConfig
Deprecated. 
getSyncBackupCount() - Method in interface com.hazelcast.spi.BackupAwareOperation
The synchronous backup count.
getSystemExecutorMBean() - Method in class com.hazelcast.jmx.InstanceMBean
 
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.client.TargetClientRequest
 
getTarget() - Method in class com.hazelcast.spi.InvocationBuilder
 
getTargetAddress() - Method in class com.hazelcast.cluster.AbstractJoiner
 
getTargetClusterConfigs() - Method in class com.hazelcast.config.WanReplicationConfig
 
getTargets() - Method in class com.hazelcast.client.MultiTargetClientRequest
 
getTcpIpConfig() - Method in class com.hazelcast.config.JoinConfig
 
getTextContent(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
getThisAddress() - Method in interface com.hazelcast.client.ClientEngine
 
getThisAddress() - Method in class com.hazelcast.client.ClientEngineImpl
 
getThisAddress() - Method in interface com.hazelcast.cluster.ClusterService
 
getThisAddress() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
getThisAddress() - Method in interface com.hazelcast.spi.NodeEngine
 
getThreadGroup() - Method in class com.hazelcast.client.HazelcastClient
 
getTime() - Method in class com.hazelcast.monitor.TimedMemberState
 
getTimeout(HazelcastInstance, String) - Static method in class com.hazelcast.hibernate.HazelcastTimestamper
 
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
 
getTopic(String) - Method in class com.hazelcast.client.HazelcastClient
 
getTopic(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
getTopic(String) - Method in interface com.hazelcast.core.HazelcastInstance
Returns the distributed topic instance with the specified name.
getTopic() - Method in interface com.hazelcast.spi.EventOperation
 
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
 
getTotalAddedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
 
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.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.
getTotalEvictedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
 
getTotalExecutionLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the total execution time of operations finished
getTotalGetLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of get operations.
getTotalMessageCount() - Method in class com.hazelcast.jmx.TopicMBean
 
getTotalPutLatency() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of put operations.
getTotalRemovedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
 
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 interface com.hazelcast.monitor.LocalMapStats
Returns the total latency of remove operations.
getTotalStartLatency() - Method in interface com.hazelcast.monitor.LocalExecutorStats
Returns the total start latency of operations started
getTotalUpdatedEntryCount() - Method in class com.hazelcast.jmx.MapMBean
 
getTraceIdentifier() - Method in interface com.hazelcast.spi.TraceableOperation
 
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.
getTransactionalObject(String, String) - Method in interface com.hazelcast.transaction.TransactionalTaskContext
 
getTransactionContext(String) - Method in class com.hazelcast.client.ClientEndpoint
 
getTransactionManagerService() - Method in interface com.hazelcast.client.ClientEngine
 
getTransactionManagerService() - Method in class com.hazelcast.client.ClientEngineImpl
 
getTransactionManagerService() - Method in interface com.hazelcast.spi.NodeEngine
 
getTransactionType() - Method in class com.hazelcast.transaction.TransactionOptions
Gets the TransactionOptions.TransactionType.
getTrustedInterfaces() - Method in class com.hazelcast.config.MulticastConfig
Gets the trusted interfaces.
getTryCount() - Method in class com.hazelcast.cluster.JoinRequest
 
getTryCount() - Method in class com.hazelcast.spi.InvocationBuilder
 
getTryPauseMillis() - Method in class com.hazelcast.spi.InvocationBuilder
 
getTxnId() - Method in interface com.hazelcast.transaction.TransactionContext
Gets the id that uniquely identifies the transaction.
getType() - Method in class com.hazelcast.client.GenericError
 
getType() - Method in interface com.hazelcast.cluster.Joiner
 
getType() - Method in class com.hazelcast.cluster.MulticastJoiner
 
getType() - Method in class com.hazelcast.cluster.TcpIpJoiner
 
getType() - Method in class com.hazelcast.cluster.TcpIpJoinerOverAWS
 
getType() - Method in class com.hazelcast.config.PermissionConfig
 
getType() - Method in enum com.hazelcast.core.EntryEventType
 
getType() - Method in enum com.hazelcast.core.ItemEventType
 
getType() - Method in class com.hazelcast.nio.serialization.Data
 
getType() - Method in interface com.hazelcast.nio.serialization.FieldDefinition
 
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
 
getUpdateInterval() - Method in class com.hazelcast.config.ManagementCenterConfig
 
getUrl() - Method in class com.hazelcast.config.ManagementCenterConfig
 
getUsage() - Method in class com.hazelcast.config.LoginModuleConfig
 
getUserContext() - Method in class com.hazelcast.client.HazelcastClient
 
getUserContext() - Method in class com.hazelcast.client.HazelcastClientProxy
 
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.
getUsername() - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
getUuid() - Method in class com.hazelcast.client.ClientEndpoint
 
getUuid() - Method in class com.hazelcast.client.ClientImpl
 
getUuid() - Method in class com.hazelcast.client.ClientPrincipal
 
getUuid() - Method in class com.hazelcast.cluster.JoinMessage
 
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.
getValue(int) - Static method in enum com.hazelcast.cluster.MemberAttributeOperationType
 
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.spring.mongodb.ValueWrapper
 
getValueCollectionType() - Method in class com.hazelcast.config.MultiMapConfig
 
getVersion() - Method in interface com.hazelcast.core.EntryView
Returns the version of the entry
getVersion() - Method in class com.hazelcast.jmx.InstanceMBean
 
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.PortableReader
 
getVersion() - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
getVersion() - Method in interface com.hazelcast.nio.serialization.SerializationContext
 
getWaitKey() - Method in interface com.hazelcast.spi.WaitSupport
 
getWaitNotifyService() - Method in interface com.hazelcast.spi.NodeEngine
 
getWaitTimeout() - Method in class com.hazelcast.spi.Operation
 
getWaitTimeout() - Method in interface com.hazelcast.spi.WaitSupport
 
getWanReplicationConfig(String) - Method in class com.hazelcast.config.Config
 
getWanReplicationConfigs() - Method in class com.hazelcast.config.Config
 
getWanReplicationRef() - Method in class com.hazelcast.config.MapConfig
 
getWanReplicationRef() - Method in class com.hazelcast.config.MapConfigReadOnly
 
getWanReplicationService() - Method in interface com.hazelcast.spi.NodeEngine
 
getWriteDelaySeconds() - Method in class com.hazelcast.config.MapStoreConfig
Returns the number of seconds to delay the store writes.
getXaResource() - Method in interface com.hazelcast.transaction.TransactionContext
Gets xaResource which will participate in XATransaction
GlobalSerializerConfig - Class in com.hazelcast.config
 
GlobalSerializerConfig() - Constructor for class com.hazelcast.config.GlobalSerializerConfig
 
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

H

handle(E) - Method in interface com.hazelcast.client.spi.EventHandler
 
handle(ResponseStream) - Method in interface com.hazelcast.client.spi.ResponseHandler
 
handlePacket(ClientPacket) - Method in class com.hazelcast.client.ClientEngineImpl
 
hasField(String) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
hasField(String) - Method in interface com.hazelcast.nio.serialization.ClassDefinition
 
hasField(String) - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
hasField(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
 
hasField(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
hashCode() - Method in class com.hazelcast.client.ClientPrincipal
 
hashCode() - Method in class com.hazelcast.client.DistributedObjectInfo
 
hashCode() - Method in class com.hazelcast.client.spi.ClientProxy
 
hashCode() - Method in class com.hazelcast.cluster.MemberInfo
 
hashCode() - Method in class com.hazelcast.config.GroupConfig
 
hashCode() - Method in class com.hazelcast.config.MapConfig
 
hashCode() - Method in class com.hazelcast.config.TopicConfig
 
hashCode() - Method in class com.hazelcast.core.LifecycleEvent
 
hashCode() - Method in class com.hazelcast.core.PartitionAwareKey
 
hashCode() - Method in class com.hazelcast.monitor.TimedMemberState
 
hashCode() - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
hashCode() - Method in class com.hazelcast.nio.serialization.Data
 
hashCode() - Method in class com.hazelcast.query.SqlPredicate
 
hashCode() - Method in class com.hazelcast.security.AbstractCredentials
 
hashCode() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
hashCode() - Method in class com.hazelcast.spi.AbstractWaitNotifyKey
 
hashCode() - Method in class com.hazelcast.spi.DefaultObjectNamespace
 
hashCode() - Method in class com.hazelcast.spi.ServiceInfo
 
hasNext() - Method in class com.hazelcast.mapreduce.KeyValueSource
Called to request if at least one more key-value pair is available from this data source.
hasTextContent(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
Hazelcast - Class in com.hazelcast.core
Factory for HazelcastInstance's, a node in a cluster.
HAZELCAST_INSTANCE_NAME - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
HazelcastAccessor - Class in com.hazelcast.hibernate.instance
Access underlying HazelcastInstance using Hibernate SessionFactory
HazelcastCache - Class in com.hazelcast.spring.cache
 
HazelcastCache(IMap<Object, Object>) - Constructor for class com.hazelcast.spring.cache.HazelcastCache
 
HazelcastCacheManager - Class in com.hazelcast.spring.cache
 
HazelcastCacheManager() - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
 
HazelcastCacheManager(HazelcastInstance) - Constructor for class com.hazelcast.spring.cache.HazelcastCacheManager
 
HazelcastCacheRegionFactory - Class in com.hazelcast.hibernate
 
HazelcastCacheRegionFactory() - Constructor for class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
HazelcastCacheRegionFactory(HazelcastInstance) - Constructor for class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
HazelcastCacheRegionFactory(Properties) - Constructor for class com.hazelcast.hibernate.HazelcastCacheRegionFactory
 
HazelcastClient - Class in com.hazelcast.client
Hazelcast Client enables you to do all Hazelcast operations without being a member of the cluster.
HazelcastClientProxy - Class in com.hazelcast.client
 
HazelcastException - Exception in com.hazelcast.core
Base Hazelcast exception.
HazelcastException() - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(String, Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastException(Throwable) - Constructor for exception com.hazelcast.core.HazelcastException
 
HazelcastInstance - Interface in com.hazelcast.core
Hazelcast instance.
HazelcastInstanceAware - Interface in com.hazelcast.core
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
HazelcastInstanceFactory - Class in com.hazelcast.hibernate.instance
 
HazelcastInstanceNotActiveException - Exception in com.hazelcast.core
Thrown when HazelcastInstance is not active during an invocation.
HazelcastInstanceNotActiveException() - Constructor for exception com.hazelcast.core.HazelcastInstanceNotActiveException
 
HazelcastLocalCacheRegionFactory - Class in com.hazelcast.hibernate
 
HazelcastLocalCacheRegionFactory() - Constructor for class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
HazelcastLocalCacheRegionFactory(HazelcastInstance) - Constructor for class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
HazelcastLocalCacheRegionFactory(Properties) - Constructor for class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
HazelcastMBean<T> - Class in com.hazelcast.jmx
 
HazelcastMBean(T, ManagementService) - Constructor for class com.hazelcast.jmx.HazelcastMBean
 
HazelcastSerializationException - Exception in com.hazelcast.nio.serialization
This is an exception thrown when an exception occurs while serializing/deserializing objects.
HazelcastSerializationException(String) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(String, Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastSerializationException(Throwable) - Constructor for exception com.hazelcast.nio.serialization.HazelcastSerializationException
 
HazelcastTimestamper - Class in com.hazelcast.hibernate
 
HEARTBEAT - Static variable in class com.hazelcast.cluster.ClusterDataSerializerHook
 
heartBeater() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
HeartbeatOperation - Class in com.hazelcast.cluster
 
HeartbeatOperation() - Constructor for class com.hazelcast.cluster.HeartbeatOperation
 
HIBERNATE_TYPE_HIBERNATE_CACHE_ENTRY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 
HIBERNATE_TYPE_HIBERNATE_CACHE_KEY - Static variable in class com.hazelcast.nio.serialization.SerializationConstants
 

I

IAtomicLong - Interface in com.hazelcast.core
IAtomicLong is a redundant and highly available distributed alternative to the java.util.concurrent.atomic.AtomicLong.
IAtomicReference<E> - Interface in com.hazelcast.core
IAtomicReference is a redundant and highly available distributed alternative to the java.util.concurrent.atomic.AtomicReference.
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
Distributed implementation of Condition.
ICountDownLatch - Interface in com.hazelcast.core
ICountDownLatch is a backed-up distributed alternative to the java.util.concurrent.CountDownLatch.
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.ClientDataSerializerHook
 
ID - Static variable in class com.hazelcast.client.ClientPortableHook
 
id - Variable in enum com.hazelcast.cluster.MemberAttributeOperationType
 
ID - Static variable in class com.hazelcast.nio.serialization.Data
 
IdentifiedDataSerializable - Interface in com.hazelcast.nio.serialization
 
IdGenerator - Interface in com.hazelcast.core
Cluster-wide unique id generator.
IExecutorService - Interface in com.hazelcast.core
Distributed implementation of ExecutorService.
IFunction<T,R> - Interface in com.hazelcast.core
Represents a function that accepts one argument and produces a result.
IHazelcastInstanceLoader - Interface in com.hazelcast.hibernate.instance
 
ilike(String, String) - Static method in class com.hazelcast.query.Predicates
 
IList<E> - Interface in com.hazelcast.core
Concurrent, distributed implementation of List
ILock - Interface in com.hazelcast.core
Distributed implementation of Lock.
IMap<K,V> - Interface in com.hazelcast.core
Concurrent, distributed, observable and queryable map.
implementation - Variable in class com.hazelcast.config.ListenerConfig
 
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.
incrementAndGet() - Method in interface com.hazelcast.core.IAtomicLong
Atomically increments the current value by one.
incrementAndGet() - Method in class com.hazelcast.jmx.AtomicLongMBean
 
IndexAwarePredicate - Interface in com.hazelcast.query
 
init(NodeEngine, Properties) - Method in class com.hazelcast.client.ClientEngineImpl
 
init(Cluster, ClientConfig) - Method in interface com.hazelcast.client.LoadBalancer
Initializes the LoadBalancer.
init(ClientConfig) - Method in class com.hazelcast.client.spi.ProxyManager
 
init(NodeEngine, Properties) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
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 interface com.hazelcast.spi.ManagedService
Initializes the ManagedService
init(HazelcastInstance, Properties, String) - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
init(FilterConfig) - Method in class com.hazelcast.web.WebFilter
 
initialize(Object) - Method in interface com.hazelcast.core.ManagedContext
Initialize the given object instance.
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 interface com.hazelcast.spi.InitializingObject
 
initialize(Object) - Method in class com.hazelcast.spring.context.SpringManagedContext
 
initializeDistributedObject(String, String) - Method in interface com.hazelcast.spi.ProxyService
 
InitializingObject - Interface in com.hazelcast.spi
 
InitialMembershipEvent - Class in com.hazelcast.core
A event that is send when a InitialMembershipListener registers itself on a Cluster.
InitialMembershipEvent(Cluster, Set<Member>) - Constructor for class com.hazelcast.core.InitialMembershipEvent
 
InitialMembershipListener - Interface in com.hazelcast.core
The InitializingMembershipListener is a MembershipListener that will first receives a InitialMembershipEvent when it is registered so it immediately knows which members are available.
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.
InputOutputFactory - Interface in com.hazelcast.nio.serialization
 
instance - Variable in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
InstanceMBean - Class in com.hazelcast.jmx
 
InstanceMBean(HazelcastInstanceImpl, ManagementService) - Constructor for class com.hazelcast.jmx.InstanceMBean
 
instanceName - Variable in class com.hazelcast.client.spi.ClientProxy
 
instanceOf(Class) - Static method in class com.hazelcast.query.Predicates
 
InterfacesConfig - Class in com.hazelcast.config
 
InterfacesConfig() - Constructor for class com.hazelcast.config.InterfacesConfig
 
InternalCompletableFuture<E> - Interface in com.hazelcast.spi
A ICompletableFuture with more functionality like getting the result without needing to deal with checked exceptions.
InvalidateEntryProcessor - Class in com.hazelcast.web
 
InvalidateEntryProcessor() - Constructor for class com.hazelcast.web.InvalidateEntryProcessor
 
InvalidateEntryProcessor(String) - Constructor for class com.hazelcast.web.InvalidateEntryProcessor
 
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
 
InvocationClientRequest - Class in com.hazelcast.client
 
InvocationClientRequest() - Constructor for class com.hazelcast.client.InvocationClientRequest
 
invoke() - Method in class com.hazelcast.client.InvocationClientRequest
 
invoke(ClientRequest, Object) - Method in class com.hazelcast.client.spi.ClientProxy
 
invoke(ClientRequest) - Method in class com.hazelcast.client.spi.ClientProxy
 
invoke(ClientRequest, Address) - Method in class com.hazelcast.client.spi.ClientProxy
 
invoke(String, Object[], String[]) - Method in class com.hazelcast.jmx.HazelcastMBean
 
invoke() - Method in class com.hazelcast.spi.InvocationBuilder
 
invokeOnAllPartitions(String, OperationFactory) - Method in interface com.hazelcast.spi.OperationService
Invokes a set of operation on each partition.
invokeOnKeyOwner(ClientRequest, Object) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnKeyOwner(ClientRequest, Object, EventHandler) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
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
invokeOnRandomTarget(ClientRequest) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnRandomTarget(ClientRequest, EventHandler) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnTarget(ClientRequest, Address) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnTarget(ClientRequest, Address, EventHandler) - Method in interface com.hazelcast.client.spi.ClientInvocationService
 
invokeOnTarget(String, Operation, Address) - Method in interface com.hazelcast.spi.OperationService
 
IO_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
 
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
 
isActive() - Method in interface com.hazelcast.spi.NodeEngine
 
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
 
isAuthenticated() - Method in class com.hazelcast.client.ClientEndpoint
 
isBinary() - Method in class com.hazelcast.config.MultiMapConfig
 
isCacheLocalEntries() - Method in class com.hazelcast.config.NearCacheConfig
 
isCheckClassDefErrors() - Method in class com.hazelcast.config.SerializationConfig
 
isCommunicateStats() - Method in class com.hazelcast.config.JobTrackerConfig
 
isCompatible(ConfigCheck) - Method in class com.hazelcast.cluster.ConfigCheck
 
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
 
isCoreService() - Method in class com.hazelcast.spi.ServiceInfo
 
isDataSerializable() - Method in class com.hazelcast.nio.serialization.Data
 
ISemaphore - Interface in com.hazelcast.core
ISemaphore is a backed-up distributed alternative to the Semaphore.
isEmpty() - Method in interface com.hazelcast.core.BaseMap
Returns true if this map contains no entries.
isEmpty() - Method in interface com.hazelcast.core.IQueue
isEmpty() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of Map.isEmpty().
isEnableCompression() - Method in class com.hazelcast.config.SerializationConfig
 
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.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.
isEnableDefaults() - Method in class com.hazelcast.config.ServicesConfig
 
isEnableSharedObject() - Method in class com.hazelcast.config.SerializationConfig
 
isError() - Method in class com.hazelcast.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.

isEvent() - Method in class com.hazelcast.client.ClientResponse
 
isExplicitVersionCheckEnabled(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
 
isFirstConnection() - Method in class com.hazelcast.client.AuthenticationRequest
 
isFirstConnection() - Method in class com.hazelcast.client.ClientEndpoint
 
isGlobalOrderingEnabled() - Method in class com.hazelcast.config.TopicConfig
 
isIncludeValue() - Method in class com.hazelcast.config.EntryListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.ItemListenerConfig
 
isIncludeValue() - Method in class com.hazelcast.config.ListenerConfig
 
isIndexed(QueryContext) - Method in interface com.hazelcast.query.IndexAwarePredicate
 
isIndexed(QueryContext) - Method in class com.hazelcast.query.PagingPredicate
Used if inner predicate is instanceof IndexAwarePredicate for checking if indexed
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
 
isInvalidateOnChange() - Method in class com.hazelcast.config.NearCacheConfig
 
isJoinInProgress() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
isJoinOperation(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
 
isKeepAlive() - Method in class com.hazelcast.client.config.SocketOptions
 
isLocal() - Method in class com.hazelcast.config.EntryListenerConfig
 
isLocal() - Method in class com.hazelcast.config.ListenerConfig
 
isLocal() - Method in interface com.hazelcast.spi.ResponseHandler
 
isLocalOnly() - Method in interface com.hazelcast.spi.EventRegistration
 
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.
isLockedByCurrentThread() - Method in interface com.hazelcast.core.ILock
Returns whether this lock is locked by current thread or not.
isManagedService() - Method in class com.hazelcast.spi.ServiceInfo
 
isMaster() - Method in interface com.hazelcast.cluster.ClusterService
 
isMaster() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
isMigrationOperation(Operation) - Static method in class com.hazelcast.spi.OperationAccessor
 
isMinimalPutsEnabledByDefault() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
isNativeClient(Properties) - Static method in class com.hazelcast.hibernate.CacheEnvironment
 
isNearCacheEnabled() - Method in class com.hazelcast.config.MapConfig
 
isNot(String) - Method in class com.hazelcast.query.EntryObject
 
isNotNull() - Method in class com.hazelcast.query.EntryObject
 
isNull() - Method in interface com.hazelcast.core.IAtomicReference
Checks if the stored reference is null.
isNull() - Method in class com.hazelcast.query.EntryObject
 
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.
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)
isPortable() - Method in class com.hazelcast.nio.serialization.Data
 
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.
isReadBackupData() - Method in class com.hazelcast.config.MapConfig
 
isRedoOperation() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
isRedoOperation() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
isResultDeserialized() - Method in class com.hazelcast.spi.InvocationBuilder
Checks if the Future should automatically deserialize the result.
isReuseAddress() - Method in class com.hazelcast.client.config.SocketOptions
 
isReuseAddress() - Method in class com.hazelcast.config.NetworkConfig
 
isRunning() - Method in class com.hazelcast.client.LifecycleServiceImpl
 
isRunning() - Method in interface com.hazelcast.core.LifecycleService
whether the instance is running
isRunning() - Method in class com.hazelcast.jmx.InstanceMBean
 
isShutdown() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
 
isSingleConnection() - Method in class com.hazelcast.client.ClientRequest
 
isSmartRouting() - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
isSmartRouting() - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
isStandardClass(Class) - Static method in class com.hazelcast.spring.mongodb.SpringMongoDBConverter
 
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.TopicConfig
Checks if statistics are enabled.
isStatusSet(int) - Method in class com.hazelcast.nio.serialization.DataAdapter
 
isTcpNoDelay() - Method in class com.hazelcast.client.config.SocketOptions
 
isTerminated() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
 
isUrgent() - Method in class com.hazelcast.nio.serialization.DataAdapter
 
isUrgent() - Method in class com.hazelcast.spi.Operation
 
isUseNativeByteOrder() - Method in class com.hazelcast.config.SerializationConfig
 
isValid() - Method in class com.hazelcast.cluster.MemberInfoUpdateOperation
 
isXAManaged() - Method in interface com.hazelcast.transaction.TransactionContext
Indicates that related transaction is managed by XAResource
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, int, E, Member) - Constructor for class com.hazelcast.core.ItemEvent
 
ItemEvent(String, ItemEventType, E, Member) - Constructor for class com.hazelcast.core.ItemEvent
 
ItemEventType - Enum in com.hazelcast.core
Type of item event.
ItemListener<E> - Interface in com.hazelcast.core
Item listener for IQueue, ISet and IList
ItemListenerConfig - Class in com.hazelcast.config
 
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
 
ItemListenerConfigReadOnly(ItemListenerConfig) - Constructor for class com.hazelcast.config.ItemListenerConfigReadOnly
 
itemRemoved(ItemEvent<E>) - Method in interface com.hazelcast.core.ItemListener
Invoked when an item is removed.
iterator() - Method in class com.hazelcast.config.AbstractXmlConfigHelper.IterableNodeList
 
iterator() - Method in interface com.hazelcast.core.IQueue
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.


J

JAVA - Static variable in class com.hazelcast.client.ClientTypes
 
Job<KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
This interface describes a mapreduce Job that is build by JobTracker.newJob(KeyValueSource).
It is used to execute mappings and calculations on the different cluster nodes and reduce or collate these mapped values to results.
JobCompletableFuture<V> - Interface in com.hazelcast.mapreduce
This is a special version of ICompletableFuture to return the assigned job id of the submit operation.
JobPartitionState - Interface in com.hazelcast.mapreduce
An implementation of this interface contains current information about the status of an process piece while operation is executing.
JobPartitionState.State - Enum in com.hazelcast.mapreduce
Definition of the processing states
JobProcessInformation - Interface in com.hazelcast.mapreduce
This interface holds basic information about a running map reduce job like state of the different partitions and the number of currently processed records.
The number of processed records is not a real time value but updated on regular base (after 1000 processed elements per node).
JobTracker - Interface in com.hazelcast.mapreduce
The JobTracker interface is used to create instances of Jobs depending on the given data structure / data source.
JobTrackerConfig - Class in com.hazelcast.config
 
JobTrackerConfig() - Constructor for class com.hazelcast.config.JobTrackerConfig
 
JobTrackerConfig(JobTrackerConfig) - Constructor for class com.hazelcast.config.JobTrackerConfig
 
JobTrackerConfigReadOnly - Class in com.hazelcast.config
 
join(AtomicBoolean) - Method in class com.hazelcast.cluster.AbstractJoiner
 
join(AtomicBoolean) - Method in interface com.hazelcast.cluster.Joiner
 
JoinCheckOperation - Class in com.hazelcast.cluster
 
JoinCheckOperation() - Constructor for class com.hazelcast.cluster.JoinCheckOperation
 
JoinCheckOperation(JoinRequest) - Constructor for class com.hazelcast.cluster.JoinCheckOperation
 
JoinConfig - Class in com.hazelcast.config
Contains the 3 different join configurations; tcp-ip/multicast/aws.
JoinConfig() - Constructor for class com.hazelcast.config.JoinConfig
 
Joiner - Interface in com.hazelcast.cluster
 
JoinMessage - Class in com.hazelcast.cluster
 
JoinMessage() - Constructor for class com.hazelcast.cluster.JoinMessage
 
JoinMessage(byte, int, Address, String, ConfigCheck, int) - Constructor for class com.hazelcast.cluster.JoinMessage
 
JoinOperation - Interface in com.hazelcast.cluster
Marker interface for join and post-join operations.
JoinRequest - Class in com.hazelcast.cluster
 
JoinRequest() - Constructor for class com.hazelcast.cluster.JoinRequest
 
JoinRequest(byte, int, Address, String, ConfigCheck, Credentials, int, int, Map<String, Object>) - Constructor for class com.hazelcast.cluster.JoinRequest
 
JoinRequestOperation - Class in com.hazelcast.cluster
 
JoinRequestOperation() - Constructor for class com.hazelcast.cluster.JoinRequestOperation
 
JoinRequestOperation(JoinRequest) - Constructor for class com.hazelcast.cluster.JoinRequestOperation
 
JPAMapStore - Class in com.hazelcast.spring.jpa
 
JPAMapStore() - Constructor for class com.hazelcast.spring.jpa.JPAMapStore
 

K

key - Variable in class com.hazelcast.core.EntryEvent
 
key() - Method in class com.hazelcast.mapreduce.KeyValueSource
Returns the current index' key for KeyPredicate analysis.
key() - Method in class com.hazelcast.query.EntryObject
 
KEY_ATTRIBUTE_NAME - Static variable in class com.hazelcast.query.QueryConstants
 
KeyBasedClientRequest - Class in com.hazelcast.client
 
KeyBasedClientRequest() - Constructor for class com.hazelcast.client.KeyBasedClientRequest
 
keyPredicate(KeyPredicate<KeyIn>) - Method in interface com.hazelcast.mapreduce.Job
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
KeyPredicate<Key> - Interface in com.hazelcast.mapreduce
This interface is used to pre evaluate keys before spreading the MapReduce task to the cluster.
keyPredicate(KeyPredicate<EntryKey>) - Method in interface com.hazelcast.mapreduce.MappingJob
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
keyPredicate(KeyPredicate<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
keyPredicate(KeyPredicate<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Defines the KeyPredicate implementation to preselect keys the MapReduce task will be executed on.
keySet() - Method in interface com.hazelcast.core.IMap
Returns a set clone of the keys contained in this map.
keySet(Predicate) - Method in interface com.hazelcast.core.IMap
Queries the map based on the specified predicate and returns the keys of matching entries.
keySet() - Method in interface com.hazelcast.core.MultiMap
Returns the set of keys in the multimap.
keySet() - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.keySet().
keySet(Predicate) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.keySet(com.hazelcast.query.Predicate) .
KeyValueSource<K,V> - Class in com.hazelcast.mapreduce
The abstract KeyValueSource class is used to implement custom data sources for mapreduce algorithms.
Default shipped implementations contains KeyValueSources for Hazelcast data structures like IMap and MultiMap.
KeyValueSource() - Constructor for class com.hazelcast.mapreduce.KeyValueSource
 

L

lessEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
 
lessEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
 
lessThan(Comparable) - Method in class com.hazelcast.query.EntryObject
 
lessThan(String, Comparable) - Static method in class com.hazelcast.query.Predicates
 
LifecycleEvent - Class in com.hazelcast.core
Lifecycle event fired when HazelcastInstance's state changes.
LifecycleEvent(LifecycleEvent.LifecycleState) - Constructor for class com.hazelcast.core.LifecycleEvent
 
LifecycleEvent.LifecycleState - Enum in com.hazelcast.core
lifecycle states
LifecycleListener - Interface in com.hazelcast.core
Listener object for lisntening lifecycle events of hazelcast instance
LifecycleMapper<KeyIn,ValueIn,KeyOut,ValueOut> - Interface in com.hazelcast.mapreduce
The LifecycleMapper interface is a more sophisticated version of Mapper normally used for complexer algorithms with a need of initialization and finalization.
LifecycleMapperAdapter<KeyIn,ValueIn,KeyOut,ValueOut> - Class in com.hazelcast.mapreduce
The abstract LifecycleMapperAdapter superclass is used to ease building mappers for the Job.
LifecycleMapperAdapter() - Constructor for class com.hazelcast.mapreduce.LifecycleMapperAdapter
 
LifecycleService - Interface in com.hazelcast.core
LifecycleService allows you to shutdown, terminate and listen to LifecycleEvent's on HazelcastInstance.
LifecycleServiceImpl - Class in com.hazelcast.client
 
LifecycleServiceImpl(HazelcastClient) - Constructor for class com.hazelcast.client.LifecycleServiceImpl
 
like(String, String) - Static method in class com.hazelcast.query.Predicates
 
ListConfig - Class in com.hazelcast.config
 
ListConfig() - Constructor for class com.hazelcast.config.ListConfig
 
ListConfig(ListConfig) - Constructor for class com.hazelcast.config.ListConfig
 
ListConfigReadOnly - Class in com.hazelcast.config
 
ListConfigReadOnly(ListConfig) - Constructor for class com.hazelcast.config.ListConfigReadOnly
 
listen(ClientRequest, Object, EventHandler) - Method in class com.hazelcast.client.spi.ClientProxy
 
listen(ClientRequest, EventHandler) - Method in class com.hazelcast.client.spi.ClientProxy
 
LISTENER - Static variable in class com.hazelcast.client.ClientPortableHook
 
ListenerConfig - Class in com.hazelcast.config
Contains the configuration for an EventListener.
ListenerConfig() - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig without className/implementation.
ListenerConfig(String) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given className.
ListenerConfig(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfig
 
ListenerConfig(EventListener) - Constructor for class com.hazelcast.config.ListenerConfig
Creates a ListenerConfig with the given implementation.
ListenerConfigReadOnly - Class in com.hazelcast.config
 
ListenerConfigReadOnly(ListenerConfig) - Constructor for class com.hazelcast.config.ListenerConfigReadOnly
 
ListMBean - Class in com.hazelcast.jmx
 
ListMBean(IList<?>, ManagementService) - Constructor for class com.hazelcast.jmx.ListMBean
 
live() - Method in class com.hazelcast.client.ClientEndpoint
 
load(String) - Static method in class com.hazelcast.config.ConfigLoader
 
load(K) - Method in interface com.hazelcast.core.MapLoader
Loads the value of a given key.
load(K) - Method in class com.hazelcast.core.MapStoreAdapter
Loads the value of a given key.
load(Long) - Method in interface com.hazelcast.core.QueueStore
Loads the value of a given key.
load(Serializable) - Method in class com.hazelcast.spring.jpa.JPAMapStore
 
load(Object) - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
loadAll(Collection<K>) - Method in interface com.hazelcast.core.MapLoader
Loads given keys.
loadAll(Collection<K>) - Method in class com.hazelcast.core.MapStoreAdapter
Loads given keys.
loadAll(Collection<Long>) - Method in interface com.hazelcast.core.QueueStore
Loads given keys.
loadAll(Collection) - Method in class com.hazelcast.spring.jpa.JPAMapStore
 
loadAll(Collection) - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
loadAllKeys() - Method in interface com.hazelcast.core.MapLoader
Loads all of the keys from the store.
loadAllKeys() - Method in class com.hazelcast.core.MapStoreAdapter
Loads all of the keys from the store.
loadAllKeys() - Method in interface com.hazelcast.core.QueueStore
Loads all of the keys from the store.
loadAllKeys() - Method in class com.hazelcast.spring.jpa.JPAMapStore
 
loadAllKeys() - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
LoadBalancer - Interface in com.hazelcast.client
LoadBalancer allows you to send operations to one of a number of endpoints(Members).
loadInstance() - Method in interface com.hazelcast.hibernate.instance.IHazelcastInstanceLoader
 
LocalExecutorStats - Interface in com.hazelcast.monitor
 
localHeapCost() - Method in class com.hazelcast.jmx.MapMBean
 
LocalInstanceStats - Interface in com.hazelcast.monitor
 
localKeySet() - Method in interface com.hazelcast.core.IMap
Returns the locally owned set of keys.
localKeySet(Predicate) - Method in interface com.hazelcast.core.IMap
Returns the keys of matching locally owned entries.
localKeySet() - Method in interface com.hazelcast.core.MultiMap
Returns the locally owned set of keys.
LocalMapStats - Interface in com.hazelcast.monitor
Local map statistics.
localMember() - Method in interface com.hazelcast.core.Member
Returns if this member is the local member.
LocalMultiMapStats - Interface in com.hazelcast.monitor
 
LocalQueueStats - Interface in com.hazelcast.monitor
Local queue statistics.
LocalTopicStats - Interface in com.hazelcast.monitor
 
localTotal() - Method in class com.hazelcast.jmx.MapMBean
 
localTotal() - Method in class com.hazelcast.jmx.MultiMapMBean
 
locateConfig(String) - Static method in class com.hazelcast.config.ConfigLoader
 
lock() - Method in interface com.hazelcast.core.ILock
lock(long, TimeUnit) - Method in interface com.hazelcast.core.ILock
Acquires the lock for the specified lease time.
lock(K) - Method in interface com.hazelcast.core.IMap
Acquires the lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.core.IMap
Acquires the lock for the specified key for the specified lease time.
lock(K) - Method in interface com.hazelcast.core.MultiMap
Acquires the lock for the specified key.
lock(K, long, TimeUnit) - Method in interface com.hazelcast.core.MultiMap
Acquires the lock for the specified key for the specified lease time.
LOCK_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
LOCK_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
LOCK_TIMEOUT - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
LockMBean - Class in com.hazelcast.jmx
 
LockMBean(ILock, ManagementService) - Constructor for class com.hazelcast.jmx.LockMBean
 
logError(Throwable) - Method in class com.hazelcast.spi.Operation
 
logger - Variable in class com.hazelcast.cluster.AbstractJoiner
 
logger - Static variable in class com.hazelcast.spring.mongodb.MongoMapStore
 
LoginModuleConfig - Class in com.hazelcast.config
 
LoginModuleConfig() - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig(String, LoginModuleConfig.LoginModuleUsage) - Constructor for class com.hazelcast.config.LoginModuleConfig
 
LoginModuleConfig.LoginModuleUsage - Enum in com.hazelcast.config
 
lookup(int, int) - Method in interface com.hazelcast.nio.serialization.SerializationContext
 
lookup(int, int, int) - Method in interface com.hazelcast.nio.serialization.SerializationContext
 
lookupOrRegisterClassDefinition(Portable) - Method in interface com.hazelcast.nio.serialization.SerializationContext
 

M

ManagedAnnotation - Annotation Type in com.hazelcast.jmx
 
ManagedContext - Interface in com.hazelcast.core
Container managed context, such as Spring, Guice and etc.
ManagedDescription - Annotation Type in com.hazelcast.jmx
 
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 like initialization and shutdown.
ManagementCenterConfig - Class in com.hazelcast.config
 
ManagementCenterConfig() - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
ManagementCenterConfig(String, int) - Constructor for class com.hazelcast.config.ManagementCenterConfig
 
ManagementService - Class in com.hazelcast.jmx
 
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_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
 
MapConfig - Class in com.hazelcast.config
 
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
 
MapConfig.EvictionPolicy - Enum in com.hazelcast.config
 
MapConfigReadOnly - Class in com.hazelcast.config
 
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
 
MapIndexConfigReadOnly(MapIndexConfig) - Constructor for class com.hazelcast.config.MapIndexConfigReadOnly
 
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.
MapMBean - Class in com.hazelcast.jmx
 
MapMBean(IMap, ManagementService) - Constructor for class com.hazelcast.jmx.MapMBean
 
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.
MappingJob<EntryKey,KeyIn,ValueIn> - Interface in com.hazelcast.mapreduce
This interface describes a mapping mapreduce Job.
For further information Job.
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
MapStore configuration
MapStoreConfig() - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig(MapStoreConfig) - Constructor for class com.hazelcast.config.MapStoreConfig
 
MapStoreConfig.InitialLoadMode - Enum in com.hazelcast.config
 
MapStoreConfigReadOnly - Class in com.hazelcast.config
 
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.
mark(int) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
markSupported() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
masterAddress - Variable in class com.hazelcast.cluster.SetMasterOperation
 
MasterConfirmationOperation - Class in com.hazelcast.cluster
 
MasterConfirmationOperation() - Constructor for class com.hazelcast.cluster.MasterConfirmationOperation
 
MAX_BACKUP_COUNT - Static variable in class com.hazelcast.config.MapConfig
 
MAX_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
 
maxPoolSize() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
 
MaxSizeConfig - Class in com.hazelcast.config
 
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
 
MaxSizeConfigReadOnly - Class in com.hazelcast.config
 
MaxSizeConfigReadOnly(MaxSizeConfig) - Constructor for class com.hazelcast.config.MaxSizeConfigReadOnly
 
MEMBER - Static variable in class com.hazelcast.cluster.ClusterDataSerializerHook
 
member - Variable in class com.hazelcast.core.EntryEvent
 
Member - Interface in com.hazelcast.core
Cluster member interface.
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.core.MembershipEvent
This event type is fired if a member attribute has been changed or removed.
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.ClientEngineImpl
 
memberAdded(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when a new member is added to the cluster.
memberAdded(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when a new member is added to the cluster.
memberAttributeChanged(MemberAttributeServiceEvent) - Method in class com.hazelcast.client.ClientEngineImpl
 
memberAttributeChanged(MemberAttributeEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when an attribute of a member was changed.
memberAttributeChanged(MemberAttributeServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when a member attribute is changed.
MemberAttributeChangedOperation - Class in com.hazelcast.cluster
 
MemberAttributeChangedOperation() - Constructor for class com.hazelcast.cluster.MemberAttributeChangedOperation
 
MemberAttributeChangedOperation(MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.cluster.MemberAttributeChangedOperation
 
MemberAttributeConfig - Class in com.hazelcast.config
 
MemberAttributeConfig() - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfig(MemberAttributeConfig) - Constructor for class com.hazelcast.config.MemberAttributeConfig
 
MemberAttributeConfigReadOnly - Class in com.hazelcast.config
 
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
 
MemberAttributeServiceEvent() - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
 
MemberAttributeServiceEvent(Cluster, MemberImpl, MemberAttributeOperationType, String, Object) - Constructor for class com.hazelcast.spi.MemberAttributeServiceEvent
 
memberCount - Variable in class com.hazelcast.cluster.JoinMessage
 
MemberGroupConfig - Class in com.hazelcast.config
Contains the configuration for a single member group.
MemberGroupConfig() - Constructor for class com.hazelcast.config.MemberGroupConfig
 
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
 
MemberInfoUpdateOperation() - Constructor for class com.hazelcast.cluster.MemberInfoUpdateOperation
 
MemberInfoUpdateOperation(Collection<MemberInfo>, long, boolean) - Constructor for class com.hazelcast.cluster.MemberInfoUpdateOperation
 
MemberLeftException - Exception in com.hazelcast.core
Thrown when a member left during an invocation or execution.
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.ClientEngineImpl
 
memberRemoved(MembershipEvent) - Method in interface com.hazelcast.core.MembershipListener
Invoked when an existing member leaves the cluster.
memberRemoved(MembershipServiceEvent) - Method in interface com.hazelcast.spi.MembershipAwareService
Invoked when an existing member leaves the cluster.
MemberRemoveOperation - Class in com.hazelcast.cluster
 
MemberRemoveOperation() - Constructor for class com.hazelcast.cluster.MemberRemoveOperation
 
MemberRemoveOperation(Address) - Constructor for class com.hazelcast.cluster.MemberRemoveOperation
 
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.ClusterDataSerializerHook
 
MEMBERSHIP_LISTENER - Static variable in class com.hazelcast.client.ClientPortableHook
 
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(Cluster, Member, int, Set<Member>) - Constructor for class com.hazelcast.spi.MembershipServiceEvent
 
MembershipServiceEvent(MembershipEvent) - Constructor for class com.hazelcast.spi.MembershipServiceEvent
 
membersString() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
MemberState - Interface in com.hazelcast.monitor
 
merge(String, EntryView, EntryView) - Method in class com.hazelcast.hibernate.VersionAwareMapMergePolicy
 
MergeClustersOperation - Class in com.hazelcast.cluster
 
MergeClustersOperation() - Constructor for class com.hazelcast.cluster.MergeClustersOperation
 
MergeClustersOperation(Address) - Constructor for class com.hazelcast.cluster.MergeClustersOperation
 
Message<E> - Class in com.hazelcast.core
Message for ITopic.
Message(String, E, long, Member) - Constructor for class com.hazelcast.core.Message
 
MessageListener<E> - Interface in com.hazelcast.core
Message listener for ITopic.
MigrationAwareService - Interface in com.hazelcast.spi
 
migrationCompleted(MigrationEvent) - Method in interface com.hazelcast.core.MigrationListener
Invoked when a partition migration is completed.
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.
MigrationListener - Interface in com.hazelcast.core
MigrationListener allows to listen partition migration events.
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.MapConfig
 
MIN_EVICTION_PERCENTAGE - Static variable in class com.hazelcast.config.MapConfig
 
MongoDBConverter - Interface in com.hazelcast.spring.mongodb
 
MongoMapStore - Class in com.hazelcast.spring.mongodb
 
MongoMapStore() - Constructor for class com.hazelcast.spring.mongodb.MongoMapStore
 
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
 
MulticastJoiner(Node) - Constructor for class com.hazelcast.cluster.MulticastJoiner
 
MulticastListener - Interface in com.hazelcast.cluster
 
MulticastService - Class in com.hazelcast.cluster
 
MulticastService(Node, MulticastSocket) - Constructor for class com.hazelcast.cluster.MulticastService
 
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
 
MultiMapConfig - Class in com.hazelcast.config
 
MultiMapConfig() - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfig
 
MultiMapConfig.ValueCollectionType - Enum in com.hazelcast.config
 
MultiMapConfigReadOnly - Class in com.hazelcast.config
 
MultiMapConfigReadOnly(MultiMapConfig) - Constructor for class com.hazelcast.config.MultiMapConfigReadOnly
 
MultiMapMBean - Class in com.hazelcast.jmx
 
MultiMapMBean(MultiMap, ManagementService) - Constructor for class com.hazelcast.jmx.MultiMapMBean
 
MultiPartitionClientRequest - Class in com.hazelcast.client
 
MultiPartitionClientRequest() - Constructor for class com.hazelcast.client.MultiPartitionClientRequest
 
MultiTargetClientRequest - Class in com.hazelcast.client
 
MultiTargetClientRequest() - Constructor for class com.hazelcast.client.MultiTargetClientRequest
 

N

name - Variable in class com.hazelcast.client.BaseClientRemoveListenerRequest
 
name - Variable in class com.hazelcast.core.EntryEvent
 
name() - Method in class com.hazelcast.jmx.CountDownLatchMBean
 
name() - Method in class com.hazelcast.jmx.ExecutorServiceMBean
 
nameMatches(String, String) - Static method in class com.hazelcast.config.Config
 
NATIVE_CLIENT_ADDRESS - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
NATIVE_CLIENT_GROUP - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
NATIVE_CLIENT_PASSWORD - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
NearCacheConfig - Class in com.hazelcast.config
 
NearCacheConfig(int, int, String, int, boolean, InMemoryFormat) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfig() - Constructor for class com.hazelcast.config.NearCacheConfig
 
NearCacheConfigReadOnly - Class in com.hazelcast.config
 
NearCacheConfigReadOnly(NearCacheConfig) - Constructor for class com.hazelcast.config.NearCacheConfigReadOnly
 
NearCacheStats - Interface in com.hazelcast.monitor
 
NetworkConfig - Class in com.hazelcast.config
 
NetworkConfig() - Constructor for class com.hazelcast.config.NetworkConfig
 
newClientTransactionContext(TransactionOptions, String) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
newCombiner(KeyIn) - Method in interface com.hazelcast.mapreduce.CombinerFactory
Build a new Combiner instance specific to the supplied key.
newCondition() - Method in interface com.hazelcast.core.ILock
This method is not implemented! Use ILock.newCondition(String) instead.
newCondition(String) - Method in interface com.hazelcast.core.ILock
Returns a new ICondition instance that is bound to this ILock instance with given name.
newCredentials() - Method in interface com.hazelcast.security.ICredentialsFactory
Creates new Credentials object.
newHazelcastClient() - Static method in class com.hazelcast.client.HazelcastClient
 
newHazelcastClient(ClientConfig) - Static method in class com.hazelcast.client.HazelcastClient
 
newHazelcastInstance(Config) - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newHazelcastInstance() - Static method in class com.hazelcast.core.Hazelcast
Creates a new HazelcastInstance (a new node in a cluster).
newId() - Method in interface com.hazelcast.core.IdGenerator
Generates and returns cluster-wide unique id.
newJob(KeyValueSource<K, V>) - Method in interface com.hazelcast.mapreduce.JobTracker
Builds a Job instance for the given KeyValueSource instance.
newMapStore(String, Properties) - Method in interface com.hazelcast.core.MapStoreFactory
Produces a MapLoader or a MapStore for the given map name and properties.
newQueueStore(String, Properties) - Method in interface com.hazelcast.core.QueueStoreFactory
 
newReducer(KeyIn) - Method in interface com.hazelcast.mapreduce.ReducerFactory
Build a new Reducer instance specific to the supplied key.
newTransactionContext() - Method in class com.hazelcast.client.HazelcastClient
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.client.HazelcastClient
 
newTransactionContext() - Method in class com.hazelcast.client.HazelcastClientProxy
 
newTransactionContext(TransactionOptions) - Method in class com.hazelcast.client.HazelcastClientProxy
 
newTransactionContext() - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread using default options.
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.core.HazelcastInstance
Creates a new TransactionContext associated with the current thread with given options.
newTransactionContext(TransactionOptions) - Method in interface com.hazelcast.transaction.TransactionManagerService
 
next() - Method in interface com.hazelcast.client.LoadBalancer
Returns the next member to route to.
nextPage() - Method in class com.hazelcast.query.PagingPredicate
setting the page value to next page
nextTimestamp() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
nextTimestamp(HazelcastInstance) - Static method in class com.hazelcast.hibernate.HazelcastTimestamper
 
NO_CLASS_ID - Static variable in class com.hazelcast.nio.serialization.Data
 
node - Variable in class com.hazelcast.cluster.AbstractJoiner
 
NodeAware - Interface in com.hazelcast.spi
 
nodeEngine - Variable in class com.hazelcast.spi.InvocationBuilder
 
NodeEngine - Interface in com.hazelcast.spi
 
NodeMBean - Class in com.hazelcast.jmx
 
NodeMBean(HazelcastInstance, Node, ManagementService) - Constructor for class com.hazelcast.jmx.NodeMBean
 
NodeMulticastListener - Class in com.hazelcast.cluster
 
NodeMulticastListener(Node) - Constructor for class com.hazelcast.cluster.NodeMulticastListener
 
NonThreadSafe - Interface in com.hazelcast.spi
Marker interface for non-thread-safe classes.
not(Predicate) - Static method in class com.hazelcast.query.Predicates
 
notEqual(Comparable) - Method in class com.hazelcast.query.EntryObject
 
notEqual(String, Comparable) - Static method in class com.hazelcast.query.Predicates
 
Notifier - Interface in com.hazelcast.spi
 
notify(T) - Method in interface com.hazelcast.spi.Callback
 
notify(Notifier) - Method in interface com.hazelcast.spi.WaitNotifyService
 

O

ObjectDataInputStream - Class in com.hazelcast.nio.serialization
 
ObjectDataInputStream(InputStream, SerializationService) - Constructor for class com.hazelcast.nio.serialization.ObjectDataInputStream
 
ObjectDataInputStream(InputStream, SerializationService, ByteOrder) - Constructor for class com.hazelcast.nio.serialization.ObjectDataInputStream
 
ObjectDataOutputStream - Class in com.hazelcast.nio.serialization
 
ObjectDataOutputStream(OutputStream, SerializationService) - Constructor for class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
ObjectDataOutputStream(OutputStream, SerializationService, ByteOrder) - Constructor for class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
ObjectNamespace - Interface in com.hazelcast.spi
 
offer(E) - Method in interface com.hazelcast.core.BaseQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions, returning true upon success and false if no space is currently available.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.core.BaseQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
offer(E) - Method in interface com.hazelcast.core.IQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions, returning true upon success and false if no space is currently available.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.core.IQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
offer(E) - Method in interface com.hazelcast.core.TransactionalQueue
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions, returning true upon success and false if no space is currently available.
offer(E, long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
oldValue - Variable in class com.hazelcast.core.EntryEvent
 
onComplete(Map<Member, Object>) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called after all executions are completed.
onDestroy() - Method in class com.hazelcast.client.spi.ClientProxy
 
onEntryEvent(EntryEvent<K, V>) - Method in class com.hazelcast.core.EntryAdapter
This method is called when an one of the methods of the EntryListener is not overridden.
onException(Throwable) - Method in class com.hazelcast.spi.Operation
 
onFailure(Throwable) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed with an error.
onKeys(Iterable<KeyIn>) - Method in interface com.hazelcast.mapreduce.Job
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(KeyIn...) - Method in interface com.hazelcast.mapreduce.Job
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<EntryKey>) - Method in interface com.hazelcast.mapreduce.MappingJob
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.MappingJob
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.ReducingJob
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(Iterable<EntryKey>) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Defines keys to execute the mapper and a possibly defined reducer against.
onKeys(EntryKey...) - Method in interface com.hazelcast.mapreduce.ReducingSubmittableJob
Defines keys to execute the mapper and a possibly defined reducer against.
onMessage(Object) - Method in interface com.hazelcast.cluster.MulticastListener
 
onMessage(Object) - Method in class com.hazelcast.cluster.NodeMulticastListener
 
onMessage(Message<E>) - Method in interface com.hazelcast.core.MessageListener
Invoked when a message is received for the added topic.
onNodeShutdown(AbstractDistributedObject) - Static method in class com.hazelcast.spi.DistributedObjectAccessor
 
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.client.ClientOutOfMemoryHandler
 
onOutOfMemory(OutOfMemoryError, HazelcastInstance[]) - Method in class com.hazelcast.core.OutOfMemoryHandler
When an OutOfMemoryError is caught by Hazelcast threads, this method is called for ALL HazelcastInstances knows by current JVM (actually ClassLoader).
onReceivedJoinRequest(JoinRequest) - Method in class com.hazelcast.cluster.MulticastJoiner
 
onReplicationEvent(WanReplicationEvent) - Method in interface com.hazelcast.spi.ReplicationSupportingService
 
onResponse(V) - Method in interface com.hazelcast.core.ExecutionCallback
Called when an execution is completed successfully.
onResponse(Member, Object) - Method in interface com.hazelcast.core.MultiExecutionCallback
Called when an execution is completed on a member.
onShutdown() - Method in class com.hazelcast.client.spi.ClientProxy
 
onWaitExpire() - Method in interface com.hazelcast.spi.WaitSupport
 
op - Variable in class com.hazelcast.spi.InvocationBuilder
 
open(NodeEngine) - Method in class com.hazelcast.mapreduce.KeyValueSource
This method is called before accessing the key-value pairs of this KeyValueSource
Operation - Class in com.hazelcast.spi
An operation could be compared the a Runnable.
Operation() - Constructor for class com.hazelcast.spi.Operation
 
OPERATION_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
 
OperationAccessor - Class in com.hazelcast.spi
 
OperationFactory - Interface in com.hazelcast.spi
A Factory for creating Operation instances.
OperationFactoryWrapper - Class in com.hazelcast.client
 
OperationFactoryWrapper() - Constructor for class com.hazelcast.client.OperationFactoryWrapper
 
OperationFactoryWrapper(OperationFactory, String) - Constructor for class com.hazelcast.client.OperationFactoryWrapper
 
operationMap - Variable in class com.hazelcast.jmx.HazelcastMBean
 
OperationService - Interface in com.hazelcast.spi
The OperationService is responsible for executing operations.
OperationServiceMBean - Class in com.hazelcast.jmx
 
OperationServiceMBean(HazelcastInstance, OperationService, ManagementService) - Constructor for class com.hazelcast.jmx.OperationServiceMBean
 
OperationTimeoutException - Exception in com.hazelcast.core
An unchecked version of TimeoutException.
OperationTimeoutException() - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
OperationTimeoutException(String, String) - Constructor for exception com.hazelcast.core.OperationTimeoutException
 
or(Predicate) - Method in class com.hazelcast.query.PredicateBuilder
 
or(Predicate, Predicate) - Static method in class com.hazelcast.query.Predicates
 
OutOfMemoryHandler - Class in com.hazelcast.core
Handler for OutOfMemoryError
OutOfMemoryHandler() - Constructor for class com.hazelcast.core.OutOfMemoryHandler
 

P

packetVersion - Variable in class com.hazelcast.cluster.JoinMessage
 
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
Construct with an inner predicate and pageSize results will be filtered via inner predicate results will be natural ordered throws IllegalArgumentException if pageSize is not greater than 0 throws IllegalArgumentException if inner predicate is also 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
Construct with an inner predicate, comparator and pageSize results will be filtered via inner predicate results will be ordered via comparator throws IllegalArgumentException if pageSize is not greater than 0 throws IllegalArgumentException if inner predicate is also PagingPredicate
PagingPredicateAccessor - Class in com.hazelcast.query
 
parse(Element) - Method in interface com.hazelcast.spi.ServiceConfigurationParser
 
parseSerialization(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
parseSocketInterceptorConfig(Node) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 
Partition - Interface in com.hazelcast.core
Virtual partition instance.
PARTITION_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
PARTITION_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
PartitionAware<T> - Interface in com.hazelcast.core
PartitionAware allows implementing keys to be located on the same member or implementing tasks to be executed on PartitionAware.getPartitionKey()'s owner member.
PartitionAwareKey<K,P> - Class in com.hazelcast.core
A PartitionAware key.
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.
PartitionClientRequest - Class in com.hazelcast.client
 
PartitionClientRequest() - Constructor for class com.hazelcast.client.PartitionClientRequest
 
PartitionGroupConfig - Class in com.hazelcast.config
With the PartitionGroupConfig you can control how primary and backups are going to be split up.
PartitionGroupConfig() - Constructor for class com.hazelcast.config.PartitionGroupConfig
 
PartitionGroupConfig.MemberGroupType - Enum in com.hazelcast.config
 
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.
PARTITIONING_STRATEGY - Static variable in class com.hazelcast.spi.AbstractDistributedObject
 
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.
PartitioningStrategyConfig - Class in com.hazelcast.config
 
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
 
PartitioningStrategyConfigReadOnly(PartitioningStrategyConfig) - Constructor for class com.hazelcast.config.PartitioningStrategyConfigReadOnly
 
PartitionMigrationEvent - Class in com.hazelcast.spi
 
PartitionMigrationEvent(MigrationEndpoint, int) - Constructor for class com.hazelcast.spi.PartitionMigrationEvent
 
PartitionReplicationEvent - Class in com.hazelcast.spi
 
PartitionReplicationEvent(int, int) - Constructor for class com.hazelcast.spi.PartitionReplicationEvent
 
PartitionService - Interface in com.hazelcast.core
InternalPartitionService allows to query Partitions and attach/detach MigrationListeners to listen partition migration events.
PartitionServiceMBean - Class in com.hazelcast.jmx
 
PartitionServiceMBean(HazelcastInstanceImpl, InternalPartitionService, ManagementService) - Constructor for class com.hazelcast.jmx.PartitionServiceMBean
 
peek() - Method in interface com.hazelcast.core.IQueue
peek() - Method in interface com.hazelcast.core.TransactionalQueue
peek(long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalQueue
PermissionConfig - Class in com.hazelcast.config
 
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
 
PermissionPolicyConfig - Class in com.hazelcast.config
 
PermissionPolicyConfig() - Constructor for class com.hazelcast.config.PermissionPolicyConfig
 
PermissionPolicyConfig(String) - Constructor for class com.hazelcast.config.PermissionPolicyConfig
 
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(long, TimeUnit) - Method in interface com.hazelcast.core.IQueue
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.IQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
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.
poolSize() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
 
Portable - Interface in com.hazelcast.nio.serialization
 
PortableAdapter<T> - Interface in com.hazelcast.nio.serialization
 
PortableFactory - Interface in com.hazelcast.nio.serialization
 
PortableHook - Interface in com.hazelcast.nio.serialization
 
PortableReader - Interface in com.hazelcast.nio.serialization
 
PortableWriter - Interface in com.hazelcast.nio.serialization
 
postConstruct(SerializationContext) - Method in class com.hazelcast.nio.serialization.Data
 
postDeregister() - Method in class com.hazelcast.jmx.HazelcastMBean
 
postDestroy() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
PostJoinAwareService - Interface in com.hazelcast.spi
 
PostJoinOperation - Class in com.hazelcast.cluster
 
PostJoinOperation() - Constructor for class com.hazelcast.cluster.PostJoinOperation
 
PostJoinOperation(Operation...) - Constructor for class com.hazelcast.cluster.PostJoinOperation
 
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.SetMBean
 
preDeregister() - Method in class com.hazelcast.jmx.TopicMBean
 
Predicate<K,V> - Interface in com.hazelcast.query
Predicate instance must be thread-safe.
PredicateBuilder - Class in com.hazelcast.query
 
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
 
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
 
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
 
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
 
Predicates.EqualPredicate() - 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
 
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
 
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
 
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
 
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
 
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
 
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
 
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
 
Predicates.RegexPredicate() - Constructor for class com.hazelcast.query.Predicates.RegexPredicate
 
Predicates.RegexPredicate(String, String) - Constructor for class com.hazelcast.query.Predicates.RegexPredicate
 
PrepareMergeOperation - Class in com.hazelcast.cluster
 
PrepareMergeOperation() - Constructor for class com.hazelcast.cluster.PrepareMergeOperation
 
PrepareMergeOperation(Address) - Constructor for class com.hazelcast.cluster.PrepareMergeOperation
 
prepareMergeRunnable() - Method in interface com.hazelcast.spi.SplitBrainHandlerService
 
prepareOperation() - Method in class com.hazelcast.client.PartitionClientRequest
 
prepareOperation() - Method in class com.hazelcast.client.TargetClientRequest
 
prepareReplicationOperation(PartitionReplicationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
 
preRegister(MBeanServer, ObjectName) - Method in class com.hazelcast.jmx.HazelcastMBean
 
previousPage() - Method in class com.hazelcast.query.PagingPredicate
setting the page value to previous page
PRINCIPAL - Static variable in class com.hazelcast.client.ClientPortableHook
 
process(Map.Entry<String, Object>) - Method in class com.hazelcast.web.InvalidateEntryProcessor
 
processMemberUpdate() - Method in class com.hazelcast.cluster.MemberInfoUpdateOperation
 
ProxyFactoryConfig - Class in com.hazelcast.client.config
 
ProxyFactoryConfig() - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyFactoryConfig(String, String) - Constructor for class com.hazelcast.client.config.ProxyFactoryConfig
 
ProxyManager - Class in com.hazelcast.client.spi
 
ProxyManager(HazelcastClient) - Constructor for class com.hazelcast.client.spi.ProxyManager
 
ProxyService - Interface in com.hazelcast.spi
A CoreService responsible for managing the DistributedObject proxies.
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
publishEvent(String, EventRegistration, Object, int) - Method in interface com.hazelcast.spi.EventService
 
publishEvent(String, Collection<EventRegistration>, Object, int) - Method in interface com.hazelcast.spi.EventService
 
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(E) - Method in interface com.hazelcast.core.IQueue
put(K, V) - Method in interface com.hazelcast.core.MultiMap
Stores a key-value pair in the multimap.
put(K, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.put(Object, Object).
put(K, V, long, TimeUnit) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.put(Object, Object, long, java.util.concurrent.TimeUnit).
put(K, V) - Method in interface com.hazelcast.core.TransactionalMultiMap
Stores a key-value pair in the multimap.
put(Object, Object, Object) - Method in interface com.hazelcast.hibernate.RegionCache
 
put(Object, Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
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.
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
Transactional implementation of IMap.putIfAbsent(Object, Object).
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.
PYTHON - Static variable in class com.hazelcast.client.ClientTypes
 

Q

QUERY_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
 
QueryConstants - Class in com.hazelcast.query
 
QueryException - Exception in com.hazelcast.query
 
QueryException() - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(String, Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QueryException(Throwable) - Constructor for exception com.hazelcast.query.QueryException
 
QUEUE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
QUEUE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
QueueConfig - Class in com.hazelcast.config
 
QueueConfig() - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfig(QueueConfig) - Constructor for class com.hazelcast.config.QueueConfig
 
QueueConfigReadOnly - Class in com.hazelcast.config
 
QueueMBean - Class in com.hazelcast.jmx
 
QueueMBean(IQueue, ManagementService) - Constructor for class com.hazelcast.jmx.QueueMBean
 
queueRemainingCapacity() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
 
queueSize() - Method in class com.hazelcast.jmx.ManagedExecutorServiceMBean
 
QueueStore<T> - Interface in com.hazelcast.core
QueueStore makes a queue backed by a central data store; such as database, disk etc.
QueueStoreConfig - Class in com.hazelcast.config
 
QueueStoreConfig() - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfig(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfig
 
QueueStoreConfigReadOnly - Class in com.hazelcast.config
 
QueueStoreConfigReadOnly(QueueStoreConfig) - Constructor for class com.hazelcast.config.QueueStoreConfigReadOnly
 
QueueStoreFactory<T> - Interface in com.hazelcast.core
 
quote(String) - Static method in class com.hazelcast.jmx.ManagementService
 

R

randomPartitionKey() - Method in interface com.hazelcast.core.PartitionService
Generates a random partition key.
read(PortableReader) - Method in class com.hazelcast.client.AuthenticationRequest
 
read(PortableReader) - Method in class com.hazelcast.client.BaseClientRemoveListenerRequest
 
read(PortableReader) - Method in class com.hazelcast.client.ClientCreateRequest
 
read(PortableReader) - Method in class com.hazelcast.client.ClientDestroyRequest
 
read(PortableReader) - Method in class com.hazelcast.client.ClientRequest
 
read() - Method in interface com.hazelcast.client.spi.ResponseStream
 
read(byte[]) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
 
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 interface com.hazelcast.nio.serialization.StreamSerializer
 
readAttribute(Map.Entry) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
 
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(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(String) - Method in class com.hazelcast.nio.serialization.DefaultPortableReader
 
readByteArray(String) - Method in class com.hazelcast.nio.serialization.MorphingPortableReader
 
readByteArray(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
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(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
 
readData(ObjectDataInput) - Method in class com.hazelcast.client.ClientResponse
 
readData(ObjectDataInput) - Method in class com.hazelcast.client.OperationFactoryWrapper
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.ConfigCheck
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.JoinMessage
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.JoinRequest
 
readData(ObjectDataInput) - Method in class com.hazelcast.cluster.MemberInfo
 
readData(ObjectDataInput) - Method in class com.hazelcast.core.MemberAttributeEvent
 
readData(ObjectDataInput) - Method in exception com.hazelcast.core.MemberLeftException
 
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.hibernate.VersionAwareMapMergePolicy
 
readData(ObjectDataInput) - Method in class com.hazelcast.monitor.TimedMemberState
 
readData(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
readData(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
readData(ObjectDataInput) - Method in class com.hazelcast.nio.serialization.Data
WARNING:

Should be in sync with DataAdapter.readFrom(java.nio.ByteBuffer)

readData(ObjectDataInput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
 
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.spi.DefaultObjectNamespace
 
readData(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
 
readData(ObjectDataInput) - Method in class com.hazelcast.transaction.TransactionOptions
 
readData(ObjectDataInput) - Method in class com.hazelcast.web.InvalidateEntryProcessor
 
readData(ObjectDataInput) - Method in class com.hazelcast.web.SessionAttributePredicate
 
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(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(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(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(DataInput) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
 
readFrom(ByteBuffer) - Method in class com.hazelcast.nio.serialization.DataAdapter
WARNING: Should be in sync with Data.readData(com.hazelcast.nio.ObjectDataInput)
readFully(byte[]) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
readFully(byte[], int, int) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
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(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
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.client.ClientDisconnectionOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.client.ClientReAuthOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.AuthorizationOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.BindOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.FinalizeJoinOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.JoinCheckOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.JoinRequestOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.MemberAttributeChangedOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.MemberInfoUpdateOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.MemberRemoveOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.MergeClustersOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.PostJoinOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.PrepareMergeOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.cluster.SetMasterOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.AbstractOperation
 
readInternal(ObjectDataInput) - Method in class com.hazelcast.spi.Operation
 
readLine() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
Deprecated. 
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(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
 
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.
readPortable(PortableReader) - Method in class com.hazelcast.client.ClientPrincipal
 
readPortable(PortableReader) - Method in class com.hazelcast.client.ClientRequest
 
readPortable(PortableReader) - Method in class com.hazelcast.client.DistributedObjectInfo
 
readPortable(PortableReader) - Method in class com.hazelcast.client.GenericError
 
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
 
readPortable(String) - Method in interface com.hazelcast.nio.serialization.PortableReader
 
readPortable(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
 
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
 
readPortableInternal(PortableReader) - Method in class com.hazelcast.security.AbstractCredentials
 
readPortableInternal(PortableReader) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
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(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
 
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
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.AllPartitionsClientRequest
 
reduce(Map<Integer, Object>) - Method in class com.hazelcast.client.MultiPartitionClientRequest
 
reduce(Map<Address, Object>) - Method in class com.hazelcast.client.MultiTargetClientRequest
 
reduce(int) - Method in class com.hazelcast.jmx.SemaphoreMBean
 
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.
reducePermits(int) - Method in interface com.hazelcast.core.ISemaphore
Shrinks the number of available permits by the indicated reduction.
reducer(ReducerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.MappingJob
Defines the ReducerFactory for this task.
Reducer<KeyIn,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.
Reducers are called in a threadsafe way so internal locking is not required.
Reducer() - Constructor for class com.hazelcast.mapreduce.Reducer
 
reducer(ReducerFactory<KeyIn, ValueIn, ValueOut>) - Method in interface com.hazelcast.mapreduce.ReducingJob
Defines the ReducerFactory for this task.
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.
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.
regex(String, String) - Static method in class com.hazelcast.query.Predicates
 
RegionCache - Interface in com.hazelcast.hibernate
 
register(String, ClientProxyFactory) - Method in class com.hazelcast.client.spi.ProxyManager
 
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(String, int, int, ExecutorType) - Method in interface com.hazelcast.spi.ExecutionService
 
registerClassDefinition(ClassDefinition) - Method in interface com.hazelcast.nio.serialization.SerializationContext
 
registerGlobal(Serializer) - Method in interface com.hazelcast.nio.serialization.SerializationService
 
registerGlobal(Serializer) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
registerListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
 
registerListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
 
registerLocalListener(String, String, Object) - Method in interface com.hazelcast.spi.EventService
 
registerLocalListener(String, String, EventFilter, Object) - Method in interface com.hazelcast.spi.EventService
 
registrationId - Variable in class com.hazelcast.client.BaseClientRemoveListenerRequest
 
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
 
remainingCapacity() - Method in interface com.hazelcast.core.IQueue
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(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) - Method in interface com.hazelcast.core.IQueue
remove() - Method in interface com.hazelcast.core.IQueue
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
Transactional implementation of IMap.remove(Object).
remove(Object, Object) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.remove(Object, Object).
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(Object) - Method in interface com.hazelcast.hibernate.RegionCache
 
REMOVE_LISTENER - Static variable in class com.hazelcast.client.ClientPortableHook
 
removeAddress(Address) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
removeAll(Collection<?>) - Method in interface com.hazelcast.core.IQueue
removeAsync(K) - Method in interface com.hazelcast.core.IMap
Asynchronously removes the given key.
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.
removeClientListener(String) - Method in interface com.hazelcast.core.ClientService
 
removeDistributedObjectListener(String) - Method in class com.hazelcast.client.HazelcastClient
 
removeDistributedObjectListener(String) - Method in class com.hazelcast.client.HazelcastClientProxy
 
removeDistributedObjectListener(String) - Method in class com.hazelcast.client.spi.ProxyManager
 
removeDistributedObjectListener(String) - Method in interface com.hazelcast.core.HazelcastInstance
Removes the specified Distributed Object listener.
RemoveDistributedObjectListenerRequest - Class in com.hazelcast.client
 
RemoveDistributedObjectListenerRequest() - Constructor for class com.hazelcast.client.RemoveDistributedObjectListenerRequest
 
RemoveDistributedObjectListenerRequest(String) - Constructor for class com.hazelcast.client.RemoveDistributedObjectListenerRequest
 
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.
removeInterceptor(String) - Method in interface com.hazelcast.core.IMap
Removes the given interceptor for this map.
removeItemListener(String) - Method in interface com.hazelcast.core.ICollection
Removes the specified item listener.
removeLifecycleListener(String) - Method in class com.hazelcast.client.LifecycleServiceImpl
 
removeLifecycleListener(String) - Method in interface com.hazelcast.core.LifecycleService
Remove lifecycle listener
removeMembershipListener(String) - Method in class com.hazelcast.cluster.ClusterProxy
 
removeMembershipListener(String) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
removeMembershipListener(String) - Method in interface com.hazelcast.core.Cluster
Removes the specified membership listener.
removeMessageListener(String) - Method in interface com.hazelcast.core.ITopic
Stops receiving messages for the given message listener.
removeMigrationListener(String) - Method in interface com.hazelcast.core.PartitionService
 
removeMulticastListener(MulticastListener) - Method in class com.hazelcast.cluster.MulticastService
 
removeProxy(ClientProxy) - Method in class com.hazelcast.client.spi.ClientContext
 
removeProxy(String, String) - Method in class com.hazelcast.client.spi.ProxyManager
 
removeProxyListener(String) - Method in interface com.hazelcast.spi.ProxyService
 
removeTransactionContext(String) - Method in class com.hazelcast.client.ClientEndpoint
 
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
Transactional implementation of IMap.replace(Object, Object).
replace(K, V, V) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.replace(Object, Object, Object).
replicaIndex - Variable in class com.hazelcast.spi.InvocationBuilder
 
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
 
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.
reset() - Method in class com.hazelcast.client.ClientEngineImpl
 
reset() - Method in class com.hazelcast.cluster.AbstractJoiner
 
reset() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
reset() - Method in interface com.hazelcast.cluster.Joiner
 
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.nio.serialization.DataAdapter
 
reset() - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
reset() - Method in class com.hazelcast.query.PagingPredicate
resets for reuse
reset() - Method in interface com.hazelcast.spi.ManagedService
reset service, back to initial state
ResponseHandler - Interface in com.hazelcast.client.spi
 
ResponseHandler - Interface in com.hazelcast.spi
 
ResponseStream - Interface in com.hazelcast.client.spi
 
resultDeserialized - Variable in class com.hazelcast.spi.InvocationBuilder
 
retainAll(Collection<?>) - Method in interface com.hazelcast.core.IQueue
RetryableRequest - Interface in com.hazelcast.client
 
returnsResponse() - Method in class com.hazelcast.client.ClientDisconnectionOperation
 
returnsResponse() - Method in class com.hazelcast.client.ClientReAuthOperation
 
returnsResponse() - Method in class com.hazelcast.cluster.AuthorizationOperation
 
returnsResponse() - Method in class com.hazelcast.cluster.JoinCheckOperation
 
returnsResponse() - Method in class com.hazelcast.cluster.MemberInfoUpdateOperation
 
returnsResponse() - Method in class com.hazelcast.cluster.PostJoinOperation
 
returnsResponse() - Method in class com.hazelcast.cluster.PrepareMergeOperation
 
returnsResponse() - Method in class com.hazelcast.cluster.TcpIpJoiner.MasterClaim
 
returnsResponse() - Method in class com.hazelcast.spi.AbstractOperation
 
returnsResponse() - Method in class com.hazelcast.spi.Operation
 
RIDICULOUS_THREADS_PER_CORE - Static variable in class com.hazelcast.client.ClientEngineImpl
 
rollbackMigration(PartitionMigrationEvent) - Method in interface com.hazelcast.spi.MigrationAwareService
 
rollbackTransaction(String) - Method in interface com.hazelcast.spi.TransactionalService
 
rollbackTransaction() - Method in interface com.hazelcast.transaction.TransactionContext
Rollback of the current transaction.
RUBY - Static variable in class com.hazelcast.client.ClientTypes
 
run() - Method in class com.hazelcast.client.ClientDisconnectionOperation
 
run() - Method in class com.hazelcast.client.ClientReAuthOperation
 
run() - Method in class com.hazelcast.cluster.AuthenticationFailureOperation
 
run() - Method in class com.hazelcast.cluster.AuthorizationOperation
 
run() - Method in class com.hazelcast.cluster.BindOperation
 
run() - Method in class com.hazelcast.cluster.FinalizeJoinOperation
 
run() - Method in class com.hazelcast.cluster.HeartbeatOperation
 
run() - Method in class com.hazelcast.cluster.JoinCheckOperation
 
run() - Method in class com.hazelcast.cluster.JoinRequestOperation
 
run() - Method in class com.hazelcast.cluster.MasterConfirmationOperation
 
run() - Method in class com.hazelcast.cluster.MemberAttributeChangedOperation
 
run() - Method in class com.hazelcast.cluster.MemberInfoUpdateOperation
 
run() - Method in class com.hazelcast.cluster.MemberRemoveOperation
 
run() - Method in class com.hazelcast.cluster.MergeClustersOperation
 
run() - Method in class com.hazelcast.cluster.MulticastService
 
run() - Method in class com.hazelcast.cluster.PostJoinOperation
 
run() - Method in class com.hazelcast.cluster.PrepareMergeOperation
 
run() - Method in class com.hazelcast.cluster.SetMasterOperation
 
run() - Method in class com.hazelcast.cluster.TcpIpJoiner.MasterClaim
 
run() - Method in class com.hazelcast.spi.Operation
 
runOperation(Operation) - Method in interface com.hazelcast.spi.OperationService
Runs operation in calling thread.
RuntimeInterruptedException - Exception in com.hazelcast.core
An unchecked version of InterruptedException.
RuntimeInterruptedException() - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 
RuntimeInterruptedException(String) - Constructor for exception com.hazelcast.core.RuntimeInterruptedException
 

S

schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
schedule(Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
schedule(String, Runnable, long, TimeUnit) - Method in interface com.hazelcast.spi.ExecutionService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
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
 
SCHEDULED_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
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
 
searchForOtherClusters() - Method in interface com.hazelcast.cluster.Joiner
 
searchForOtherClusters() - Method in class com.hazelcast.cluster.MulticastJoiner
 
searchForOtherClusters() - Method in class com.hazelcast.cluster.TcpIpJoiner
 
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
 
SecurityConfig - Class in com.hazelcast.config
 
SecurityConfig() - Constructor for class com.hazelcast.config.SecurityConfig
 
SecurityContext - Interface in com.hazelcast.security
SecurityContext is responsible for managing lifecycle of security object such as ICredentialsFactory, IPermissionPolicy etc, to creating LoginContextes for member and client authentications and checking permissions for client operations.
select(Member) - Method in interface com.hazelcast.core.MemberSelector
Decides for the given member to be part of an operation or not.
SEMAPHORE_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
SEMAPHORE_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
SemaphoreConfig - Class in com.hazelcast.config
Contains the configuration for an ISemaphore.
SemaphoreConfig() - Constructor for class com.hazelcast.config.SemaphoreConfig
Creates a default configured SemaphoreConfig.
SemaphoreConfig(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfig
Creates a SemaphoreConfig by cloning another one.
SemaphoreConfigReadOnly - Class in com.hazelcast.config
 
SemaphoreConfigReadOnly(SemaphoreConfig) - Constructor for class com.hazelcast.config.SemaphoreConfigReadOnly
 
SemaphoreMBean - Class in com.hazelcast.jmx
 
SemaphoreMBean(ISemaphore, ManagementService) - Constructor for class com.hazelcast.jmx.SemaphoreMBean
 
send(JoinMessage) - Method in class com.hazelcast.cluster.MulticastService
 
send(Operation, Address) - Method in interface com.hazelcast.spi.OperationService
Executes an operation remotely.
send(Response, Address) - Method in interface com.hazelcast.spi.OperationService
 
sendEvent(Object, int) - Method in class com.hazelcast.client.ClientEndpoint
 
sendJoinRequest(Address, boolean) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
sendResponse(Object, int) - Method in class com.hazelcast.client.ClientEndpoint
 
sendResponse(Object) - Method in interface com.hazelcast.spi.ResponseHandler
 
sendShutdownMessage() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
SerializationConfig - Class in com.hazelcast.config
Contains the serialization configuration a HazelcastInstance.
SerializationConfig() - Constructor for class com.hazelcast.config.SerializationConfig
 
SerializationConstants - Class in com.hazelcast.nio.serialization
 
SerializationContext - Interface in com.hazelcast.nio.serialization
 
SerializationService - Interface in com.hazelcast.nio.serialization
 
SerializationServiceBuilder - Class in com.hazelcast.nio.serialization
 
SerializationServiceBuilder() - Constructor for class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
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
This interface is used to automatically register serializers from external Hazelcast or user modules.
Both types of Serializers are supported (StreamSerializer and ByteArraySerializer).
service - Variable in class com.hazelcast.client.ClientRequest
 
SERVICE_NAME - Static variable in class com.hazelcast.client.ClientEngineImpl
 
SERVICE_NAME - Static variable in class com.hazelcast.cluster.ClusterServiceImpl
 
ServiceConfig - Class in com.hazelcast.config
 
ServiceConfig() - Constructor for class com.hazelcast.config.ServiceConfig
 
ServiceConfigurationParser<T> - Interface in com.hazelcast.spi
 
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
 
serviceName - Variable in class com.hazelcast.spi.InvocationBuilder
 
ServicesConfig - Class in com.hazelcast.config
 
ServicesConfig() - Constructor for class com.hazelcast.config.ServicesConfig
 
servletContext - Variable in class com.hazelcast.web.WebFilter
 
SESSION_ATTRIBUTE_ID - Static variable in class com.hazelcast.web.WebDataSerializerHook
 
SessionAttributePredicate - Class in com.hazelcast.web
 
SessionAttributePredicate() - Constructor for class com.hazelcast.web.SessionAttributePredicate
 
SessionAttributePredicate(String) - Constructor for class com.hazelcast.web.SessionAttributePredicate
 
sessionCreated(HttpSessionEvent) - Method in class com.hazelcast.web.SessionListener
 
sessionDestroyed(HttpSessionEvent) - Method in class com.hazelcast.web.SessionListener
 
SessionListener - Class in com.hazelcast.web
 
SessionListener() - Constructor for class com.hazelcast.web.SessionListener
 
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
Transactional implementation of IMap.set(Object, Object).
set(long) - Method in class com.hazelcast.jmx.AtomicLongMBean
 
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
 
setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
setAddresses(List<String>) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setAlgorithm(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setAllowUnsafe(boolean) - Method in class com.hazelcast.config.SerializationConfig
 
setAllowUnsafe(boolean) - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
setAndGet(E) - Method in interface com.hazelcast.core.IAtomicReference
Sets and gets the value.
setApplicationContext(ApplicationContext) - Method in class com.hazelcast.spring.context.SpringManagedContext
 
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
 
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
 
setAttributes(AttributeList) - Method in class com.hazelcast.jmx.HazelcastMBean
 
setAwsConfig(AwsConfig) - Method in class com.hazelcast.config.JoinConfig
 
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
 
setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfig
 
setBinary(boolean) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
 
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.
setBufferSize(int) - Method in class com.hazelcast.client.config.SocketOptions
 
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.
setByteOrder(ByteOrder) - Method in class com.hazelcast.config.SerializationConfig
 
setByteOrder(ByteOrder) - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
setCacheLocalEntries(boolean) - Method in class com.hazelcast.config.NearCacheConfig
 
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
 
setCallId(int) - Method in class com.hazelcast.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
 
setCheckClassDefErrors(boolean) - Method in class 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.client.config.ClientConfig
 
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.SerializationServiceBuilder
 
setClassName(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
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.SerializerConfig
 
setClassName(String) - Method in class com.hazelcast.config.ServiceConfig
 
setClassName(String) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the name for the SocketInterceptor implementation class
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
 
setClusterId(String) - Method in class com.hazelcast.config.ManagementCenterConfig
 
setClusterName(String) - Method in class com.hazelcast.monitor.TimedMemberState
 
setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfig
 
setCommunicateStats(boolean) - Method in class com.hazelcast.config.JobTrackerConfigReadOnly
 
SetConfig - Class in com.hazelcast.config
 
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.SerializationServiceBuilder
 
setConfigObject(Object) - Method in class com.hazelcast.config.ServiceConfig
 
SetConfigReadOnly - Class in com.hazelcast.config
 
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
 
setConnection(Operation, Connection) - Static method in class com.hazelcast.spi.OperationAccessor
 
setConnectionAttemptLimit(int) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
setConnectionAttemptLimit(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setConnectionAttemptPeriod(int) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
setConnectionAttemptPeriod(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
setConnectionTimeout(int) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
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.
setContext(ClientContext) - Method in class com.hazelcast.client.spi.ClientProxy
 
setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientConfig
 
setCredentials(Credentials) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCredentialsClassname(String) - Method in class com.hazelcast.client.config.ClientSecurityConfig
 
setCrudRepository(CrudRepository) - Method in class com.hazelcast.spring.jpa.JPAMapStore
 
setData(Data) - Method in class com.hazelcast.nio.serialization.DataAdapter
 
setDataSerializableFactories(Map<Integer, DataSerializableFactory>) - Method in class com.hazelcast.config.SerializationConfig
 
setDataSerializableFactoryClasses(Map<Integer, String>) - Method in class com.hazelcast.config.SerializationConfig
 
setDistributedObjectListener(String) - Method in class com.hazelcast.client.ClientEndpoint
 
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.
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
 
setEnableCompression(boolean) - Method in class 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.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
 
setEnableSharedObject(boolean) - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
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
 
setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfig
When max.
setEvictionPercentage(int) - Method in class com.hazelcast.config.MapConfigReadOnly
 
setEvictionPolicy(MapConfig.EvictionPolicy) - Method in class com.hazelcast.config.MapConfig
 
setEvictionPolicy(MapConfig.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
 
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
 
setExecutorPoolSize(int) - Method in class com.hazelcast.client.config.ClientConfig
 
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
Sets the name for the com.hazelcast.nio.ssl.SSLContextFactory implementation class
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
Sets the com.hazelcast.nio.ssl.SSLContextFactory implementation object
setFirstConnection(boolean) - Method in class com.hazelcast.client.AuthenticationRequest
 
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.
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.client.config.ClientConfig
 
setGroupConfig(GroupConfig) - Method in class com.hazelcast.config.Config
 
setGroupName(String) - Method in class com.hazelcast.cluster.ConfigCheck
 
setGroupName(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
 
setGroupPassword(String) - Method in class com.hazelcast.cluster.ConfigCheck
 
setGroupPassword(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
 
setGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.config.PartitionGroupConfig
Sets the MemberGroupType.
setHazelcastInstance(HazelcastInstance) - Method in interface com.hazelcast.core.HazelcastInstanceAware
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
setHazelcastInstance(HazelcastInstance) - Method in class com.hazelcast.spring.cache.HazelcastCacheManager
 
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(Serializer) - Method in class com.hazelcast.config.SerializerConfig
Sets the serializer implementation instance.
setImplementation(Object) - Method in class com.hazelcast.config.SocketInterceptorConfig
Sets the SocketInterceptor implementation object
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
 
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
setInitialOutputBufferSize(int) - Method in class 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.MapConfig
Data 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
 
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.
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
 
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
 
setJoinerType(String) - Method in class com.hazelcast.cluster.ConfigCheck
 
setKeepAlive(boolean) - Method in class com.hazelcast.client.config.SocketOptions
 
setKey(byte[]) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setLicenseKey(String) - Method in class com.hazelcast.config.Config
 
setLingerSeconds(int) - Method in class com.hazelcast.client.config.SocketOptions
 
setListConfigs(Map<String, ListConfig>) - Method in class com.hazelcast.config.Config
 
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.client.config.ClientConfig
 
setListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.Config
 
setListenerRegistration(String, String, String) - Method in class com.hazelcast.client.ClientEndpoint
 
setLoadBalancer(LoadBalancer) - Method in class com.hazelcast.client.config.ClientConfig
 
setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfig
 
setLocal(boolean) - Method in class com.hazelcast.config.EntryListenerConfigReadOnly
 
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.
setManagedContext(ManagedContext) - Method in class com.hazelcast.client.config.ClientConfig
 
setManagedContext(ManagedContext) - Method in class com.hazelcast.config.Config
 
setManagedContext(ManagedContext) - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
setManagementCenterConfig(ManagementCenterConfig) - Method in class com.hazelcast.config.Config
 
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
 
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
 
SetMasterOperation - Class in com.hazelcast.cluster
 
SetMasterOperation() - Constructor for class com.hazelcast.cluster.SetMasterOperation
 
SetMasterOperation(Address) - Constructor for class com.hazelcast.cluster.SetMasterOperation
 
setMasterTime(long) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
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
 
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
 
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.
setMemberGroupType(PartitionGroupConfig.MemberGroupType) - Method in class com.hazelcast.cluster.ConfigCheck
 
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(MemberState) - 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
 
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfig
 
setMessageListenerConfigs(List<ListenerConfig>) - Method in class com.hazelcast.config.TopicConfigReadOnly
 
setMongoTemplate(MongoTemplate) - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
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.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.
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.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
 
setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfig
 
setNearCacheConfig(NearCacheConfig) - Method in class com.hazelcast.config.MapConfigReadOnly
 
setNearCacheConfigMap(Map<String, NearCacheConfig>) - Method in class com.hazelcast.client.config.ClientConfig
 
setNetworkConfig(ClientNetworkConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setNetworkConfig(NetworkConfig) - Method in class com.hazelcast.config.Config
 
setNode(Node) - Method in interface com.hazelcast.spi.NodeAware
 
setNodeEngine(NodeEngine) - Method in class com.hazelcast.spi.Operation
 
setObjectName(Hashtable<String, String>) - Method in class com.hazelcast.jmx.HazelcastMBean
 
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.
setPagingPredicateAnchor(PagingPredicate, Map.Entry) - Static method in class com.hazelcast.query.PagingPredicateAccessor
 
setPartitionGroupConfig(PartitionGroupConfig) - Method in class com.hazelcast.config.Config
 
setPartitionGroupEnabled(boolean) - Method in class com.hazelcast.cluster.ConfigCheck
 
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
 
setPartitioningStrategy(PartitioningStrategy) - Method in class 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
 
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.
setPassword(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setPassword(String) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfig
 
setPoolSize(int) - Method in class com.hazelcast.config.ExecutorConfigReadOnly
 
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.
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.
setProxyFactoryConfigs(List<ProxyFactoryConfig>) - Method in class com.hazelcast.client.config.ClientConfig
 
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
 
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
 
setReAuth(boolean) - Method in class com.hazelcast.client.AuthenticationRequest
 
setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
setRedoOperation(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
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.BaseClientRemoveListenerRequest
 
setReplicaIndex(int) - Method in class com.hazelcast.spi.InvocationBuilder
 
setReplicaIndex(int) - Method in class com.hazelcast.spi.Operation
 
setReplicationImpl(String) - Method in class com.hazelcast.config.WanTargetClusterConfig
 
setReplicationImplObject(Object) - Method in class com.hazelcast.config.WanTargetClusterConfig
 
setRequiredMember(String) - Method in class com.hazelcast.config.TcpIpConfig
Sets the required member.
setResponseHandler(ResponseHandler) - Method in class com.hazelcast.spi.Operation
 
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.client.config.SocketOptions
 
setReuseAddress(boolean) - Method in class com.hazelcast.config.NetworkConfig
 
setSalt(String) - Method in class com.hazelcast.config.SymmetricEncryptionConfig
 
setSecretKey(String) - Method in class com.hazelcast.config.AwsConfig
Sets the secret key to access AWS.
setSecurityConfig(ClientSecurityConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setSecurityConfig(SecurityConfig) - Method in class com.hazelcast.config.Config
 
setSecurityGroupName(String) - Method in class com.hazelcast.config.AwsConfig
Sets the security group name.
setSecurityToken(String) - Method in class com.hazelcast.config.ManagementCenterConfig
 
setSemaphoreConfigs(Map<String, SemaphoreConfig>) - Method in class com.hazelcast.config.Config
 
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.client.config.ClientConfig
 
setSerializationConfig(SerializationConfig) - Method in class com.hazelcast.config.Config
 
setSerializerConfigs(Collection<SerializerConfig>) - Method in class com.hazelcast.config.SerializationConfig
 
setService(String) - Method in class com.hazelcast.client.config.ProxyFactoryConfig
 
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.spi.Operation
 
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.
setSingleConnection() - Method in class com.hazelcast.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
 
setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
setSmartRouting(boolean) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSocketInterceptorConfig(SocketInterceptorConfig) - Method in class com.hazelcast.config.NetworkConfig
Sets the SocketInterceptorConfig.
setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientConfig
Deprecated. 
setSocketOptions(SocketOptions) - Method in class com.hazelcast.client.config.ClientNetworkConfig
 
setSSLConfig(SSLConfig) - Method in class com.hazelcast.client.config.ClientNetworkConfig
Sets the SSLConfig.
setSSLConfig(SSLConfig) - Method in class com.hazelcast.config.NetworkConfig
Sets the SSLConfig.
setStartTime(Operation, long) - Static method in class com.hazelcast.spi.OperationAccessor
 
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.SetConfigReadOnly
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfig
 
setStatisticsEnabled(boolean) - Method in class com.hazelcast.config.TopicConfigReadOnly
 
setStatus(int) - Method in class com.hazelcast.nio.serialization.DataAdapter
 
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.
setSymmetricEncryptionConfig(SymmetricEncryptionConfig) - Method in class com.hazelcast.config.NetworkConfig
Sets the SymmetricEncryptionConfig.
setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfig
Deprecated. 
setSyncBackupCount(int) - Method in class com.hazelcast.config.MultiMapConfigReadOnly
 
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.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
 
setTcpNoDelay(boolean) - Method in class com.hazelcast.client.config.SocketOptions
 
setTime(long) - Method in class com.hazelcast.monitor.TimedMemberState
 
setTimeout(long, TimeUnit) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the timeout.
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
 
setTransactionContext(TransactionContext) - Method in class com.hazelcast.client.ClientEndpoint
 
setTransactionType(TransactionOptions.TransactionType) - Method in class com.hazelcast.transaction.TransactionOptions
Sets the TransactionOptions.TransactionType.
setTrustedInterfaces(Set<String>) - Method in class com.hazelcast.config.MulticastConfig
Sets the trusted interfaces.
setTryCount(int) - Method in class com.hazelcast.cluster.JoinRequest
 
setTryCount(int) - Method in class com.hazelcast.spi.InvocationBuilder
 
setTryPauseMillis(long) - Method in class com.hazelcast.spi.InvocationBuilder
 
setType(PermissionConfig.PermissionType) - Method in class com.hazelcast.config.PermissionConfig
 
setTypeClass(Class) - Method in class com.hazelcast.config.SerializerConfig
 
setTypeClassName(String) - Method in class com.hazelcast.config.SerializerConfig
 
setUpdateInterval(int) - Method in class com.hazelcast.config.ManagementCenterConfig
 
setUrl(String) - Method in class com.hazelcast.config.ManagementCenterConfig
 
setUsage(LoginModuleConfig.LoginModuleUsage) - Method in class com.hazelcast.config.LoginModuleConfig
 
setUseNativeByteOrder(boolean) - Method in class com.hazelcast.config.SerializationConfig
 
setUseNativeByteOrder(boolean) - Method in class 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
 
setValidateTarget(boolean) - Method in class com.hazelcast.spi.Operation
 
setValue(Object) - Method in class com.hazelcast.spring.mongodb.ValueWrapper
 
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
 
setVersion(int) - Method in class com.hazelcast.nio.serialization.SerializationServiceBuilder
 
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
 
setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfig
Sets the number of seconds to delay before writing (storing) the dirty records
setWriteDelaySeconds(int) - Method in class com.hazelcast.config.MapStoreConfigReadOnly
 
SharedService - Interface in com.hazelcast.spi
 
shouldBackup() - Method in interface com.hazelcast.spi.BackupAwareOperation
Checks if a backup needs to be made.
shouldNotify() - Method in interface com.hazelcast.spi.Notifier
 
shouldWait() - Method in interface com.hazelcast.spi.WaitSupport
 
shutdown(boolean) - Method in class com.hazelcast.client.ClientEngineImpl
 
shutdown() - Method in class com.hazelcast.client.HazelcastClient
 
shutdown() - Method in class com.hazelcast.client.HazelcastClientProxy
 
shutdown() - Method in class com.hazelcast.client.LifecycleServiceImpl
 
shutdown(boolean) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
shutdown() - Method in interface com.hazelcast.core.HazelcastInstance
Shuts down this HazelcastInstance.
shutdown() - Method in interface com.hazelcast.core.LifecycleService
gracefully shutdowns HazelcastInstance.
shutdown() - Method in class com.hazelcast.jmx.InstanceMBean
 
shutdown(boolean) - Method in interface com.hazelcast.spi.ManagedService
Shuts down the ManagedService.
SHUTDOWN_ON_STOP - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
shutdownAll() - Static method in class com.hazelcast.client.HazelcastClient
 
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.jmx.ManagementService
 
shutdownExecutor(String) - Method in interface com.hazelcast.spi.ExecutionService
 
shutdownInstance() - Method in class com.hazelcast.web.WebFilter
 
shutdownOnStop(Properties, boolean) - Static method in class com.hazelcast.hibernate.CacheEnvironment
 
signal() - Method in interface com.hazelcast.core.ICondition
signalAll() - Method in interface com.hazelcast.core.ICondition
signalOneBackupComplete() - Method in interface com.hazelcast.spi.BackupCompletionCallback
 
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.IQueue
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
Transactional implementation of Map.size().
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 interface com.hazelcast.hibernate.RegionCache
 
skip(long) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
skipBytes(int) - Method in class com.hazelcast.nio.serialization.ObjectDataInputStream
 
SocketInterceptorConfig - Class in com.hazelcast.config
 
SocketInterceptorConfig() - Constructor for class com.hazelcast.config.SocketInterceptorConfig
 
SocketOptions - Class in com.hazelcast.client.config
 
SocketOptions() - Constructor for class com.hazelcast.client.config.SocketOptions
 
SPI_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
SPI_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
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.
SpringAware - Annotation Type in com.hazelcast.spring.context
Annotates a class for injection of Spring dependencies.
SpringManagedContext - Class in com.hazelcast.spring.context
 
SpringManagedContext() - Constructor for class com.hazelcast.spring.context.SpringManagedContext
 
SpringMongoDBConverter - Class in com.hazelcast.spring.mongodb
 
SpringMongoDBConverter(Mongo, String) - Constructor for class com.hazelcast.spring.mongodb.SpringMongoDBConverter
 
SpringMongoDBConverter(MongoTemplate) - Constructor for class com.hazelcast.spring.mongodb.SpringMongoDBConverter
 
SqlPredicate - Class in com.hazelcast.query
 
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
 
start(Settings, Properties) - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
start(Settings, Properties) - Method in class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
startClusterMerge(Address) - Method in class com.hazelcast.cluster.AbstractJoiner
 
stateChanged(LifecycleEvent) - Method in interface com.hazelcast.core.LifecycleListener
Called when instance's state changes
stop() - Method in class com.hazelcast.cluster.MulticastService
 
stop() - Method in class com.hazelcast.hibernate.AbstractHazelcastCacheRegionFactory
 
stop() - Method in class com.hazelcast.hibernate.HazelcastLocalCacheRegionFactory
 
stopListening(BaseClientRemoveListenerRequest, String) - Method in class com.hazelcast.client.spi.ClientProxy
 
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(Serializable, Object) - Method in class com.hazelcast.spring.jpa.JPAMapStore
 
store(Object, Object) - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
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.spring.jpa.JPAMapStore
 
storeAll(Map) - Method in class com.hazelcast.spring.mongodb.MongoMapStore
 
StreamSerializer<T> - Interface in com.hazelcast.nio.serialization
 
submit(Runnable) - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
submit(Callable<T>) - Method in interface com.hazelcast.client.spi.ClientExecutionService
 
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() - 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
 
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.
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.
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.
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.
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.
SymmetricEncryptionConfig - Class in com.hazelcast.config
 
SymmetricEncryptionConfig() - Constructor for class com.hazelcast.config.SymmetricEncryptionConfig
 
SYSTEM_EXECUTOR - Static variable in interface com.hazelcast.spi.ExecutionService
 
systemLogService - Variable in class com.hazelcast.cluster.AbstractJoiner
 

T

take() - Method in interface com.hazelcast.core.IQueue
target - Variable in class com.hazelcast.spi.InvocationBuilder
 
TargetClientRequest - Class in com.hazelcast.client
 
TargetClientRequest() - Constructor for class com.hazelcast.client.TargetClientRequest
 
TcpIpConfig - Class in com.hazelcast.config
Contains the configuration for the Tcp/Ip join mechanism.
TcpIpConfig() - Constructor for class com.hazelcast.config.TcpIpConfig
 
TcpIpJoiner - Class in com.hazelcast.cluster
 
TcpIpJoiner(Node) - Constructor for class com.hazelcast.cluster.TcpIpJoiner
 
TcpIpJoiner.MasterClaim - Class in com.hazelcast.cluster
 
TcpIpJoiner.MasterClaim() - Constructor for class com.hazelcast.cluster.TcpIpJoiner.MasterClaim
 
TcpIpJoinerOverAWS - Class in com.hazelcast.cluster
 
TcpIpJoinerOverAWS(Node) - Constructor for class com.hazelcast.cluster.TcpIpJoinerOverAWS
 
terminate() - Method in class com.hazelcast.client.LifecycleServiceImpl
 
terminate() - Method in interface com.hazelcast.core.LifecycleService
terminate HazelcastInstance ungracefully.
THIS_ATTRIBUTE_NAME - Static variable in class com.hazelcast.query.QueryConstants
 
thisAddress - Variable in class com.hazelcast.cluster.ClusterServiceImpl
 
thisMember - Variable in class com.hazelcast.cluster.ClusterServiceImpl
 
THREADS_PER_CORE - Static variable in class com.hazelcast.client.ClientEngineImpl
 
throwExceptionIfNull(Object) - Method in class com.hazelcast.client.spi.ClientProxy
 
throwNotActiveException() - Method in class com.hazelcast.spi.AbstractDistributedObject
 
TimedMemberState - Class in com.hazelcast.monitor
 
TimedMemberState() - Constructor for class com.hazelcast.monitor.TimedMemberState
 
toArray() - Method in interface com.hazelcast.core.IQueue
toArray(T[]) - Method in interface com.hazelcast.core.IQueue
toByteArray() - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
toData(Object) - Method in interface com.hazelcast.client.ClientEngine
 
toData(Object) - Method in class com.hazelcast.client.ClientEngineImpl
 
toData(Object) - Method in class com.hazelcast.client.spi.ClientProxy
 
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 interface com.hazelcast.spi.NodeEngine
 
toDBObject(Object) - Method in interface com.hazelcast.spring.mongodb.MongoDBConverter
 
toDBObject(Object) - Method in class com.hazelcast.spring.mongodb.SpringMongoDBConverter
 
toObject(Data) - Method in interface com.hazelcast.client.ClientEngine
 
toObject(Data) - Method in class com.hazelcast.client.ClientEngineImpl
 
toObject(Object) - Method in class com.hazelcast.client.spi.ClientProxy
 
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 interface com.hazelcast.spi.NodeEngine
 
toObject(Class, DBObject) - Method in interface com.hazelcast.spring.mongodb.MongoDBConverter
 
toObject(Class, DBObject) - Method in class com.hazelcast.spring.mongodb.SpringMongoDBConverter
 
TOPIC_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
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
Creates a TopicConfig by cloning another TopicConfig.
TopicConfigReadOnly - Class in com.hazelcast.config
 
TopicConfigReadOnly(TopicConfig) - Constructor for class com.hazelcast.config.TopicConfigReadOnly
 
TopicMBean - Class in com.hazelcast.jmx
 
TopicMBean(ITopic, ManagementService) - Constructor for class com.hazelcast.jmx.TopicMBean
 
TopologyChangedException - Exception in com.hazelcast.mapreduce
This exception is thrown when a topology change happens during the execution of a map reduce job and the TopologyChangedStrategy is set to TopologyChangedStrategy.CANCEL_RUNNING_OPERATION.
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 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.
toReal(SerializationContext) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
toStoreValue(Object) - Method in class com.hazelcast.spring.cache.HazelcastCache
 
toString() - Method in class com.hazelcast.client.ClientEndpoint
 
toString() - Method in class com.hazelcast.client.ClientPrincipal
 
toString() - Method in class com.hazelcast.client.GenericError
 
toString() - Method in class com.hazelcast.cluster.BindOperation
 
toString() - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
toString() - Method in class com.hazelcast.cluster.JoinMessage
 
toString() - Method in class com.hazelcast.cluster.JoinRequest
 
toString() - Method in class com.hazelcast.cluster.JoinRequestOperation
 
toString() - Method in class com.hazelcast.cluster.MemberInfo
 
toString() - Method in class com.hazelcast.cluster.MemberInfoUpdateOperation
 
toString() - Method in class com.hazelcast.cluster.PostJoinOperation
 
toString() - Method in class com.hazelcast.cluster.SetMasterOperation
 
toString() - Method in class com.hazelcast.config.AwsConfig
 
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.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.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.MembershipEvent
 
toString() - Method in class com.hazelcast.core.MigrationEvent
 
toString() - Method in class com.hazelcast.core.PartitionAwareKey
 
toString() - Method in class com.hazelcast.monitor.TimedMemberState
 
toString() - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
toString() - Method in class com.hazelcast.nio.serialization.Data
 
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.security.UsernamePasswordCredentials
 
toString() - Method in class com.hazelcast.spi.DefaultObjectNamespace
 
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.transaction.TransactionOptions
 
total() - Method in interface com.hazelcast.monitor.LocalMapStats
Returns the total number of total operations
totalSize() - Method in class com.hazelcast.nio.serialization.Data
Calculates the size of the binary after the Data is serialized.
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.
TransactionalList<E> - Interface in com.hazelcast.core
Transactional implementation of IList.
TransactionalMap<K,V> - Interface in com.hazelcast.core
Transactional implementation of BaseMap.
TransactionalMultiMap<K,V> - Interface in com.hazelcast.core
Transactional implementation of BaseMultiMap.
TransactionalObject - Interface in com.hazelcast.transaction
Marker interface for all transactional distributed objects.
TransactionalQueue<E> - Interface in com.hazelcast.core
Transactional implementation of BaseQueue.
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.
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
 
TransactionManagerService - Interface in com.hazelcast.transaction
 
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
 
TRY_COUNT - Static variable in class com.hazelcast.client.MultiTargetClientRequest
 
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.
tryCount - Variable in class com.hazelcast.spi.InvocationBuilder
 
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(Object, Object) - Method in interface com.hazelcast.hibernate.RegionCache
 
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.
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.
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.
tryStopThreads(HazelcastClient) - Static method in class com.hazelcast.client.ClientOutOfMemoryHandler.ClientHelper
 
tryStopThreads(HazelcastInstance) - Method in class com.hazelcast.core.OutOfMemoryHandler
Tries to stop internal Hazelcast threads (such as service thread, IO threads, executor threads).

U

unloadInstance() - Method in interface com.hazelcast.hibernate.instance.IHazelcastInstanceLoader
 
unlock() - Method in interface com.hazelcast.core.ILock
Releases the lock.
unlock(K) - Method in interface com.hazelcast.core.IMap
Releases the lock for the specified key.
unlock(K) - Method in interface com.hazelcast.core.MultiMap
Releases the lock for the specified key.
unlock(Object, SoftLock) - Method in interface com.hazelcast.hibernate.RegionCache
 
update(Object, Object, Object, Object, SoftLock) - Method in interface com.hazelcast.hibernate.RegionCache
 
updateMemberAttribute(String, MemberAttributeOperationType, String, Object) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
UrgentSystemOperation - Interface in com.hazelcast.spi
An Marker interface that signals that an operation is an urgent System Operation.
UrlXmlConfig - Class in com.hazelcast.config
A Config which is loaded using some url pointing to a Hazelcast XML file.
UrlXmlConfig(String) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(String, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
UrlXmlConfig(URL) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url and uses the System.properties to replace variables in the XML.
UrlXmlConfig(URL, Properties) - Constructor for class com.hazelcast.config.UrlXmlConfig
Creates new Config which is loaded from the given url.
USE_NATIVE_CLIENT - Static variable in class com.hazelcast.hibernate.CacheEnvironment
 
UsernamePasswordCredentials - Class in com.hazelcast.security
Simple implementation of Credentials using username and password as security attributes.
UsernamePasswordCredentials() - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
UsernamePasswordCredentials(String, String) - Constructor for class com.hazelcast.security.UsernamePasswordCredentials
 
uuid - Variable in class com.hazelcast.cluster.JoinMessage
 

V

validateJoinMessage(JoinMessage) - Method in class com.hazelcast.cluster.ClusterServiceImpl
 
validatesTarget() - Method in class com.hazelcast.cluster.PostJoinOperation
 
validatesTarget() - Method in class com.hazelcast.spi.Operation
 
value - Variable in class com.hazelcast.core.EntryEvent
 
value - Variable in class com.hazelcast.query.Predicates.EqualPredicate
 
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.
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.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.MapConfig.EvictionPolicy
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.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.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.nio.serialization.FieldType
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.TransactionOptions.TransactionType
Returns the enum constant of this type with the specified name.
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.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.MapConfig.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.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.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.TransactionalMap
Transactional implementation of IMap.values().
values(Predicate) - Method in interface com.hazelcast.core.TransactionalMap
Transactional implementation of IMap.values(com.hazelcast.query.Predicate) .
values(String) - Method in class com.hazelcast.jmx.MapMBean
 
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.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.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.TransactionOptions.TransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
ValueWrapper - Class in com.hazelcast.spring.mongodb
 
ValueWrapper(Object) - Constructor for class com.hazelcast.spring.mongodb.ValueWrapper
 
VersionAwareMapMergePolicy - Class in com.hazelcast.hibernate
 
VersionAwareMapMergePolicy() - Constructor for class com.hazelcast.hibernate.VersionAwareMapMergePolicy
 

W

WaitNotifyKey - Interface in com.hazelcast.spi
 
WaitNotifyService - Interface in com.hazelcast.spi
 
WaitSupport - Interface in com.hazelcast.spi
 
WanReplicationConfig - Class in com.hazelcast.config
 
WanReplicationConfig() - Constructor for class com.hazelcast.config.WanReplicationConfig
 
WanReplicationRef - Class in com.hazelcast.config
 
WanReplicationRef() - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRef(String, String) - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRef(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRef
 
WanReplicationRefReadOnly - Class in com.hazelcast.config
 
WanReplicationRefReadOnly(WanReplicationRef) - Constructor for class com.hazelcast.config.WanReplicationRefReadOnly
 
WanTargetClusterConfig - Class in com.hazelcast.config
 
WanTargetClusterConfig() - Constructor for class com.hazelcast.config.WanTargetClusterConfig
 
WEB_DS_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
WEB_PORTABLE_FACTORY - Static variable in class com.hazelcast.nio.serialization.FactoryIdHelper
 
WebDataSerializerHook - Class in com.hazelcast.web
 
WebDataSerializerHook() - Constructor for class com.hazelcast.web.WebDataSerializerHook
 
WebFilter - Class in com.hazelcast.web
 
WebFilter() - Constructor for class com.hazelcast.web.WebFilter
 
WebFilter(Properties) - Constructor for class com.hazelcast.web.WebFilter
 
write(PortableWriter) - Method in class com.hazelcast.client.AuthenticationRequest
 
write(PortableWriter) - Method in class com.hazelcast.client.BaseClientRemoveListenerRequest
 
write(PortableWriter) - Method in class com.hazelcast.client.ClientCreateRequest
 
write(PortableWriter) - Method in class com.hazelcast.client.ClientDestroyRequest
 
write(PortableWriter) - Method in class com.hazelcast.client.ClientRequest
 
write(T) - Method in interface com.hazelcast.nio.serialization.ByteArraySerializer
 
write(ObjectDataOutput, Boolean) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.BooleanSerializer
 
write(ObjectDataOutput, Byte) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ByteSerializer
 
write(ObjectDataOutput, char[]) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.CharArraySerializer
 
write(ObjectDataOutput, Character) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.CharSerializer
 
write(ObjectDataOutput, double[]) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.DoubleArraySerializer
 
write(ObjectDataOutput, Double) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.DoubleSerializer
 
write(ObjectDataOutput, float[]) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.FloatArraySerializer
 
write(ObjectDataOutput, Float) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.FloatSerializer
 
write(ObjectDataOutput, int[]) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.IntegerArraySerializer
 
write(ObjectDataOutput, Integer) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.IntegerSerializer
 
write(ObjectDataOutput, long[]) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.LongArraySerializer
 
write(ObjectDataOutput, Long) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.LongSerializer
 
write(ObjectDataOutput, short[]) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ShortArraySerializer
 
write(ObjectDataOutput, Short) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.ShortSerializer
 
write(ObjectDataOutput, String) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.StringSerializer
 
write(byte[]) - Method in class com.hazelcast.nio.serialization.ConstantSerializers.TheByteArraySerializer
 
write(ObjectDataOutput, BigDecimal) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.BigDecimalSerializer
 
write(ObjectDataOutput, BigInteger) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.BigIntegerSerializer
 
write(ObjectDataOutput, Class) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.ClassSerializer
 
write(ObjectDataOutput, Date) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.DateSerializer
 
write(ObjectDataOutput, Enum) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.EnumSerializer
 
write(ObjectDataOutput, Externalizable) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.Externalizer
 
write(ObjectDataOutput, Object) - Method in class com.hazelcast.nio.serialization.DefaultSerializers.ObjectSerializer
 
write(int) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
write(byte[], int, int) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
write(byte[]) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
write(ObjectDataOutput, T) - Method in interface com.hazelcast.nio.serialization.StreamSerializer
 
writeBoolean(String, boolean) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeBoolean(boolean) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeBoolean(String, boolean) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeByte(String, byte) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeByte(int) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeByte(String, byte) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeByteArray(String, byte[]) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeByteArray(String, byte[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeBytes(String) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeChar(String, int) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeChar(int) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeChar(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeCharArray(String, char[]) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeCharArray(char[]) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeCharArray(String, char[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeChars(String) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.client.ClientResponse
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.client.OperationFactoryWrapper
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.ConfigCheck
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.JoinMessage
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.JoinRequest
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.cluster.MemberInfo
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.core.MemberAttributeEvent
 
writeData(ObjectDataOutput) - Method in exception com.hazelcast.core.MemberLeftException
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.core.MigrationEvent
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.core.PartitionAwareKey
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.hibernate.VersionAwareMapMergePolicy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.monitor.TimedMemberState
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.nio.serialization.BinaryClassDefinitionProxy
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.nio.serialization.ClassDefinitionImpl
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.nio.serialization.Data
WARNING:

Should be in sync with DataAdapter.writeTo(java.nio.ByteBuffer)

Data.totalSize() should be updated whenever writeData method is changed.

writeData(ObjectDataOutput) - Method in interface com.hazelcast.nio.serialization.DataSerializable
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.PagingPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.PredicateBuilder
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.AbstractPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.AndPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.BetweenPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.EqualPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.GreaterLessPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.InPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.LikePredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.NotPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.OrPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.Predicates.RegexPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.query.SqlPredicate
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.DefaultObjectNamespace
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.spi.Operation
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.transaction.TransactionOptions
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.web.InvalidateEntryProcessor
 
writeData(ObjectDataOutput) - Method in class com.hazelcast.web.SessionAttributePredicate
 
writeDouble(String, double) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeDouble(double) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeDouble(String, double) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeDoubleArray(String, double[]) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeDoubleArray(double[]) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeDoubleArray(String, double[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeFloat(String, float) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeFloat(float) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeFloat(String, float) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeFloatArray(String, float[]) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeFloatArray(float[]) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeFloatArray(String, float[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeInt(String, int) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeInt(int) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeInt(String, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeIntArray(String, int[]) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeIntArray(int[]) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeIntArray(String, int[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.client.ClientDisconnectionOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.client.ClientReAuthOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.AuthorizationOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.BindOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.FinalizeJoinOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.JoinCheckOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.JoinRequestOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.MemberAttributeChangedOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.MemberInfoUpdateOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.MemberRemoveOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.MergeClustersOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.PostJoinOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.PrepareMergeOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.cluster.SetMasterOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.AbstractOperation
 
writeInternal(ObjectDataOutput) - Method in class com.hazelcast.spi.Operation
 
writeLong(String, long) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeLong(long) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeLong(String, long) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeLongArray(String, long[]) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeLongArray(long[]) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeLongArray(String, long[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeNullPortable(String, int, int) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeNullPortable(String, int, int) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeObject(Object) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeObject(ObjectDataOutput, Object) - Method in interface com.hazelcast.nio.serialization.SerializationService
 
writeObject(ObjectDataOutput, Object) - Method in class com.hazelcast.nio.serialization.SerializationServiceImpl
 
writePortable(PortableWriter) - Method in class com.hazelcast.client.ClientPrincipal
 
writePortable(PortableWriter) - Method in class com.hazelcast.client.ClientRequest
 
writePortable(PortableWriter) - Method in class com.hazelcast.client.DistributedObjectInfo
 
writePortable(PortableWriter) - Method in class com.hazelcast.client.GenericError
 
writePortable(String, Portable) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writePortable(PortableWriter) - Method in interface com.hazelcast.nio.serialization.Portable
 
writePortable(String, Portable) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writePortable(PortableWriter) - Method in class com.hazelcast.security.AbstractCredentials
 
writePortableArray(String, Portable[]) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writePortableArray(String, Portable[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writePortableInternal(PortableWriter) - Method in class com.hazelcast.security.AbstractCredentials
 
writePortableInternal(PortableWriter) - Method in class com.hazelcast.security.UsernamePasswordCredentials
 
writeShort(String, short) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeShort(int) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeShort(String, short) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeShortArray(String, short[]) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeShortArray(short[]) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeShortArray(String, short[]) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 
writeTo(MigrationEvent.MigrationStatus, DataOutput) - Static method in enum com.hazelcast.core.MigrationEvent.MigrationStatus
 
writeTo(ByteBuffer) - Method in class com.hazelcast.nio.serialization.DataAdapter
WARNING: Should be in sync with Data.writeData(com.hazelcast.nio.ObjectDataOutput)
writeUTF(String, String) - Method in class com.hazelcast.nio.serialization.DefaultPortableWriter
 
writeUTF(String) - Method in class com.hazelcast.nio.serialization.ObjectDataOutputStream
 
writeUTF(String, String) - Method in interface com.hazelcast.nio.serialization.PortableWriter
 

X

XmlClientConfigBuilder - Class in com.hazelcast.client.config
 
XmlClientConfigBuilder(String) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(File) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(URL) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder(InputStream) - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlClientConfigBuilder() - Constructor for class com.hazelcast.client.config.XmlClientConfigBuilder
 
XmlConfigBuilder - Class in com.hazelcast.config
A XML ConfigBuilder implementation.
XmlConfigBuilder(String) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that reads from the provided file.
XmlConfigBuilder(InputStream) - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that reads from the given InputStream.
XmlConfigBuilder() - Constructor for class com.hazelcast.config.XmlConfigBuilder
Constructs a XmlConfigBuilder that tries to find a usable XML configuration file.
xmlToJavaName(String) - Method in class com.hazelcast.config.AbstractXmlConfigHelper
 

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

Copyright © 2014 Hazelcast, Inc.. All Rights Reserved.