LogCabin
LogCabin::Server::RaftConsensus Member List
This is the complete list of members for LogCabin::Server::RaftConsensus, including all inherited members.
advanceCommitIndex()LogCabin::Server::RaftConsensus [private]
append(const std::vector< const Storage::Log::Entry * > &entries)LogCabin::Server::RaftConsensus [private]
appendEntries(std::unique_lock< Mutex > &lockGuard, Peer &peer)LogCabin::Server::RaftConsensus [private]
becomeLeader()LogCabin::Server::RaftConsensus [private]
beginSnapshot(uint64_t lastIncludedIndex)LogCabin::Server::RaftConsensus
bootstrapConfiguration()LogCabin::Server::RaftConsensus
CANDIDATE enum valueLogCabin::Server::RaftConsensus [private]
ClientResult enum nameLogCabin::Server::RaftConsensus
Clock typedefLogCabin::Server::RaftConsensus
ClusterClock typedefLogCabin::Server::RaftConsensus
clusterClockLogCabin::Server::RaftConsensus [private]
commitIndexLogCabin::Server::RaftConsensus [private]
Configuration typedefLogCabin::Server::RaftConsensus
configurationLogCabin::Server::RaftConsensus [private]
ConfigurationManager typedefLogCabin::Server::RaftConsensus
configurationManagerLogCabin::Server::RaftConsensus [private]
currentEpochLogCabin::Server::RaftConsensus [mutable, private]
currentTermLogCabin::Server::RaftConsensus [private]
discardUnneededEntries()LogCabin::Server::RaftConsensus [private]
ELECTION_TIMEOUTLogCabin::Server::RaftConsensus [private]
exit()LogCabin::Server::RaftConsensus
exitingLogCabin::Server::RaftConsensus [private]
FAIL enum valueLogCabin::Server::RaftConsensus
FOLLOWER enum valueLogCabin::Server::RaftConsensus [private]
getConfiguration(Protocol::Raft::SimpleConfiguration &configuration, uint64_t &id) const LogCabin::Server::RaftConsensus
getLastCommitIndex() const LogCabin::Server::RaftConsensus
getLastLogTerm() const LogCabin::Server::RaftConsensus [private]
getLeaderHint() const LogCabin::Server::RaftConsensus
getNextEntry(uint64_t lastIndex) const LogCabin::Server::RaftConsensus
getSnapshotStats() const LogCabin::Server::RaftConsensus
globalsLogCabin::Server::RaftConsensus [private]
handleAppendEntries(const Protocol::Raft::AppendEntries::Request &request, Protocol::Raft::AppendEntries::Response &response)LogCabin::Server::RaftConsensus
handleInstallSnapshot(const Protocol::Raft::InstallSnapshot::Request &request, Protocol::Raft::InstallSnapshot::Response &response)LogCabin::Server::RaftConsensus
handleRequestVote(const Protocol::Raft::RequestVote::Request &request, Protocol::Raft::RequestVote::Response &response)LogCabin::Server::RaftConsensus
HEARTBEAT_PERIODLogCabin::Server::RaftConsensus [private]
init()LogCabin::Server::RaftConsensus
installSnapshot(std::unique_lock< Mutex > &lockGuard, Peer &peer)LogCabin::Server::RaftConsensus [private]
interruptAll()LogCabin::Server::RaftConsensus [private]
invariantsLogCabin::Server::RaftConsensus [private]
Invariants typedefLogCabin::Server::RaftConsensus
lastSnapshotBytesLogCabin::Server::RaftConsensus [private]
lastSnapshotClusterTimeLogCabin::Server::RaftConsensus [private]
lastSnapshotIndexLogCabin::Server::RaftConsensus [private]
lastSnapshotTermLogCabin::Server::RaftConsensus [private]
LEADER enum valueLogCabin::Server::RaftConsensus [private]
leaderDiskThreadLogCabin::Server::RaftConsensus [private]
leaderDiskThreadMain()LogCabin::Server::RaftConsensus [private]
leaderDiskThreadWorkingLogCabin::Server::RaftConsensus [private]
leaderIdLogCabin::Server::RaftConsensus [private]
LocalServer typedefLogCabin::Server::RaftConsensus
logLogCabin::Server::RaftConsensus [private]
logSyncQueuedLogCabin::Server::RaftConsensus [private]
MAX_LOG_ENTRIES_PER_REQUESTLogCabin::Server::RaftConsensus [private]
Mutex typedefLogCabin::Server::RaftConsensus
mutexLogCabin::Server::RaftConsensus [mutable, private]
NOT_LEADER enum valueLogCabin::Server::RaftConsensus
numEntriesTruncatedLogCabin::Server::RaftConsensus [private]
numPeerThreadsLogCabin::Server::RaftConsensus [private]
operator<<(std::ostream &os, const RaftConsensus &raft)LogCabin::Server::RaftConsensus [friend]
operator<<(std::ostream &os, ClientResult clientResult)LogCabin::Server::RaftConsensus [friend]
operator<<(std::ostream &os, State state)LogCabin::Server::RaftConsensus [friend]
packEntries(uint64_t nextIndex, Protocol::Raft::AppendEntries::Request &request) const LogCabin::Server::RaftConsensus [private]
Peer typedefLogCabin::Server::RaftConsensus
peerThreadMain(std::shared_ptr< Peer > peer)LogCabin::Server::RaftConsensus [private]
printElectionState() const LogCabin::Server::RaftConsensus [private]
RaftConsensus(Globals &globals)LogCabin::Server::RaftConsensus [explicit]
RaftConsensusInternal::Invariants classLogCabin::Server::RaftConsensus [friend]
RaftConsensusInternal::LocalServer classLogCabin::Server::RaftConsensus [friend]
RaftConsensusInternal::Peer classLogCabin::Server::RaftConsensus [friend]
readSnapshot()LogCabin::Server::RaftConsensus [private]
replicate(const Core::Buffer &operation)LogCabin::Server::RaftConsensus
replicateEntry(Storage::Log::Entry &entry, std::unique_lock< Mutex > &lockGuard)LogCabin::Server::RaftConsensus [private]
requestVote(std::unique_lock< Mutex > &lockGuard, Peer &peer)LogCabin::Server::RaftConsensus [private]
RETRY enum valueLogCabin::Server::RaftConsensus
RPC_FAILURE_BACKOFFLogCabin::Server::RaftConsensus [private]
Server typedefLogCabin::Server::RaftConsensus
serverAddressesLogCabin::Server::RaftConsensus
serverIdLogCabin::Server::RaftConsensus
sessionManagerLogCabin::Server::RaftConsensus [private]
setConfiguration(const Protocol::Client::SetConfiguration::Request &request, Protocol::Client::SetConfiguration::Response &response)LogCabin::Server::RaftConsensus
setElectionTimer()LogCabin::Server::RaftConsensus [private]
setSupportedStateMachineVersions(uint16_t minSupported, uint16_t maxSupported)LogCabin::Server::RaftConsensus
snapshotDone(uint64_t lastIncludedIndex, std::unique_ptr< Storage::SnapshotFile::Writer > writer)LogCabin::Server::RaftConsensus
snapshotReaderLogCabin::Server::RaftConsensus [mutable, private]
snapshotWriterLogCabin::Server::RaftConsensus [private]
SOFT_RPC_SIZE_LIMITLogCabin::Server::RaftConsensus [private]
startElectionAtLogCabin::Server::RaftConsensus [private]
startNewElection()LogCabin::Server::RaftConsensus [private]
stateLogCabin::Server::RaftConsensus [private]
State enum nameLogCabin::Server::RaftConsensus [private]
STATE_MACHINE_UPDATER_BACKOFFLogCabin::Server::RaftConsensus [private]
stateChangedLogCabin::Server::RaftConsensus [mutable, private]
stateMachineUpdaterThreadLogCabin::Server::RaftConsensus [private]
stateMachineUpdaterThreadMain()LogCabin::Server::RaftConsensus [private]
stepDown(uint64_t newTerm)LogCabin::Server::RaftConsensus [private]
stepDownThreadLogCabin::Server::RaftConsensus [private]
stepDownThreadMain()LogCabin::Server::RaftConsensus [private]
storageLayoutLogCabin::Server::RaftConsensus [private]
SUCCESS enum valueLogCabin::Server::RaftConsensus
TimePoint typedefLogCabin::Server::RaftConsensus
timerThreadLogCabin::Server::RaftConsensus [private]
timerThreadMain()LogCabin::Server::RaftConsensus [private]
updateLogMetadata()LogCabin::Server::RaftConsensus [private]
updateServerStats(Protocol::ServerStats &serverStats) const LogCabin::Server::RaftConsensus
upToDateLeader(std::unique_lock< Mutex > &lockGuard) const LogCabin::Server::RaftConsensus [private]
votedForLogCabin::Server::RaftConsensus [private]
withholdVotesUntilLogCabin::Server::RaftConsensus [private]
~RaftConsensus()LogCabin::Server::RaftConsensus
 All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Friends Defines