All Classes

Class Description
AbstractCacheConfig<K,​V>
Base class for CacheConfig
AbstractDiscoveryStrategy
An common abstract superclass for DiscoveryStrategy implementations, offering convenient access to configuration properties (which may be overridden on the system's environment or JVM properties), as well as a ILogger instance.
AbstractIMapEvent
The abstract class for a map event IMapEvent.
AbstractLoadBalancer
An abstract LoadBalancer implementation.
AbstractLogger
Abstract ILogger implementation that provides implementations for convenience methods like finest, info, warning and severe.
AbstractPbeReplacer
The common parent for ConfigReplacer implementations which allow to mask values by encrypting the value.
AbstractSymmetricEncryptionConfig<T extends AbstractSymmetricEncryptionConfig>
Base class for symmetric encryption configuration classes.
AbstractWanPublisherConfig
Base class for WAN publisher configuration.
AbstractXmlConfigBuilder
Contains logic for replacing system variables in the XML file and importing XML files from different locations.
AbstractXmlConfigBuilder.ConfigType  
AbstractXmlConfigHelper
Contains Hazelcast XML Configuration helper methods and variables.
AbstractYamlConfigBuilder
Contains logic for replacing system variables in the YAML file and importing YAML files from different locations.
ActionConstants  
Address
Represents an address of a member in the cluster.
AddressHelper
This is a client side utility class for working with addresses and cluster connections
AddressPicker
Strategy to select an Address that a Hazelcast cluster member binds its server socket to and a (potentially different) address that Hazelcast will advertise to other cluster members and clients.
AdvancedNetworkConfig
Similar to NetworkConfig with the additional ability to define multiple endpoints, each with its own separate protocol/security and/or socket properties.
AdvancedNetworkConfig.MemberNetworkingView
Member endpoint decorated as a NetworkConfig Facade used during bootstrap to hide if-logic between the two networking configuration approaches
Aggregator<I,​R>
Defines a contract for all aggregators.
Aggregators
A utility class to create basic Aggregator instances.
AliasedDiscoveryConfig<T extends AliasedDiscoveryConfig<T>>
Configuration for discovery strategy aliases, e.g.
AllPermissions  
AllPermissions.AllPermissionsCollection  
AtomicLongPermission  
AtomicReferencePermission  
AttributeConfig
Contains the configuration of a custom attribute that will be extracted from a Map's entry using a given ValueExtractor.
AuthenticationConfig
This interface represents authentication configuration in a security realm.
AuthenticationException
A HazelcastException that is thrown when there is an Authentication failure: e.g.
AvroProcessors
Static utility class with factories of Apache Avro source and sink processors.
AvroSinks
Contains factory methods for Apache Avro sinks.
AvroSourceBuilder<D>
Builder for an Avro file source which reads records from Avro files in a directory (but not its subdirectories) and emits output object created by mapOutputFn.
AvroSources
Contains factory methods for Apache Avro sources.
AwsConfig
The AWSConfig contains the configuration for AWS join mechanism.
AzureConfig
Configuration for the Azure Discovery Strategy.
BackupAwareEntryProcessor<K,​V,​T>
An invocable function that allows applications to perform compound operations on a Cache.Entry atomically, according to the defined consistency of a Cache.
BackupTaskState
The state of the hot restart backup task
BackupTaskStatus
The status of the hot restart backup task, including progress and state.
BaseMap<K,​V>
Base interface for Hazelcast distributed maps.
BaseMetricsConfig<T extends BaseMetricsConfig>
Base class of configuration options specific to metrics collection.
BaseMultiMap<K,​V>
Base interface for Hazelcast distributed multi-maps.
BaseQueue<E>
Base interface for Hazelcast distributed queues.
BasicSSLContextFactory
Empty implementation.
Beta
An element annotated with this annotation is considered beta status.
BiConsumerEx<T,​U>
Serializable variant of java.util.function.BiConsumer which declares checked exception.
BiFunctionEx<T,​U,​R>
Serializable variant of java.util.function.BiFunction which declares checked exception.
BinaryOperatorEx<T>
Serializable variant of java.util.function.BinaryOperator which declares checked exception.
BiPredicateEx<T,​U>
Serializable variant of java.util.function.BiPredicate which declares checked exception.
BitmapIndexOptions
Configures indexing options specific to bitmap indexes.
BitmapIndexOptions.UniqueKeyTransformation
Defines an assortment of transformations which can be applied to unique key values.
BuildInfo  
BuildInfoProvider
Provides information about current Hazelcast build.
ByteArraySerializer<T>
For sample usage custom serialization and other way of custom serialization see StreamSerializer.
CacheConfig<K,​V>
Contains all the configuration for the ICache.
CacheConfigAccessor
Accessor for CacheConfig fields
CacheConfiguration<K,​V>
Mutable extension to CompleteConfiguration
CacheDeserializedValues
Control caching of de-serialized values.
CacheEntryView<K,​V>
Entry info for cache record.
CacheEventType
Hazelcast JCache implementation's internal event types.
CacheEvictionPolicyComparator<K,​V>
ICache specific EvictionPolicyComparator for comparing CacheEntryViews to be evicted.
CacheNotExistsException
This exception class is thrown while creating CacheRecordStore instances but the cache config does not exist on the node to create the instance on.
CachePartitionLostListenerConfig
Configuration for CachePartitionLostListener
CachePermission  
CacheSimpleConfig
Simple configuration to hold parsed XML configuration.
CacheSimpleConfig.ExpiryPolicyFactoryConfig
Represents configuration for "ExpiryPolicyFactory".
CacheSimpleConfig.ExpiryPolicyFactoryConfig.DurationConfig
Represents duration configuration with duration amount and time unit for the "TimedExpiryPolicyFactoryConfig".
CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig
Represents configuration for time based "ExpiryPolicyFactory" with duration and time unit.
CacheSimpleConfig.ExpiryPolicyFactoryConfig.TimedExpiryPolicyFactoryConfig.ExpiryPolicyType
Represents type of the "TimedExpiryPolicyFactoryConfig".
CacheSimpleEntryListenerConfig
Simple configuration to hold parsed listener config.
CacheStatistics
Cache statistics
CacheUtil
Utility class for various cache related operations to be used by our internal structure and end user.
CallerNotMemberException
A RetryableHazelcastException that indicates that an operation was sent by a machine which isn't member in the cluster when the operation is executed.
CannotReplicateException
A CPSubsystemException which is thrown when an entry cannot be replicated, which can occur in one of the following cases: a member leaves the CP group CP group itself is terminated uncommitted entry count reaches to (see RaftAlgorithmConfig.getUncommittedEntryCountToRejectNewAppends()) a membership change is requested before an entry is committed on a term
CardinalityEstimator
CardinalityEstimator is a redundant and highly available distributed data-structure used for probabilistic cardinality estimation purposes, on unique items, in significantly sized data cultures.
CardinalityEstimatorConfig
Configuration options for the CardinalityEstimator
CardinalityEstimatorPermission  
ClassDefinition
ClassDefinition defines a class schema for Portable classes.
ClassDefinitionBuilder
ClassDefinitionBuilder is used to build and register ClassDefinitions manually.
ClassFilter
Holds blacklist and whitelist configuration in java deserialization configuration.
ClassNameFilter
Allows to intercept class resolution during deserialization based on classname.
ClasspathXmlConfig
A Config which is initialized by loading an XML configuration file from the classpath.
ClasspathYamlConfig
A Config which is initialized by loading a YAML configuration file from the classpath.
Client
The Client interface allows to get information about a connected client's socket address, type and UUID.
ClientClasspathXmlConfig
A ClientConfig which is initialized by loading an XML configuration file from the classpath.
ClientClasspathYamlConfig
A ClientConfig which is initialized by loading an YAML configuration file from the classpath.
ClientCloudConfig
hazelcast.cloud configuration to let the client connect the cluster via hazelcast.cloud
ClientConfig
Main configuration to setup a Hazelcast Client
ClientConfigXmlGenerator
The ClientConfigXmlGenerator is responsible for transforming a ClientConfig to a Hazelcast Client XML string.
ClientConnectionStrategyConfig
Client connection strategy configuration is used for setting custom strategies and configuring strategy parameters.
ClientConnectionStrategyConfig.ReconnectMode
Reconnect options.
ClientConsoleApp
A demo application to demonstrate a Hazelcast client.
ClientFailoverClasspathXmlConfig
A ClientFailoverConfig which is initialized by loading an XML configuration file from the classpath.
ClientFailoverClasspathYamlConfig
A ClientFailoverConfig which is initialized by loading a YAML configuration file from the classpath.
ClientFailoverConfig
Config class to configure multiple client configs to be used by single client instance The client will try to connect them in given order.
ClientFlakeIdGeneratorConfig
The ClientFlakeIdGeneratorConfig contains the configuration for the client regarding Flake ID Generator.
ClientIcmpPingConfig
Configuration for icmp ping failure detector of clients.
ClientListener
The ClientListener provides the ability to listen to clients connecting and disconnecting from the member.
ClientMetricsConfig
Client-side metrics collection configuration.
ClientNetworkConfig
Contains configuration parameters for client network related behaviour
ClientNotAllowedInClusterException
A HazelcastException that is thrown when client can not use this cluster.
ClientOutOfMemoryHandler
To clear resources of the client upon OutOfMemory
ClientProperty
Defines the name and default value for Hazelcast Client properties.
ClientReliableTopicConfig
Contains the ReliableTopic configuration for a client.
ClientSecurityConfig
Contains the security configuration for the client.
ClientService
ClientService allows you to query connected Clients and attach/detach ClientListeners to listen to connection events.
ClientStateListener
Helper class for the user to track the lifecycle state of the client.
ClientUserCodeDeploymentConfig
Configuration of User Code Deployment.
Cluster
Hazelcast cluster interface.
ClusterPermission  
ClusterPermissionCollection  
ClusterProperty
Defines the name and default value for Hazelcast properties.
ClusterState
ClusterState are several possible states of the cluster where each state can allow and/or deny specific actions and/or change behavior of specific actions.
CollectionConfig<T extends CollectionConfig>
Provides configuration service for Collection.
ComparatorEx<T>
Serializable variant of java.util.Comparator which declares checked exception.
Config
Contains all the configuration to start a HazelcastInstance.
ConfigAccessor
Private API for accessing configuration at runtime
ConfigBuilder
Interface for all config builders.
ConfigPatternMatcher
The ConfigPatternMatcher provides a strategy to match an item name to a configuration pattern.
ConfigPermission  
ConfigReplacer
Interface to be implemented by pluggable variable replacers for the configuration files.
ConfigXmlGenerator
The ConfigXmlGenerator is responsible for transforming a Config to a Hazelcast XML string.
ConfigXmlGenerator.XmlGenerator
Utility class to build xml using a StringBuilder.
ConnectionRetryConfig
Connection Retry Config is controls the period among the retries and when should a client gave up retrying.
ConsistencyCheckStrategy
Strategy for checking the consistency of data between replicas.
ConsistencyLostException
Exception that indicates that the consistency guarantees provided by some service has been lost.
ConsoleApp
Special thanks to Alexandre Vasseur for providing this very nice test application.
ConsumerEx<T>
Serializable variant of java.util.function.Consumer which declares checked exception.
CountDownLatchPermission  
CPGroup
Contains information about a CP group.
CPGroup.CPGroupStatus
Represents status of a CP group
CPGroupDestroyedException
A CPSubsystemException which is thrown when a request is sent to a destroyed CP group.
CPGroupId
Identifier for CP groups.
CPMember
A CP member is a Hazelcast member that is internally elected to be part of the CPSubsystem, hence maintain CP data structures.
CPSession
Represents a CP session.
CPSession.CPSessionOwnerType
Represents type of endpoints that create CP sessions
CPSessionManagementService
This interface offers API for managing CP sessions.
CPSubsystem
CP Subsystem is a component of Hazelcast that builds a strongly consistent layer for a set of distributed data structures.
CPSubsystemConfig
Contains configuration options for CP Subsystem.
CPSubsystemException
Base exception for failures in CP Subsystem
CPSubsystemManagementService
This interface offers APIs for managing CP members and groups.
CRDTReplicationConfig
Configures the replication mechanism for all CRDT implementations.
Credentials
Credentials represents an identity to be authenticated.
CredentialsFactoryConfig
Contains the configuration for Credentials Factory.
CredentialsIdentityConfig
Identity configuration which just holds given credentials instance.
DataSerializable
DataSerializable is a serialization method alternative to standard Java serialization.
DataSerializableFactory
DataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization.
DefaultAuthenticationConfig
Default AuthenticationConfig implementation which just references the DefaultLoginModule.
DefaultPartitioningStrategy
A PartitioningStrategy that checks if the key implements PartitionAware.
DenyAllPermissionCollection  
DestroyEventContext<T>
Hook to decouple Hazelcast object from the tenant
DiscardMergePolicy<V,​T extends MergingValue<V>>
Merges only entries from the destination data structure and discards all entries from the source data structure.
DiscoveryConfig
This configuration class describes the top-level config of the discovery SPI and its discovery strategies.
DiscoveryMode
The DiscoveryMode describes how the DiscoveryStrategy is going to behave on discovery requests.
DiscoveryNode
A DiscoveryNode describes a nodes addresses (private and if necessary a public one) as well as attributes assigned to this node.
DiscoveryService
The DiscoveryService interface defines the basic entry point into the Discovery SPI implementation.
DiscoveryServiceProvider
The DiscoveryServiceProvider interface provides the possibility to build DiscoveryServices.
DiscoveryServiceSettings
The DiscoveryServiceSettings class is used to pass the necessary configuration to create a DiscoveryService to the DiscoveryServiceProvider.
DiscoveryStrategy
The DiscoveryStrategy itself is the actual implementation to discover nodes based on whatever environment is used to run the Hazelcast cloud.
DiscoveryStrategyConfig
This configuration class describes a DiscoveryStrategy based on a parsed XML or configured manually using the config API
DiscoveryStrategyFactory
The DiscoveryStrategyFactory is the entry point for strategy vendors.
DistributedObject
Base interface for all distributed objects.
DistributedObjectDestroyedException
A HazelcastException that indicates that a DistributedObject access was attempted, but the object is destroyed.
DistributedObjectEvent
DistributedObjectEvent is fired when a DistributedObject is created or destroyed cluster-wide.
DistributedObjectEvent.EventType
Type of the DistributedObjectEvent.
DistributedObjectListener
DistributedObjectListener notifies when a DistributedObject is created or destroyed cluster-wide.
DistributedObjectUtil
Utility class for DistributedObject.
DuplicateTaskException
An exception thrown when a task's name is already used before for another (or the same, if re-attempted) schedule.
DurableExecutorConfig
Contains the configuration for an DurableExecutorService.
DurableExecutorService
Durable implementation of ExecutorService.
DurableExecutorServiceFuture<V>
A Future where one can obtain the task ID for tracking the response.
DurableExecutorServicePermission  
Echo
Echoes to screen.
EncryptionAtRestConfig
Contains configuration for the Hot Restart Persistence at Rest encryption
EncryptionReplacer
This class is an example ConfigReplacer implementation which decrypts encrypted values.
Endpoint
Endpoint represents a peer in the cluster.
EndpointConfig
Endpoint configuration that defines communication/networking properties common to both incoming/outgoing connections eg.
EndpointQualifier
An EndpointQualifier is a (ProtocolType, String) tuple that uniquely identifies groups of network connections sharing a common ProtocolType and the same network settings, when Hazelcast is configured with AdvancedNetworkConfig enabled.
EntryAdapter<K,​V>
Adapter for MapListener.
EntryAddedListener<K,​V>
Invoked upon addition of an entry.
EntryEvent<K,​V>
Map Entry event.
EntryEventType
Type of entry event.
EntryEvictedListener<K,​V>
Invoked upon eviction of an entry.
EntryExpiredListener<K,​V>
Listener which is notified after removal of an entry due to the expiration-based-eviction.
EntryListener<K,​V>
Map Entry listener to get notified when a map entry is added, removed, updated, evicted or expired.
EntryListenerConfig
Configuration for EntryListener
EntryLoadedListener<K,​V>
Invoked upon load of an entry.
EntryLoader<K,​V>
This is an extension to MapLoader.
EntryLoader.MetadataAwareValue<V>
Represents a value with an expiration time attached to it.
EntryMergedListener<K,​V>
Invoked after WAN replicated entry is merged.
EntryProcessor<K,​V,​R>
An EntryProcessor passes you a Map.Entry.
EntryRemovedListener<K,​V>
Invoked upon removal of an entry.
EntryStore<K,​V>
This is an extension to MapStore.
EntryUpdatedListener<K,​V>
Invoked upon update of an entry.
EntryView<K,​V>
Represents a read-only view of a data structure entry.
EurekaConfig
Configuration for the Eureka Discovery Strategy.
EventJournalCacheEvent<K,​V>
The event for the cache event journal.
EventJournalConfig
Configuration for an event journal.
EventJournalMapEvent<K,​V>
The event for the map event journal.
EventLostEvent
This event is fired in case of an event lost detection.
EventLostListener
Invoked upon lost of event or events.
EvictableEntryView<K,​V>
Contract point (from the end user perspective) for serving/accessing entries that can be evicted.
EvictionConfig
Configuration for eviction.
EvictionPolicy
Eviction Policy enum.
EvictionPolicyComparator<K,​V,​E extends EvictableEntryView<K,​V>>
A kind of Comparator to be used while comparing entries to be evicted.
ExecutionCallback<V>
ExecutionCallback allows to asynchronously get notified when the execution is completed, either successfully or with error.
ExecutorConfig
Contains the configuration for an IExecutorService.
ExecutorServicePermission  
ExpirationTimeMergePolicy<V,​T extends MergingValue<V> & MergingExpirationTime>
Merges data structure entries from source to destination data structure if the source entry will expire later than the destination entry.
FencedLock
A linearizable & distributed & reentrant implementation of Lock.
FencedLockConfig
Contains configuration options for FencedLock
FieldDefinition
FieldDefinition defines name, type, index of a field
FieldType  
FileSystemXmlConfig
A Config which includes functionality for loading itself from a XML configuration file.
FileSystemYamlConfig
A Config which includes functionality for loading itself from a YAML configuration file.
FlakeIdGenerator
A cluster-wide unique ID generator.
FlakeIdGeneratorConfig
The FlakeIdGeneratorConfig contains the configuration for the member regarding Flake ID Generator.
FlakeIdGeneratorPermission  
FunctionEx<T,​R>
Serializable variant of java.util.function.Function which declares checked exception.
Functions
Factory methods for several common functions.
GcpConfig
Configuration for the GCP Discovery Strategy.
GeneratedBuildProperties
This class is generated in a build-time from a template stored at src/main/template/com/hazelcast/instance/GeneratedBuildProperties.
GlobalSerializerConfig
Contains the configuration for global serializer.
GrpcService<T,​R>
Represents a gRPC service that can be used as part of a mapUsingServiceAsync call.
GrpcServices
Provides ServiceFactory implementations for calling gRPC endpoints.
HadoopProcessors
Static utility class with factories of Apache Hadoop Hadoop source and sink processors.
HadoopSinks
Factories of Apache Hadoop sinks.
HadoopSources
Contains factory methods for Apache Hadoop sources.
Hazelcast
Factory for HazelcastInstance's, a node in a cluster.
HazelcastCacheManager
Contract point of Hazelcast cache manager implementations (client + server) based on CacheManager.
HazelcastCachingProvider
Hazelcast implementation of JCache CachingProvider.
HazelcastClient
The HazelcastClient is comparable to the Hazelcast class and provides the ability the create and manage Hazelcast clients.
HazelcastClientNotActiveException
Thrown when Hazelcast client is not active during an invocation.
HazelcastClientOfflineException
Thrown when Hazelcast client is offline during an invocation.
HazelcastException
Base Hazelcast exception.
HazelcastExpiryPolicy
Hazelcast provides overloads of the typical cache operations with a custom ExpiryPolicy parameter.
This class provides a custom implementation of an ExpiryPolicy to react on all three types of policies: Create Access Update
HazelcastInstance
Hazelcast instance.
HazelcastInstanceAware
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
HazelcastInstanceNotActiveException
Thrown when HazelcastInstance is not active during an invocation.
HazelcastJsonValue
HazelcastJsonValue is a wrapper for JSON formatted strings.
HazelcastMemberStarter
Starts a Hazelcast Member.
HazelcastOSGiInstance
Contract point for HazelcastInstance implementations based on OSGi service.
HazelcastOSGiService
Contract point for Hazelcast services on top of OSGI.
HazelcastOverloadException
A HazelcastException that is thrown when the system won't handle more load due to an overload.
HazelcastProperties
Container for configured Hazelcast properties (see HazelcastProperty).
HazelcastProperty
Interface for Hazelcast Member and Client properties.
HazelcastRuntimePermission
Class which holds named Hazelcast permissions for Security Manager checks.
HazelcastSerializationException
This is an exception thrown when an exception occurs while serializing/deserializing objects.
HazelcastXAResource
Interface for providing Hazelcast as an XAResource
HeartbeatAware
SplitBrainProtectionFunctions which implement this interface will be notified of member heartbeats.
HigherHitsMergePolicy<V,​T extends MergingValue<V> & MergingHits>
Merges data structure entries from source to destination data structure if the source entry has more hits than the destination one.
HotRestartClusterDataRecoveryPolicy
Specifies the policy that will be respected during hot restart cluster start
HotRestartConfig
Configures the Hot Restart Persistence per Hazelcast data structure.
HotRestartPersistenceConfig
Configures the Hot Restart stores.
HotRestartService
Service for interacting with Hot Restart.
HyperLogLogMergePolicy
Only available for HyperLogLog backed CardinalityEstimator.
IAtomicLong
IAtomicLong is a redundant and highly available distributed alternative to the AtomicLong.
IAtomicReference<E>
IAtomicReference is a redundant and highly available distributed alternative to the AtomicReference.
ICache<K,​V>
This ICache interface is the Cache extension offered by Hazelcast JCache.
In addition to the standard set of JCache methods defined in the JSR 107 specification, Hazelcast provides additional operations to support a broader range of programing styles.
ICacheManager
ICacheManager is the entry point to access JSR-107 (JCache) caches via HazelcastInstance interface.
IcmpFailureDetectorConfig
This Failure Detector may be configured in addition to one of Deadline and Phi Accual Failure Detectors.
It operates at Layer 3 of the OSI protocol, and provides much quicker and more deterministic detection of hardware
and other lower level events.
ICollection<E>
Concurrent, distributed, partitioned, listenable collection.
ICountDownLatch
ICountDownLatch is a backed-up distributed alternative to the java.util.concurrent.CountDownLatch.
ICredentialsFactory
ICredentialsFactory is used to create Credentials objects to be used during node authentication before connection is accepted by the master node.
IdentifiedDataSerializable
IdentifiedDataSerializable is an extension to DataSerializable to avoid reflection during de-serialization.
IdentityConfig
This interface represents identity configuration in security realms or client security configurations.
IExecutorService
Distributed implementation of ExecutorService.
IFunction<T,​R>
Represents a function that accepts one argument and produces a result.
IList<E>
Concurrent, distributed implementation of List.
ILogger
The Hazelcast logging interface.
IMap<K,​V>
Concurrent, distributed, observable and queryable map.
IMapEvent
Map events common contract.
IndeterminateOperationState
A marker interface for exceptions to denote that execution status of an invocation is not known
IndeterminateOperationStateException
IndeterminateOperationStateException is thrown when result of an invocation becomes indecisive.
IndexConfig
Configuration of an index.
IndexType
Type of the index.
InitialMembershipEvent
An event that is sent when a InitialMembershipListener registers itself on a Cluster.
InitialMembershipListener
The InitializingMembershipListener is a MembershipListener that first receives a InitialMembershipEvent when it is registered so it immediately knows which members are available.
InMemoryFormat
Storage format type of values stored in cluster
InMemoryXmlConfig
Creates a Config loaded from an in-memory Hazelcast XML String.
InMemoryYamlConfig
Creates a Config loaded from an in-memory Hazelcast YAML String.
InstancePermission
TODO: Object Permission
InterfacesConfig
Contains the configuration for Interfaces.
InvalidConfigurationException
A InvalidConfigurationException is thrown when an Hazelcast faces an invalid configuration.
IPermissionPolicy
IPermissionPolicy is used to determine any Subject's permissions to perform a security sensitive Hazelcast operation.
IQueue<E>
Concurrent, blocking, distributed, observable queue.
IScheduledExecutorService
Distributed & durable implementation similar to, but not directly inherited ScheduledExecutorService.
IScheduledFuture<V>
A delayed result-bearing action that can be cancelled.
ISemaphore
ISemaphore is a fault-tolerant distributed alternative to the Semaphore.
ISet<E>
Concurrent, distributed implementation of Set
ItemEvent<E>
Event for a collection item.
ItemEventType
Type of item events.
ItemListener<E>
Item listener for IQueue, ISet and IList
ItemListenerConfig
Contains the configuration for an Item Listener.
ITopic<E>
Hazelcast provides distribution mechanism for publishing messages that are delivered to multiple subscribers, which is also known as a publish/subscribe (pub/sub) messaging model.
JaasAuthenticationConfig
This AuthenticationConfig implementation is a imple holder for login module configurations.
JavaKeyStoreSecureStoreConfig
Java KeyStore Secure Store configuration.
JavaSerializationFilterConfig
Configuration for Serialization Filter.
JetBuildInfo  
JetClientBeanDefinitionParser
BeanDefinitionParser for Hazelcast Jet Client Configuration.
JetCommandLine  
JetCommandLine.JetVersionProvider  
JetCommandLine.Verbosity  
JetHazelcastBeanDefinitionParser
BeanDefinitionParser for Hazelcast Instance created via Jet Instance.
JetInstanceBeanDefinitionParser
BeanDefinitionParser for Hazelcast Jet Instance Configuration.
JetMemberStarter
Main class that starts a Hazelcast Jet instance.
JetNamespaceHandler
Hazelcast Jet Custom Namespace Definitions.
JetSpringServiceFactories
Utility class with methods that create several useful Spring Bean service factories and transform functions.
JoinConfig
Contains the 3 different join configurations; TCP-IP/multicast/AWS.
KafkaProcessors
Static utility class with factories of Apache Kafka source and sink processors.
KafkaSinks
Contains factory methods for Apache Kafka sinks.
KafkaSinks.Builder<E>
A builder for Kafka sink.
KafkaSources
Contains factory methods for Apache Kafka sources.
KubernetesConfig
Configuration for the Kubernetes Discovery Strategy.
LatestAccessMergePolicy<V,​T extends MergingValue<V> & MergingLastAccessTime>
Merges data structure entries from source to destination data structure if the source entry has been accessed more recently than the destination entry.
LatestUpdateMergePolicy<V,​T extends MergingValue<V> & MergingLastUpdateTime>
Merges data structure entries from source to destination data structure if the source entry was updated more frequently than the destination entry.
LdapAuthenticationConfig
Typed authentication configuration for BasicLdapLoginModule and LdapLoginModule.
LdapRoleMappingMode
Enum for LDAP role mapping modes.
LdapSearchScope
Search scope types for LDAP queries.
LeaderDemotedException
A CPSubsystemException which is thrown when an appended but not-committed entry is truncated by the new leader.
LifecycleEvent
Lifecycle events are fired when the HazelcastInstance state changes.
LifecycleEvent.LifecycleState
Lifecycle states
LifecycleListener
Listener object for listening to lifecycle events of the Hazelcast instance
LifecycleService
LifecycleService allows you to shutdown, terminate, and listen to LifecycleEvents on HazelcastInstance.
LineReader
Reads a line of input.
ListConfig
Contains the configuration for an IList.
ListenerConfig
Contains the configuration for an EventListener.
ListPermission  
LoadBalancer
LoadBalancer allows you to send operations to one of a number of endpoints(Members).
LocalExecutorStats
Local executor service statistics.
LocalIndexStats
Provides local statistics for an index to be used by MemberState implementations.
LocalInstanceStats
Base interface for local instance statistics.
LocalMapStats
Local map statistics to be used by MemberState implementations.
LocalMemberResetException
An exception provided to MemberLeftException as a cause when the local member is resetting itself
LocalMultiMapStats
Local multi map statistics to be used by MemberState implementations.
LocalQueueStats
Local queue statistics to be used by MemberState implementations.
LocalReplicatedMapStats
Local replicated map statistics to be used by MemberState implementations.
LocalTopicStats
Local topic statistics to be used by MemberState implementations.
LockAcquireLimitReachedException
Thrown when the current lock holder could not acquired the lock reentrantly because the configured lock acquire limit is reached.
LockAware
Determines if the object implementing this interface is locked or not.
LockOwnershipLostException
Thrown when an endpoint (either a Hazelcast server or a client) interacts with a FencedLock instance after its CP session is closed in the underlying CP group and its lock ownership is cancelled.
LockPermission  
Log4j2Factory
Logging to Log4j 2.x.
Log4j2Factory.Log4j2Logger  
Log4jFactory  
LogEvent  
Logger
Provides static utilities to access the global shared logging machinery.
LoggerFactory  
LoggerFactorySupport  
LoggingService  
LoginModuleConfig
Configuration for Login Module
LoginModuleConfig.LoginModuleUsage
Usage of Login Module
LogListener  
ManagedContext
Container managed context, such as Spring, Guice and etc.
ManagementCenterConfig
Contains the configuration for Hazelcast Management Center.
MapClearedListener
Invoked after all entries are removed by IMap.clear().
MapConfig
Contains the configuration for an IMap.
MapEvent
Used for map-wide events like EntryEventType.EVICT_ALL and EntryEventType.CLEAR_ALL.
MapEvictedListener
Invoked after all entries are evicted by IMap.evictAll().
MapEvictionPolicyComparator<K,​V>
IMap specific EvictionPolicyComparator for comparing EntryViews to be evicted.
MapInterceptor
MapInterceptor is used to intercept changes to the map, allowing access to the values before and after adding them to the map.
MapListener
A marker interface which is used to get notified upon a map or an entry event.
MapLoader<K,​V>
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
Provides Lifecycle support for the implementing MapLoader class.
MapPartitionLostEvent
Used for providing information about the lost partition for a map
MapPartitionLostListener
Invoked when owner and all backups of a partition is lost for a specific map.
MapPartitionLostListenerConfig
Configuration for MapPartitionLostListener
MapPermission  
MapStore<K,​V>
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>
Adapter for MapStore.
MapStoreConfig
Contains the configuration for a Map Store.
MapStoreConfig.InitialLoadMode
Initial load module
MapStoreFactory<K,​V>
Factory for MapLoader or MapStore instances, specifiable in MapStoreConfig.
MatchingPointConfigPatternMatcher
This ConfigPatternMatcher supports a simplified wildcard matching.
MaxSizePolicy
Maximum Size Policy
Member
Cluster member interface.
MemberAddressProvider
IMPORTANT This interface is not intended to provide addresses of other cluster members with which the hazelcast instance will form a cluster.
MemberAddressProviderConfig
Configuration for a custom MemberAddressProvider strategy.
MemberAttributeConfig
Contains configuration for attribute of member.
MemberGroup
A collection of members to which a single partition replica can be assigned.
MemberGroupConfig
Contains the configuration for a single member group.
MemberLeftException
A ExecutionException thrown when a member left during an invocation or execution.
MemberSelector
Implementations of this interface 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 is up to the implementation to decide if the member is going to be used or not.
MemberSelectors
A utility class to get MemberSelector instances.
MembershipAdapter
Adapter for MembershipListener.
MembershipEvent
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster and similar methods.
MembershipListener
Cluster membership listener.
MemberSocketInterceptor
Member Socket Interceptor can be registered via see SocketInterceptorConfig Warning: a MemberSocketInterceptor provides access to the socket and will bypass any TLS encryption.
MemberVersion
Determines the Hazelcast codebase version in terms of major.minor.patch version.
MemcacheProtocolConfig
This class allows to enable MEMCACHE text protocol support in Hazelcast.
MemorySize
MemorySize represents a memory size with given value and MemoryUnit.
MemoryUnit
MemoryUnit represents memory size at a given unit of granularity and provides utility methods to convert across units.
MergePolicyConfig
Configuration for SplitBrainMergePolicy.
MergingCosts
Represents a read-only view of memory costs for the merging process after a split-brain.
MergingCreationTime
Represents a read-only view a creation time for the merging process after a split-brain.
MergingEntry<K,​V>
Represents a read-only view of a data structure key/value-pair for the merging process after a split-brain.
MergingExpirationTime
Represents a read-only view of an expiration time for the merging process after a split-brain.
MergingHits
Represents a read-only view access hits for the merging process after a split-brain.
MergingLastAccessTime
Represents a read-only view of a last access time for the merging process after a split-brain.
MergingLastStoredTime
Represents a read-only view of a last stored time for the merging process after a split-brain.
MergingLastUpdateTime
Represents a read-only view of a last update time for the merging process after a split-brain.
MergingMaxIdle
Represents a read-only view of a MaxIdle for the merging process after a split-brain.
MergingTTL
Represents a read-only view of a TTL for the merging process after a split-brain.
MergingValue<V>
Represents a read-only view of a data structure value for the merging process after a split-brain.
MergingVersion
Represents a read-only view of a version for the merging process after a split-brain.
MergingView
Marker interface representing a read-only view of a data structure for the merging process after a split-brain.
MerkleTreeConfig
Configuration for a merkle tree.
Message<E>
Message for ITopic.
MessageListener<E>
Message listener for ITopic.
MetadataPolicy
Hazelcast may process objects of supported types ahead of time to create additional metadata about them.
MetricsConfig
Member-side metrics collection configuration.
MetricsJmxConfig
JMX related metrics configuration.
MetricsManagementCenterConfig
Management Center related metrics configuration.
MigrationListener
MigrationListener provides the ability to listen to partition migration process and events.
MigrationState
MigrationState shows statistical information about the migration, such as; migration start time, number of planned replica migrations, number of completed replica migrations, total elapsed migration time etc.
MulticastConfig
Contains the configuration for the multicast discovery mechanism.
MulticastDiscoveryStrategy
The multicast DiscoveryStrategy.
MulticastDiscoveryStrategyFactory
Factory class which returns MulticastDiscoveryStrategy to Discovery SPI
MulticastProperties
Defines the name and default value for the Multicast Discovery Strategy.
MultiExecutionCallback
MultiExecutionCallback provides notification for when an execution is completed on each member that a task is submitted to.
MultiMap<K,​V>
A specialized map whose keys can be associated with multiple values.
MultiMapConfig
Configuration for MultiMap.
MultiMapConfig.ValueCollectionType
Type of value collection
MultiMapPermission  
MutationDisallowedException
Exception that indicates that the state found on this replica disallows mutation.
NamedConfig
Interface for hazelcast data structures with name
NamedTask
The NamedTask interface should be implemented by any task that needs to have an identification and enhanced atomicity upon scheduling the task.
NativeMemoryConfig
Configures native memory region.
NativeMemoryConfig.MemoryAllocatorType
Type of memory allocator: STANDARD: allocate/free memory using default OS memory manager POOLED: manage memory blocks in pool
NativeOutOfMemoryError
Thrown when Hazelcast cannot allocate required native memory.
NearCacheConfig
Contains the configuration for a Near Cache.
NearCacheConfig.LocalUpdatePolicy
Defines how to reflect local updates to the Near Cache.
NearCacheConfigAccessor
Accessor for the EvictionConfig of a NearCacheConfig to initialize the old default max size, if no size was configured by the user.
NearCachePreloaderConfig
Configuration for storing and pre-loading Near Cache keys.
NearCacheStats
Near Cache statistics to be used by MemberState implementations.
NetworkConfig
Contains configuration for Network.
NoDataMemberInClusterException
Thrown when there is no data member in the cluster to assign partitions.
NodeFilter
The NodeFilter, if supplied, will retrieve all discovered nodes and might apply additional filtering based on vendor provided metadata.
NoLogFactory  
NotLeaderException
A CPSubsystemException which is thrown when a leader-only request is received by a non-leader member.
ObjectDataInput
Provides serialization methods for arrays of primitive types.
ObjectDataOutput
Provides serialization methods for arrays by extending DataOutput
Offloadable
Allows off-loading the processing unit implementing this interface to the specified or default Executor.
OnJoinPermissionOperationName
Enum of operation names for handling client permissions when the member is joining into the cluster.
OperationTimeoutException
An unchecked version of TimeoutException.
OutOfMemoryHandler
Handler for OutOfMemoryError.
OverflowPolicy
Using this policy one can control the behavior what should to be done when an item is about to be added to the ringbuffer, but there is 0 remaining capacity.
PagingPredicate<K,​V>
This interface is a special Predicate which helps to get a page-by-page result of a query.
Parameters
This interface is used to pass parameters of a method call to a SecurityInterceptor.
Partition
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count' ClusterProperty.
PartitionAware<T>
PartitionAware means that data will be based in the same member based on the partition key and implementing tasks will be executed on the PartitionAware.getPartitionKey()'s owner member.
PartitionAwareKey<K,​P>
PartitionEvent
PartitionEvent is a base interface for partition related events.
PartitionGroupConfig
With PartitionGroupConfig, you can control how primary and backup partitions are mapped to physical Members.
PartitionGroupConfig.MemberGroupType
Type of member groups.
PartitionGroupMetaData
This class contains the definition of known Discovery SPI metadata to support automatic generation of zone aware backup strategies based on cloud or service discovery provided information.
PartitionGroupStrategy
A PartitionGroupStrategy implementation defines a strategy how backup groups are designed.
PartitioningStrategy<K>
PartitioningStrategy allows keys to be located on the same member.
PartitioningStrategyConfig
Contains the configuration for partitioning strategy.
PartitionLostEvent
The event that is fired when a partition lost its owner and all backups.
PartitionLostListener
PartitionLostListener provides the ability to be notified upon a possible data loss when a partition loses a replica.
PartitionMigratingException
A RetryableHazelcastException that is thrown when an operation is executed on a partition, but that partition is currently being moved around.
PartitionPredicate<K,​V>
A Predicate that restricts the execution of a Predicate to a single Partition.
PartitionService
PartitionService allows you to query Partitions and attach/detach MigrationListeners to listen to partition migration events.
PassThroughMergePolicy<V,​T extends MergingValue<V>>
Merges data structure entries from source to destination directly unless the merging entry is null.
PasswordCredentials
Credentials type for name/password representation.
PermissionConfig
Contains the configuration for a permission.
PermissionConfig.PermissionType
Type of permission
PermissionPolicyConfig
Contains the configuration for policy of permission
PingAware
Split brain protection functions that need access to ICMP ping failure detector should implement this interface; the instance of PingFailureDetector used by this member's ClusterHeartbeatManager will be provided on initialization.
Pipelining<E>
The Pipelining can be used to speed up requests.
PNCounter
PN (Positive-Negative) CRDT counter.
PNCounterConfig
Configuration for a PNCounter
PNCounterPermission  
Portable
Portable provides an alternative serialization method.
PortableFactory
PortableFactory is used to create Portable instances during de-serialization.
PortableReader
Provides a mean of reading portable fields from a binary in form of java primitives arrays of java primitives, nested portable fields and array of portable fields.
PortableWriter
Provides a mean of writing portable fields to a binary in form of java primitives arrays of java primitives, nested portable fields and array of portable fields.
PostProcessingMapStore
Implement this interface if you modify the value in MapStore.store(K key, V value) method.
Predicate<K,​V>
Represents a map entry predicate.
PredicateBuilder
This interface provides functionality to build a predicate.
PredicateBuilder.EntryObject
This interface provides entry-level functionality related to building a predicate.
PredicateConfig
Contains the configuration for an Predicate.
PredicateEx<T>
Serializable variant of java.util.function.Predicate which declares checked exception.
Predicates
A utility class to create new PredicateBuilder and Predicate instances.
PrefixedDistributedObject
Contact point for special DistributedObject's which has prefixed name.
PrivateApi
Marker for private functionality.
ProbabilisticSplitBrainProtectionConfigBuilder
Builder for a SplitBrainProtectionConfig configured with ProbabilisticSplitBrainProtectionFunction that considers members present in the context of a split brain protection using a probabilistic, adaptive split brain protection function.
Projection<I,​O>
Enables transforming object into other objects.
Projections
A utility class to create basic Projection instances.
PropertyDefinition
This interface describes an extended approach of the currently available pure property based configuration inside Hazelcast and helps implementing an automatic and transparent way to verify configuration as well as converting types based on provided validators and converters.
PropertyReplacer
ConfigReplacer for replacing property names with property values for properties provided in PropertyReplacer.init(Properties) method.
PropertyTypeConverter
This enum class contains basic TypeConverter implementations to convert strings to all common basic Java types.
ProtobufSerializer<T extends com.google.protobuf.GeneratedMessageV3>
Adapts a generated Google Protocol Buffers v3 serializer class to the Hazelcast StreamSerializer interface.
ProtobufSerializerHook<T extends com.google.protobuf.GeneratedMessageV3>
Simplifies using the Hazelcast Serializer Hook mechanism to register a Google Protocol Buffers serializer with the Hazelcast Jet cluster.
ProtocolType
Types of server sockets.
ProxyFactoryConfig
This class is related to SPI.
PutIfAbsentMergePolicy<V,​T extends MergingValue<V>>
Merges data structure entries from source to destination if they don't exist in the destination data structure.
PythonServiceConfig
Configuration object for the Python service factory, used in a mapUsingPython stage.
PythonTransforms
Transforms which allow the user to call Python user-defined functions from inside a Jet pipeline.
QueryCache<K,​V>
A concurrent, queryable data structure which is used to cache results of a continuous query executed on an IMap.
QueryCacheConfig
Contains configuration for QueryCache.
QueryConstants
Contains constants for Query.
QueryException
Exception class for the Query.
QueryResultSizeExceededException
This exception is thrown when a query exceeds a configurable result size limit.
QueueConfig
Contains the configuration for an IQueue.
QueuePermission  
QueueStore<T>
QueueStore makes a queue backed by a central data store; such as database, disk, etc.
QueueStoreConfig
Configuration for the QueueStore.
QueueStoreFactory<T>
Creates a new QueueStore.
RaftAlgorithmConfig
Configuration for Hazelcast's implementation of the Raft consensus algorithm
RandomLB
A LoadBalancer that selects a random member to route to.
ReachedMaxSizeException
Exception thrown when a write-behind MapStore rejects to accept a new element.
ReadOnly
Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
ReadResultSet<E>
RealmConfig
Security realm represents the security configuration for part of the system (e.g.
RecentlyActiveSplitBrainProtectionConfigBuilder
Builder for a SplitBrainProtectionConfig configured with RecentlyActiveSplitBrainProtectionFunction that considers members present in the context of a split brain protection if the last received heartbeat is within a recent window of time.
RegexConfigPatternMatcher
This ConfigPatternMatcher uses Java regular expressions for matching.
ReliableMessageListener<E>
A MessageListener to better integrate with the reliable topic.
ReliableTopicConfig
Configuration for a reliable ITopic.
ReliableTopicPermission  
ReplicaMigrationEvent
An event fired when a partition replica migration completes or fails.
ReplicatedMap<K,​V>
A ReplicatedMap is a map-like data structure with weak consistency and values locally stored on every node of the cluster.
ReplicatedMapCantBeCreatedOnLiteMemberException
Thrown when HazelcastInstance.getReplicatedMap(String) is invoked on a lite member.
ReplicatedMapConfig
Contains the configuration for an ReplicatedMap
ReplicatedMapPermission  
ResponseAlreadySentException
A HazelcastException indicating that there is some kind of system error causing a response to be send multiple times for some operation.
RestApiConfig
This class allows to control which parts of Hazelcast REST API will be enabled.
RestEndpointGroup
Enum of REST endpoint groups.
RestServerEndpointConfig
Server socket endpoint config specialized for REST service Allows configuring access to REST groups similar to RestApiConfig
RetryableException
Marker interface for exceptions to indicate that an operation can be retried.
RetryableHazelcastException
A 'marker' exception that indicates that an operation can be retried.
RetryableIOException
A IOException indicating that there was a IO failure, but it can be retried.
Ringbuffer<E>
A Ringbuffer is a data structure where the content is stored in a ring-like structure.
RingbufferConfig
Contains the configuration for the Ringbuffer.
RingbufferMergeData
A ringbuffer implementation holding data involved in split-brain healing.
RingbufferMergeDataReadOnlyIterator<E>
Read-only iterator over items in a provided RingbufferMergeData.
RingBufferPermission  
RingbufferStore<T>
Ringbuffer store makes a ring buffer backed by a central data store; such as database, disk, etc.
RingbufferStoreConfig
Configuration for the RingbufferStore.
RingbufferStoreFactory<T>
Creates a new RingbufferStore.
RoundRobinLB
A LoadBalancer implementation that relies on using round robin to a next member to send a request to.
RuntimeInterruptedException
An unchecked version of InterruptedException.
S3Sinks
Contains factory methods for creating AWS S3 sinks.
S3Sources
Contains factory methods for creating AWS S3 sources.
ScheduledExecutorConfig
Configuration options for the IScheduledExecutorService.
ScheduledExecutorConfig.CapacityPolicy
Capacity policy options
ScheduledExecutorPermission  
ScheduledTaskHandler
Resource handler pointing to a IScheduledFuture.
ScheduledTaskStatistics
Statistics and timing info for a IScheduledFuture accessible through IScheduledFuture.getStats()
SecureCallable<V>
A secure callable that runs in a sandbox.
SecureStoreConfig
Abstract Secure Store configuration class.
SecurityConfig
Contains configuration for Security
SecurityContext
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.
SecurityInterceptor
This interface allows to intercept requests which were produced by an API call like map.put, queue.offer...
SecurityInterceptorConfig
This class is used to configure SecurityInterceptor
SecurityService
Provides necessary methods to initiate security related config changes.
SemaphoreConfig
Contains configuration options for CP ISemaphore
SemaphorePermission  
SerializationConfig
Contains the serialization configuration of HazelcastInstance.
Serializer
Base interface of custom serialization interfaces
SerializerConfig
Contains the serialization configuration for a particular class.
SerializerHook<T>
This interface is used to automatically register serializers from external Hazelcast or user modules.
Both types of Serializers are supported (StreamSerializer and ByteArraySerializer).
ServerSocketEndpointConfig
Endpoint configuration that defines a listening side (server)
ServiceConfig
Configuration for a single service.
ServiceNotFoundException
A HazelcastException that indicates that a requested service is not exist.
SetConfig
Contains the configuration for an ISet.
SetPermission  
SilentException
Marked interface for exceptions.
SimpleDiscoveryNode
Simple immutable implementation of the DiscoveryNode interface for convenience when implementing a DiscoveryStrategy.
SimplePropertyDefinition
Simple immutable implementation of PropertyDefinition for convenience of implementors.
SimpleTokenCredentials
Simple implementation of Credentials using a raw byte array token.
SimulateLoadTask
A simulated load test.
Slf4jFactory  
SocketInterceptor
An interface that provides the ability to intercept the creation of sockets.
SocketInterceptorConfig
Contains the configuration for interceptor socket.
SocketOptions
TCP Socket options
SplitBrainMergePolicy<V,​T extends MergingValue<V>,​R>
Policy for merging data structure values after a split-brain has been healed.
SplitBrainMergePolicyProvider
A provider for SplitBrainMergePolicy instances.
SplitBrainMergeTypes
Collection of interfaces which define the provided merge types for each data structure.
SplitBrainMergeTypes.AtomicLongMergeTypes
Provided merge types of IAtomicLong.
SplitBrainMergeTypes.AtomicReferenceMergeTypes
Provided merge types of IAtomicReference.
SplitBrainMergeTypes.CacheMergeTypes<K,​V>
Provided merge types of ICache.
SplitBrainMergeTypes.CardinalityEstimatorMergeTypes
Provided merge types of CardinalityEstimator.
SplitBrainMergeTypes.CollectionMergeTypes<V>
Provided merge types of collections (ISet and IList).
SplitBrainMergeTypes.MapMergeTypes<K,​V>
Provided merge types of IMap.
SplitBrainMergeTypes.MultiMapMergeTypes<K,​V>
Provided merge types of MultiMap.
SplitBrainMergeTypes.QueueMergeTypes<V>
Provided merge types of IQueue.
SplitBrainMergeTypes.ReplicatedMapMergeTypes<K,​V>
Provided merge types of ReplicatedMap.
SplitBrainMergeTypes.RingbufferMergeTypes
Provided merge types of Ringbuffer.
SplitBrainMergeTypes.ScheduledExecutorMergeTypes
Provided merge types of IScheduledExecutorService.
SplitBrainProtection
SplitBrainProtection provides access to the current status of a split brain protection.
SplitBrainProtectionConfig
Configuration for cluster split brain protection, a means to protect consistency of data from network partitions.
SplitBrainProtectionConfigBuilder
Commons for split brain protection config builders.
SplitBrainProtectionEvent
An Event that is send when a SplitBrainProtection changes.
SplitBrainProtectionException
An exception thrown when the cluster size is below the defined threshold.
SplitBrainProtectionFunction
A function that can be used to conclude whether the minimum cluster size property is satisfied? The split brain protection function is consulted:
When a cluster membership change occurs (member added or removed) Whenever a hearbeat is received from a member, in case the SplitBrainProtectionFunction also implements HeartbeatAware A SplitBrainProtectionFunction that implements HeartbeatAware will be also notified of heartbeats.
SplitBrainProtectionListener
Listener to get notified when a split brain protection state is changed
SplitBrainProtectionListenerConfig
Configuration class for SplitBrainProtectionListener
SplitBrainProtectionOn
Represents a cluster split brain protection type
SplitBrainProtectionService
Split brain protection service can be used to trigger cluster split brain protections at any time.
SSLConfig
SSL configuration.
SSLContextFactory
Factory class for creating SSLContext
StaleAppendRequestException
A CPSubsystemException which is thrown when a Raft leader node appends an entry to its local Raft log, but demotes to the follower role before learning the commit status of the entry.
StaleSequenceException
An RuntimeException that is thrown when accessing an item in the Ringbuffer using a sequence that is smaller than the current head sequence and that the ringbuffer store is disabled.
StaleTaskException
Exception thrown by the IScheduledFuture during any operation on a stale (=previously destroyed) task.
StaleTaskIdException
An RuntimeException that is thrown when retrieving the result of a task via DurableExecutorService if the result of the task is overwritten.
StandardLoggerFactory  
StatefulTask<K,​V>
An interface to provide means for saving & loading state for Runnable and Callable tasks scheduled with an IScheduledExecutorService.
StaticCredentialsFactory
The credentials factory implementation which just takes credentials in a constructor and provides it for every StaticCredentialsFactory.newCredentials() call.
StaticLB
The StaticLB is a LoadBalancer that always returns the same member.
StreamSerializer<T>
A base class for custom serialization.
StringAndPartitionAwarePartitioningStrategy  
StringPartitioningStrategy  
SupplierEx<T>
Serializable variant of java.util.function.Supplier which declares checked exception.
SymmetricEncryptionConfig
Contains configuration for symmetric encryption
TargetDisconnectedException
Thrown when a client invocation is failed because related target is disconnected and whether the invocation is run or not, is indeterminate
TargetNotMemberException
A RetryableHazelcastException that indicates operation was sent to a machine that isn't member of the cluster.
TargetNotReplicaException
Exception that indicates that the receiver of a CRDT operation is not a CRDT replica.
TaskUtils
A helper class with utilities to act upon Runnable and/or Callable tasks.
TcpIpConfig
Contains the configuration for the Tcp/Ip join mechanism.
TenantControl
Hooks for multi-tenancy for application servers Hazelcast uses separate threads to invoke operations this interface acts a hook to establish a thread-local tenant context so that operation invocations into application servers are handled correctly This is used by application servers to establish thread context for class loading, CDI, EJB and JPA invocations
TenantControlFactory
A TenantControlFactory supplies TenantControl objects when Hazelcast service attaches the tenant control to a distributed object.
TlsAuthenticationConfig
Typed authentication configuration for the X509CertificateLoginModule.
ToDoubleFunctionEx<T>
Serializable variant of java.util.function.ToDoubleFunction which declares checked exception.
ToIntFunctionEx<T>
Serializable variant of java.util.function.ToIntFunction which declares checked exception.
TokenCredentials
Credentials type for custom authentication (token based).
TokenEncoding
Possible token encodings.
TokenIdentityConfig
Simple token identity configuration.
ToLongFunctionEx<T>
Serializable variant of java.util.function.ToLongFunction which declares checked exception.
TopicConfig
Contains the configuration for a ITopic.
TopicOverloadException
A HazelcastException thrown when a publisher wants to write to a topic, but there is not sufficient storage to deal with the event.
TopicOverloadPolicy
A policy to deal with an overloaded topic; so topic where there is no place to store new messages.
TopicPermission  
TransactionalList<E>
Transactional implementation of IList.
TransactionalMap<K,​V>
Transactional implementation of BaseMap.
TransactionalMultiMap<K,​V>
Transactional implementation of BaseMultiMap.
TransactionalObject
Marker interface for all transactional distributed objects.
TransactionalQueue<E>
Transactional implementation of BaseQueue.
TransactionalSet<E>
Transactional implementation of ISet.
TransactionalTask<T>
Contains the logic that is going to be executed within a transaction.
TransactionalTaskContext
Provides a context to access transactional data-structures, like the TransactionalMap.
TransactionContext
Provides a context to perform transactional operations: beginning/committing transactions, but also retrieving transactional data-structures like the TransactionalMap.
TransactionException
A HazelcastException that is thrown when something goes wrong while dealing with transactions and transactional data-structures.
TransactionManagerService  
TransactionNotActiveException
A HazelcastException thrown when an a transactional operation is executed without an active transaction.
TransactionOptions
Contains the configuration for a Hazelcast transaction.
TransactionOptions.TransactionType
The type of transaction.
TransactionPermission  
TransactionTimedOutException
Thrown when a transaction has timed out.
TypeConverter
Implementations of this interface define a certain type conversation.
TypedByteArrayDeserializer<T>
This interface allows deserialization of a binary data with a provided class type.
TypedDataSerializable
This interface adds the possibility for the class to act as if it is another class when being deserialized using DataSerializable
TypedStreamDeserializer<T>
This interface allows deserialization of a binary data with a provided class type.
UndefinedErrorCodeException
This exception is thrown when an exception that is coming from server is not recognized by the protocol.
UrlXmlConfig
A Config which is loaded using some url pointing to a Hazelcast XML file.
UrlYamlConfig
A Config which is loaded using some url pointing to a Hazelcast YAML file.
UserCodeDeploymentConfig
Configuration of User Code Deployment.
UserCodeDeploymentConfig.ClassCacheMode
Controls caching of classes loaded from remote members
UserCodeDeploymentConfig.ProviderMode
Controls how to react to receiving a classloading request from a remote member
UserCodeDeploymentPermission  
UsernamePasswordCredentials
Simple implementation of PasswordCredentials using name and password as security attributes.
UsernamePasswordIdentityConfig
Simple username/password identity configuration.
ValidationException
This exception is thrown from ValueValidator implementations whenever the validation has not succeed for any reason.
ValueCallback<T>
Enables notifying about values extracted in a ValueExtractor
ValueCollector<T>
Enables collecting values extracted in a ValueExtractor
ValueExtractor<T,​A>
Common superclass for all extractors that enable the user to define custom attributes and extract their values.
ValueReader
Enables reading the value of the attribute specified by the path
ValueReadingException
Exception thrown if there is any checked or unchecked exception caught in the value reading in ValueReader
ValueValidator<T extends Comparable<T>>
This interface defines a certain validation logic implementation to test if a given value is expected to be correct or not.
VaultSecureStoreConfig
HashiCorp Vault Secure Store configuration.
Version
A generic version to be used with VersionAware classes.
VersionAware
An instance which supports versioning.
VersionedPortable
VersionedPortable is an extension to Portable to support per class version instead of a global serialization version.
WanAcknowledgeType
Determines acknowledge waiting type of wan replication operation invocation.
WanBatchPublisherConfig
Configuration object for the built-in WAN publisher (available in Hazelcast Enterprise).
WanConsumer
Interface to be implemented by custom WAN event consumers.
WanConsumerConfig
Config for processing WAN events received from a target cluster.
WanCustomPublisherConfig
Configuration object for a custom WAN publisher.
WanEvent<T>
Interface for all WAN replication messages
WanEventCounters
Counters for WAN events for a single distributed object type (map or cache).
WanEventCounters.DistributedObjectWanEventCounters
Counters for WAN events for a single map or cache.
WanEventType
The type of the WAN event, signifies the type of the mutation that occurred that caused the WAN event.
WanMigrationAwarePublisher<T>
Interface for WAN publisher migration related events.
WanProtocolVersionAware
An instance which is used in WAN and supports versioning.
WanPublisher<T>
This interface offers the implementation of different kinds of replication techniques like TCP, UDP or maybe even an JMS based service.
WanPublisherState
Defines the state in which a WAN publisher can be in if it is not shutting down.
WanQueueFullBehavior
Determines the behavior of WAN replication impl.
WanQueueFullException
A HazelcastException that is thrown when the wan replication queues are full This exception is only thrown when WAN is configured with WanQueueFullBehavior.THROW_EXCEPTION
WanReplicationConfig
Configuration for WAN replication.
WanReplicationRef
Configuration for a WAN target replication reference.
WanSyncConfig
Configuration object for the WAN sync mechanism.
WildcardConfigPatternMatcher
This ConfigPatternMatcher supports a simplified wildcard matching.
WrongTargetException
A RetryableHazelcastException indicating that an operation is executed on a wrong member.
XmlClientConfigBuilder
Loads the ClientConfig using XML.
XmlClientFailoverConfigBuilder
Loads the ClientFailoverConfig using XML.
XmlConfigBuilder
A XML ConfigBuilder implementation.
YamlClientConfigBuilder
Loads the ClientConfig using YAML.
YamlClientFailoverConfigBuilder
Loads the ClientFailoverConfig using YAML.
YamlConfigBuilder
A YAML ConfigBuilder implementation.