Log detailed correlated consensus data together (#5302)

Combine multiple related debug log data points into a single
message. Allows quick correlation of events that
previously were either not logged or, if logged, strewn
across multiple lines, making correlation difficult.
The Heartbeat Timer and consensus ledger accept processing
each have this capability.

Also guarantees that log entries will be written if the
node is a validator, regardless of log severity level.
Otherwise, the level of these messages is at INFO severity.
This commit is contained in:
Mark Travis
2025-02-27 10:02:57 -08:00
committed by GitHub
parent 0a1ca0600f
commit af018c7b0b
20 changed files with 546 additions and 134 deletions

View File

@@ -67,6 +67,10 @@ private:
void void
write(beast::severities::Severity level, std::string const& text) write(beast::severities::Severity level, std::string const& text)
override; override;
void
writeAlways(beast::severities::Severity level, std::string const& text)
override;
}; };
/** Manages a system file containing logged output. /** Manages a system file containing logged output.
@@ -256,6 +260,14 @@ private:
x x
#endif #endif
#ifndef CLOG
#define CLOG(ss) \
if (!ss) \
; \
else \
*ss
#endif
//------------------------------------------------------------------------------ //------------------------------------------------------------------------------
// Debug logging: // Debug logging:

View File

@@ -112,6 +112,16 @@ public:
virtual void virtual void
write(Severity level, std::string const& text) = 0; write(Severity level, std::string const& text) = 0;
/** Bypass filter and write text to the sink at the specified severity.
* Always write the message, but maintain the same formatting as if
* it passed through a level filter.
*
* @param level Level to display in message.
* @param text Text to write to sink.
*/
virtual void
writeAlways(Severity level, std::string const& text) = 0;
private: private:
Severity thresh_; Severity thresh_;
bool m_console; bool m_console;

View File

@@ -93,6 +93,13 @@ public:
using beast::Journal; using beast::Journal;
sink_.write(level, prefix_ + text); sink_.write(level, prefix_ + text);
} }
void
writeAlways(severities::Severity level, std::string const& text) override
{
using beast::Journal;
sink_.writeAlways(level, prefix_ + text);
}
}; };
} // namespace beast } // namespace beast

View File

@@ -47,6 +47,14 @@ Logs::Sink::write(beast::severities::Severity level, std::string const& text)
logs_.write(level, partition_, text, console()); logs_.write(level, partition_, text, console());
} }
void
Logs::Sink::writeAlways(
beast::severities::Severity level,
std::string const& text)
{
logs_.write(level, partition_, text, console());
}
//------------------------------------------------------------------------------ //------------------------------------------------------------------------------
Logs::File::File() : m_stream(nullptr) Logs::File::File() : m_stream(nullptr)

View File

@@ -66,6 +66,11 @@ public:
write(severities::Severity, std::string const&) override write(severities::Severity, std::string const&) override
{ {
} }
void
writeAlways(severities::Severity, std::string const&) override
{
}
}; };
//------------------------------------------------------------------------------ //------------------------------------------------------------------------------

View File

@@ -53,6 +53,12 @@ public:
if (level >= threshold()) if (level >= threshold())
++m_count; ++m_count;
} }
void
writeAlways(severities::Severity level, std::string const&) override
{
++m_count;
}
}; };
void void

View File

@@ -116,6 +116,10 @@ struct Peer
} }
}; };
class TestConsensusLogger
{
};
/** Generic Validations adaptor that simply ignores recently stale /** Generic Validations adaptor that simply ignores recently stale
* validations * validations
*/ */
@@ -532,7 +536,8 @@ struct Peer
closeResolution, closeResolution,
rawCloseTimes, rawCloseTimes,
mode, mode,
std::move(consensusJson)); std::move(consensusJson),
validating());
} }
void void
@@ -542,7 +547,8 @@ struct Peer
NetClock::duration const& closeResolution, NetClock::duration const& closeResolution,
ConsensusCloseTimes const& rawCloseTimes, ConsensusCloseTimes const& rawCloseTimes,
ConsensusMode const& mode, ConsensusMode const& mode,
Json::Value&& consensusJson) Json::Value&& consensusJson,
const bool validating)
{ {
schedule(delays.ledgerAccept, [=, this]() { schedule(delays.ledgerAccept, [=, this]() {
const bool proposing = mode == ConsensusMode::proposing; const bool proposing = mode == ConsensusMode::proposing;
@@ -877,6 +883,13 @@ struct Peer
{ {
} }
bool
validating() const
{
// does not matter
return false;
}
//-------------------------------------------------------------------------- //--------------------------------------------------------------------------
// A locally submitted transaction // A locally submitted transaction
void void
@@ -917,7 +930,7 @@ struct Peer
// Not yet modeling dynamic UNL. // Not yet modeling dynamic UNL.
hash_set<PeerID> nowUntrusted; hash_set<PeerID> nowUntrusted;
consensus.startRound( consensus.startRound(
now(), bestLCL, lastClosedLedger, nowUntrusted, runAsValidator); now(), bestLCL, lastClosedLedger, nowUntrusted, runAsValidator, {});
} }
// Start the consensus process assuming it is not yet running // Start the consensus process assuming it is not yet running

View File

@@ -57,6 +57,14 @@ public:
std::cout << clock_.now().time_since_epoch().count() << " " << text std::cout << clock_.now().time_since_epoch().count() << " " << text
<< std::endl; << std::endl;
} }
void
writeAlways(beast::severities::Severity level, std::string const& text)
override
{
std::cout << clock_.now().time_since_epoch().count() << " " << text
<< std::endl;
}
}; };
class Sim class Sim

View File

@@ -60,6 +60,14 @@ class CaptureLogs : public Logs
std::lock_guard lock(strmMutex_); std::lock_guard lock(strmMutex_);
strm_ << text; strm_ << text;
} }
void
writeAlways(beast::severities::Severity level, std::string const& text)
override
{
std::lock_guard lock(strmMutex_);
strm_ << text;
}
}; };
public: public:

View File

@@ -48,6 +48,13 @@ class CheckMessageLogs : public Logs
if (text.find(owner_.msg_) != std::string::npos) if (text.find(owner_.msg_) != std::string::npos)
*owner_.pFound_ = true; *owner_.pFound_ = true;
} }
void
writeAlways(beast::severities::Severity level, std::string const& text)
override
{
write(level, text);
}
}; };
public: public:

View File

@@ -860,7 +860,7 @@ class ServerStatus_test : public beast::unit_test::suite,
// mark the Network as having an Amendment Warning, but won't fail // mark the Network as having an Amendment Warning, but won't fail
env.app().getOPs().setAmendmentWarned(); env.app().getOPs().setAmendmentWarned();
env.app().getOPs().beginConsensus(env.closed()->info().hash); env.app().getOPs().beginConsensus(env.closed()->info().hash, {});
// consensus doesn't change // consensus doesn't change
BEAST_EXPECT( BEAST_EXPECT(
@@ -991,7 +991,7 @@ class ServerStatus_test : public beast::unit_test::suite,
// mark the Network as Amendment Blocked, but still won't fail until // mark the Network as Amendment Blocked, but still won't fail until
// ELB is enabled (next step) // ELB is enabled (next step)
env.app().getOPs().setAmendmentBlocked(); env.app().getOPs().setAmendmentBlocked();
env.app().getOPs().beginConsensus(env.closed()->info().hash); env.app().getOPs().beginConsensus(env.closed()->info().hash, {});
// consensus now sees validation disabled // consensus now sees validation disabled
BEAST_EXPECT( BEAST_EXPECT(

View File

@@ -96,6 +96,13 @@ public:
suite_.log << text << std::endl; suite_.log << text << std::endl;
} }
void
writeAlways(beast::severities::Severity level, std::string const& text)
override
{
suite_.log << text << std::endl;
}
}; };
//-------------------------------------------------------------------------- //--------------------------------------------------------------------------

View File

@@ -50,12 +50,26 @@ public:
void void
write(beast::severities::Severity level, std::string const& text) override; write(beast::severities::Severity level, std::string const& text) override;
void
writeAlways(beast::severities::Severity level, std::string const& text)
override;
}; };
inline void inline void
SuiteJournalSink::write( SuiteJournalSink::write(
beast::severities::Severity level, beast::severities::Severity level,
std::string const& text) std::string const& text)
{
// Only write the string if the level at least equals the threshold.
if (level >= threshold())
writeAlways(level, text);
}
inline void
SuiteJournalSink::writeAlways(
beast::severities::Severity level,
std::string const& text)
{ {
using namespace beast::severities; using namespace beast::severities;
@@ -80,9 +94,7 @@ SuiteJournalSink::write(
return "FTL:"; return "FTL:";
}(); }();
// Only write the string if the level at least equals the threshold. suite_.log << s << partition_ << text << std::endl;
if (level >= threshold())
suite_.log << s << partition_ << text << std::endl;
} }
class SuiteJournal class SuiteJournal
@@ -127,9 +139,16 @@ public:
{ {
if (level < threshold()) if (level < threshold())
return; return;
writeAlways(level, text);
}
inline void
writeAlways(beast::severities::Severity level, std::string const& text)
override
{
strm_ << text << std::endl; strm_ << text << std::endl;
} }
std::stringstream const& std::stringstream const&
messages() const messages() const
{ {

View File

@@ -45,6 +45,7 @@
#include <xrpl/protocol/digest.h> #include <xrpl/protocol/digest.h>
#include <algorithm> #include <algorithm>
#include <iomanip>
#include <mutex> #include <mutex>
namespace ripple { namespace ripple {
@@ -434,7 +435,8 @@ RCLConsensus::Adaptor::onAccept(
NetClock::duration const& closeResolution, NetClock::duration const& closeResolution,
ConsensusCloseTimes const& rawCloseTimes, ConsensusCloseTimes const& rawCloseTimes,
ConsensusMode const& mode, ConsensusMode const& mode,
Json::Value&& consensusJson) Json::Value&& consensusJson,
const bool validating)
{ {
app_.getJobQueue().addJob( app_.getJobQueue().addJob(
jtACCEPT, jtACCEPT,
@@ -445,6 +447,7 @@ RCLConsensus::Adaptor::onAccept(
// is accepted, the consensus results and capture by reference state // is accepted, the consensus results and capture by reference state
// will not change until startRound is called (which happens via // will not change until startRound is called (which happens via
// endConsensus). // endConsensus).
RclConsensusLogger clog("onAccept", validating, j_);
this->doAccept( this->doAccept(
result, result,
prevLedger, prevLedger,
@@ -452,7 +455,7 @@ RCLConsensus::Adaptor::onAccept(
rawCloseTimes, rawCloseTimes,
mode, mode,
std::move(cj)); std::move(cj));
this->app_.getOPs().endConsensus(); this->app_.getOPs().endConsensus(clog.ss());
}); });
} }
@@ -935,17 +938,22 @@ RCLConsensus::getJson(bool full) const
} }
void void
RCLConsensus::timerEntry(NetClock::time_point const& now) RCLConsensus::timerEntry(
NetClock::time_point const& now,
std::unique_ptr<std::stringstream> const& clog)
{ {
try try
{ {
std::lock_guard _{mutex_}; std::lock_guard _{mutex_};
consensus_.timerEntry(now); consensus_.timerEntry(now, clog);
} }
catch (SHAMapMissingNode const& mn) catch (SHAMapMissingNode const& mn)
{ {
// This should never happen // This should never happen
JLOG(j_.error()) << "During consensus timerEntry: " << mn.what(); std::stringstream ss;
ss << "During consensus timerEntry: " << mn.what();
JLOG(j_.error()) << ss.str();
CLOG(clog) << ss.str();
Rethrow(); Rethrow();
} }
} }
@@ -1082,7 +1090,8 @@ RCLConsensus::startRound(
RCLCxLedger::ID const& prevLgrId, RCLCxLedger::ID const& prevLgrId,
RCLCxLedger const& prevLgr, RCLCxLedger const& prevLgr,
hash_set<NodeID> const& nowUntrusted, hash_set<NodeID> const& nowUntrusted,
hash_set<NodeID> const& nowTrusted) hash_set<NodeID> const& nowTrusted,
std::unique_ptr<std::stringstream> const& clog)
{ {
std::lock_guard _{mutex_}; std::lock_guard _{mutex_};
consensus_.startRound( consensus_.startRound(
@@ -1090,6 +1099,36 @@ RCLConsensus::startRound(
prevLgrId, prevLgrId,
prevLgr, prevLgr,
nowUntrusted, nowUntrusted,
adaptor_.preStartRound(prevLgr, nowTrusted)); adaptor_.preStartRound(prevLgr, nowTrusted),
clog);
} }
RclConsensusLogger::RclConsensusLogger(
const char* label,
const bool validating,
beast::Journal j)
: j_(j)
{
if (!validating && !j.info())
return;
start_ = std::chrono::steady_clock::now();
ss_ = std::make_unique<std::stringstream>();
header_ = "ConsensusLogger ";
header_ += label;
header_ += ": ";
}
RclConsensusLogger::~RclConsensusLogger()
{
if (!ss_)
return;
auto const duration = std::chrono::duration_cast<std::chrono::milliseconds>(
std::chrono::steady_clock::now() - start_);
std::stringstream outSs;
outSs << header_ << "duration " << (duration.count() / 1000) << '.'
<< std::setw(3) << std::setfill('0') << (duration.count() % 1000)
<< "s. " << ss_->str();
j_.sink().writeAlways(beast::severities::kInfo, outSs.str());
}
} // namespace ripple } // namespace ripple

View File

@@ -36,8 +36,12 @@
#include <xrpl/protocol/RippleLedgerHash.h> #include <xrpl/protocol/RippleLedgerHash.h>
#include <xrpl/protocol/STValidation.h> #include <xrpl/protocol/STValidation.h>
#include <atomic> #include <atomic>
#include <memory>
#include <mutex> #include <mutex>
#include <set> #include <set>
#include <sstream>
#include <string>
namespace ripple { namespace ripple {
class InboundTransactions; class InboundTransactions;
@@ -316,6 +320,7 @@ class RCLConsensus
@param mode Our participating mode at the time consensus was @param mode Our participating mode at the time consensus was
declared declared
@param consensusJson Json representation of consensus state @param consensusJson Json representation of consensus state
@param validating whether this is a validator
*/ */
void void
onAccept( onAccept(
@@ -324,7 +329,8 @@ class RCLConsensus
NetClock::duration const& closeResolution, NetClock::duration const& closeResolution,
ConsensusCloseTimes const& rawCloseTimes, ConsensusCloseTimes const& rawCloseTimes,
ConsensusMode const& mode, ConsensusMode const& mode,
Json::Value&& consensusJson); Json::Value&& consensusJson,
const bool validating);
/** Process the accepted ledger that was a result of simulation/force /** Process the accepted ledger that was a result of simulation/force
accept. accept.
@@ -484,11 +490,14 @@ public:
RCLCxLedger::ID const& prevLgrId, RCLCxLedger::ID const& prevLgrId,
RCLCxLedger const& prevLgr, RCLCxLedger const& prevLgr,
hash_set<NodeID> const& nowUntrusted, hash_set<NodeID> const& nowUntrusted,
hash_set<NodeID> const& nowTrusted); hash_set<NodeID> const& nowTrusted,
std::unique_ptr<std::stringstream> const& clog);
//! @see Consensus::timerEntry //! @see Consensus::timerEntry
void void
timerEntry(NetClock::time_point const& now); timerEntry(
NetClock::time_point const& now,
std::unique_ptr<std::stringstream> const& clog = {});
//! @see Consensus::gotTxSet //! @see Consensus::gotTxSet
void void
@@ -530,6 +539,36 @@ private:
Consensus<Adaptor> consensus_; Consensus<Adaptor> consensus_;
beast::Journal const j_; beast::Journal const j_;
}; };
/** Collects logging information.
*
* Eases correlating multiple data points together to
* help follow flow of a complex activity, such as
* consensus heartbeat timer. If we
* are a validator, then always write output to
* debug log on destruction. Otherwise, INFO
* level.
*/
class RclConsensusLogger
{
std::string header_;
beast::Journal j_;
std::unique_ptr<std::stringstream> ss_;
std::chrono::steady_clock::time_point start_;
public:
explicit RclConsensusLogger(
const char* label,
bool validating,
beast::Journal j);
~RclConsensusLogger();
std::unique_ptr<std::stringstream> const&
ss()
{
return ss_;
}
};
} // namespace ripple } // namespace ripple
#endif #endif

View File

@@ -1407,7 +1407,7 @@ ApplicationImp::setup(boost::program_options::variables_map const& cmdline)
// start first consensus round // start first consensus round
if (!m_networkOPs->beginConsensus( if (!m_networkOPs->beginConsensus(
m_ledgerMaster->getClosedLedger()->info().hash)) m_ledgerMaster->getClosedLedger()->info().hash, {}))
{ {
JLOG(m_journal.fatal()) << "Unable to start consensus"; JLOG(m_journal.fatal()) << "Unable to start consensus";
return false; return false;

View File

@@ -75,6 +75,7 @@
#include <mutex> #include <mutex>
#include <optional> #include <optional>
#include <set> #include <set>
#include <sstream>
#include <string> #include <string>
#include <tuple> #include <tuple>
#include <unordered_map> #include <unordered_map>
@@ -381,9 +382,11 @@ private:
public: public:
bool bool
beginConsensus(uint256 const& networkClosed) override; beginConsensus(
uint256 const& networkClosed,
std::unique_ptr<std::stringstream> const& clog) override;
void void
endConsensus() override; endConsensus(std::unique_ptr<std::stringstream> const& clog) override;
void void
setStandAlone() override; setStandAlone() override;
@@ -1008,6 +1011,8 @@ NetworkOPsImp::setAccountHistoryJobTimer(SubAccountHistoryInfoWeak subInfo)
void void
NetworkOPsImp::processHeartbeatTimer() NetworkOPsImp::processHeartbeatTimer()
{ {
RclConsensusLogger clog(
"Heartbeat Timer", mConsensus.validating(), m_journal);
{ {
std::unique_lock lock{app_.getMasterMutex()}; std::unique_lock lock{app_.getMasterMutex()};
@@ -1023,9 +1028,17 @@ NetworkOPsImp::processHeartbeatTimer()
if (mMode != OperatingMode::DISCONNECTED) if (mMode != OperatingMode::DISCONNECTED)
{ {
setMode(OperatingMode::DISCONNECTED); setMode(OperatingMode::DISCONNECTED);
JLOG(m_journal.warn()) std::stringstream ss;
<< "Node count (" << numPeers << ") has fallen " ss << "Node count (" << numPeers << ") has fallen "
<< "below required minimum (" << minPeerCount_ << ")."; << "below required minimum (" << minPeerCount_ << ").";
JLOG(m_journal.warn()) << ss.str();
CLOG(clog.ss()) << "set mode to DISCONNECTED: " << ss.str();
}
else
{
CLOG(clog.ss())
<< "already DISCONNECTED. too few peers (" << numPeers
<< "), need at least " << minPeerCount_;
} }
// MasterMutex lock need not be held to call setHeartbeatTimer() // MasterMutex lock need not be held to call setHeartbeatTimer()
@@ -1033,6 +1046,7 @@ NetworkOPsImp::processHeartbeatTimer()
// We do not call mConsensus.timerEntry until there are enough // We do not call mConsensus.timerEntry until there are enough
// peers providing meaningful inputs to consensus // peers providing meaningful inputs to consensus
setHeartbeatTimer(); setHeartbeatTimer();
return; return;
} }
@@ -1041,24 +1055,38 @@ NetworkOPsImp::processHeartbeatTimer()
setMode(OperatingMode::CONNECTED); setMode(OperatingMode::CONNECTED);
JLOG(m_journal.info()) JLOG(m_journal.info())
<< "Node count (" << numPeers << ") is sufficient."; << "Node count (" << numPeers << ") is sufficient.";
CLOG(clog.ss()) << "setting mode to CONNECTED based on " << numPeers
<< " peers. ";
} }
// Check if the last validated ledger forces a change between these // Check if the last validated ledger forces a change between these
// states. // states.
auto origMode = mMode.load();
CLOG(clog.ss()) << "mode: " << strOperatingMode(origMode, true);
if (mMode == OperatingMode::SYNCING) if (mMode == OperatingMode::SYNCING)
setMode(OperatingMode::SYNCING); setMode(OperatingMode::SYNCING);
else if (mMode == OperatingMode::CONNECTED) else if (mMode == OperatingMode::CONNECTED)
setMode(OperatingMode::CONNECTED); setMode(OperatingMode::CONNECTED);
auto newMode = mMode.load();
if (origMode != newMode)
{
CLOG(clog.ss())
<< ", changing to " << strOperatingMode(newMode, true);
}
CLOG(clog.ss()) << ". ";
} }
mConsensus.timerEntry(app_.timeKeeper().closeTime()); mConsensus.timerEntry(app_.timeKeeper().closeTime(), clog.ss());
CLOG(clog.ss()) << "consensus phase " << to_string(mLastConsensusPhase);
const ConsensusPhase currPhase = mConsensus.phase(); const ConsensusPhase currPhase = mConsensus.phase();
if (mLastConsensusPhase != currPhase) if (mLastConsensusPhase != currPhase)
{ {
reportConsensusStateChange(currPhase); reportConsensusStateChange(currPhase);
mLastConsensusPhase = currPhase; mLastConsensusPhase = currPhase;
CLOG(clog.ss()) << " changed to " << to_string(mLastConsensusPhase);
} }
CLOG(clog.ss()) << ". ";
setHeartbeatTimer(); setHeartbeatTimer();
} }
@@ -1815,7 +1843,9 @@ NetworkOPsImp::switchLastClosedLedger(
} }
bool bool
NetworkOPsImp::beginConsensus(uint256 const& networkClosed) NetworkOPsImp::beginConsensus(
uint256 const& networkClosed,
std::unique_ptr<std::stringstream> const& clog)
{ {
XRPL_ASSERT( XRPL_ASSERT(
networkClosed.isNonZero(), networkClosed.isNonZero(),
@@ -1835,8 +1865,10 @@ NetworkOPsImp::beginConsensus(uint256 const& networkClosed)
{ {
JLOG(m_journal.warn()) << "Don't have LCL, going to tracking"; JLOG(m_journal.warn()) << "Don't have LCL, going to tracking";
setMode(OperatingMode::TRACKING); setMode(OperatingMode::TRACKING);
CLOG(clog) << "beginConsensus Don't have LCL, going to tracking. ";
} }
CLOG(clog) << "beginConsensus no previous ledger. ";
return false; return false;
} }
@@ -1871,7 +1903,8 @@ NetworkOPsImp::beginConsensus(uint256 const& networkClosed)
networkClosed, networkClosed,
prevLedger, prevLedger,
changes.removed, changes.removed,
changes.added); changes.added,
clog);
const ConsensusPhase currPhase = mConsensus.phase(); const ConsensusPhase currPhase = mConsensus.phase();
if (mLastConsensusPhase != currPhase) if (mLastConsensusPhase != currPhase)
@@ -1910,7 +1943,7 @@ NetworkOPsImp::mapComplete(std::shared_ptr<SHAMap> const& map, bool fromAcquire)
} }
void void
NetworkOPsImp::endConsensus() NetworkOPsImp::endConsensus(std::unique_ptr<std::stringstream> const& clog)
{ {
uint256 deadLedger = m_ledgerMaster.getClosedLedger()->info().parentHash; uint256 deadLedger = m_ledgerMaster.getClosedLedger()->info().parentHash;
@@ -1928,7 +1961,10 @@ NetworkOPsImp::endConsensus()
checkLastClosedLedger(app_.overlay().getActivePeers(), networkClosed); checkLastClosedLedger(app_.overlay().getActivePeers(), networkClosed);
if (networkClosed.isZero()) if (networkClosed.isZero())
{
CLOG(clog) << "endConsensus last closed ledger is zero. ";
return; return;
}
// WRITEME: Unless we are in FULL and in the process of doing a consensus, // WRITEME: Unless we are in FULL and in the process of doing a consensus,
// we must count how many nodes share our LCL, how many nodes disagree with // we must count how many nodes share our LCL, how many nodes disagree with
@@ -1962,7 +1998,7 @@ NetworkOPsImp::endConsensus()
} }
} }
beginConsensus(networkClosed); beginConsensus(networkClosed, clog);
} }
void void
@@ -3890,7 +3926,7 @@ NetworkOPsImp::acceptLedger(
// FIXME Could we improve on this and remove the need for a specialized // FIXME Could we improve on this and remove the need for a specialized
// API in Consensus? // API in Consensus?
beginConsensus(m_ledgerMaster.getClosedLedger()->info().hash); beginConsensus(m_ledgerMaster.getClosedLedger()->info().hash, {});
mConsensus.simulate(app_.timeKeeper().closeTime(), consensusDelay); mConsensus.simulate(app_.timeKeeper().closeTime(), consensusDelay);
return m_ledgerMaster.getCurrentLedger()->info().seq; return m_ledgerMaster.getCurrentLedger()->info().seq;
} }

View File

@@ -180,9 +180,11 @@ public:
// network state machine // network state machine
virtual bool virtual bool
beginConsensus(uint256 const& netLCL) = 0; beginConsensus(
uint256 const& netLCL,
std::unique_ptr<std::stringstream> const& clog) = 0;
virtual void virtual void
endConsensus() = 0; endConsensus(std::unique_ptr<std::stringstream> const& clog) = 0;
virtual void virtual void
setStandAlone() = 0; setStandAlone() = 0;
virtual void virtual void

View File

@@ -34,18 +34,32 @@ shouldCloseLedger(
std::chrono::milliseconds openTime, // Time waiting to close this ledger std::chrono::milliseconds openTime, // Time waiting to close this ledger
std::chrono::milliseconds idleInterval, std::chrono::milliseconds idleInterval,
ConsensusParms const& parms, ConsensusParms const& parms,
beast::Journal j) beast::Journal j,
std::unique_ptr<std::stringstream> const& clog)
{ {
CLOG(clog) << "shouldCloseLedger params anyTransactions: "
<< anyTransactions << ", prevProposers: " << prevProposers
<< ", proposersClosed: " << proposersClosed
<< ", proposersValidated: " << proposersValidated
<< ", prevRoundTime: " << prevRoundTime.count() << "ms"
<< ", timeSincePrevClose: " << timeSincePrevClose.count() << "ms"
<< ", openTime: " << openTime.count() << "ms"
<< ", idleInterval: " << idleInterval.count() << "ms"
<< ", ledgerMIN_CLOSE: " << parms.ledgerMIN_CLOSE.count() << "ms"
<< ". ";
using namespace std::chrono_literals; using namespace std::chrono_literals;
if ((prevRoundTime < -1s) || (prevRoundTime > 10min) || if ((prevRoundTime < -1s) || (prevRoundTime > 10min) ||
(timeSincePrevClose > 10min)) (timeSincePrevClose > 10min))
{ {
// These are unexpected cases, we just close the ledger // These are unexpected cases, we just close the ledger
JLOG(j.warn()) << "shouldCloseLedger Trans=" std::stringstream ss;
<< (anyTransactions ? "yes" : "no") ss << "shouldCloseLedger Trans=" << (anyTransactions ? "yes" : "no")
<< " Prop: " << prevProposers << "/" << proposersClosed << " Prop: " << prevProposers << "/" << proposersClosed
<< " Secs: " << timeSincePrevClose.count() << " Secs: " << timeSincePrevClose.count()
<< " (last: " << prevRoundTime.count() << ")"; << " (last: " << prevRoundTime.count() << ")";
JLOG(j.warn()) << ss.str();
CLOG(clog) << "closing ledger: " << ss.str() << ". ";
return true; return true;
} }
@@ -53,12 +67,14 @@ shouldCloseLedger(
{ {
// If more than half of the network has closed, we close // If more than half of the network has closed, we close
JLOG(j.trace()) << "Others have closed"; JLOG(j.trace()) << "Others have closed";
CLOG(clog) << "closing ledger because enough others have already. ";
return true; return true;
} }
if (!anyTransactions) if (!anyTransactions)
{ {
// Only close at the end of the idle interval // Only close at the end of the idle interval
CLOG(clog) << "no transactions, returning. ";
return timeSincePrevClose >= idleInterval; // normal idle return timeSincePrevClose >= idleInterval; // normal idle
} }
@@ -66,6 +82,7 @@ shouldCloseLedger(
if (openTime < parms.ledgerMIN_CLOSE) if (openTime < parms.ledgerMIN_CLOSE)
{ {
JLOG(j.debug()) << "Must wait minimum time before closing"; JLOG(j.debug()) << "Must wait minimum time before closing";
CLOG(clog) << "not closing because under ledgerMIN_CLOSE. ";
return false; return false;
} }
@@ -75,10 +92,12 @@ shouldCloseLedger(
if (openTime < (prevRoundTime / 2)) if (openTime < (prevRoundTime / 2))
{ {
JLOG(j.debug()) << "Ledger has not been open long enough"; JLOG(j.debug()) << "Ledger has not been open long enough";
CLOG(clog) << "not closing because not open long enough. ";
return false; return false;
} }
// Close the ledger // Close the ledger
CLOG(clog) << "no reason to not close. ";
return true; return true;
} }
@@ -88,8 +107,14 @@ checkConsensusReached(
std::size_t total, std::size_t total,
bool count_self, bool count_self,
std::size_t minConsensusPct, std::size_t minConsensusPct,
bool reachedMax) bool reachedMax,
std::unique_ptr<std::stringstream> const& clog)
{ {
CLOG(clog) << "checkConsensusReached params: agreeing: " << agreeing
<< ", total: " << total << ", count_self: " << count_self
<< ", minConsensusPct: " << minConsensusPct
<< ", reachedMax: " << reachedMax << ". ";
// If we are alone for too long, we have consensus. // If we are alone for too long, we have consensus.
// Delaying consensus like this avoids a circumstance where a peer // Delaying consensus like this avoids a circumstance where a peer
// gets ahead of proposers insofar as it has not received any proposals. // gets ahead of proposers insofar as it has not received any proposals.
@@ -102,7 +127,13 @@ checkConsensusReached(
if (total == 0) if (total == 0)
{ {
if (reachedMax) if (reachedMax)
{
CLOG(clog)
<< "Consensus reached because nobody shares our position and "
"maximum duration has passed.";
return true; return true;
}
CLOG(clog) << "Consensus not reached and nobody shares our position. ";
return false; return false;
} }
@@ -110,11 +141,22 @@ checkConsensusReached(
{ {
++agreeing; ++agreeing;
++total; ++total;
CLOG(clog) << "agreeing and total adjusted: " << agreeing << ','
<< total << ". ";
} }
std::size_t currentPercentage = (agreeing * 100) / total; std::size_t currentPercentage = (agreeing * 100) / total;
CLOG(clog) << "currentPercentage: " << currentPercentage;
return currentPercentage >= minConsensusPct; bool const ret = currentPercentage >= minConsensusPct;
if (ret)
{
CLOG(clog) << ", consensus reached. ";
}
else
{
CLOG(clog) << ", consensus not reached. ";
}
return ret;
} }
ConsensusState ConsensusState
@@ -127,22 +169,26 @@ checkConsensus(
std::chrono::milliseconds currentAgreeTime, std::chrono::milliseconds currentAgreeTime,
ConsensusParms const& parms, ConsensusParms const& parms,
bool proposing, bool proposing,
beast::Journal j) beast::Journal j,
std::unique_ptr<std::stringstream> const& clog)
{ {
JLOG(j.trace()) << "checkConsensus: prop=" << currentProposers << "/" CLOG(clog) << "checkConsensus: prop=" << currentProposers << "/"
<< prevProposers << " agree=" << currentAgree << prevProposers << " agree=" << currentAgree
<< " validated=" << currentFinished << " validated=" << currentFinished
<< " time=" << currentAgreeTime.count() << "/" << " time=" << currentAgreeTime.count() << "/"
<< previousAgreeTime.count() << " proposing? " << proposing << previousAgreeTime.count() << " proposing? " << proposing
<< " minimum duration to reach consensus: " << " minimum duration to reach consensus: "
<< parms.ledgerMIN_CONSENSUS.count() << "ms" << parms.ledgerMIN_CONSENSUS.count() << "ms"
<< " max consensus time " << " max consensus time " << parms.ledgerMAX_CONSENSUS.count()
<< parms.ledgerMAX_CONSENSUS.count() << "s" << "s"
<< " minimum consensus percentage: " << " minimum consensus percentage: " << parms.minCONSENSUS_PCT
<< parms.minCONSENSUS_PCT; << ". ";
if (currentAgreeTime <= parms.ledgerMIN_CONSENSUS) if (currentAgreeTime <= parms.ledgerMIN_CONSENSUS)
{
CLOG(clog) << "Not reached. ";
return ConsensusState::No; return ConsensusState::No;
}
if (currentProposers < (prevProposers * 3 / 4)) if (currentProposers < (prevProposers * 3 / 4))
{ {
@@ -151,6 +197,7 @@ checkConsensus(
if (currentAgreeTime < (previousAgreeTime + parms.ledgerMIN_CONSENSUS)) if (currentAgreeTime < (previousAgreeTime + parms.ledgerMIN_CONSENSUS))
{ {
JLOG(j.trace()) << "too fast, not enough proposers"; JLOG(j.trace()) << "too fast, not enough proposers";
CLOG(clog) << "Too fast, not enough proposers. Not reached. ";
return ConsensusState::No; return ConsensusState::No;
} }
} }
@@ -162,9 +209,11 @@ checkConsensus(
currentProposers, currentProposers,
proposing, proposing,
parms.minCONSENSUS_PCT, parms.minCONSENSUS_PCT,
currentAgreeTime > parms.ledgerMAX_CONSENSUS)) currentAgreeTime > parms.ledgerMAX_CONSENSUS,
clog))
{ {
JLOG(j.debug()) << "normal consensus"; JLOG(j.debug()) << "normal consensus";
CLOG(clog) << "reached. ";
return ConsensusState::Yes; return ConsensusState::Yes;
} }
@@ -175,14 +224,17 @@ checkConsensus(
currentProposers, currentProposers,
false, false,
parms.minCONSENSUS_PCT, parms.minCONSENSUS_PCT,
currentAgreeTime > parms.ledgerMAX_CONSENSUS)) currentAgreeTime > parms.ledgerMAX_CONSENSUS,
clog))
{ {
JLOG(j.warn()) << "We see no consensus, but 80% of nodes have moved on"; JLOG(j.warn()) << "We see no consensus, but 80% of nodes have moved on";
CLOG(clog) << "We see no consensus, but 80% of nodes have moved on";
return ConsensusState::MovedOn; return ConsensusState::MovedOn;
} }
// no consensus yet // no consensus yet
JLOG(j.trace()) << "no consensus"; JLOG(j.trace()) << "no consensus";
CLOG(clog) << "No consensus. ";
return ConsensusState::No; return ConsensusState::No;
} }

View File

@@ -55,6 +55,7 @@ namespace ripple {
@param idleInterval the network's desired idle interval @param idleInterval the network's desired idle interval
@param parms Consensus constant parameters @param parms Consensus constant parameters
@param j journal for logging @param j journal for logging
@param clog log object to which to append
*/ */
bool bool
shouldCloseLedger( shouldCloseLedger(
@@ -67,7 +68,8 @@ shouldCloseLedger(
std::chrono::milliseconds openTime, std::chrono::milliseconds openTime,
std::chrono::milliseconds idleInterval, std::chrono::milliseconds idleInterval,
ConsensusParms const& parms, ConsensusParms const& parms,
beast::Journal j); beast::Journal j,
std::unique_ptr<std::stringstream> const& clog = {});
/** Determine whether the network reached consensus and whether we joined. /** Determine whether the network reached consensus and whether we joined.
@@ -82,6 +84,7 @@ shouldCloseLedger(
@param parms Consensus constant parameters @param parms Consensus constant parameters
@param proposing whether we should count ourselves @param proposing whether we should count ourselves
@param j journal for logging @param j journal for logging
@param clog log object to which to append
*/ */
ConsensusState ConsensusState
checkConsensus( checkConsensus(
@@ -93,7 +96,8 @@ checkConsensus(
std::chrono::milliseconds currentAgreeTime, std::chrono::milliseconds currentAgreeTime,
ConsensusParms const& parms, ConsensusParms const& parms,
bool proposing, bool proposing,
beast::Journal j); beast::Journal j,
std::unique_ptr<std::stringstream> const& clog = {});
/** Generic implementation of consensus algorithm. /** Generic implementation of consensus algorithm.
@@ -340,11 +344,13 @@ public:
Called by the client code to start each round of consensus. Called by the client code to start each round of consensus.
@param now The network adjusted time @param now The network adjusted time
@param prevLedgerID the ID of the last ledger @param prevLedgerID the ID of the last ledger
@param prevLedger The last ledger @param prevLedger The last ledger
@param nowUntrusted ID of nodes that are newly untrusted this round @param nowUntrusted ID of nodes that are newly untrusted this round
@param proposing Whether we want to send proposals to peers this round. @param proposing Whether we want to send proposals to peers this
round.
@param clog log object to which to append
@note @b prevLedgerID is not required to the ID of @b prevLedger since @note @b prevLedgerID is not required to the ID of @b prevLedger since
the ID may be known locally before the contents of the ledger arrive the ID may be known locally before the contents of the ledger arrive
@@ -355,7 +361,8 @@ public:
typename Ledger_t::ID const& prevLedgerID, typename Ledger_t::ID const& prevLedgerID,
Ledger_t prevLedger, Ledger_t prevLedger,
hash_set<NodeID_t> const& nowUntrusted, hash_set<NodeID_t> const& nowUntrusted,
bool proposing); bool proposing,
std::unique_ptr<std::stringstream> const& clog = {});
/** A peer has proposed a new position, adjust our tracking. /** A peer has proposed a new position, adjust our tracking.
@@ -370,10 +377,13 @@ public:
/** Call periodically to drive consensus forward. /** Call periodically to drive consensus forward.
@param now The network adjusted time @param now The network adjusted time
@param clog log object to which to append
*/ */
void void
timerEntry(NetClock::time_point const& now); timerEntry(
NetClock::time_point const& now,
std::unique_ptr<std::stringstream> const& clog = {});
/** Process a transaction set acquired from the network /** Process a transaction set acquired from the network
@@ -439,11 +449,14 @@ private:
NetClock::time_point const& now, NetClock::time_point const& now,
typename Ledger_t::ID const& prevLedgerID, typename Ledger_t::ID const& prevLedgerID,
Ledger_t const& prevLedger, Ledger_t const& prevLedger,
ConsensusMode mode); ConsensusMode mode,
std::unique_ptr<std::stringstream> const& clog);
// Change our view of the previous ledger // Change our view of the previous ledger
void void
handleWrongLedger(typename Ledger_t::ID const& lgrId); handleWrongLedger(
typename Ledger_t::ID const& lgrId,
std::unique_ptr<std::stringstream> const& clog);
/** Check if our previous ledger matches the network's. /** Check if our previous ledger matches the network's.
@@ -451,7 +464,7 @@ private:
the network and need to bow out/switch modes. the network and need to bow out/switch modes.
*/ */
void void
checkLedger(); checkLedger(std::unique_ptr<std::stringstream> const& clog);
/** If we radically changed our consensus context for some reason, /** If we radically changed our consensus context for some reason,
we need to replay recent proposals so that they're not lost. we need to replay recent proposals so that they're not lost.
@@ -473,7 +486,7 @@ private:
switch to the establish phase and start the consensus process. switch to the establish phase and start the consensus process.
*/ */
void void
phaseOpen(); phaseOpen(std::unique_ptr<std::stringstream> const& clog);
/** Handle establish phase. /** Handle establish phase.
@@ -484,7 +497,7 @@ private:
If we have consensus, move to the accepted phase. If we have consensus, move to the accepted phase.
*/ */
void void
phaseEstablish(); phaseEstablish(std::unique_ptr<std::stringstream> const& clog);
/** Evaluate whether pausing increases likelihood of validation. /** Evaluate whether pausing increases likelihood of validation.
* *
@@ -509,22 +522,24 @@ private:
* @return Whether to pause to wait for lagging proposers. * @return Whether to pause to wait for lagging proposers.
*/ */
bool bool
shouldPause() const; shouldPause(std::unique_ptr<std::stringstream> const& clog) const;
// Close the open ledger and establish initial position. // Close the open ledger and establish initial position.
void void
closeLedger(); closeLedger(std::unique_ptr<std::stringstream> const& clog);
// Adjust our positions to try to agree with other validators. // Adjust our positions to try to agree with other validators.
void void
updateOurPositions(); updateOurPositions(std::unique_ptr<std::stringstream> const& clog);
bool bool
haveConsensus(); haveConsensus(std::unique_ptr<std::stringstream> const& clog);
// Create disputes between our position and the provided one. // Create disputes between our position and the provided one.
void void
createDisputes(TxSet_t const& o); createDisputes(
TxSet_t const& o,
std::unique_ptr<std::stringstream> const& clog = {});
// Update our disputes given that this node has adopted a new position. // Update our disputes given that this node has adopted a new position.
// Will call createDisputes as needed. // Will call createDisputes as needed.
@@ -534,7 +549,7 @@ private:
// Revoke our outstanding proposal, if any, and cease proposing // Revoke our outstanding proposal, if any, and cease proposing
// until this round ends. // until this round ends.
void void
leaveConsensus(); leaveConsensus(std::unique_ptr<std::stringstream> const& clog);
// The rounded or effective close time estimate from a proposer // The rounded or effective close time estimate from a proposer
NetClock::time_point NetClock::time_point
@@ -621,7 +636,8 @@ Consensus<Adaptor>::startRound(
typename Ledger_t::ID const& prevLedgerID, typename Ledger_t::ID const& prevLedgerID,
Ledger_t prevLedger, Ledger_t prevLedger,
hash_set<NodeID_t> const& nowUntrusted, hash_set<NodeID_t> const& nowUntrusted,
bool proposing) bool proposing,
std::unique_ptr<std::stringstream> const& clog)
{ {
if (firstRound_) if (firstRound_)
{ {
@@ -658,7 +674,7 @@ Consensus<Adaptor>::startRound(
} }
} }
startRoundInternal(now, prevLedgerID, prevLedger, startMode); startRoundInternal(now, prevLedgerID, prevLedger, startMode, clog);
} }
template <class Adaptor> template <class Adaptor>
void void
@@ -666,10 +682,14 @@ Consensus<Adaptor>::startRoundInternal(
NetClock::time_point const& now, NetClock::time_point const& now,
typename Ledger_t::ID const& prevLedgerID, typename Ledger_t::ID const& prevLedgerID,
Ledger_t const& prevLedger, Ledger_t const& prevLedger,
ConsensusMode mode) ConsensusMode mode,
std::unique_ptr<std::stringstream> const& clog)
{ {
phase_ = ConsensusPhase::open; phase_ = ConsensusPhase::open;
JLOG(j_.debug()) << "transitioned to ConsensusPhase::open"; JLOG(j_.debug()) << "transitioned to ConsensusPhase::open ";
CLOG(clog) << "startRoundInternal transitioned to ConsensusPhase::open, "
"previous ledgerID: "
<< prevLedgerID << ", seq: " << prevLedger.seq() << ". ";
mode_.set(mode, adaptor_); mode_.set(mode, adaptor_);
now_ = now; now_ = now;
prevLedgerID_ = prevLedgerID; prevLedgerID_ = prevLedgerID;
@@ -690,11 +710,14 @@ Consensus<Adaptor>::startRoundInternal(
previousLedger_.seq() + typename Ledger_t::Seq{1}); previousLedger_.seq() + typename Ledger_t::Seq{1});
playbackProposals(); playbackProposals();
CLOG(clog) << "number of peer proposals,previous proposers: "
<< currPeerPositions_.size() << ',' << prevProposers_ << ". ";
if (currPeerPositions_.size() > (prevProposers_ / 2)) if (currPeerPositions_.size() > (prevProposers_ / 2))
{ {
// We may be falling behind, don't wait for the timer // We may be falling behind, don't wait for the timer
// consider closing the ledger immediately // consider closing the ledger immediately
timerEntry(now_); CLOG(clog) << "consider closing the ledger immediately. ";
timerEntry(now_, clog);
} }
} }
@@ -816,25 +839,35 @@ Consensus<Adaptor>::peerProposalInternal(
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::timerEntry(NetClock::time_point const& now) Consensus<Adaptor>::timerEntry(
NetClock::time_point const& now,
std::unique_ptr<std::stringstream> const& clog)
{ {
CLOG(clog) << "Consensus<Adaptor>::timerEntry. ";
// Nothing to do if we are currently working on a ledger // Nothing to do if we are currently working on a ledger
if (phase_ == ConsensusPhase::accepted) if (phase_ == ConsensusPhase::accepted)
{
CLOG(clog) << "Nothing to do during accepted phase. ";
return; return;
}
now_ = now; now_ = now;
CLOG(clog) << "Set network adjusted time to " << to_string(now) << ". ";
// Check we are on the proper ledger (this may change phase_) // Check we are on the proper ledger (this may change phase_)
checkLedger(); const auto phaseOrig = phase_;
CLOG(clog) << "Phase " << to_string(phaseOrig) << ". ";
checkLedger(clog);
if (phaseOrig != phase_)
{
CLOG(clog) << "Changed phase to << " << to_string(phase_) << ". ";
}
if (phase_ == ConsensusPhase::open) if (phase_ == ConsensusPhase::open)
{ phaseOpen(clog);
phaseOpen();
}
else if (phase_ == ConsensusPhase::establish) else if (phase_ == ConsensusPhase::establish)
{ phaseEstablish(clog);
phaseEstablish(); CLOG(clog) << "timerEntry finishing in phase " << to_string(phase_) << ". ";
}
} }
template <class Adaptor> template <class Adaptor>
@@ -894,7 +927,7 @@ Consensus<Adaptor>::simulate(
using namespace std::chrono_literals; using namespace std::chrono_literals;
JLOG(j_.info()) << "Simulating consensus"; JLOG(j_.info()) << "Simulating consensus";
now_ = now; now_ = now;
closeLedger(); closeLedger({});
result_->roundTime.tick(consensusDelay.value_or(100ms)); result_->roundTime.tick(consensusDelay.value_or(100ms));
result_->proposers = prevProposers_ = currPeerPositions_.size(); result_->proposers = prevProposers_ = currPeerPositions_.size();
prevRoundTime_ = result_->roundTime.read(); prevRoundTime_ = result_->roundTime.read();
@@ -1009,14 +1042,17 @@ Consensus<Adaptor>::getJson(bool full) const
// Handle a change in the prior ledger during a consensus round // Handle a change in the prior ledger during a consensus round
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::handleWrongLedger(typename Ledger_t::ID const& lgrId) Consensus<Adaptor>::handleWrongLedger(
typename Ledger_t::ID const& lgrId,
std::unique_ptr<std::stringstream> const& clog)
{ {
CLOG(clog) << "handleWrongLedger. ";
XRPL_ASSERT( XRPL_ASSERT(
lgrId != prevLedgerID_ || previousLedger_.id() != lgrId, lgrId != prevLedgerID_ || previousLedger_.id() != lgrId,
"ripple::Consensus::handleWrongLedger : have wrong ledger"); "ripple::Consensus::handleWrongLedger : have wrong ledger");
// Stop proposing because we are out of sync // Stop proposing because we are out of sync
leaveConsensus(); leaveConsensus(clog);
// First time switching to this ledger // First time switching to this ledger
if (prevLedgerID_ != lgrId) if (prevLedgerID_ != lgrId)
@@ -1039,41 +1075,58 @@ Consensus<Adaptor>::handleWrongLedger(typename Ledger_t::ID const& lgrId)
} }
if (previousLedger_.id() == prevLedgerID_) if (previousLedger_.id() == prevLedgerID_)
{
CLOG(clog) << "previousLedger_.id() == prevLeverID_ " << prevLedgerID_
<< ". ";
return; return;
}
// we need to switch the ledger we're working from // we need to switch the ledger we're working from
if (auto newLedger = adaptor_.acquireLedger(prevLedgerID_)) if (auto newLedger = adaptor_.acquireLedger(prevLedgerID_))
{ {
JLOG(j_.info()) << "Have the consensus ledger " << prevLedgerID_; JLOG(j_.info()) << "Have the consensus ledger " << prevLedgerID_;
CLOG(clog) << "Have the consensus ledger " << prevLedgerID_ << ". ";
startRoundInternal( startRoundInternal(
now_, lgrId, *newLedger, ConsensusMode::switchedLedger); now_, lgrId, *newLedger, ConsensusMode::switchedLedger, clog);
} }
else else
{ {
CLOG(clog) << "Still on wrong ledger. ";
mode_.set(ConsensusMode::wrongLedger, adaptor_); mode_.set(ConsensusMode::wrongLedger, adaptor_);
} }
} }
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::checkLedger() Consensus<Adaptor>::checkLedger(std::unique_ptr<std::stringstream> const& clog)
{ {
CLOG(clog) << "checkLedger. ";
auto netLgr = auto netLgr =
adaptor_.getPrevLedger(prevLedgerID_, previousLedger_, mode_.get()); adaptor_.getPrevLedger(prevLedgerID_, previousLedger_, mode_.get());
CLOG(clog) << "network ledgerid " << netLgr << ", " << "previous ledger "
<< prevLedgerID_ << ". ";
if (netLgr != prevLedgerID_) if (netLgr != prevLedgerID_)
{ {
JLOG(j_.warn()) << "View of consensus changed during " std::stringstream ss;
<< to_string(phase_) << " status=" << to_string(phase_) ss << "View of consensus changed during " << to_string(phase_)
<< ", " << " mode=" << to_string(mode_.get()); << " mode=" << to_string(mode_.get()) << ", " << prevLedgerID_
JLOG(j_.warn()) << prevLedgerID_ << " to " << netLgr; << " to " << netLgr << ", "
JLOG(j_.warn()) << Json::Compact{previousLedger_.getJson()}; << Json::Compact{previousLedger_.getJson()} << ". ";
JLOG(j_.debug()) << "State on consensus change " JLOG(j_.warn()) << ss.str();
<< Json::Compact{getJson(true)}; CLOG(clog) << ss.str();
handleWrongLedger(netLgr); CLOG(clog) << "State on consensus change "
<< Json::Compact{getJson(true)} << ". ";
handleWrongLedger(netLgr, clog);
} }
else if (previousLedger_.id() != prevLedgerID_) else if (previousLedger_.id() != prevLedgerID_)
handleWrongLedger(netLgr); {
CLOG(clog) << "previousLedger_.id() != prevLedgerID_: "
<< previousLedger_.id() << ',' << to_string(prevLedgerID_)
<< ". ";
handleWrongLedger(netLgr, clog);
}
} }
template <class Adaptor> template <class Adaptor>
@@ -1095,8 +1148,9 @@ Consensus<Adaptor>::playbackProposals()
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::phaseOpen() Consensus<Adaptor>::phaseOpen(std::unique_ptr<std::stringstream> const& clog)
{ {
CLOG(clog) << "phaseOpen. ";
using namespace std::chrono; using namespace std::chrono;
// it is shortly before ledger close time // it is shortly before ledger close time
@@ -1109,25 +1163,44 @@ Consensus<Adaptor>::phaseOpen()
// This computes how long since last ledger's close time // This computes how long since last ledger's close time
milliseconds sinceClose; milliseconds sinceClose;
{ {
bool previousCloseCorrect = auto const mode = mode_.get();
(mode_.get() != ConsensusMode::wrongLedger) && bool const closeAgree = previousLedger_.closeAgree();
previousLedger_.closeAgree() && auto const prevCloseTime = previousLedger_.closeTime();
(previousLedger_.closeTime() != auto const prevParentCloseTimePlus1 =
(previousLedger_.parentCloseTime() + 1s)); previousLedger_.parentCloseTime() + 1s;
bool const previousCloseCorrect =
(mode != ConsensusMode::wrongLedger) && closeAgree &&
(prevCloseTime != prevParentCloseTimePlus1);
auto lastCloseTime = previousCloseCorrect auto const lastCloseTime = previousCloseCorrect
? previousLedger_.closeTime() // use consensus timing ? prevCloseTime // use consensus timing
: prevCloseTime_; // use the time we saw internally : prevCloseTime_; // use the time we saw internally
if (now_ >= lastCloseTime) if (now_ >= lastCloseTime)
sinceClose = duration_cast<milliseconds>(now_ - lastCloseTime); sinceClose = duration_cast<milliseconds>(now_ - lastCloseTime);
else else
sinceClose = -duration_cast<milliseconds>(lastCloseTime - now_); sinceClose = -duration_cast<milliseconds>(lastCloseTime - now_);
CLOG(clog) << "calculating how long since last ledger's close time "
"based on mode : "
<< to_string(mode) << ", previous closeAgree: " << closeAgree
<< ", previous close time: " << to_string(prevCloseTime)
<< ", previous parent close time + 1s: "
<< to_string(prevParentCloseTimePlus1)
<< ", previous close time seen internally: "
<< to_string(prevCloseTime_)
<< ", last close time: " << to_string(lastCloseTime)
<< ", since close: " << sinceClose.count() << ". ";
} }
auto const idleInterval = std::max<milliseconds>( auto const idleInterval = std::max<milliseconds>(
adaptor_.parms().ledgerIDLE_INTERVAL, adaptor_.parms().ledgerIDLE_INTERVAL,
2 * previousLedger_.closeTimeResolution()); 2 * previousLedger_.closeTimeResolution());
CLOG(clog) << "idle interval set to " << idleInterval.count()
<< "ms based on "
<< "ledgerIDLE_INTERVAL: "
<< adaptor_.parms().ledgerIDLE_INTERVAL.count()
<< ", previous ledger close time resolution: "
<< previousLedger_.closeTimeResolution().count() << "ms. ";
// Decide if we should close the ledger // Decide if we should close the ledger
if (shouldCloseLedger( if (shouldCloseLedger(
@@ -1140,16 +1213,20 @@ Consensus<Adaptor>::phaseOpen()
openTime_.read(), openTime_.read(),
idleInterval, idleInterval,
adaptor_.parms(), adaptor_.parms(),
j_)) j_,
clog))
{ {
closeLedger(); CLOG(clog) << "closing ledger. ";
closeLedger(clog);
} }
} }
template <class Adaptor> template <class Adaptor>
bool bool
Consensus<Adaptor>::shouldPause() const Consensus<Adaptor>::shouldPause(
std::unique_ptr<std::stringstream> const& clog) const
{ {
CLOG(clog) << "shouldPause? ";
auto const& parms = adaptor_.parms(); auto const& parms = adaptor_.parms();
std::uint32_t const ahead( std::uint32_t const ahead(
previousLedger_.seq() - previousLedger_.seq() -
@@ -1176,6 +1253,7 @@ Consensus<Adaptor>::shouldPause() const
result_->roundTime.read() > parms.ledgerMAX_CONSENSUS) result_->roundTime.read() > parms.ledgerMAX_CONSENSUS)
{ {
j_.debug() << "not pausing (early)" << vars.str(); j_.debug() << "not pausing (early)" << vars.str();
CLOG(clog) << "Not pausing (early). ";
return false; return false;
} }
@@ -1253,16 +1331,24 @@ Consensus<Adaptor>::shouldPause() const
} }
if (willPause) if (willPause)
{
j_.warn() << "pausing" << vars.str(); j_.warn() << "pausing" << vars.str();
CLOG(clog) << "pausing " << vars.str() << ". ";
}
else else
{
j_.debug() << "not pausing" << vars.str(); j_.debug() << "not pausing" << vars.str();
CLOG(clog) << "not pausing. ";
}
return willPause; return willPause;
} }
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::phaseEstablish() Consensus<Adaptor>::phaseEstablish(
std::unique_ptr<std::stringstream> const& clog)
{ {
CLOG(clog) << "phaseEstablish. ";
// can only establish consensus if we already took a stance // can only establish consensus if we already took a stance
XRPL_ASSERT(result_, "ripple::Consensus::phaseEstablish : result is set"); XRPL_ASSERT(result_, "ripple::Consensus::phaseEstablish : result is set");
@@ -1274,25 +1360,39 @@ Consensus<Adaptor>::phaseEstablish()
convergePercent_ = result_->roundTime.read() * 100 / convergePercent_ = result_->roundTime.read() * 100 /
std::max<milliseconds>(prevRoundTime_, parms.avMIN_CONSENSUS_TIME); std::max<milliseconds>(prevRoundTime_, parms.avMIN_CONSENSUS_TIME);
CLOG(clog) << "convergePercent_ " << convergePercent_
<< " is based on round duration so far: "
<< result_->roundTime.read().count() << "ms, "
<< "previous round duration: " << prevRoundTime_.count()
<< "ms, "
<< "avMIN_CONSENSUS_TIME: " << parms.avMIN_CONSENSUS_TIME.count()
<< "ms. ";
// Give everyone a chance to take an initial position // Give everyone a chance to take an initial position
if (result_->roundTime.read() < parms.ledgerMIN_CONSENSUS) if (result_->roundTime.read() < parms.ledgerMIN_CONSENSUS)
{
CLOG(clog) << "ledgerMIN_CONSENSUS not reached: "
<< parms.ledgerMIN_CONSENSUS.count() << "ms. ";
return; return;
}
updateOurPositions(); updateOurPositions(clog);
// Nothing to do if too many laggards or we don't have consensus. // Nothing to do if too many laggards or we don't have consensus.
if (shouldPause() || !haveConsensus()) if (shouldPause(clog) || !haveConsensus(clog))
return; return;
if (!haveCloseTimeConsensus_) if (!haveCloseTimeConsensus_)
{ {
JLOG(j_.info()) << "We have TX consensus but not CT consensus"; JLOG(j_.info()) << "We have TX consensus but not CT consensus";
CLOG(clog) << "We have TX consensus but not CT consensus. ";
return; return;
} }
JLOG(j_.info()) << "Converge cutoff (" << currPeerPositions_.size() JLOG(j_.info()) << "Converge cutoff (" << currPeerPositions_.size()
<< " participants)"; << " participants)";
CLOG(clog) << "Converge cutoff (" << currPeerPositions_.size()
<< " participants). Transitioned to ConsensusPhase::accepted. ";
adaptor_.updateOperatingMode(currPeerPositions_.size()); adaptor_.updateOperatingMode(currPeerPositions_.size());
prevProposers_ = currPeerPositions_.size(); prevProposers_ = currPeerPositions_.size();
prevRoundTime_ = result_->roundTime.read(); prevRoundTime_ = result_->roundTime.read();
@@ -1304,12 +1404,13 @@ Consensus<Adaptor>::phaseEstablish()
closeResolution_, closeResolution_,
rawCloseTimes_, rawCloseTimes_,
mode_.get(), mode_.get(),
getJson(true)); getJson(true),
adaptor_.validating());
} }
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::closeLedger() Consensus<Adaptor>::closeLedger(std::unique_ptr<std::stringstream> const& clog)
{ {
// We should not be closing if we already have a position // We should not be closing if we already have a position
XRPL_ASSERT(!result_, "ripple::Consensus::closeLedger : result is not set"); XRPL_ASSERT(!result_, "ripple::Consensus::closeLedger : result is not set");
@@ -1325,7 +1426,12 @@ Consensus<Adaptor>::closeLedger()
if (acquired_.emplace(result_->txns.id(), result_->txns).second) if (acquired_.emplace(result_->txns.id(), result_->txns).second)
adaptor_.share(result_->txns); adaptor_.share(result_->txns);
if (mode_.get() == ConsensusMode::proposing) const auto mode = mode_.get();
CLOG(clog)
<< "closeLedger transitioned to ConsensusPhase::establish, mode: "
<< to_string(mode)
<< ", number of peer positions: " << currPeerPositions_.size() << ". ";
if (mode == ConsensusMode::proposing)
adaptor_.propose(result_->position); adaptor_.propose(result_->position);
// Create disputes with any peer positions we have transactions for // Create disputes with any peer positions we have transactions for
@@ -1334,9 +1440,7 @@ Consensus<Adaptor>::closeLedger()
auto const& pos = pit.second.proposal().position(); auto const& pos = pit.second.proposal().position();
auto const it = acquired_.find(pos); auto const it = acquired_.find(pos);
if (it != acquired_.end()) if (it != acquired_.end())
{ createDisputes(it->second, clog);
createDisputes(it->second);
}
} }
} }
@@ -1362,7 +1466,8 @@ participantsNeeded(int participants, int percent)
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::updateOurPositions() Consensus<Adaptor>::updateOurPositions(
std::unique_ptr<std::stringstream> const& clog)
{ {
// We must have a position if we are updating it // We must have a position if we are updating it
XRPL_ASSERT( XRPL_ASSERT(
@@ -1372,6 +1477,8 @@ Consensus<Adaptor>::updateOurPositions()
// Compute a cutoff time // Compute a cutoff time
auto const peerCutoff = now_ - parms.proposeFRESHNESS; auto const peerCutoff = now_ - parms.proposeFRESHNESS;
auto const ourCutoff = now_ - parms.proposeINTERVAL; auto const ourCutoff = now_ - parms.proposeINTERVAL;
CLOG(clog) << "updateOurPositions. peerCutoff " << to_string(peerCutoff)
<< ", ourCutoff " << to_string(ourCutoff) << ". ";
// Verify freshness of peer positions and compute close times // Verify freshness of peer positions and compute close times
std::map<NetClock::time_point, int> closeTimeVotes; std::map<NetClock::time_point, int> closeTimeVotes;
@@ -1454,6 +1561,7 @@ Consensus<Adaptor>::updateOurPositions()
neededWeight = parms.avLATE_CONSENSUS_PCT; neededWeight = parms.avLATE_CONSENSUS_PCT;
else else
neededWeight = parms.avSTUCK_CONSENSUS_PCT; neededWeight = parms.avSTUCK_CONSENSUS_PCT;
CLOG(clog) << "neededWeight " << neededWeight << ". ";
int participants = currPeerPositions_.size(); int participants = currPeerPositions_.size();
if (mode_.get() == ConsensusMode::proposing) if (mode_.get() == ConsensusMode::proposing)
@@ -1469,9 +1577,12 @@ Consensus<Adaptor>::updateOurPositions()
int const threshConsensus = int const threshConsensus =
participantsNeeded(participants, parms.avCT_CONSENSUS_PCT); participantsNeeded(participants, parms.avCT_CONSENSUS_PCT);
JLOG(j_.info()) << "Proposers:" << currPeerPositions_.size() std::stringstream ss;
<< " nw:" << neededWeight << " thrV:" << threshVote ss << "Proposers:" << currPeerPositions_.size()
<< " thrC:" << threshConsensus; << " nw:" << neededWeight << " thrV:" << threshVote
<< " thrC:" << threshConsensus;
JLOG(j_.info()) << ss.str();
CLOG(clog) << ss.str();
for (auto const& [t, v] : closeTimeVotes) for (auto const& [t, v] : closeTimeVotes)
{ {
@@ -1500,6 +1611,7 @@ Consensus<Adaptor>::updateOurPositions()
<< " Mode:" << to_string(mode_.get()) << " Mode:" << to_string(mode_.get())
<< " Thresh:" << threshConsensus << " Thresh:" << threshConsensus
<< " Pos:" << consensusCloseTime.time_since_epoch().count(); << " Pos:" << consensusCloseTime.time_since_epoch().count();
CLOG(clog) << "No close time consensus. ";
} }
} }
@@ -1517,9 +1629,11 @@ Consensus<Adaptor>::updateOurPositions()
result_->txns = std::move(*ourNewSet); result_->txns = std::move(*ourNewSet);
JLOG(j_.info()) << "Position change: CTime " std::stringstream ss;
<< consensusCloseTime.time_since_epoch().count() ss << "Position change: CTime "
<< ", tx " << newID; << consensusCloseTime.time_since_epoch().count() << ", tx " << newID;
JLOG(j_.info()) << ss.str();
CLOG(clog) << ss.str();
result_->position.changePosition(newID, consensusCloseTime, now_); result_->position.changePosition(newID, consensusCloseTime, now_);
@@ -1547,7 +1661,8 @@ Consensus<Adaptor>::updateOurPositions()
template <class Adaptor> template <class Adaptor>
bool bool
Consensus<Adaptor>::haveConsensus() Consensus<Adaptor>::haveConsensus(
std::unique_ptr<std::stringstream> const& clog)
{ {
// Must have a stance if we are checking for consensus // Must have a stance if we are checking for consensus
XRPL_ASSERT(result_, "ripple::Consensus::haveConsensus : has result"); XRPL_ASSERT(result_, "ripple::Consensus::haveConsensus : has result");
@@ -1587,10 +1702,14 @@ Consensus<Adaptor>::haveConsensus()
result_->roundTime.read(), result_->roundTime.read(),
adaptor_.parms(), adaptor_.parms(),
mode_.get() == ConsensusMode::proposing, mode_.get() == ConsensusMode::proposing,
j_); j_,
clog);
if (result_->state == ConsensusState::No) if (result_->state == ConsensusState::No)
{
CLOG(clog) << "No consensus. ";
return false; return false;
}
// There is consensus, but we need to track if the network moved on // There is consensus, but we need to track if the network moved on
// without us. // without us.
@@ -1598,14 +1717,18 @@ Consensus<Adaptor>::haveConsensus()
{ {
JLOG(j_.error()) << "Unable to reach consensus"; JLOG(j_.error()) << "Unable to reach consensus";
JLOG(j_.error()) << Json::Compact{getJson(true)}; JLOG(j_.error()) << Json::Compact{getJson(true)};
CLOG(clog) << "Unable to reach consensus "
<< Json::Compact{getJson(true)} << ". ";
} }
CLOG(clog) << "Consensus has been reached. ";
return true; return true;
} }
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::leaveConsensus() Consensus<Adaptor>::leaveConsensus(
std::unique_ptr<std::stringstream> const& clog)
{ {
if (mode_.get() == ConsensusMode::proposing) if (mode_.get() == ConsensusMode::proposing)
{ {
@@ -1617,24 +1740,34 @@ Consensus<Adaptor>::leaveConsensus()
mode_.set(ConsensusMode::observing, adaptor_); mode_.set(ConsensusMode::observing, adaptor_);
JLOG(j_.info()) << "Bowing out of consensus"; JLOG(j_.info()) << "Bowing out of consensus";
CLOG(clog) << "Bowing out of consensus. ";
} }
} }
template <class Adaptor> template <class Adaptor>
void void
Consensus<Adaptor>::createDisputes(TxSet_t const& o) Consensus<Adaptor>::createDisputes(
TxSet_t const& o,
std::unique_ptr<std::stringstream> const& clog)
{ {
// Cannot create disputes without our stance // Cannot create disputes without our stance
XRPL_ASSERT(result_, "ripple::Consensus::createDisputes : result is set"); XRPL_ASSERT(result_, "ripple::Consensus::createDisputes : result is set");
// Only create disputes if this is a new set // Only create disputes if this is a new set
if (!result_->compares.emplace(o.id()).second) auto const emplaced = result_->compares.emplace(o.id()).second;
CLOG(clog) << "createDisputes: new set? " << !emplaced << ". ";
if (!emplaced)
return; return;
// Nothing to dispute if we agree // Nothing to dispute if we agree
if (result_->txns.id() == o.id()) if (result_->txns.id() == o.id())
{
CLOG(clog) << "both sets are identical. ";
return; return;
}
CLOG(clog) << "comparing existing with new set: " << result_->txns.id()
<< ',' << o.id() << ". ";
JLOG(j_.debug()) << "createDisputes " << result_->txns.id() << " to " JLOG(j_.debug()) << "createDisputes " << result_->txns.id() << " to "
<< o.id(); << o.id();
@@ -1678,6 +1811,7 @@ Consensus<Adaptor>::createDisputes(TxSet_t const& o)
result_->disputes.emplace(txID, std::move(dtx)); result_->disputes.emplace(txID, std::move(dtx));
} }
JLOG(j_.debug()) << dc << " differences found"; JLOG(j_.debug()) << dc << " differences found";
CLOG(clog) << "disputes: " << dc << ". ";
} }
template <class Adaptor> template <class Adaptor>