public interface CPSubsystem
HazelcastInstance.getCPSubsystem(). Its data
 structures are CP with respect to the CAP principle, i.e., they always
 maintain linearizability and prefer consistency over availability during
 network partitions. Besides network partitions, CP Subsystem withstands
 server and client failures.
 
 Currently, CP Subsystem contains only the implementations of Hazelcast's
 concurrency APIs. Since these APIs do not maintain large states, all members
 of a Hazelcast cluster do not necessarily take part in CP Subsystem.
 The number of Hazelcast members that takes part in CP Subsystem is specified
 with CPSubsystemConfig.setCPMemberCount(int). Say that it is
 configured as N. Then, when a Hazelcast cluster starts, the first N members
 form CP Subsystem. These members are called CPMembers, and they can
 also contain data for other regular -AP- Hazelcast data structures, such as
 IMap, ISet.
 
 Data structures in CP Subsystem run in CPGroups. Each CP group
 elects its own Raft leader and runs the Raft consensus algorithm
 independently. CP Subsystem runs 2 CP groups by default. The first one is
 the METADATA CP group which is an internal CP group responsible for managing
 CP members and CP groups. It is initialized during cluster startup if CP
 Subsystem is enabled via CPSubsystemConfig.setCPMemberCount(int).
 The second CP group is the DEFAULT CP group, whose name is given in
 CPGroup.DEFAULT_GROUP_NAME. If a group name is not specified while
 creating a CP data structure proxy, that data structure is mapped to
 the DEFAULT CP group. For instance, when a CP IAtomicLong instance
 is created via .getAtomicLong("myAtomicLong"), it is initialized on
 the DEFAULT CP group. Besides these 2 pre-defined CP groups, custom CP
 groups can be created at run-time while fetching CP data structure proxies.
 For instance, if a CP IAtomicLong is created by calling
 .getAtomicLong("myAtomicLong@myGroup"), first a new CP group is
 created with the name "myGroup" and then "myAtomicLong" is initialized on
 this custom CP group.
 
This design implies that each CP member can participate to more than one CP group. CP Subsystem runs a periodic background task to ensure that each CP member performs the Raft leadership role for roughly equal number of CP groups. For instance, if there are 3 CP members and 3 CP groups, each CP member becomes Raft leader for only 1 CP group. If one more CP group is created, then one of the CP members gets the Raft leader role for 2 CP groups. This is done because Raft is a leader-based consensus algorithm. A Raft leader node becomes responsible for handling incoming requests from callers and replicating them to follower nodes. If a CP member gets the Raft leadership role for too many CP groups compared to other CP members, it can turn into a bottleneck.
 CP member count of CP groups are specified via
 CPSubsystemConfig.setGroupSize(int). Please note that this
 configuration does not have to be same with the CP member count. Namely,
 number of CP members in CP Subsystem can be larger than the configured
 CP group size. CP groups usually consist of an odd number of CP members
 between 3 and 7. Operations are committed & executed only after they are
 successfully replicated to the majority of CP members in a CP group.
 An odd number of CP members is more advantageous to an even number because
 of the quorum or majority calculations. For a CP group of N members,
 majority is calculated as N / 2 + 1. For instance, in a CP group of 5 CP
 members, operations are committed when they are replicated to at least 3 CP
 members. This CP group can tolerate failure of 2 CP members and remain
 available. However, if we run a CP group with 6 CP members, it can still
 tolerate failure of 2 CP members because majority of 6 is 4. Therefore,
 it does not improve the degree of fault tolerance compared to 5 CP members.
 
 CP Subsystem achieves horizontal scalability thanks to all of
 the aforementioned CP group management capabilities. You can scale out
 the throughput and memory capacity by distributing your CP data structures
 to multiple CP groups (i.e., manual partitioning / sharding) and
 distributing those CP groups over CP members (i.e., choosing a CP group size
 that is smaller than the CP member count configuration). Nevertheless,
 the current set of CP data structures have quite low memory overheads.
 Moreover, related to the Raft consensus algorithm, each CP group makes use
 of internal heartbeat RPCs to maintain authority of the Raft leader and help
 lagging CP group members to make progress. Last, the new CP lock and
 semaphore implementations rely on a brand new session mechanism. In a
 nutshell, a Hazelcast server or a client starts a new session on the
 corresponding CP group when it makes its very first lock or semaphore
 acquire request, and then periodically commits session heartbeats to this CP
 group in order to indicate its liveliness. It means that if CP locks and
 semaphores are distributed to multiple CP groups, there will be a session
 management overhead on each CP group. Please see CPSession for more
 details. For these reasons, we recommend developers to use a minimal number
 of CP groups. For most use cases, the DEFAULT CP group should be sufficient
 to maintain all CP data structure instances. Custom CP groups is recommended
 only when you benchmark your deployment and decide that performance of
 the DEFAULT CP group is not sufficient for your workload.
 
 CP Subsystem runs a discovery process on cluster startup. When CP Subsystem
 is enabled by setting a positive value to
 CPSubsystemConfig.setCPMemberCount(int), say N, the first N members
 in the Hazelcast cluster member list initiate this discovery process. Other
 Hazelcast members skip this step. The CP discovery process runs out of
 the box on top of Hazelcast's cluster member list without requiring any
 custom configuration for different environments. It is completed when each
 one of the first N Hazelcast members initializes its local CP member list
 and commits it to the METADATA CP group. A soon-to-be CP member
 terminates itself if any of the following conditions occur before the CP
 discovery process is completed:
 
 The CP data structure proxies differ from the other Hazelcast data
 structure proxies in two aspects. First, an internal commit is performed on
 the METADATA CP group every time you fetch a proxy from this interface.
 Hence, callers should cache returned proxy objects. Second, if you call
 DistributedObject.destroy() on a CP data structure proxy, that data
 structure is terminated on the underlying CP group and cannot be
 reinitialized until the CP group is force-destroyed via
 CPSubsystemManagementService.forceDestroyCPGroup(String). For this
 reason, please make sure that you are completely done with a CP data
 structure before destroying its proxy.
 
 By default, CP Subsystem works only in memory without persisting any state
 to disk. It means that a crashed CP member is not able to join to
 the cluster back by restoring its previous state. Therefore, crashed CP
 members create a danger for gradually losing majority of CP groups and
 eventually cause the total loss of availability of CP Subsystem. To prevent
 such situations, crashed CP members can be removed from CP Subsystem and
 replaced in CP groups with other available CP members. This flexibility
 provides a good degree of fault-tolerance at run-time. Please see
 CPSubsystemConfig and CPSubsystemManagementService for more
 details.
 
 CP Subsystem offers disk persistence as well. When it is enabled via
 CPSubsystemConfig.setPersistenceEnabled(boolean), CP members persist
 their local state to stable storage and can restore their state after
 crashes. This capability significantly improves the overall reliability of
 CP Subsystem by enabling recovery of crashed CP members. When you restart
 crashed CP members, they restore their local state and resume working as if
 they have never crashed. If you cannot restart a CP member on the same
 machine, you can move its data to another machine and restart it with a new
 address. CP Subsystem Persistence enables you to handle single or multiple CP
 member crashes, or even whole cluster crashes and guarantee that committed
 operations are not lost after recovery. In other words, CP member crashes
 and restarts do not create any consistency problem. As long as majority of
 CP members are available after recovery, CP Subsystem remains operational.
 
 When CP Subsystem Persistence is enabled, all Hazelcast cluster members
 create a sub-directory under the base persistence directory which is
 specified via CPSubsystemConfig.getBaseDir(). This means that AP
 Hazelcast members, which are the ones not marked as CP members during
 the CP discovery process, create their persistence directories as well.
 Those members persist only the information that they are not CP members.
 This is done because when a Hazelcast member starts with CP Subsystem
 Persistence enabled, it checks if there is a CP persistence directory
 belonging to itself. If it founds one, it skips the CP discovery process and
 initializes its CP member identity from the persisted data. If it was an AP
 member before shutdown or crash, it restores this information and starts as
 an AP member. Otherwise, it could think that the CP discovery process has
 not been executed and trigger it, which would break CP Subsystem.
 
In light of this information, If you have both CP and AP members in your cluster when CP Subsystem Persistence is enabled, and if you want to perform a cluster-wide restart, you need to ensure that AP members are also restarted with their CP persistence directories.
 There is a significant behavioral difference during CP member shutdown when
 CP Subsystem Persistence is enabled and disabled. When disabled (the default
 mode in which CP Subsystem works only in memory), a shutting down CP member
 is replaced with other available CP members in all of its CP groups in order
 not to decrease or more importantly not to lose majorities of CP groups.
 It is because CP members keep their local state only in memory when CP
 Subsystem Persistence is disabled, hence a shut-down CP member cannot join
 back with its CP identity and state, hence it is better to remove it from CP
 Subsystem to not to harm availability of CP groups. If there is no other
 available CP member to replace a shutting down CP member in a CP group, that
 CP group's size is reduced by 1 and its majority value is recalculated.
 On the other hand, when CP Subsystem Persistence is enabled, a shut-down CP
 member can come back by restoring its CP state. Therefore, it is not
 automatically removed from CP Subsystem when CP Subsystem Persistence is
 enabled. It is up to the user to remove shut-down CP members
 via CPSubsystemManagementService.removeCPMember(UUID) )} if they will
 not come back.
 
In summary, CP member shutdown behaviour is as follows:
 Moreover, there is a subtle point about concurrent shutdown of CP
 members when CP Subsystem Persistence is disabled. If there are N CP members
 in CP Subsystem, HazelcastInstance.shutdown() can be called on N-2
 CP members concurrently. Once these N-2 CP members complete their shutdown,
 the remaining 2 CP members must be shut down serially. Even though
 the shutdown API can be called concurrently on multiple CP members, since
 the METADATA CP group handles shutdown requests serially, it would be simpler
 to shut down CP members one by one, by calling
 HazelcastInstance.shutdown() on the next CP member once the current
 CP member completes its shutdown. This rule does not apply when CP Subsystem
 Persistence is enabled so you can shut down your CP members concurrently
 if you enabled CP Subsystem Persistence. Please see CPSubsystem
 to learn more about the shut-down behaviour of CP members. It is
 enough for users to recall this rule while shutting down CP members when
 CP Subsystem Persistence is disabled. Interested users can read the rest of
 this paragraph to learn the reasoning behind this rule. Each shutdown
 request internally requires a Raft commit to the METADATA CP group when CP
 Subsystem Persistence is disabled. A CP member proceeds to shutdown after it
 receives a response of this commit. To be able to perform a Raft commit,
 the METADATA CP group must have its majority up and running. When only 2 CP
 members are left after graceful shutdowns, the majority of the METADATA CP
 group becomes 2. If the last 2 CP members shut down concurrently, one of
 them is likely to perform its Raft commit faster than the other one and
 leave the cluster before the other CP member completes its Raft commit.
 In this case, the last CP member waits for a response of its commit attempt
 on the METADATA CP group, and times out eventually. This situation causes
 an unnecessary delay on shutdown process of the last CP member. On the other
 hand, when the last 2 CP members shut down serially, the N-1th member
 receives the response of its commit after its shutdown request is committed
 also on the last CP member. Then, the last CP member checks its local data
 to notice that it is the last CP member alive, and proceeds its shutdown
 without attempting a Raft commit on the METADATA CP group.
 
CP Subsystem's fault tolerance capabilities are summarized below. For the sake of simplicity, let's assume that both the CP member count and CP group size configurations are configured as the same and we use only the DEFAULT CP group. In the list below, "a permanent crash" means that a CP member either crashes while CP Subsystem Persistence is disabled, hence it cannot be recovered with its CP identity and data, or it crashes while CP Subsystem Persistence is enabled but its CP data cannot be recovered, for instance, due to a total server crash or a disk failure.
CPSubsystemManagementService.removeCPMember(UUID). This API call
 removes the given CP member from all CP groups and recalculates their
 majority values. If there is another available CP member in CP Subsystem,
 the removed CP member is replaced with that one, or the user can promote
 an AP member of the Hazelcast cluster to the CP role via
 CPSubsystemManagementService.promoteToCPMember().CPSubsystemManagementService.reset().
 When CPSubsystemConfig.getCPMemberCount() is greater than
 CPSubsystemConfig.getGroupSize(), CP groups are formed by selecting
 a subset of CP members. In this case, each CP group can have a different set
 of CP members, therefore different fault-tolerance and availability
 conditions. In the following list, CP Subsystem's additional fault
 tolerance capabilities are discussed for this configuration case.
 
CPSubsystemManagementService.forceDestroyCPGroup(String). When this
 API is called, the CP group is terminated non-gracefully without the Raft
 mechanics. After this API call, all existing CP data structure proxies that
 talk to this CP group fail with CPGroupDestroyedException. However,
 if a new proxy is created afterwards, then this CP group is re-created from
 scratch with a new set of CP members. Losing majority of a non-METADATA CP
 group can be likened to partition-loss scenario of AP Hazelcast. Please note
 that non-METADATA CP groups that have lost their majority must be
 force-destroyed immediately, because they can block the METADATA CP group
 to perform membership changes on CP Subsystem.CPSubsystemManagementService.reset().CPSubsystemConfig, 
CPMember, 
CPGroup, 
CPSession, 
CPSubsystemManagementService| Modifier and Type | Method and Description | 
|---|---|
| UUID | addGroupAvailabilityListener(CPGroupAvailabilityListener listener)Registers a new CPGroupAvailabilityListener to listen CP group availability changes. | 
| UUID | addMembershipListener(CPMembershipListener listener)Registers a new CPMembershipListener to listen CP membership changes. | 
| IAtomicLong | getAtomicLong(String name)Returns a proxy for an  IAtomicLonginstance created on CP
 Subsystem. | 
| <E> IAtomicReference<E> | getAtomicReference(String name)Returns a proxy for an  IAtomicReferenceinstance created on
 CP Subsystem. | 
| ICountDownLatch | getCountDownLatch(String name)Returns a proxy for an  ICountDownLatchinstance created on
 CP Subsystem. | 
| CPSessionManagementService | getCPSessionManagementService()Returns the  CPSessionManagementServiceof this Hazelcast
 instance. | 
| CPSubsystemManagementService | getCPSubsystemManagementService()Returns the  CPSubsystemManagementServiceof this Hazelcast
 instance. | 
| CPMember | getLocalCPMember()Returns the local CP member if this Hazelcast member is part of
 CP Subsystem, returns null otherwise. | 
| FencedLock | getLock(String name)Returns a proxy for an  FencedLockinstance created on CP
 Subsystem. | 
| ISemaphore | getSemaphore(String name)Returns a proxy for an  ISemaphoreinstance created on CP
 Subsystem. | 
| boolean | removeGroupAvailabilityListener(UUID id)Removes CPGroupAvailabilityListener registration. | 
| boolean | removeMembershipListener(UUID id)Removes membership listener registration. | 
@Nonnull IAtomicLong getAtomicLong(@Nonnull String name)
IAtomicLong instance created on CP
 Subsystem. Hazelcast's IAtomicLong is a distributed version of
 java.util.concurrent.atomic.AtomicLong. If no group name is
 given within the "name" parameter, then the IAtomicLong instance
 will be created on the DEFAULT CP group. If a group name is given, like
 .getAtomicLong("myLong@group1"), the given group will be
 initialized first, if not initialized already, and then the
 IAtomicLong instance will be created on this group. Returned
 IAtomicLong instance offers linearizability and behaves as a CP
 register. When a network partition occurs, proxies that exist on the
 minority side of its CP group lose availability.
 Each call of this method performs a commit to the METADATA CP group. Hence, callers should cache the returned proxy.
name - name of the IAtomicLong proxyIAtomicLong proxy for the given nameHazelcastException - if CP Subsystem is not enabled@Nonnull <E> IAtomicReference<E> getAtomicReference(@Nonnull String name)
IAtomicReference instance created on
 CP Subsystem. Hazelcast's IAtomicReference is a distributed
 version of java.util.concurrent.atomic.AtomicLong. If no group
 name is given within the "name" parameter, then
 the IAtomicReference instance will be created on the DEFAULT CP
 group. If a group name is given, like
 .getAtomicReference("myRef@group1"), the given group will be
 initialized first, if not initialized already, and then the
 IAtomicReference instance will be created on this group.
 Returned IAtomicReference instance offers linearizability and
 behaves as a CP register. When a network partition occurs, proxies that
 exist on the minority side of its CP group lose availability.
 Each call of this method performs a commit to the METADATA CP group. Hence, callers should cache the returned proxy.
E - the type of object referred to by the referencename - name of the IAtomicReference proxyIAtomicReference proxy for the given nameHazelcastException - if CP Subsystem is not enabled@Nonnull ICountDownLatch getCountDownLatch(@Nonnull String name)
ICountDownLatch instance created on
 CP Subsystem. Hazelcast's ICountDownLatch is a distributed
 version of java.util.concurrent.CountDownLatch. If no group
 name is given within the "name" parameter, then
 the ICountDownLatch instance will be created on the DEFAULT CP
 group. If a group name is given, like
 .getCountDownLatch("myLatch@group1"), the given group will be
 initialized first, if not initialized already, and then the
 ICountDownLatch instance will be created on this group. Returned
 ICountDownLatch instance offers linearizability. When a network
 partition occurs, proxies that exist on the minority side of its CP
 group lose availability.
 Each call of this method performs a commit to the METADATA CP group. Hence, callers should cache the returned proxy.
name - name of the ICountDownLatch proxyICountDownLatch proxy for the given nameHazelcastException - if CP Subsystem is not enabled@Nonnull FencedLock getLock(@Nonnull String name)
FencedLock instance created on CP
 Subsystem. Hazelcast's FencedLock is a distributed version of
 java.util.concurrent.locks.Lock. If no group name is given
 within the "name" parameter, then the FencedLock instance will
 be created on the DEFAULT CP group. If a group name is given, like
 .getLock("myLock@group1"), the given group will be initialized
 first, if not initialized already, and then the FencedLock
 instance will be created on this group. Returned FencedLock
 instance offers linearizability. When a network partition occurs,
 proxies that exist on the minority side of its CP group lose
 availability.
 Each call of this method performs a commit to the METADATA CP group. Hence, callers should cache the returned proxy.
name - name of the FencedLock proxyFencedLock proxy for the given nameHazelcastException - if CP Subsystem is not enabledFencedLockConfig@Nonnull ISemaphore getSemaphore(@Nonnull String name)
ISemaphore instance created on CP
 Subsystem. Hazelcast's ISemaphore is a distributed version of
 java.util.concurrent.Semaphore. If no group name is given
 within the "name" parameter, then the ISemaphore instance will
 be created on the DEFAULT CP group. If a group name is given, like
 .getSemaphore("mySemaphore@group1"), the given group will be
 initialized first, if not initialized already, and then the
 ISemaphore instance will be created on this group. Returned
 ISemaphore instance offers linearizability. When a network
 partition occurs, proxies that exist on the minority side of its CP
 group lose availability.
 Each call of this method performs a commit to the METADATA CP group. Hence, callers should cache the returned proxy.
name - name of the ISemaphore proxyISemaphore proxy for the given nameHazelcastException - if CP Subsystem is not enabledSemaphoreConfigCPMember getLocalCPMember()
 This method is a shortcut for CPSubsystemManagementService.getLocalCPMember()
 method. Calling this method is equivalent to calling
 getCPSubsystemManagementService().getLocalCPMember().
HazelcastException - if CP Subsystem is not enabledCPSubsystemManagementService.getLocalCPMember()CPSubsystemManagementService getCPSubsystemManagementService()
CPSubsystemManagementService of this Hazelcast
 instance. CPSubsystemManagementService offers APIs for managing
 CP members and CP groups.CPSubsystemManagementService of this Hazelcast instanceCPSessionManagementService getCPSessionManagementService()
CPSessionManagementService of this Hazelcast
 instance. CPSessionManagementService offers APIs for managing CP
 sessions.CPSessionManagementService of this Hazelcast instanceUUID addMembershipListener(CPMembershipListener listener)
listener - membership listenerboolean removeMembershipListener(UUID id)
id - of the registrationUUID addGroupAvailabilityListener(CPGroupAvailabilityListener listener)
listener - group availability listenerboolean removeGroupAvailabilityListener(UUID id)
id - of the registrationCopyright © 2021 Hazelcast, Inc.. All rights reserved.