Package | Description |
---|---|
com.hazelcast.client.cp.internal.datastructures.atomiclong |
Contains client-side proxy impl of
Raft-based
IAtomicLong |
com.hazelcast.client.cp.internal.datastructures.atomicref |
Contains client-side proxy impl of
Raft-based
IAtomicReference |
com.hazelcast.client.cp.internal.datastructures.countdownlatch |
Contains client-side proxy impl of
Raft-based
ICountDownLatch |
com.hazelcast.client.cp.internal.datastructures.lock |
Contains client-side proxy impl of
Raft-based
FencedLock |
com.hazelcast.client.cp.internal.datastructures.semaphore |
Contains client-side proxy impl of Raft-based
ISemaphore |
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.client | |
com.hazelcast.cp.internal.datastructures.atomiclong |
Contains service classes for the Raft-based
IAtomicLong implementation |
com.hazelcast.cp.internal.datastructures.atomiclong.operation |
Contains operations for the Raft-based
IAtomicLong implementation |
com.hazelcast.cp.internal.datastructures.atomiclong.proxy |
Contains
IAtomicLong functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.atomicref |
Contains service classes for the Raft-based
IAtomicReference implementation |
com.hazelcast.cp.internal.datastructures.atomicref.operation |
Contains operations for the Raft-based
IAtomicReference implementation |
com.hazelcast.cp.internal.datastructures.atomicref.proxy |
Contains
IAtomicReference functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.countdownlatch |
Contains service classes for the Raft-based
ICountDownLatch implementation |
com.hazelcast.cp.internal.datastructures.countdownlatch.operation |
Contains operations for the Raft-based
ICountDownLatch implementation |
com.hazelcast.cp.internal.datastructures.countdownlatch.proxy |
Contains
IAtomicLong functionality
based on the Raft algorithm. |
com.hazelcast.cp.internal.datastructures.lock |
Contains service classes for the Raft-based
ILock
and FencedLock implementation |
com.hazelcast.cp.internal.datastructures.lock.operation |
Contains operations for the Raft-based
ILock implementation |
com.hazelcast.cp.internal.datastructures.semaphore |
Contains service classes for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.datastructures.semaphore.operation |
Contains operations for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.datastructures.spi |
Contains the abstractions that is used for managing proxies
for the Raft-based data structure implementations
|
com.hazelcast.cp.internal.datastructures.spi.blocking |
Contains the interfaces and abstractions that are implemented / extended
by blocking Raft services, such as Lock, Semaphore, and CountDownLatch
|
com.hazelcast.cp.internal.datastructures.spi.blocking.operation |
Contains the operations that are used by the
AbstractBlockingService abstraction |
com.hazelcast.cp.internal.datastructures.spi.operation |
Contains the operations that is used for managing proxies
for the Raft-based data structure implementations
|
com.hazelcast.cp.internal.operation |
Contains operations for the Raft Invocation SPI
|
com.hazelcast.cp.internal.operation.integration |
Contains Hazelcast operations that carry out Raft RPCs
|
com.hazelcast.cp.internal.raft |
Contains abstractions that are defined
for the core Raft algorithm implementation
|
com.hazelcast.cp.internal.raft.impl |
Contains implementation classes of the Raft algorithm
|
com.hazelcast.cp.internal.raft.impl.state |
Contains classes that keep state of Raft nodes
|
com.hazelcast.cp.internal.raftop |
Contains operations that are used in Hazelcast's Raft implementation
|
com.hazelcast.cp.internal.raftop.metadata |
Contains operations that are used in the Metadata CP group
|
com.hazelcast.cp.internal.raftop.snapshot |
Contains operations that are used by Hazelcast to implement
Raft's snapshotting mechanism
|
com.hazelcast.cp.internal.session |
Contains service classes
for the Raft-based
ISemaphore implementation |
com.hazelcast.cp.internal.session.operation |
Contains operations that are internally used by the CP session API
|
com.hazelcast.cp.lock |
Contains locking APIs of the CP subsystem
|
com.hazelcast.spi.impl.operationservice.impl |
Contains the code for the
InternalOperationService implementation. |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftAtomicLongProxy.getGroupId() |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftAtomicRefProxy.getGroupId() |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftCountDownLatchProxy.getGroupId() |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftFencedLockProxy.getGroupId() |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftSessionlessSemaphoreProxy.getGroupId() |
CPGroupId |
RaftSessionAwareSemaphoreProxy.getGroupId() |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
CPGroup.id()
Returns unique id of the CP group
|
Modifier and Type | Method and Description |
---|---|
ICompletableFuture<Collection<CPGroupId>> |
CPSubsystemManagementService.getCPGroupIds()
Returns all active CP group ids.
|
Modifier and Type | Method and Description |
---|---|
CPGroupId |
CPGroupDestroyedException.getGroupId() |
Constructor and Description |
---|
CPGroupDestroyedException(CPGroupId groupId) |
NotLeaderException(CPGroupId groupId,
Endpoint local,
Endpoint leader) |
Modifier and Type | Class and Description |
---|---|
class |
RaftGroupId
Implementation of
CPGroupId . |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
MetadataRaftGroupManager.createRaftGroup(String groupName,
Collection<CPMemberInfo> members,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
Collection<CPGroupId> |
MetadataRaftGroupManager.getActiveGroupIds() |
ICompletableFuture<Collection<CPGroupId>> |
RaftService.getAllCPGroupIds() |
ICompletableFuture<Collection<CPGroupId>> |
RaftService.getCPGroupIds() |
Collection<CPGroupId> |
RaftService.getCPGroupIdsLocally() |
Collection<CPGroupId> |
MetadataRaftGroupManager.getDestroyingGroupIds() |
Collection<CPGroupId> |
MetadataRaftGroupManager.getGroupIds() |
Modifier and Type | Method and Description |
---|---|
void |
RaftService.createRaftNode(CPGroupId groupId,
Collection<CPMemberInfo> members) |
InternalCompletableFuture<Object> |
RaftInvocationManager.destroy(CPGroupId groupId) |
void |
RaftService.destroyRaftNode(CPGroupId groupId) |
ICompletableFuture<CPGroup> |
RaftService.getCPGroup(CPGroupId groupId) |
CPGroupInfo |
RaftService.getCPGroupLocally(CPGroupId groupId) |
CPGroupInfo |
MetadataRaftGroupManager.getGroup(CPGroupId groupId) |
RaftNode |
RaftService.getOrInitRaftNode(CPGroupId groupId) |
RaftNode |
RaftService.getRaftNode(CPGroupId groupId) |
void |
RaftService.handleAppendEntries(CPGroupId groupId,
AppendRequest request,
CPMember target) |
void |
RaftService.handleAppendResponse(CPGroupId groupId,
AppendFailureResponse response,
CPMember target) |
void |
RaftService.handleAppendResponse(CPGroupId groupId,
AppendSuccessResponse response,
CPMember target) |
void |
RaftService.handlePreVoteRequest(CPGroupId groupId,
PreVoteRequest request,
CPMember target) |
void |
RaftService.handlePreVoteResponse(CPGroupId groupId,
PreVoteResponse response,
CPMember target) |
void |
RaftService.handleSnapshot(CPGroupId groupId,
InstallSnapshot request,
CPMember target) |
void |
RaftService.handleVoteRequest(CPGroupId groupId,
VoteRequest request,
CPMember target) |
void |
RaftService.handleVoteResponse(CPGroupId groupId,
VoteResponse response,
CPMember target) |
<T> InternalCompletableFuture<T> |
RaftInvocationManager.invoke(CPGroupId groupId,
RaftOp raftOp) |
<T> InternalCompletableFuture<T> |
RaftInvocationManager.invoke(CPGroupId groupId,
RaftOp raftOp,
boolean deserializeResponse) |
boolean |
RaftService.isRaftGroupDestroyed(CPGroupId groupId) |
void |
TermChangeAwareService.onNewTermCommit(CPGroupId groupId,
long commitIndex)
Invokes as part of the first commit after a new leader is elected.
|
void |
RaftService.onRaftGroupDestroyed(CPGroupId groupId) |
void |
RaftNodeLifecycleAwareService.onRaftGroupDestroyed(CPGroupId groupId)
Called on the thread of the Raft group when the given Raft node is
destroyed, either gracefully or forcefully.
|
void |
RaftService.onRaftNodeSteppedDown(CPGroupId groupId) |
void |
RaftNodeLifecycleAwareService.onRaftNodeSteppedDown(CPGroupId groupId)
Called on the thread of the Raft group when the given Raft node is
stepped down, either because it is shutting down, or it could not be
added to the Raft group
|
<T> InternalCompletableFuture<T> |
RaftInvocationManager.query(CPGroupId groupId,
RaftOp raftOp,
QueryPolicy queryPolicy) |
<T> InternalCompletableFuture<T> |
RaftInvocationManager.query(CPGroupId groupId,
RaftOp raftOp,
QueryPolicy queryPolicy,
boolean deserializeResponse) |
<T> InternalCompletableFuture<T> |
RaftInvocationManager.queryLocally(CPGroupId groupId,
RaftOp raftOp,
QueryPolicy queryPolicy) |
void |
MetadataRaftGroupManager.restoreSnapshot(CPGroupId groupId,
long commitIndex,
MetadataRaftGroupSnapshot snapshot) |
void |
RaftService.restoreSnapshot(CPGroupId groupId,
long commitIndex,
MetadataRaftGroupSnapshot snapshot) |
abstract Object |
RaftOp.run(CPGroupId groupId,
long commitIndex)
Contains actual Raft operation logic.
|
void |
RaftService.stepDownRaftNode(CPGroupId groupId) |
MetadataRaftGroupSnapshot |
MetadataRaftGroupManager.takeSnapshot(CPGroupId groupId,
long commitIndex) |
MetadataRaftGroupSnapshot |
RaftService.takeSnapshot(CPGroupId groupId,
long commitIndex) |
void |
MetadataRaftGroupManager.triggerDestroyRaftGroup(CPGroupId groupId) |
Modifier and Type | Method and Description |
---|---|
void |
MetadataRaftGroupManager.completeDestroyRaftGroups(Set<CPGroupId> groupIds) |
MembershipChangeSchedule |
MetadataRaftGroupManager.completeRaftGroupMembershipChanges(long commitIndex,
Map<CPGroupId,Tuple2<Long,Long>> changedGroups) |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractCPMessageTask.invoke(CPGroupId groupId,
RaftOp op) |
protected void |
AbstractCPMessageTask.query(CPGroupId groupId,
RaftOp op,
QueryPolicy policy) |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftAtomicLong.groupId() |
Modifier and Type | Method and Description |
---|---|
boolean |
RaftAtomicLongService.destroyRaftObject(CPGroupId groupId,
String name) |
RaftAtomicLong |
RaftAtomicLongService.getAtomicLong(CPGroupId groupId,
String name) |
void |
RaftAtomicLongService.onRaftGroupDestroyed(CPGroupId groupId) |
void |
RaftAtomicLongService.onRaftNodeSteppedDown(CPGroupId groupId) |
void |
RaftAtomicLongService.restoreSnapshot(CPGroupId groupId,
long commitIndex,
RaftAtomicLongSnapshot snapshot) |
RaftAtomicLongSnapshot |
RaftAtomicLongService.takeSnapshot(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
Object |
AlterOp.run(CPGroupId groupId,
long commitIndex) |
Object |
ApplyOp.run(CPGroupId groupId,
long commitIndex) |
Object |
LocalGetOp.run(CPGroupId groupId,
long commitIndex) |
Object |
CompareAndSetOp.run(CPGroupId groupId,
long commitIndex) |
Object |
GetAndAddOp.run(CPGroupId groupId,
long commitIndex) |
Object |
AddAndGetOp.run(CPGroupId groupId,
long commitIndex) |
Object |
GetAndSetOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftAtomicLongProxy.getGroupId() |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftAtomicRef.groupId() |
Modifier and Type | Method and Description |
---|---|
boolean |
RaftAtomicRefService.destroyRaftObject(CPGroupId groupId,
String name) |
RaftAtomicRef |
RaftAtomicRefService.getAtomicRef(CPGroupId groupId,
String name) |
void |
RaftAtomicRefService.onRaftGroupDestroyed(CPGroupId groupId) |
void |
RaftAtomicRefService.onRaftNodeSteppedDown(CPGroupId groupId) |
void |
RaftAtomicRefService.restoreSnapshot(CPGroupId groupId,
long commitIndex,
RaftAtomicRefSnapshot snapshot) |
RaftAtomicRefSnapshot |
RaftAtomicRefService.takeSnapshot(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
Object |
ApplyOp.run(CPGroupId groupId,
long commitIndex) |
Object |
ContainsOp.run(CPGroupId groupId,
long commitIndex) |
Object |
CompareAndSetOp.run(CPGroupId groupId,
long commitIndex) |
Object |
GetOp.run(CPGroupId groupId,
long commitIndex) |
Object |
SetOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftAtomicRefProxy.getGroupId() |
Modifier and Type | Method and Description |
---|---|
boolean |
RaftCountDownLatchService.await(CPGroupId groupId,
String name,
AwaitInvocationKey key,
long timeoutMillis) |
int |
RaftCountDownLatchService.countDown(CPGroupId groupId,
String name,
UUID invocationUuid,
int expectedRound) |
protected RaftCountDownLatchRegistry |
RaftCountDownLatchService.createNewRegistry(CPGroupId groupId) |
protected RaftCountDownLatch |
RaftCountDownLatchRegistry.createNewResource(CPGroupId groupId,
String name) |
int |
RaftCountDownLatchService.getRemainingCount(CPGroupId groupId,
String name) |
int |
RaftCountDownLatchService.getRound(CPGroupId groupId,
String name) |
boolean |
RaftCountDownLatchService.trySetCount(CPGroupId groupId,
String name,
int count) |
Modifier and Type | Method and Description |
---|---|
Object |
CountDownOp.run(CPGroupId groupId,
long commitIndex) |
Object |
AwaitOp.run(CPGroupId groupId,
long commitIndex) |
Object |
GetRoundOp.run(CPGroupId groupId,
long commitIndex) |
Object |
GetCountOp.run(CPGroupId groupId,
long commitIndex) |
Object |
TrySetCountOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftCountDownLatchProxy.getGroupId() |
Modifier and Type | Method and Description |
---|---|
AcquireResult |
RaftLockService.acquire(CPGroupId groupId,
String name,
LockInvocationKey key,
long timeoutMs) |
protected com.hazelcast.cp.internal.datastructures.lock.RaftLockRegistry |
RaftLockService.createNewRegistry(CPGroupId groupId) |
RaftLockOwnershipState |
RaftLockService.getLockOwnershipState(CPGroupId groupId,
String name) |
boolean |
RaftLockService.release(CPGroupId groupId,
long commitIndex,
String name,
LockEndpoint endpoint,
UUID invocationUid) |
Modifier and Type | Method and Description |
---|---|
Object |
GetLockOwnershipStateOp.run(CPGroupId groupId,
long commitIndex) |
Object |
LockOp.run(CPGroupId groupId,
long commitIndex) |
Object |
TryLockOp.run(CPGroupId groupId,
long commitIndex) |
Object |
UnlockOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
AcquireResult |
RaftSemaphoreService.acquirePermits(CPGroupId groupId,
String name,
AcquireInvocationKey key,
long timeoutMs) |
int |
RaftSemaphoreService.availablePermits(CPGroupId groupId,
String name) |
boolean |
RaftSemaphoreService.changePermits(CPGroupId groupId,
long commitIndex,
String name,
SemaphoreEndpoint endpoint,
UUID invocationUid,
int permits) |
protected RaftSemaphoreRegistry |
RaftSemaphoreService.createNewRegistry(CPGroupId groupId) |
protected RaftSemaphore |
RaftSemaphoreRegistry.createNewResource(CPGroupId groupId,
String name) |
int |
RaftSemaphoreService.drainPermits(CPGroupId groupId,
String name,
long commitIndex,
SemaphoreEndpoint endpoint,
UUID invocationUid) |
boolean |
RaftSemaphoreService.initSemaphore(CPGroupId groupId,
String name,
int permits) |
void |
RaftSemaphoreService.releasePermits(CPGroupId groupId,
long commitIndex,
String name,
SemaphoreEndpoint endpoint,
UUID invocationUid,
int permits) |
Modifier and Type | Method and Description |
---|---|
Object |
ReleasePermitsOp.run(CPGroupId groupId,
long commitIndex) |
Object |
AvailablePermitsOp.run(CPGroupId groupId,
long commitIndex) |
Object |
DrainPermitsOp.run(CPGroupId groupId,
long commitIndex) |
Object |
InitSemaphoreOp.run(CPGroupId groupId,
long commitIndex) |
Object |
ChangePermitsOp.run(CPGroupId groupId,
long commitIndex) |
Object |
AcquirePermitsOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
boolean |
RaftRemoteService.destroyRaftObject(CPGroupId groupId,
String objectName)
Destroys the given CP data structure on the CP group.
|
Modifier and Type | Field and Description |
---|---|
protected CPGroupId |
ResourceRegistry.groupId |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
BlockingResource.getGroupId() |
CPGroupId |
ResourceRegistry.getGroupId() |
Modifier and Type | Method and Description |
---|---|
protected abstract RR |
AbstractBlockingService.createNewRegistry(CPGroupId groupId)
Creates a registry for the given Raft group.
|
protected abstract R |
ResourceRegistry.createNewResource(CPGroupId groupId,
String name) |
boolean |
AbstractBlockingService.destroyRaftObject(CPGroupId groupId,
String name) |
void |
AbstractBlockingService.expireWaitKeys(CPGroupId groupId,
Collection<Tuple2<String,UUID>> keys) |
Collection<Long> |
AbstractBlockingService.getAttachedSessions(CPGroupId groupId) |
Collection<Tuple2<Address,Long>> |
AbstractBlockingService.getLiveOperations(CPGroupId groupId) |
protected RR |
AbstractBlockingService.getOrInitRegistry(CPGroupId groupId) |
RR |
AbstractBlockingService.getRegistryOrNull(CPGroupId groupId) |
protected void |
AbstractBlockingService.heartbeatSession(CPGroupId groupId,
long sessionId) |
protected void |
AbstractBlockingService.notifyWaitKeys(CPGroupId groupId,
String name,
Collection<W> keys,
Object result) |
void |
AbstractBlockingService.onRaftGroupDestroyed(CPGroupId groupId) |
void |
AbstractBlockingService.onRaftNodeSteppedDown(CPGroupId groupId) |
void |
AbstractBlockingService.onSessionClose(CPGroupId groupId,
long sessionId) |
void |
AbstractBlockingService.restoreSnapshot(CPGroupId groupId,
long commitIndex,
RR registry) |
protected void |
AbstractBlockingService.scheduleTimeout(CPGroupId groupId,
String name,
UUID invocationUid,
long timeoutMs) |
RR |
AbstractBlockingService.takeSnapshot(CPGroupId groupId,
long commitIndex) |
Constructor and Description |
---|
BlockingResource(CPGroupId groupId,
String name) |
ResourceRegistry(CPGroupId groupId) |
Modifier and Type | Method and Description |
---|---|
Object |
ExpireWaitKeysOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
Object |
DestroyRaftObjectOp.run(CPGroupId groupId,
long commitIndex) |
Constructor and Description |
---|
ChangeRaftGroupMembershipOp(CPGroupId groupId,
long membersCommitIndex,
CPMemberInfo member,
MembershipChangeMode membershipChangeMode) |
DefaultRaftReplicateOp(CPGroupId groupId,
RaftOp op) |
DestroyRaftGroupOp(CPGroupId groupId) |
RaftQueryOp(CPGroupId groupId,
RaftOp raftOp,
QueryPolicy queryPolicy) |
Modifier and Type | Field and Description |
---|---|
protected CPGroupId |
AsyncRaftOp.groupId |
Constructor and Description |
---|
AppendFailureResponseOp(CPGroupId groupId,
AppendFailureResponse appendResponse) |
AppendRequestOp(CPGroupId groupId,
AppendRequest appendRequest) |
AppendSuccessResponseOp(CPGroupId groupId,
AppendSuccessResponse appendResponse) |
InstallSnapshotOp(CPGroupId groupId,
InstallSnapshot installSnapshot) |
PreVoteRequestOp(CPGroupId groupId,
PreVoteRequest voteRequest) |
PreVoteResponseOp(CPGroupId groupId,
PreVoteResponse voteResponse) |
VoteRequestOp(CPGroupId groupId,
VoteRequest voteRequest) |
VoteResponseOp(CPGroupId groupId,
VoteResponse voteResponse) |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotAwareService.restoreSnapshot(CPGroupId groupId,
long commitIndex,
T snapshot)
Restores the snapshot for specified
CPGroupId . |
T |
SnapshotAwareService.takeSnapshot(CPGroupId groupId,
long commitIndex)
Creates a snapshot for specified
CPGroupId . |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftNodeImpl.getGroupId() |
CPGroupId |
RaftNode.getGroupId()
Returns the groupId which this node belongs to.
|
Constructor and Description |
---|
RaftNodeImpl(CPGroupId groupId,
Endpoint localMember,
Collection<Endpoint> members,
RaftAlgorithmConfig raftAlgorithmConfig,
RaftIntegration raftIntegration) |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
RaftState.groupId() |
Constructor and Description |
---|
RaftState(CPGroupId groupId,
Endpoint localEndpoint,
Collection<Endpoint> endpoints,
int logCapacity) |
Modifier and Type | Method and Description |
---|---|
Object |
NotifyTermChangeOp.run(CPGroupId groupId,
long commitIndex) |
Object |
GetInitialRaftGroupMembersIfCurrentGroupMemberOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
Object |
MetadataRaftGroupOp.run(CPGroupId groupId,
long commitIndex) |
Constructor and Description |
---|
CreateRaftNodeOp(CPGroupId groupId,
Collection<CPMemberInfo> initialMembers) |
GetRaftGroupOp(CPGroupId targetGroupId) |
TriggerDestroyRaftGroupOp(CPGroupId targetGroupId) |
Constructor and Description |
---|
CompleteDestroyRaftGroupsOp(Set<CPGroupId> groupIds) |
CompleteRaftGroupMembershipChangesOp(Map<CPGroupId,Tuple2<Long,Long>> changedGroups) |
DestroyRaftNodesOp(Collection<CPGroupId> groupIds) |
Modifier and Type | Method and Description |
---|---|
Object |
RestoreSnapshotOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
void |
RaftSessionService.closeInactiveSessions(CPGroupId groupId,
Collection<Long> inactiveSessions) |
boolean |
RaftSessionService.closeSession(CPGroupId groupId,
long sessionId) |
SessionResponse |
RaftSessionService.createNewSession(CPGroupId groupId,
Address endpoint,
String endpointName,
CPSession.CPSessionOwnerType endpointType) |
void |
RaftSessionService.expireSessions(CPGroupId groupId,
Collection<Tuple2<Long,Long>> sessionsToExpire) |
long |
RaftSessionService.generateThreadId(CPGroupId groupId) |
Collection<Long> |
SessionAwareService.getAttachedSessions(CPGroupId groupId)
Returns a collection of session ids that this service has attached some
resources.
|
Collection<CPSession> |
RaftSessionService.getSessionsLocally(CPGroupId groupId) |
void |
RaftSessionService.heartbeat(CPGroupId groupId,
long sessionId) |
void |
SessionAccessor.heartbeat(CPGroupId groupId,
long sessionId)
Performs a heartbeat for the given session id in the Raft group.
|
boolean |
RaftSessionService.isActive(CPGroupId groupId,
long sessionId) |
boolean |
SessionAccessor.isActive(CPGroupId groupId,
long sessionId)
Checks if there is an active session with the given id in the Raft group
|
void |
RaftSessionService.onNewTermCommit(CPGroupId groupId,
long commitIndex) |
void |
RaftSessionService.onRaftGroupDestroyed(CPGroupId groupId) |
void |
RaftSessionService.onRaftNodeSteppedDown(CPGroupId groupId) |
void |
SessionAwareService.onSessionClose(CPGroupId groupId,
long sessionId)
Called when a session is closed.
|
void |
RaftSessionService.restoreSnapshot(CPGroupId groupId,
long commitIndex,
com.hazelcast.cp.internal.session.RaftSessionRegistry registry) |
com.hazelcast.cp.internal.session.RaftSessionRegistry |
RaftSessionService.takeSnapshot(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
Object |
CloseSessionOp.run(CPGroupId groupId,
long commitIndex) |
Object |
GetSessionsOp.run(CPGroupId groupId,
long commitIndex) |
Object |
HeartbeatSessionOp.run(CPGroupId groupId,
long commitIndex) |
Object |
ExpireSessionsOp.run(CPGroupId groupId,
long commitIndex) |
Object |
GenerateThreadIdOp.run(CPGroupId groupId,
long commitIndex) |
Object |
CreateSessionOp.run(CPGroupId groupId,
long commitIndex) |
Object |
CloseInactiveSessionsOp.run(CPGroupId groupId,
long commitIndex) |
Modifier and Type | Method and Description |
---|---|
CPGroupId |
FencedLock.getGroupId()
Returns id of the CP group that runs this
FencedLock instance |
Constructor and Description |
---|
RaftInvocation(com.hazelcast.spi.impl.operationservice.impl.Invocation.Context context,
RaftInvocationContext raftInvocationContext,
CPGroupId groupId,
Operation op,
int retryCount,
long retryPauseMillis,
long callTimeoutMillis) |
RaftInvocation(com.hazelcast.spi.impl.operationservice.impl.Invocation.Context context,
RaftInvocationContext raftInvocationContext,
CPGroupId groupId,
Operation op,
int retryCount,
long retryPauseMillis,
long callTimeoutMillis,
boolean deserializeResponse) |
Copyright © 2020 Hazelcast, Inc.. All Rights Reserved.