Package | Description |
---|---|
com.hazelcast.client |
Contains classes/interfaces related to Client
|
com.hazelcast.client.impl.protocol.exception | |
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 the CP subsystem
|
com.hazelcast.cp.internal.datastructures.exception |
Contains internal exceptions related to Raft-based data structure
implementations
|
com.hazelcast.cp.internal.exception |
Contains internal exceptions that are being used
by the CP subsystem implementation
|
com.hazelcast.cp.internal.raft.exception |
Contains exception classes that can be thrown by the CP subsystem
|
com.hazelcast.cp.internal.session |
Contains service classes
for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.lock.exception |
Contains exception classes related to the locking API of the CP subsystem
|
com.hazelcast.crdt |
This package contains 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.flakeidgen.impl | |
com.hazelcast.internal.cluster.impl |
This package contains the implementation of the cluster functionality.
|
com.hazelcast.internal.partition |
Contains the internals for partition assignment/management, migration, replication etc.
|
com.hazelcast.internal.yaml |
Contains classes for loading, parsing YAML documents and building a
YAML specific DOM of
YamlNode instances
The YAML documents are loaded and parsed with the external SnakeYaml
parser, which supports YAML 1.2 documents, and the JSON schema. |
com.hazelcast.map |
Contains Hazelcast map module classes.
|
com.hazelcast.map.impl.operation |
Package for map operations.
|
com.hazelcast.mapreduce |
This package contains the MapReduce API definition for Hazelcast.
All map reduce operations running in a distributed manner inside the active Hazelcast cluster. |
com.hazelcast.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.quorum |
Contains classes related to cluster quorum.
|
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.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 client can not use this cluster. |
class |
UndefinedErrorCodeException
This exception is thrown when an exception that is coming from server is not recognized by the protocol.
|
Modifier and Type | Class and Description |
---|---|
class |
MaxMessageSizeExceeded
Thrown when client message size exceeds Integer.MAX_VALUE
|
Modifier and Type | Class and Description |
---|---|
class |
ConfigurationException
A
HazelcastException that is thrown when something is wrong with the server or client configuration. |
class |
InvalidConfigurationException
A InvalidConfigurationException is thrown when there is 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 |
DuplicateInstanceNameException
Thrown when a duplicate instance name is detected.
|
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 the 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 an installed snapshot
causes an appended entry to be truncated from the Raft log before its commit
status is discovered. |
Modifier and Type | Class and Description |
---|---|
class |
WaitKeyCancelledException
Thrown when a wait key is cancelled and means that
the corresponding operation has not succeeded
|
Modifier and Type | Class and Description |
---|---|
class |
CannotCreateRaftGroupException
An internal exception thrown when a Raft group is attempted to be created
with a Hazelcast node that is not an active CP member.
|
class |
CannotRemoveCPMemberException
Thrown while a CP member is requested to be removed from the CP subsystem
while there is an ongoing process for another member.
|
class |
MetadataRaftGroupInitInProgressException
Thrown when all CP members have not committed their CP member list
and initialization of the Metadata Raft group is not completed yet.
|
Modifier and Type | Class and Description |
---|---|
class |
MemberAlreadyExistsException
A
CPSubsystemException which is thrown when a member, which is
requested to be added to a CP group, is already member of that group. |
class |
MemberDoesNotExistException
A
CPSubsystemException which is thrown when a member, which is
requested to be removed from a CP group, is not a member of that group
or is already removed from that group. |
class |
MismatchingGroupMembersCommitIndexException
A
CPSubsystemException which is thrown when a membership change is
requested but expected members commitIndex doesn't match the actual members
commitIndex in the Raft state. |
Modifier and Type | Class and Description |
---|---|
class |
SessionExpiredException
Thrown when an operation is attached to a Raft session is no longer active
|
Modifier and Type | Class and Description |
---|---|
class |
LockAcquireLimitExceededException
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 |
NodeIdOutOfRangeException
Exception thrown from member if that member is not able to generate IDs using Flake ID generator
because its node ID is too big.
|
Modifier and Type | Class and Description |
---|---|
class |
ClusterTopologyChangedException
Thrown when a cluster topology change is detected.
|
class |
ConfigMismatchException
Exception thrown when 2 nodes want to join, but there configuration doesn't match
|
class |
VersionMismatchException
Indicates that the version of a joining member is not compatible with the cluster version.
|
Modifier and Type | Class and Description |
---|---|
class |
PartitionStateVersionMismatchException
Thrown when local partition-state version doesn't match the version
of master member while running a migration/replication operation.
|
Modifier and Type | Class and Description |
---|---|
class |
YamlException |
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 |
EntryOffloadableLockMismatchException
Actor of the EntryOffloadableOperation -> EntryOffloadableSetUnlockOperation combined operations flow.
|
Modifier and Type | Class and Description |
---|---|
class |
RemoteMapReduceException
Deprecated.
MapReduce is deprecated and will be removed in 4.0.
For map aggregations, you can use
Aggregator on IMap.
For general data processing, it is superseded by Hazelcast Jet. |
class |
TopologyChangedException
Deprecated.
MapReduce is deprecated and will be removed in 4.0.
For map aggregations, you can use
Aggregator on IMap.
For general data processing, it is superseded by Hazelcast Jet. |
Modifier and Type | Class and Description |
---|---|
class |
HazelcastSerializationException
This is an exception thrown when an exception 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 |
QuorumException
An exception thrown when the cluster size is below the defined threshold.
|
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 is send 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 |
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 |
WANReplicationQueueFullException
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 © 2019 Hazelcast, Inc.. All Rights Reserved.