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 ExecutorService and 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 |
AuthenticationException
A
HazelcastException that is thrown when there is an Authentication failure: e.g. |
class |
ClientNotAllowedInClusterException
A
HazelcastException that is thrown when the client can not use a cluster. |
class |
UndefinedErrorCodeException
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.
|
Modifier and Type | Class and Description |
---|---|
class |
InvalidConfigurationException
A InvalidConfigurationException is thrown when an Hazelcast faces
an invalid configuration.
|
Modifier and Type | Class and Description |
---|---|
class |
ValidationException
This exception is thrown from
ValueValidator
implementations whenever the validation has not succeed for any reason. |
Modifier and Type | Class and Description |
---|---|
class |
ConsistencyLostException
Exception that indicates that the consistency guarantees provided by
some service has been lost.
|
class |
HazelcastOverloadException
A
HazelcastException that is thrown when the system won't handle more load due to
an overload. |
class |
IndeterminateOperationStateException
IndeterminateOperationStateException is thrown when result of an invocation becomes indecisive.
|
class |
LocalMemberResetException
An exception provided to
MemberLeftException as a cause when the local member is resetting itself |
class |
OperationTimeoutException
An unchecked version of
TimeoutException . |
class |
RuntimeInterruptedException
An unchecked version of
InterruptedException . |
Modifier and Type | Class and Description |
---|---|
class |
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
|
class |
CPGroupDestroyedException
A
CPSubsystemException which is thrown when a request is sent to
a destroyed CP group. |
class |
CPSubsystemException
Base exception for failures in CP Subsystem
|
class |
LeaderDemotedException
A
CPSubsystemException which is thrown when
an appended but not-committed entry is truncated by the new leader. |
class |
NotLeaderException
A
CPSubsystemException which is thrown when
a leader-only request is received by a non-leader member. |
class |
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. |
Modifier and Type | Class and Description |
---|---|
class |
LockAcquireLimitReachedException
Thrown 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 |
MutationDisallowedException
Exception that indicates that the state found on this replica disallows
mutation.
|
class |
TargetNotReplicaException
Exception that indicates that the receiver of a CRDT operation is not
a CRDT replica.
|
Modifier and Type | Class and Description |
---|---|
class |
StaleTaskIdException
An
RuntimeException that is thrown when retrieving the result of a task via DurableExecutorService if the
result of the task is overwritten. |
Modifier and Type | Class and Description |
---|---|
class |
JetException
Base Jet exception.
|
class |
JobAlreadyExistsException
Thrown when a named job is submitted while there is an active job
with the same name.
|
class |
RestartableException
Exception 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 |
JobNotFoundException
Thrown when a job could not be found on the master node
|
class |
TopologyChangedException
Thrown when a topology change causes a job to abort.
|
Modifier and Type | Class and Description |
---|---|
class |
QueryResultSizeExceededException
This exception is thrown when a query exceeds a configurable result size limit.
|
Modifier and Type | Class and Description |
---|---|
class |
HazelcastSerializationException
An exception thrown when a problem occurs while serializing/deserializing objects.
|
Modifier and Type | Class and Description |
---|---|
class |
NoDataMemberInClusterException
Thrown when there is no data member in the cluster to assign partitions.
|
Modifier and Type | Class and Description |
---|---|
class |
QueryException
Exception class for the Query.
|
Modifier and Type | Class and Description |
---|---|
class |
ReplicatedMapCantBeCreatedOnLiteMemberException
Thrown when
HazelcastInstance.getReplicatedMap(String) is invoked on a lite member. |
Modifier and Type | Class and Description |
---|---|
class |
DuplicateTaskException
An exception thrown when a task's name is already used before for another (or the same, if re-attempted) schedule.
|
class |
StaleTaskException
Exception thrown by the
IScheduledFuture during any operation on a stale (=previously destroyed) task. |
Modifier and Type | Class and Description |
---|---|
class |
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. |
class |
DistributedObjectDestroyedException
A
HazelcastException that indicates that a DistributedObject
access was attempted, but the object is destroyed. |
class |
PartitionMigratingException
A
RetryableHazelcastException that is thrown when an operation is executed
on a partition, but that partition is currently being moved around. |
class |
ResponseAlreadySentException
A HazelcastException indicating that there is some kind of system error causing a response to be send
multiple times for some operation.
|
class |
RetryableHazelcastException
A 'marker' exception that indicates that an operation can be retried.
|
class |
ServiceNotFoundException
A
HazelcastException that indicates that a requested service is not exist. |
class |
TargetDisconnectedException
Thrown when a client invocation is failed because related target is disconnected and
whether the invocation is run or not, is indeterminate
|
class |
TargetNotMemberException
A
RetryableHazelcastException that indicates operation was sent to a
machine that isn't member of the cluster. |
class |
WrongTargetException
A
RetryableHazelcastException indicating that an operation is executed on
a wrong member. |
Modifier and Type | Class and Description |
---|---|
class |
SplitBrainProtectionException
An exception thrown when the cluster size is below the defined threshold.
|
Modifier and Type | Class and Description |
---|---|
class |
HazelcastSqlException
An exception occurred during SQL query execution.
|
Modifier and Type | Class and Description |
---|---|
class |
TopicOverloadException
A
HazelcastException thrown 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 |
TransactionException
A
HazelcastException that is thrown when something goes wrong
while dealing with transactions and transactional data-structures. |
class |
TransactionNotActiveException
A
HazelcastException thrown when an a transactional operation is executed without an active transaction. |
class |
TransactionTimedOutException
Thrown when a transaction has timed out.
|
Modifier and Type | Class and Description |
---|---|
class |
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 |
Copyright © 2022 Hazelcast, Inc.. All rights reserved.