All Classes and Interfaces
Class
Description
Configuration base for config types with a factory class and its properties.
Common configuration shared by authentication modules provided out-of-the box in Hazelcast.
A 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.Configuration base for config types with a factory class and its properties.
The abstract class for a map event
IMapEvent
.Abstract
ILogger
implementation that provides implementations for convenience methods like
finest, info, warning and severe.The common parent for
ConfigReplacer
implementations which allow to mask values by encrypting the value.Base class for symmetric encryption configuration classes.
Contains logic for replacing system variables in the XML file and importing XML files from different locations.
Contains Hazelcast XML Configuration helper methods and variables.
Contains logic for replacing system variables in the YAML file and importing YAML files from different locations.
Represents an address of a member in the cluster.
Defines a contract for all aggregators.
A utility class to create basic
Aggregator
instances.This interface represents authentication configuration in a security realm.
A
HazelcastException
that is thrown when there is an Authentication failure: e.g.Configuration for the Discovery Strategy Auto Detection.
The
AutoDisposableTask
interface should be implemented by any single run task
which is to be destroyed automatically after executionBase interface for Hazelcast distributed maps.
Base class of configuration options specific to metrics collection.
Base interface for Hazelcast distributed queues.
An element annotated with this annotation is considered beta status.
Serializable
variant of java.util.function.BiFunction
which declares checked exception.Configures indexing options specific to bitmap indexes.
Defines an assortment of transformations which can be applied to
unique key
values.Configuration options specific for B-Tree indexes.
For sample usage custom serialization and other way of custom serialization
see
StreamSerializer
.Entry info for cache record.
A
RetryableHazelcastException
that indicates that an operation was sent by a machine which isn't member
in the cluster when the operation is executed.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
a membership change is requested before an entry is committed
on a term
Capacity represents a memory capacity with given value and
MemoryUnit
.Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated.
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated.
Holds blacklist and whitelist configuration in java deserialization configuration.
Allows to intercept class resolution during deserialization based on class name.
The Client interface allows to get information about
a connected client's socket address, type and UUID.
A
ClientConfig
which is initialized by loading an XML configuration file from the classpath.A
ClientConfig
which is initialized by loading an YAML configuration file from the classpath.Main configuration to setup a Hazelcast Client
ConfigRecognizer
implementation that recognizes Hazelcast
client declarative configurations based on an extensible set of
built-in ConfigRecognizer
implementations.The ClientConfigXmlGenerator is responsible for transforming a
ClientConfig
to a Hazelcast Client XML string.Client connection strategy configuration is used for setting custom strategies and configuring strategy parameters.
Reconnect options.
A
ClientFailoverConfig
which is initialized by loading an XML
configuration file from the classpath.A
ClientFailoverConfig
which is initialized by loading a YAML
configuration file from the classpath.Config class to configure multiple client configs to be used by single client instance.
ConfigRecognizer
implementation that recognizes Hazelcast
client failover declarative configurations based on an extensible set
of built-in ConfigRecognizer
implementations.The
ClientFlakeIdGeneratorConfig
contains the configuration for the client
regarding Flake ID Generator
.Configuration for icmp ping failure detector of clients.
Client-side metrics collection configuration.
Contains configuration parameters for client network related behaviour
A
HazelcastException
that is thrown when the client can not use a cluster.To clear resources of the client upon OutOfMemory
Defines the name and default value for Hazelcast Client properties.
Contains the ReliableTopic configuration for a client.
Contains the security configuration for the client.
Deprecated, for removal: This API element is subject to removal in a future version.
since 5.4, "User Code Deployment" is replaced by the "User Code Namespaces" feature
UserCodeNamespacesConfig
Hazelcast cluster interface.
Defines the name and default value for Hazelcast properties.
Config for client routing and associated options.
Provides means of reading Compact serialized fields from the binary data.
In 5.0, this feature is disabled by default and has to be enabled via
configuration
An accessor for the package-private fields of the
CompactSerializationConfig
.Defines the contract of the serializers used for Compact serialization.
Provides means of writing compact serialized fields to the binary data.
The ConfigPatternMatcher provides a strategy to match an item name
to a configuration pattern.
Interface for recognizing a declarative Hazelcast configuration
based on the rules defined in the actual implementation.
Interface to be implemented by pluggable variable replacers for the configuration files.
Stream wrapping or copying a generic
InputStream
for the
ConfigRecognizer
API.The ConfigXmlGenerator is responsible for transforming a
ClientConfig
to a Hazelcast XML string.Utility class to build xml using a
StringBuilder
.Connection Retry Config is controls the period among the retries and when should a client gave up
retrying.
Exception that indicates that the consistency guarantees provided by
some service has been lost.
Serializable
variant of java.util.function.Consumer
which declares checked exception.Contains information about a CP group.
Represents status of a CP group
CPGroupAvailabilityEvent is published when a CP group's
availability is decreased, or it has lost the majority completely.
CPGroupAvailabilityListener is notified when availability
of a CP group decreases, or it loses the majority completely.
A
CPSubsystemException
which is thrown when a request is sent to
a destroyed CP group.Identifier for CP groups.
Represents an immutable snapshot of the current CP groups view
from 1 member of the Hazelcast cluster.
CPMap is a key-value store within CP.
A CP member is a Hazelcast member that is internally elected to be part of
the
CPSubsystem
, hence maintain CP data structures.CPMembershipEvent is published when a CP member is added to
or removed from the CP Subsystem.
Membership event type.
CPMembershipListener is notified when a CP member is added to
or removed from the CP Subsystem.
Info (name, serviceName, group) about a CP object
CP Subsystem is a component of Hazelcast that builds a strongly consistent
layer for a set of distributed data structures.
Base exception for failures in CP Subsystem
Credentials represents an identity to be authenticated.
CredentialsCallback is used to retrieve
Credentials
.Contains the configuration for Credentials Factory.
Identity configuration which just holds given credentials instance.
DataSerializable is a serialization method alternative to standard Java
serialization.
DataSerializableFactory is used to create IdentifiedDataSerializable instances during de-serialization.
Default
AuthenticationConfig
implementation which just references the DefaultLoginModule
.A
PartitioningStrategy
that checks if the key implements PartitionAware
.This configuration class describes the top-level config of the discovery
SPI and its discovery strategies.
A
DiscoveryNode
describes a nodes addresses (private and if
necessary a public one) as well as attributes assigned to this node.The
DiscoveryService
interface defines the basic entry point
into the Discovery SPI implementation.The
DiscoveryServiceProvider
interface provides the possibility to build DiscoveryService
s.The
DiscoveryServiceSettings
class is used to pass the necessary
configuration to create a DiscoveryService
to the
DiscoveryServiceProvider
.The
DiscoveryStrategy
itself is the actual implementation to discover
nodes based on whatever environment is used to run the Hazelcast cloud.This configuration class describes a
DiscoveryStrategy
based on a parsed XML or configured manually using the config APIThe
DiscoveryStrategyFactory
is the entry point for strategy vendors.Level of the discovery strategy.
Base interface for all distributed objects.
A
HazelcastException
that indicates that a DistributedObject
access was attempted, but the object is destroyed.DistributedObjectEvent is fired when a
DistributedObject
is created or destroyed cluster-wide.Type of the DistributedObjectEvent.
DistributedObjectListener notifies when a
DistributedObject
is created or destroyed cluster-wide.An exception thrown when a task's name is already used before for another (or the same, if re-attempted) schedule.
This class is an example
ConfigReplacer
implementation which decrypts
encrypted values.Endpoint represents a peer in the cluster.
Endpoint configuration that defines communication/networking properties common to both incoming/outgoing connections
e.g.
Adapter for
MapListener
.Invoked upon addition of an entry.
Map Entry event.
Type of entry event.
Invoked upon size-based-eviction of an entry.
Invoked upon expiration-based removal of an entry.
Map Entry listener to get notified when a map entry is added,
removed, updated, evicted or expired.
Invoked upon load of an entry.
Invoked after WAN replicated entry is merged.
An EntryProcessor processes a
Map.Entry
.Invoked upon removal of an entry.
Invoked upon update of an entry.
Represents a read-only view of a data structure entry.
The event for the map event journal.
Contract point (from the end user perspective)
for serving/accessing entries that can be evicted.
Configuration for eviction.
Eviction Policy enum.
A kind of
Comparator
to be
used while comparing entries to be evicted.ExecutionCallback allows to asynchronously get notified when the execution is completed,
either successfully or with error.
Interface to provide parity with IMap set and put operations.
A linearizable & distributed & reentrant implementation of
Lock
.Defines the name, type and index of a field.
Field Type for
Portable
format to be used with ClassDefinition.getFieldType(String)
APIA cluster-wide unique ID generator.
Serializable
variant of java.util.function.Function
which declares checked exception.Factory methods for several common functions.
Interface for creating
GenericRecord
instances.Contains the configuration for global serializer.
The HazelcastClient provides the ability the create and manage Hazelcast clients.
Thrown when Hazelcast client is not active during an invocation.
Thrown when Hazelcast client is offline during an invocation.
Base Hazelcast exception.
Hazelcast provides overloads of the typical cache operations with a custom
This class provides a custom implementation of an
ExpiryPolicy
parameter.This class provides a custom implementation of an
ExpiryPolicy
to
react on all three types of policies:
Create
Access
Update
Hazelcast instance.
Used to get HazelcastInstance reference when submitting a Runnable/Callable using Hazelcast ExecutorService.
Thrown when HazelcastInstance is not active during an invocation.
Runs java client in an endless loop against a Hazelcast cluster to test stability.
HazelcastJsonValue is a wrapper for JSON formatted strings.
A
HazelcastException
that is thrown when the system won't handle more load due to
an overload.Container for configured Hazelcast properties (see { HazelcastProperty}).
Interface for Hazelcast Member and Client properties.
An exception thrown when a problem occurs while serializing/deserializing objects.
IAtomicLong is a redundant and highly available distributed alternative to
the
AtomicLong
.IAtomicReference is a redundant and highly available distributed alternative
to the
AtomicReference
.Concurrent, distributed, partitioned, listenable collection.
ICountDownLatch is a backed-up distributed alternative to the
java.util.concurrent.CountDownLatch
.ICredentialsFactory is used to create
Credentials
objects to be used during node authentication before connection is
accepted by the master node.IdentifiedDataSerializable is an extension to
DataSerializable
to avoid reflection during de-serialization.This interface represents identity configuration in security realms or client security configurations.
Distributed implementation of
ExecutorService
.Represents a function that accepts one argument and produces a result.
Concurrent, distributed implementation of
List
.The Hazelcast logging interface.
Concurrent, distributed, observable and queryable map.
Map events common contract.
A marker interface for exceptions to denote that execution status of an invocation is not known
IndeterminateOperationStateException is thrown when result of an invocation becomes indecisive.
Configuration of an index.
Type of the index.
An event that is sent when a
InitialMembershipListener
registers itself on a Cluster
.The InitialMembershipListener is a
MembershipListener
that first receives an
InitialMembershipEvent
when it is registered, so it immediately knows which members are available.Storage format type of values stored in cluster
Configures tracking of a running Hazelcast instance.
The mode in which this instance is running.
Product name for the Hazelcast instance
Enumeration of instance properties provided to the format pattern for
output.
Contains the configuration for Interfaces.
A InvalidConfigurationException is thrown when Hazelcast faces
an invalid configuration.
Concurrent, blocking, distributed, observable queue.
Distributed & durable implementation similar to, but not directly
inherited
ScheduledExecutorService
.A delayed result-bearing action that can be cancelled.
ISemaphore is a fault-tolerant distributed alternative to the
Semaphore
.Event for a collection item.
Type of item events.
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.
This
AuthenticationConfig
implementation is a simple holder for login module configurations.Configuration for Serialization Filters and Reflection Filters.
This class configures the Kerberos identity.
Enum for LDAP role mapping modes.
Search scope types for LDAP queries.
A
CPSubsystemException
which is thrown when
an appended but not-committed entry is truncated by the new leader.Lifecycle events are fired when the HazelcastInstance state changes.
Lifecycle states
Listener object for listening to lifecycle events of the Hazelcast instance
LifecycleService allows you to shut down, terminate, and listen to
LifecycleEvent
s
on HazelcastInstance.Contains the configuration for an
EventListener
.LoadBalancer
allows you to send operations to one of a number of endpoints (members).Provides local statistics for an index.
Local map statistics.
An exception provided to
MemberLeftException
as a cause when the local member is resetting itselfLocal statistics related to partition data replication.
Thrown when the current lock holder could not acquire the lock reentrantly
because the configured lock acquire limit is reached.
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.Logging to Log4j 2.x.
Provides static utilities to access the global shared logging machinery.
Configuration for Login Module
Usage of Login Module
Container managed context, such as Spring, Guice etc.
Invoked after all entries are removed by
IMap.clear()
.Contains the configuration for an
IMap
.Used for map-wide events like
EntryEventType.EVICT_ALL
and EntryEventType.CLEAR_ALL
.Invoked after all entries are evicted by
IMap.evictAll()
.MapInterceptor is used to intercept changes to the map, allowing access to
the values before and after adding them to the map.
A marker interface which is used to get
notified upon a map or an entry event.
Used for providing information about the lost partition for a map
Invoked when owner and all backups of a partition is lost for a specific map.
This
ConfigPatternMatcher
supports a simplified wildcard matching.Maximum Size Policy
Cluster member interface.
A collection of members to which a single partition replica can be assigned.
A
ExecutionException
thrown when a member left during an invocation or execution.Implementations of this interface select members
that are capable of executing a special kind of task.
The
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.A utility class to get
MemberSelector
instances.Adapter for MembershipListener.
Membership event fired when a new member is added to the cluster and/or when a member leaves the cluster
and similar methods.
Cluster membership listener.
Member Socket Interceptor can be registered via
see
SocketInterceptorConfig
Determines the Hazelcast codebase version in terms of major.minor.patch version.
Deprecated.
Since 5.1,
Capacity
should be used instead.Memory tier configuration of Tiered-Store.
MemoryUnit represents memory size at a given unit of
granularity and provides utility methods to convert across units.
Message for
ITopic
.Message listener for
ITopic
.JMX related metrics configuration.
MigrationListener provides the ability to listen to
partition migration process and events.
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.
The multicast
DiscoveryStrategy
.Factory class which returns
MulticastDiscoveryStrategy
to Discovery SPIDefines the name and default value for the Multicast Discovery Strategy.
MultiExecutionCallback provides notification for when an execution is completed on each member
that a task is submitted to.
Exception that indicates that the state found on this replica disallows
mutation.
Interface for hazelcast data structures with name
The
NamedTask
interface should be implemented by any task that needs to have an identification and enhanced
atomicity upon scheduling the task.Marker for interfaces that can be implemented by users and executed on clusters via User Code Deployment.
Configures native memory region.
Type of memory allocator:
STANDARD: allocate/free memory using default OS memory manager
POOLED: manage memory blocks in pool
Thrown when Hazelcast cannot allocate required native memory.
Contains the configuration for a Near Cache.
Defines how to reflect local updates to the Near Cache.
Accessor for the
EvictionConfig
of a NearCacheConfig
to initialize the old default max size,
if no size was configured by the user.Configuration for storing and preloading Near Cache keys.
Near Cache statistics.
Thrown when there is no data member in the cluster to assign partitions.
The NodeFilter, if supplied, will retrieve all discovered nodes and might
apply additional filtering based on vendor provided metadata.
A
CPSubsystemException
which is thrown when
a leader-only request is received by a non-leader member.Provides serialization methods for arrays of primitive types.
Provides serialization methods for arrays by extending DataOutput
An unchecked version of
TimeoutException
.Handler for
OutOfMemoryError
.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.This interface is a special Predicate which helps to get a page-by-page result of a query.
In Hazelcast the data is split up in partitions: by default, 271 and configurable through the 'hazelcast.partition.count'
ClusterProperty.
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.PartitionEvent is a base interface for partition related events.
A
PartitionGroupStrategy
implementation defines a strategy
how backup groups are designed.PartitioningStrategy allows keys to be located on the same member.
The event is fired when a primary replica of the partition is lost.
PartitionLostListener provides the ability to be notified upon a
possible data loss when a partition loses a replica.
A
RetryableHazelcastException
that is thrown when an operation is executed
on a partition, but that partition is currently being moved around.PartitionService allows you to query
Partition
s and attach/detach MigrationListener
s to listen to partition
migration events.Credentials
type for name/password representation.Configuration class for persistent memory devices (e.g.
Configuration class for directories that persistent memories are mounted at.
The enumeration of the supported persistent memory operational modes.
PN (Positive-Negative) CRDT counter.
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated.
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated.
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated.
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated.
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated.
Represents a map entry predicate.
This interface provides functionality to build a predicate.
This interface provides entry-level functionality related to building a predicate.
A utility class to create new
PredicateBuilder
and Predicate
instances.Marker for private functionality.
Enables transforming object into other objects.
A utility class to create basic
Projection
instances.This interface describes an extended approach of the currently available
pure property based configuration inside Hazelcast and helps to implement
an automatic and transparent way to verify configuration as well as converting
types based on provided validators and converters.
ConfigReplacer for replacing property names with property values for properties provided in
PropertyReplacer.init(Properties)
method.This enum class contains basic
TypeConverter
implementations to
convert strings to all common basic Java types.This class is related to SPI.
Contains constants for Query.
Exception class for the Query.
This exception is thrown when a query exceeds a configurable result size limit.
Exception thrown when a write-behind
MapStore
rejects to accept a new element.Allows notifying Hazelcast that the processing unit implementing this interface will not do any modifications.
The result of a
Ringbuffer.readManyAsync(long, int, int, com.hazelcast.core.IFunction)
operation.Security realm represents the security configuration for part of the system (e.g.
This JAAS
Callback
is used to retrieve a RealmConfig
from client or member configuration.A
MessageListener
to better integrate with the reliable topic.An event fired when a partition replica migration completes or fails.
A ReplicatedMap is a map data structure with weak consistency
and has entries stored locally on every node of the cluster.
Thrown when
HazelcastInstance.getReplicatedMap(String)
is invoked on a lite member.A HazelcastException indicating that there is some kind of system error causing a response to be send
multiple times for some operation.
Marker interface for exceptions to indicate that an operation can be retried.
A 'marker' exception that indicates that an operation can be retried.
A
IOException
indicating that there was a IO failure, but it can be retried.A Ringbuffer is a data structure where the content is stored in a ring-like
structure.
Strategy for routing client connections to members.
Resource handler pointing to a
IScheduledFuture
.Statistics and timing info for a
IScheduledFuture
accessible through IScheduledFuture.getStats()
Contains the serialization configuration of
HazelcastInstance
.Base interface of custom serialization interfaces
Contains the serialization configuration for a particular class.
This interface is used to automatically register serializers from external
Hazelcast or user modules.
A
HazelcastException
that indicates that a requested service is not exist.Marker interface for exceptions.
Typed authentication configuration for
SimplePropertiesLoginModule
.Helper immutable object representing user attributes (i.e.
Simple immutable implementation of the
DiscoveryNode
interface for convenience
when implementing a DiscoveryStrategy
.Simple immutable implementation of
PropertyDefinition
for convenience of implementors.Simple implementation of
Credentials
using a raw byte array token.An interface that provides the ability to intercept the creation of sockets.
Contains the configuration for interceptor socket.
TCP Socket options
An exception thrown when the cluster size is below the defined threshold.
SSL configuration.
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.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.Exception thrown by the
IScheduledFuture
during any operation on a stale (=previously destroyed) task.An interface to provide means for saving & loading state for
Runnable
and Callable
tasks scheduled with an IScheduledExecutorService
.The credentials factory implementation which just takes credentials in a constructor and provides it for every
StaticCredentialsFactory.newCredentials()
call.A base class for custom serialization.
Serializable
variant of java.util.function.Supplier
which declares checked exception.Deprecated.
since 4.2
Thrown when a client invocation is failed because related target is disconnected and
whether the invocation is run or not, is indeterminate
A
RetryableHazelcastException
that indicates operation was sent to a
machine that isn't member of the cluster.Exception that indicates that the receiver of a CRDT operation is not
a CRDT replica.
Contains the configuration for the Tcp/Ip join mechanism.
Typed authentication configuration for the
X509CertificateLoginModule
.Credentials
type for custom authentication (token based).Possible token encodings.
Simple token identity configuration.
A
HazelcastException
thrown when a publisher wants to write to a topic, but there insufficient storage
to deal with the event.A policy to deal with an overloaded topic; so topic where there is no
place to store new messages.
Implementations of this interface define a certain type conversion.
This interface allows deserialization of a binary data with a provided class type.
This interface adds the possibility for the class to act as if it is another class when being deserialized using
DataSerializable
This interface allows deserialization of a binary data with a provided class type.
This exception is thrown when an exception that is coming from server is not recognized by the protocol and
it can not be constructed by the client via reflection.
An UnsupportedClusterVersionException is thrown when a Hazelcast Client
attempts to connect to a cluster with a configuration that is not supported
by the cluster version.
An UnsupportedRoutingModeException is thrown when a Hazelcast Client
is configured with a
RoutingMode
that is not supported by the cluster.Simple implementation of
PasswordCredentials
using
name and password as security attributes.Simple username/password identity configuration.
This exception is thrown from
ValueValidator
implementations whenever the validation has not succeeded for any reason.This interface defines a certain validation logic implementation
to test if a given value is expected to be correct or not.
A generic version to be used with
VersionAware
classes.An instance which supports versioning.
Deprecated, for removal: This API element is subject to removal in a future version.
Portable Serialization has been deprecated.
An instance which is used in WAN and supports versioning.
A
RetryableHazelcastException
indicating that an operation is executed on
a wrong member.Loads the
ClientConfig
using XML.Loads the
ClientFailoverConfig
using XML.Loads the
ClientConfig
using YAML.Loads the
ClientFailoverConfig
using YAML.