| Package | Description | 
|---|---|
| com.hazelcast.client | Contains classes/interfaces related to Client | 
| com.hazelcast.config | Provides classes for configuring HazelcastInstance. | 
| com.hazelcast.config.properties | This package contains the public API for properties defined in the XML configuration. | 
| com.hazelcast.core | Provides core API interfaces/classes. | 
| com.hazelcast.cp.exception | Contains exceptions that can be thrown by APIs of CP Subsystem | 
| com.hazelcast.cp.lock.exception | Contains exception classes related to the locking API of CP Subsystem | 
| com.hazelcast.crdt | This package contains the common classes for CRDT (conflict-free replicated
 data type) implementations based on the Hazelcast infrastructure. | 
| com.hazelcast.durableexecutor | This package contains DurableExecutorService functionality for Hazelcast. The DurableExecutorService extends the ExecutorServiceand provides additional methods like
 executing tasks on a member who is owner of a specific key. | 
| com.hazelcast.jet | Hazelcast Jet is a distributed computation engine running on top of
 Hazelcast IMDG technology. | 
| com.hazelcast.jet.core | Jet's Core API. | 
| com.hazelcast.map | Contains Hazelcast map module classes. | 
| com.hazelcast.nio.serialization | Contains interfaces/classes related to serialization,
 such as serializer interfaces, input/output streams. | 
| com.hazelcast.partition | Contains the partition logic for Hazelcast. | 
| com.hazelcast.query | Contains interfaces/classes related to Hazelcast query and indexing support. | 
| com.hazelcast.replicatedmap | Classes for replicated map. | 
| com.hazelcast.scheduledexecutor | This package contains ScheduledExecutorService functionality for Hazelcast. | 
| com.hazelcast.spi.exception | Contains exceptions for Hazelcast SPI. | 
| com.hazelcast.splitbrainprotection | Contains classes related to cluster split brain protection. | 
| com.hazelcast.sql | This package contains the SQL API. | 
| com.hazelcast.topic | Contains the API for the  ITopic. | 
| com.hazelcast.transaction | Provides interfaces/classes for Hazelcast transaction support. | 
| com.hazelcast.wan | This package contains the WAN replication API | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AuthenticationExceptionA  HazelcastExceptionthat is thrown when there is an Authentication failure: e.g. | 
| class  | ClientNotAllowedInClusterExceptionA  HazelcastExceptionthat is thrown when the client can not use a cluster. | 
| class  | UndefinedErrorCodeExceptionThis 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. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | InvalidConfigurationExceptionA InvalidConfigurationException is thrown when an Hazelcast faces
 an invalid configuration. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ValidationExceptionThis exception is thrown from  ValueValidatorimplementations whenever the validation has not succeed for any reason. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ConsistencyLostExceptionException that indicates that the consistency guarantees provided by
 some service has been lost. | 
| class  | HazelcastOverloadExceptionA  HazelcastExceptionthat is thrown when the system won't handle more load due to
 an overload. | 
| class  | IndeterminateOperationStateExceptionIndeterminateOperationStateException is thrown when result of an invocation becomes indecisive. | 
| class  | LocalMemberResetExceptionAn exception provided to  MemberLeftExceptionas a cause when the local member is resetting itself | 
| class  | OperationTimeoutExceptionAn unchecked version of  TimeoutException. | 
| class  | RuntimeInterruptedExceptionAn unchecked version of  InterruptedException. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CannotReplicateExceptionA  CPSubsystemExceptionwhich 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
 (seeRaftAlgorithmConfig.getUncommittedEntryCountToRejectNewAppends())
 a membership change is requested before an entry is committed
 on a term | 
| class  | CPGroupDestroyedExceptionA  CPSubsystemExceptionwhich is thrown when a request is sent to
 a destroyed CP group. | 
| class  | CPSubsystemExceptionBase exception for failures in CP Subsystem | 
| class  | LeaderDemotedExceptionA  CPSubsystemExceptionwhich is thrown when
 an appended but not-committed entry is truncated by the new leader. | 
| class  | NotLeaderExceptionA  CPSubsystemExceptionwhich is thrown when
 a leader-only request is received by a non-leader member. | 
| class  | StaleAppendRequestExceptionA  CPSubsystemExceptionwhich 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. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | LockAcquireLimitReachedExceptionThrown when the current lock holder could not acquired the lock reentrantly
 because the configured lock acquire limit is reached. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MutationDisallowedExceptionException that indicates that the state found on this replica disallows
 mutation. | 
| class  | TargetNotReplicaExceptionException that indicates that the receiver of a CRDT operation is not
 a CRDT replica. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | StaleTaskIdExceptionAn  RuntimeExceptionthat is thrown when retrieving the result of a task viaDurableExecutorServiceif the
 result of the task is overwritten. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | JetExceptionBase Jet exception. | 
| class  | JobAlreadyExistsExceptionThrown when a named job is submitted while there is an active job
 with the same name. | 
| class  | RestartableExceptionException to throw from job-executing methods to indicate a failure that can
 be resolved by restarting the job. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | JobNotFoundExceptionThrown when a job could not be found on the master node | 
| class  | TopologyChangedExceptionThrown when a topology change causes a job to abort. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QueryResultSizeExceededExceptionThis exception is thrown when a query exceeds a configurable result size limit. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HazelcastSerializationExceptionAn exception thrown when a problem occurs while serializing/deserializing objects. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | NoDataMemberInClusterExceptionThrown when there is no data member in the cluster to assign partitions. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | QueryExceptionException class for the Query. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ReplicatedMapCantBeCreatedOnLiteMemberExceptionThrown when  HazelcastInstance.getReplicatedMap(String)is invoked on a lite member. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DuplicateTaskExceptionAn exception thrown when a task's name is already used before for another (or the same, if re-attempted) schedule. | 
| class  | StaleTaskExceptionException thrown by the  IScheduledFutureduring any operation on a stale (=previously destroyed) task. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CallerNotMemberExceptionA  RetryableHazelcastExceptionthat indicates that an operation was sent by a machine which isn't member
 in the cluster when the operation is executed. | 
| class  | DistributedObjectDestroyedExceptionA  HazelcastExceptionthat indicates that aDistributedObjectaccess was attempted, but the object is destroyed. | 
| class  | PartitionMigratingExceptionA  RetryableHazelcastExceptionthat is thrown when an operation is executed
 on a partition, but that partition is currently being moved around. | 
| class  | ResponseAlreadySentExceptionA HazelcastException indicating that there is some kind of system error causing a response to be send
 multiple times for some operation. | 
| class  | RetryableHazelcastExceptionA 'marker' exception that indicates that an operation can be retried. | 
| class  | ServiceNotFoundExceptionA  HazelcastExceptionthat indicates that a requested service is not exist. | 
| class  | TargetDisconnectedExceptionThrown when a client invocation is failed because related target is disconnected and
 whether the invocation is run or not, is indeterminate | 
| class  | TargetNotMemberExceptionA  RetryableHazelcastExceptionthat indicates operation was sent to a
 machine that isn't member of the cluster. | 
| class  | WrongTargetExceptionA  RetryableHazelcastExceptionindicating that an operation is executed on
 a wrong member. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SplitBrainProtectionExceptionAn exception thrown when the cluster size is below the defined threshold. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HazelcastSqlExceptionAn exception occurred during SQL query execution. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TopicOverloadExceptionA  HazelcastExceptionthrown when a publisher wants to write to a topic, but there is not sufficient storage
 to deal with the event. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TransactionExceptionA  HazelcastExceptionthat is thrown when something goes wrong
 while dealing with transactions and transactional data-structures. | 
| class  | TransactionNotActiveExceptionA  HazelcastExceptionthrown when an a transactional operation is executed without an active transaction. | 
| class  | TransactionTimedOutExceptionThrown when a transaction has timed out. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | WanQueueFullExceptionA  HazelcastExceptionthat
 is thrown when the wan replication queues are full
 This exception is only thrown when WAN is configured withWanQueueFullBehavior.THROW_EXCEPTION | 
Copyright © 2023 Hazelcast, Inc.. All rights reserved.