| Package | Description | 
|---|---|
| com.hazelcast.client.impl | Implementation classes of the com.hazelcast.client interfaces | 
| com.hazelcast.core | Provides core API interfaces/classes. | 
| com.hazelcast.cp | Contains public APIs of the CP subsystem | 
| com.hazelcast.cp.exception | Contains exceptions that can be thrown by APIs of the CP subsystem | 
| com.hazelcast.cp.internal | Contains implementation of the CP subsystem | 
| com.hazelcast.cp.internal.raft.exception | Contains exception classes that can be thrown by the CP subsystem | 
| com.hazelcast.cp.internal.raft.impl | Contains implementation classes of the Raft algorithm | 
| com.hazelcast.cp.internal.raft.impl.command | Contains  RaftGroupCmdimplementations that are used by the core Raft algorithm implementation | 
| com.hazelcast.cp.internal.raft.impl.dto | Contains structs that are used in Raft RPCs | 
| com.hazelcast.cp.internal.raft.impl.handler | Contains request/response handler tasks. | 
| com.hazelcast.cp.internal.raft.impl.log | Contains the log abstraction which is maintained by the Raft algorithm | 
| com.hazelcast.cp.internal.raft.impl.state | Contains classes that keep state of Raft nodes | 
| com.hazelcast.cp.internal.raft.impl.task | Contains tasks running on leader or leader-candidates. | 
| com.hazelcast.cp.internal.raftop | Contains operations that are used in Hazelcast's Raft implementation | 
| com.hazelcast.instance | This package contains Hazelcast Instance functionality. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ClientEndpointRepresents an endpoint to a client. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ClientEndpointImplThe  ClientEndpointandClientimplementation. | 
| class  | ClientEventEvent used for notification of client connection and disconnection | 
| class  | ClientImplDefault  Clientimplementation. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | ClientThe Client interface allows to get information about
 a connected client's socket address, type and UUID. | 
| interface  | MemberCluster member interface. | 
| Modifier and Type | Method and Description | 
|---|---|
| Endpoint | HazelcastInstance. getLocalEndpoint()Returns the local Endpoint which this HazelcastInstance belongs to. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | CPMemberA CP member is a Hazelcast member that is internally elected to be part of
 the  CPSubsystem, hence maintain CP data structures. | 
| Modifier and Type | Method and Description | 
|---|---|
| Endpoint | CPSubsystemException. getLeader()Returns the leader endpoint of related CP group, if known/available
 by the time this exception is thrown. | 
| Constructor and Description | 
|---|
| CannotReplicateException(Endpoint leader) | 
| CPSubsystemException(Endpoint leader) | 
| CPSubsystemException(String message,
                    Endpoint leader) | 
| CPSubsystemException(String message,
                    Endpoint leader,
                    Throwable cause) | 
| LeaderDemotedException(Endpoint local,
                      Endpoint leader) | 
| NotLeaderException(CPGroupId groupId,
                  Endpoint local,
                  Endpoint leader) | 
| StaleAppendRequestException(Endpoint leader) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | CPMemberInfoCPMemberrepresents a member in Raft group. | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<Endpoint> | MismatchingGroupMembersCommitIndexException. getMembers() | 
| Constructor and Description | 
|---|
| MemberAlreadyExistsException(Endpoint member) | 
| MemberDoesNotExistException(Endpoint member) | 
| Constructor and Description | 
|---|
| MismatchingGroupMembersCommitIndexException(long commitIndex,
                                           Collection<Endpoint> members) | 
| Modifier and Type | Method and Description | 
|---|---|
| Endpoint | RaftNodeImpl. getLeader() | 
| Endpoint | RaftNode. getLeader()Returns the known leader endpoint. | 
| Endpoint | RaftNodeImpl. getLocalMember() | 
| Endpoint | RaftNode. getLocalMember()Returns the Raft endpoint for this node. | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<Endpoint> | RaftNodeImpl. getAppliedMembers() | 
| Collection<Endpoint> | RaftNode. getAppliedMembers()Returns the currently effective member list of the raft group this node
 belongs to. | 
| Collection<Endpoint> | RaftNodeImpl. getCommittedMembers() | 
| Collection<Endpoint> | RaftNode. getCommittedMembers()Returns the last committed member list of the raft group this node
 belongs to. | 
| Collection<Endpoint> | RaftNodeImpl. getInitialMembers() | 
| Collection<Endpoint> | RaftNode. getInitialMembers()Returns the initial member list of the Raft group this node belongs to. | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | RaftIntegration. isReachable(Endpoint endpoint)Returns true if the endpoint is reachable by the time this method
 is called, false otherwise. | 
| ICompletableFuture | RaftNodeImpl. replicateMembershipChange(Endpoint member,
                         MembershipChangeMode mode) | 
| ICompletableFuture | RaftNode. replicateMembershipChange(Endpoint member,
                         MembershipChangeMode mode)Replicates the membership change to the Raft group. | 
| ICompletableFuture | RaftNodeImpl. replicateMembershipChange(Endpoint member,
                         MembershipChangeMode mode,
                         long groupMembersCommitIndex) | 
| ICompletableFuture | RaftNode. replicateMembershipChange(Endpoint member,
                         MembershipChangeMode mode,
                         long groupMembersCommitIndex)Replicates the membership change to the Raft group, if expected members
 commit index is equal to the actual one stored in Raft state. | 
| void | RaftNodeImpl. send(AppendFailureResponse response,
    Endpoint target) | 
| boolean | RaftIntegration. send(AppendFailureResponse response,
    Endpoint target)Sends the  AppendFailureResponseto target endpoint to be handled
 by itsRaftNode.handleAppendResponse(AppendFailureResponse). | 
| void | RaftNodeImpl. send(AppendRequest request,
    Endpoint target) | 
| boolean | RaftIntegration. send(AppendRequest request,
    Endpoint target)Sends the  AppendRequestto target endpoint to be handled by
 itsRaftNode.handleAppendRequest(AppendRequest). | 
| void | RaftNodeImpl. send(AppendSuccessResponse response,
    Endpoint target) | 
| boolean | RaftIntegration. send(AppendSuccessResponse response,
    Endpoint target)Sends the  AppendSuccessResponseto target endpoint to be handled
 by itsRaftNode.handleAppendResponse(AppendSuccessResponse). | 
| boolean | RaftIntegration. send(InstallSnapshot request,
    Endpoint target)Sends the  InstallSnapshotto target endpoint to be handled by
 itsRaftNode.handleInstallSnapshot(InstallSnapshot). | 
| void | RaftNodeImpl. send(PreVoteRequest request,
    Endpoint target) | 
| boolean | RaftIntegration. send(PreVoteRequest request,
    Endpoint target)Sends the  PreVoteRequestto target endpoint to be handled by
 itsRaftNode.handlePreVoteRequest(PreVoteRequest). | 
| void | RaftNodeImpl. send(PreVoteResponse response,
    Endpoint target) | 
| boolean | RaftIntegration. send(PreVoteResponse response,
    Endpoint target)Sends the  PreVoteResponseto target endpoint to be handled by
 itsRaftNode.handlePreVoteResponse(PreVoteResponse). | 
| void | RaftNodeImpl. send(VoteRequest request,
    Endpoint target) | 
| boolean | RaftIntegration. send(VoteRequest request,
    Endpoint target)Sends the  VoteRequestto target endpoint to be handled by
 itsRaftNode.handleVoteRequest(VoteRequest). | 
| void | RaftNodeImpl. send(VoteResponse response,
    Endpoint target) | 
| boolean | RaftIntegration. send(VoteResponse response,
    Endpoint target)Sends the  VoteResponseto target endpoint to be handled by
 itsRaftNode.handleVoteResponse(VoteResponse). | 
| void | RaftNodeImpl. sendAppendRequest(Endpoint follower)Sends an append-entries request to the follower member. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RaftNodeImpl. updateGroupMembers(long logIndex,
                  Collection<Endpoint> members)Updates Raft group members. | 
| Constructor and Description | 
|---|
| RaftNodeImpl(CPGroupId groupId,
            Endpoint localMember,
            Collection<Endpoint> members,
            RaftAlgorithmConfig raftAlgorithmConfig,
            RaftIntegration raftIntegration) | 
| Constructor and Description | 
|---|
| RaftNodeImpl(CPGroupId groupId,
            Endpoint localMember,
            Collection<Endpoint> members,
            RaftAlgorithmConfig raftAlgorithmConfig,
            RaftIntegration raftIntegration) | 
| Modifier and Type | Method and Description | 
|---|---|
| Endpoint | UpdateRaftGroupMembersCmd. getMember() | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<Endpoint> | UpdateRaftGroupMembersCmd. getMembers() | 
| Constructor and Description | 
|---|
| UpdateRaftGroupMembersCmd(Collection<Endpoint> members,
                         Endpoint member,
                         MembershipChangeMode mode) | 
| Constructor and Description | 
|---|
| UpdateRaftGroupMembersCmd(Collection<Endpoint> members,
                         Endpoint member,
                         MembershipChangeMode mode) | 
| Modifier and Type | Method and Description | 
|---|---|
| Endpoint | VoteRequest. candidate() | 
| Endpoint | PreVoteRequest. candidate() | 
| Endpoint | AppendFailureResponse. follower() | 
| Endpoint | AppendSuccessResponse. follower() | 
| Endpoint | AppendRequest. leader() | 
| Endpoint | InstallSnapshot. leader() | 
| Endpoint | VoteResponse. voter() | 
| Endpoint | PreVoteResponse. voter() | 
| Constructor and Description | 
|---|
| AppendFailureResponse(Endpoint follower,
                     int term,
                     long expectedNextIndex) | 
| AppendRequest(Endpoint leader,
             int term,
             int prevLogTerm,
             long prevLogIndex,
             long leaderCommitIndex,
             LogEntry[] entries) | 
| AppendSuccessResponse(Endpoint follower,
                     int term,
                     long lastLogIndex) | 
| InstallSnapshot(Endpoint leader,
               int term,
               SnapshotEntry snapshot) | 
| PreVoteRequest(Endpoint candidate,
              int nextTerm,
              int lastLogTerm,
              long lastLogIndex) | 
| PreVoteResponse(Endpoint voter,
               int term,
               boolean granted) | 
| VoteRequest(Endpoint candidate,
           int term,
           int lastLogTerm,
           long lastLogIndex) | 
| VoteResponse(Endpoint voter,
            int term,
            boolean granted) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected abstract Endpoint | AbstractResponseHandlerTask. sender() | 
| protected Endpoint | VoteResponseHandlerTask. sender() | 
| protected Endpoint | PreVoteResponseHandlerTask. sender() | 
| protected Endpoint | AppendSuccessResponseHandlerTask. sender() | 
| protected Endpoint | AppendFailureResponseHandlerTask. sender() | 
| Modifier and Type | Method and Description | 
|---|---|
| Collection<Endpoint> | SnapshotEntry. groupMembers() | 
| Constructor and Description | 
|---|
| SnapshotEntry(int term,
             long index,
             Object operation,
             long groupMembersLogIndex,
             Collection<Endpoint> groupMembers) | 
| Modifier and Type | Method and Description | 
|---|---|
| Endpoint | RaftState. leader()Returns the known leader | 
| Endpoint | RaftState. votedFor()Returns the endpoint this note voted for | 
| Modifier and Type | Method and Description | 
|---|---|
| Map<Endpoint,FollowerState> | LeaderState. getFollowerStates() | 
| Collection<Endpoint> | RaftState. initialMembers() | 
| Collection<Endpoint> | RaftGroupMembers. members()Return all members in this group. | 
| Collection<Endpoint> | RaftState. members()Returns all members in the last applied group members | 
| Collection<Endpoint> | RaftGroupMembers. remoteMembers()Returns remote members in this group, excluding the local member. | 
| Collection<Endpoint> | RaftState. remoteMembers()Returns remote members in the last applied group members | 
| Modifier and Type | Method and Description | 
|---|---|
| void | LeaderState. add(Endpoint follower,
   long lastLogIndex)Add a new follower with the leader's  lastLogIndex. | 
| FollowerState | LeaderState. getFollowerState(Endpoint follower) | 
| boolean | CandidateState. grantVote(Endpoint address)Persists vote for the endpoint during election. | 
| boolean | RaftGroupMembers. isKnownMember(Endpoint endpoint)Returns true if the endpoint is a member of this group, false otherwise. | 
| boolean | RaftState. isKnownMember(Endpoint endpoint)Returns true if the endpoint is a member of the last applied group, false otherwise. | 
| void | RaftState. leader(Endpoint endpoint)Updates the known leader | 
| void | RaftState. persistVote(int term,
           Endpoint endpoint)Persist a vote for the endpoint in current term during leader election. | 
| void | LeaderState. remove(Endpoint follower)Removes a follower from leader maintained state. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | RaftState. restoreGroupMembers(long logIndex,
                   Collection<Endpoint> members)Restores group members from the snapshot. | 
| void | RaftState. updateGroupMembers(long logIndex,
                  Collection<Endpoint> members)Initializes the last applied group members with the members and logIndex. | 
| Constructor and Description | 
|---|
| RaftState(CPGroupId groupId,
         Endpoint localEndpoint,
         Collection<Endpoint> endpoints,
         int logCapacity) | 
| Constructor and Description | 
|---|
| RaftState(CPGroupId groupId,
         Endpoint localEndpoint,
         Collection<Endpoint> endpoints,
         int logCapacity) | 
| Constructor and Description | 
|---|
| MembershipChangeTask(RaftNodeImpl raftNode,
                    SimpleCompletableFuture resultFuture,
                    Endpoint member,
                    MembershipChangeMode membershipChangeMode) | 
| MembershipChangeTask(RaftNodeImpl raftNode,
                    SimpleCompletableFuture resultFuture,
                    Endpoint member,
                    MembershipChangeMode membershipChangeMode,
                    Long groupMembersCommitIndex) | 
| Constructor and Description | 
|---|
| GetInitialRaftGroupMembersIfCurrentGroupMemberOp(Endpoint cpMember) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractMember | 
| class  | MemberImpl | 
Copyright © 2020 Hazelcast, Inc.. All Rights Reserved.