Interface | Description |
---|---|
AbstractPaxosRepair.Listener | |
AbstractPaxosRepair.StateUpdater<S,I,T extends java.lang.Throwable> | |
BallotGenerator | |
Paxos.Async<Result> | |
PaxosOperationLock |
Class | Description |
---|---|
AbstractPaxosRepair | |
AbstractPaxosRepair.Failure | |
AbstractPaxosRepair.Result | |
AbstractPaxosRepair.State | |
Ballot | |
Ballot.Serializer | |
BallotGenerator.Default | |
BallotGenerator.Global | |
Commit | |
Commit.Accepted | |
Commit.AcceptedWithTTL | |
Commit.Agreed | |
Commit.CommitSerializer<T extends Commit> | |
Commit.Committed | |
Commit.CommittedWithTTL | |
Commit.Proposal | |
ContentionStrategy |
A strategy for making back-off decisions for Paxos operations that fail to make progress because of other paxos operations.
|
Paxos |
This class serves as an entry-point to Cassandra's implementation of Paxos Consensus.
|
PaxosCommit<OnDone extends java.util.function.Consumer<? super org.apache.cassandra.service.paxos.PaxosCommit.Status>> | |
PaxosCommit.RequestHandler | |
PaxosCommitAndPrepare | |
PaxosCommitAndPrepare.RequestHandler | |
PaxosCommitAndPrepare.RequestSerializer | |
PaxosPrepare |
Perform one paxos "prepare" attempt, with various optimisations.
|
PaxosPrepare.RequestHandler | |
PaxosPrepare.RequestSerializer | |
PaxosPrepare.ResponseSerializer | |
PaxosPrepareRefresh |
Nodes that have promised in response to our prepare, may be missing the latestCommit, meaning we cannot be sure the
prior round has been committed to the necessary quorum of participants, so that it will be visible to future quorums.
|
PaxosPrepareRefresh.RequestHandler | |
PaxosPrepareRefresh.RequestSerializer | |
PaxosPrepareRefresh.ResponseSerializer | |
PaxosPropose<OnDone extends java.util.function.Consumer<? super org.apache.cassandra.service.paxos.PaxosPropose.Status>> |
In waitForNoSideEffect mode, we will not return failure to the caller until
we have received a complete set of refusal responses, or at least one accept,
indicating (respectively) that we have had no side effect, or that we cannot
know if we our proposal produced a side effect.
|
PaxosPropose.RequestHandler |
The proposal request handler, i.e.
|
PaxosPropose.RequestSerializer | |
PaxosPropose.ResponseSerializer | |
PaxosRepair |
Facility to finish any in-progress paxos transaction, and ensure that a quorum of nodes agree on the most recent operation.
|
PaxosRepair.RequestHandler |
The proposal request handler, i.e.
|
PaxosRepair.RequestSerializer | |
PaxosRepair.ResponseSerializer | |
PaxosRepairHistory | |
PaxosRequestCallback<T> | |
PaxosState |
We save to memory the result of each operation before persisting to disk, however each operation that performs
the update does not return a result to the coordinator until the result is fully persisted.
|
PaxosState.Key | |
PaxosState.MaybePromise | |
PaxosState.Snapshot | |
PaxosState.UnsafeSnapshot | |
PrepareResponse | |
PrepareResponse.PrepareResponseSerializer | |
TablePaxosRepairHistory |
Enum | Description |
---|---|
Ballot.Flag | |
ContentionStrategy.Type | |
PaxosState.MaybePromise.Outcome |
Copyright © 2009-2022 The Apache Software Foundation