All Downloads are FREE. Search and download functionalities are using the official Maven repository.

com.swirlds.platform.ConsensusImpl Maven / Gradle / Ivy

Go to download

Swirlds is a software platform designed to build fully-distributed applications that harness the power of the cloud without servers. Now you can develop applications with fairness in decision making, speed, trust and reliability, at a fraction of the cost of traditional server-based platforms.

The newest version!
/*
 * Copyright (C) 2016-2024 Hedera Hashgraph, LLC
 *
 * Licensed under the Apache License, Version 2.0 (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at
 *
 *      http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */

package com.swirlds.platform;

import static com.swirlds.logging.legacy.LogMarker.CONSENSUS_VOTING;
import static com.swirlds.logging.legacy.LogMarker.STARTUP;
import static com.swirlds.platform.consensus.ConsensusConstants.FIRST_CONSENSUS_NUMBER;

import com.hedera.hapi.platform.event.EventConsensusData;
import com.hedera.hapi.util.HapiUtils;
import com.swirlds.base.time.Time;
import com.swirlds.common.context.PlatformContext;
import com.swirlds.common.platform.NodeId;
import com.swirlds.common.utility.Threshold;
import com.swirlds.common.utility.throttle.RateLimitedLogger;
import com.swirlds.logging.legacy.LogMarker;
import com.swirlds.platform.consensus.AncestorSearch;
import com.swirlds.platform.consensus.CandidateWitness;
import com.swirlds.platform.consensus.ConsensusConstants;
import com.swirlds.platform.consensus.ConsensusRounds;
import com.swirlds.platform.consensus.ConsensusSnapshot;
import com.swirlds.platform.consensus.ConsensusSorter;
import com.swirlds.platform.consensus.ConsensusUtils;
import com.swirlds.platform.consensus.CountingVote;
import com.swirlds.platform.consensus.EventWindow;
import com.swirlds.platform.consensus.InitJudges;
import com.swirlds.platform.consensus.RoundElections;
import com.swirlds.platform.consensus.ThreadSafeConsensusInfo;
import com.swirlds.platform.event.AncientMode;
import com.swirlds.platform.event.EventUtils;
import com.swirlds.platform.event.PlatformEvent;
import com.swirlds.platform.eventhandling.EventConfig;
import com.swirlds.platform.gossip.shadowgraph.Generations;
import com.swirlds.platform.internal.ConsensusRound;
import com.swirlds.platform.internal.EventImpl;
import com.swirlds.platform.metrics.ConsensusMetrics;
import com.swirlds.platform.system.address.AddressBook;
import com.swirlds.platform.util.MarkerFileWriter;
import edu.umd.cs.findbugs.annotations.NonNull;
import edu.umd.cs.findbugs.annotations.Nullable;
import java.time.Duration;
import java.time.Instant;
import java.util.ArrayList;
import java.util.Collection;
import java.util.HashSet;
import java.util.Iterator;
import java.util.LinkedList;
import java.util.List;
import org.apache.logging.log4j.LogManager;
import org.apache.logging.log4j.Logger;

/**
 * All the code for calculating the consensus for events in a hashgraph. This calculates the
 * consensus timestamp and consensus order, according to the hashgraph consensus algorithm.
 *
 * 

Every method in this file is private, except for some getters and the addEvent method. * Therefore, if care is taken so that only one thread at a time can be in the call to addEvent, * then only one thread at a time will be anywhere in this is class (except for the getters). None * of the variables are volatile, so calls to the getters by other threads may not see effects of * addEvent immediately. * *

The consensus order is calculated incrementally: each time a new event is added to the * hashgraph, it immediately finds the consensus order for all the older events for which that is * possible. It uses a fundamental theorem that was not included in the tech report. That theorem * is: * *

Theorem: If every known witness in round R in hashgraph A has its fame decided by A, and * S_{A,R} is the set of known famous witnesses in round R in hashgraph A, and if at least one event * created in round R+2 is known in A, then S_{A,R} is immutable and will never change as the * hashgraph grows in the future. Furthermore, any consistent hashgraph B will have an S_{B,R} that * is a subset of S_{A,R}, and as B grows during gossip, it will eventually be the case that S_{B,R} * = S_{A,R} with probability one. * *

Proof: the R+2 event strongly sees more than 2/3 of members having R+1 witnesses that vote NO * on the fame of any unknown R event X that will be discovered in the future. Any future R+2 voter * will strongly see a (possibly) different set of more than 2/3 of the R+1 population, and the * intersection of the two sets will all be NO votes for the new voter. So the new voter will see * less than 1/3 YES votes, and more than 1/3 NO votes, and will therefore vote no. Therefore every * R+3 voter will see unanimous NO votes, and will decide NO. Therefore X will not be famous. So the * set of famous in R will never grow in the future. (And so the consensus theorems imply that B * will eventually agree). * *

In other words, you never know whether new events and witnesses will be added to round R in * the future. But if all the known witnesses in that round have their fame decided (and if a round * R+2 event is known), then you know for sure that there will never be any more famous witnesses * discovered for round R. So you can safely calculate the received round and consensus time stamp * for every event that will have a received round of R. This is the key to the incremental * algorithm: as soon as all known witnesses in R have their fame decided (and there is at least one * R+2 event), then we can decide the consensus for a new batch of events: all those with received * round R. * *

There will be at least one famous event in each round. This is a theorem in the tech report, * but both the theorem and its proof should be adjusted to say the following: * *

Definition: a "voter" is a witness in round R that is strongly seen by at least one witness in * round R+1. * *

Theorem: For any R, there exists a witness X in round R that will be famous, and this will be * decided at the latest when one event in round R+3 is known. * *

Proof: Each voter in R+1 strongly sees more than 2n/3 witnesses in R, therefore each witness * in R is on average strongly seen by more than 2n/3 of the voters in R+1. There must be at least * one that is not below average, so let X be an R witness that is strongly seen by more than 2n/3 * round R+1 voters. Those voters will vote YES on the fame of X, because they see X. Any round R+2 * witness will receive votes from more than 2n/3 round R+1 voters, therefore it will receive a * majority of its votes for X being YES, therefore it will either vote or decide YES. If any R+2 * witness decides, then X is known to be famous at that time. If none do, then as soon as an R+3 * witness exists, it will see unanimous YES votes, and it will decide YES. So X will be known to be * famous after the first witness of R+3 is known (or earlier). * *

In normal operation, with everyone online and everyone honest, we might expect that all of the * round R witnesses will be known to be famous after the first event of round R+2 is known. But * even in the worst case, where some computers are down (even honest ones), and many dishonest * members are forking, the theorem still guarantees at least one famous witness is known by R+3. * *

It is another theorem that the d12 and d2 algorithm have more than two thirds of the * population creating unique famous witnesses (judges) in each round. It is a theorem that d1 does, * too, for the algorithmn described in 2016, and is conjectured to be true for the 2019 version, * too. * *

Another new theorem used here: * *

Theorem: If a new witness X is added to round R, but at least one already exists in round R+2, * then X will not be famous (so there is no need to hold the elections). * *

Proof: If an event X currently exists in round R+2, then when the new event Y is added to * round R, it won't be an ancestor of X, nor of the witnesses that X strongly sees. Therefore, X * will collect unanimous votes of NO for the fame of Y, so X will decide that Y is not famous. * Therefore, once a round R+2 event is added to the hashgraph, the set of possible unique famous * witnesses for round R is fixed, and the unique famous witnesses will end up being a subset of it. * *

NOTE: for concision, all of the above talks about things like "2/3 of the members" or "2/3 of * the witnesses". In every case, it should be interpreted to actually mean "members whose stake * adds up to more than 2/3 of the total stake", and "witnesses created by members whose stake is * more than 2/3 of the total". */ public class ConsensusImpl extends ThreadSafeConsensusInfo implements Consensus { public static final String COIN_ROUND_MARKER_FILE = "consensus-coin-round"; public static final String NO_SUPER_MAJORITY_MARKER_FILE = "consensus-no-super-majority"; public static final String NO_JUDGES_MARKER_FILE = "consensus-no-judges"; public static final String CONSENSUS_EXCEPTION_MARKER_FILE = "consensus-exception"; private static final Logger logger = LogManager.getLogger(ConsensusImpl.class); /** wall clock time */ private final Time time; /** the only address book currently, until address book changes are implemented */ private final AddressBook addressBook; /** metrics related to consensus */ private final ConsensusMetrics consensusMetrics; /** used for searching the hashgraph */ private final AncestorSearch search = new AncestorSearch(); /** * recently added events. this list is used for recalculating metadata once a new round is * decided. as soon as events reach consensus or become stale, they are discarded from this * list. */ private final List recentEvents = new LinkedList<>(); /** stores all round information */ private final ConsensusRounds rounds; /** * Number of events that have reached consensus order. This is used for setting consensus order * numbers in events, so it must be part of the signed state. */ private long numConsensus = FIRST_CONSENSUS_NUMBER; /** * The last consensus timestamp. This is equal to the consensus time of the last transaction in * the last event that reached consensus. This is null if no event has reached consensus yet. * As each event reaches its consensus, its timestamp is moved forward (if necessary) to be * after this time by n {@link ConsensusConstants#MIN_TRANS_TIMESTAMP_INCR_NANOS} nanoseconds, * if the event had n transactions (or n=1 if no transactions). */ private Instant lastConsensusTime = null; /** * if consensus is not starting from genesis, this instance is used to accurately calculate the * round for events */ private InitJudges initJudges = null; /** * Migration mode is used to migrate from an old state which saves consensus events and does * not have judge hashes. Since we don't have the judge hashes, we can't calculate the round * number of new events. So we use the round number from the events from state to calculate * the round number of new events. This is only used for one round after loading an old state. */ private boolean migrationMode = false; /** * The ancient mode used to determine if an event is ancient or not. */ private AncientMode ancientMode; /** The marker file writer */ private MarkerFileWriter markerFileWriter; /** The rate limited logger for rounds without a super majority of weight on judges */ private RateLimitedLogger noSuperMajorityLogger; /** The rate limited logger for rounds with no judge */ private RateLimitedLogger noJudgeLogger; /** The rate limited logger for coin rounds */ private RateLimitedLogger coinRoundLogger; /** * A flag that signals if we are currently replaying the PCES or not. */ private boolean pcesMode = false; /** * Constructs an empty object (no events) to keep track of elections and calculate consensus. * * @param platformContext the platform context containing configuration * @param consensusMetrics metrics related to consensus * @param addressBook the global address book, which never changes */ public ConsensusImpl( @NonNull final PlatformContext platformContext, @NonNull final ConsensusMetrics consensusMetrics, @NonNull final AddressBook addressBook) { super(platformContext); this.time = platformContext.getTime(); this.markerFileWriter = new MarkerFileWriter(platformContext); this.consensusMetrics = consensusMetrics; // until we implement address book changes, we will just use the use this address book this.addressBook = addressBook; this.rounds = new ConsensusRounds(config, getStorage(), addressBook); this.ancientMode = platformContext .getConfiguration() .getConfigData(EventConfig.class) .getAncientMode(); this.noSuperMajorityLogger = new RateLimitedLogger(logger, platformContext.getTime(), Duration.ofMinutes(1)); this.noJudgeLogger = new RateLimitedLogger(logger, platformContext.getTime(), Duration.ofMinutes(1)); this.coinRoundLogger = new RateLimitedLogger(logger, platformContext.getTime(), Duration.ofMinutes(1)); } /** * Load consensus from a snapshot. This will continue consensus from the round of the snapshot * once all the required events are provided. */ @Override public void loadSnapshot(@NonNull final ConsensusSnapshot snapshot) { reset(); initJudges = new InitJudges(snapshot.round(), new HashSet<>(snapshot.judgeHashes())); rounds.loadFromMinimumJudge(snapshot.getMinimumJudgeInfoList()); updateRoundGenerations(rounds.getFameDecidedBelow()); numConsensus = snapshot.nextConsensusNumber(); lastConsensusTime = snapshot.consensusTimestamp(); } /** Reset this instance to a state of a newly created instance */ private void reset() { recentEvents.clear(); rounds.reset(); numConsensus = 0; lastConsensusTime = null; initJudges = null; updateRoundGenerations(rounds.getFameDecidedBelow()); } /** * Set whether events are currently being sourced from the PCES. * * @param pcesMode true if we are currently replaying the PCES, false otherwise */ public void setPcesMode(final boolean pcesMode) { this.pcesMode = pcesMode; } /** * Add an event to consensus. It must already have been instantiated, checked for being a * duplicate of an existing event, had its signature created or checked. It must also be linked * to its parents. * *

This method will add it to consensus and propagate all its effects. So if the consensus * order can now be calculated for an event (which wasn't possible before), then it will do so * and return a list of consensus rounds. * *

It is possible that adding this event will decide the fame of the last candidate witness * in a round, and so the round will become decided, and so a batch of events will reach * consensus. The list of events that reached consensus (if any) will be returned in a consensus * round. * * @param event the event to be added * @return A list of consensus rounds or an empty list if no consensus was reached */ @NonNull @Override public List addEvent(@NonNull final EventImpl event) { try { recentEvents.add(event); // set its round to undefined so that it gets calculated event.setRoundCreated(ConsensusConstants.ROUND_UNDEFINED); ConsensusRound consensusRound; final boolean lastJudgeFound = checkInitJudges(event); if (!noInitJudgesMissing()) { // we should not do any calculations or voting until we have found all the init judges return List.of(); } if (lastJudgeFound) { // when we find the last init judge, we have to recalculate the metadata for all events consensusRound = recalculateAndVote(); } else { // this is the most common case, we are not looking for init judges so we simply calculate the // metadata for the event and vote if it's a witness consensusRound = calculateAndVote(event); } final List rounds = new ArrayList<>(); while (consensusRound != null) { rounds.add(consensusRound); consensusRound = recalculateAndVote(); } return rounds; } catch (final Exception e) { markerFileWriter.writeMarkerFile(CONSENSUS_EXCEPTION_MARKER_FILE); throw e; } } /** * Round fame is calculated for one round at a time. If fame has been decided for a round, we * recalculate the metadata for all non-ancient non-consensus events. This may trigger another * round having its fame decided. * * @return a consensus round if fame has been decided, null otherwise */ @Nullable private ConsensusRound recalculateAndVote() { rounds.recalculating(); for (final Iterator iterator = recentEvents.iterator(); iterator.hasNext(); ) { final EventImpl insertedEvent = iterator.next(); if (rounds.isLastDecidedJudge(insertedEvent) && round(insertedEvent.getSelfParent()) == ConsensusConstants.ROUND_NEGATIVE_INFINITY && round(insertedEvent.getOtherParent()) == ConsensusConstants.ROUND_NEGATIVE_INFINITY) { // If an event was a judge in the last round decided AND is not a descendant of any other judge in // this round, we leave all of its metadata intact. We know that it is not a descendant of any other // judge in this round if all of its parents have a round of -infinity. // // Its round must stay intact so that descendants can determine their round numbers. // We don't call calculateAndVote() for this event because: // - its metadata will be unchanged // - it will not vote // - it will never decide a round continue; } if (insertedEvent.isConsensus() || isAncient(insertedEvent.getBaseEvent())) { insertedEvent.clearMetadata(); // all events that are consensus or ancient have a round of -infinity insertedEvent.setRoundCreated(ConsensusConstants.ROUND_NEGATIVE_INFINITY); iterator.remove(); continue; } // for all other events, we need to recalculate its round and metadata insertedEvent.clearMetadata(); insertedEvent.setRoundCreated(ConsensusConstants.ROUND_UNDEFINED); final ConsensusRound consensusRound = calculateAndVote(insertedEvent); if (consensusRound != null) { return consensusRound; } } return null; } @Nullable private ConsensusRound calculateAndVote(final EventImpl event) { // find the roundCreated, and store it using event.setRoundCreated() round(event); consensusMetrics.addedEvent(event); // force it to memoize for this event now, to avoid deep recursion of these methods later calculateMetadata(event); if (!witness(event)) { return null; } event.setWitness(true); if (rounds.getElectionRoundNumber() <= event.getRoundCreated()) { if (rounds.getElectionRoundNumber() == event.getRoundCreated()) { // this is a candidate witness which we are voting on, we might need to create // elections for this witness, but this witness does not vote rounds.newWitness(event); } else { // this is a witness for a round later than the round being voted on, so it should // vote in all elections in the current round voteInAllElections(event); } } else { // this is a witness for a decided round, so it is not a famous witness event.setFamous(false); event.setFameDecided(true); } // in most cases, we only need to do this check after voting, since that is the only time a // round could be decided. but there is an edge case for which we need to check it for // non-witnesses // EDGE CASE: // if a round gets decided before we have found all the init judges, we cannot proceed with // finding consensus events. this is because we need to find all the init judges so that we // can find their common ancestors and mark them as having reached consensus. once we have // done this, we can find the consensus events for the next round, which in this case would // be the election round. if we didn't do that, then an event could reach consensus twice. final RoundElections roundElections = rounds.getElectionRound(); if (roundElections.isDecided() && noInitJudgesMissing()) { // all famous witnesses for this round are now known. None will ever be added again. We // know this round has at least one witness. We know they all have fame decided. We // know the next 2 rounds have events in them, because otherwise we couldn't have // decided the fame here. Therefore, any new witness added to this round in the future // will be instantly decided as not famous. Therefore, the set of famous witnesses // in this round is now completely known and immutable. So we can call the following, to // record that fact, and propagate appropriately. return roundDecided(roundElections); } return null; } /** * @return true if there are no init judges missing */ private boolean noInitJudgesMissing() { return initJudges == null || initJudges.allJudgesFound(); } /** * Checks if an event is an init judge. If it is, it will set its round created and judge flags. * if it's the last missing judge, it will also mark events which have previously reached * consensus and return true. * * @param event the event to check * @return true if the event is the last init judge we are looking for */ private boolean checkInitJudges(@NonNull final EventImpl event) { if (noInitJudgesMissing() || !initJudges.isInitJudge(event.getBaseHash())) { return false; } // we found one of the missing init judges initJudges.judgeFound(event); logger.info( STARTUP.getMarker(), "Found init judge %s, num remaining: {}" .formatted(event.getBaseEvent().getDescriptor()), initJudges::numMissingJudges); if (!initJudges.allJudgesFound()) { return false; } // we now have the last of the missing judges, so find every known event that is an // ancestor of all of them, and mark it as having consensus. We won't handle its // transactions or do anything else with it, since it had earlier achieved consensus // and affected the signed state that we started from. We won't even set its consensus // fields such as roundReceived, because they aren't known, will never be known, and // aren't needed. We'll just mark it as having consensus, so we don't calculate // consensus for it again in the future. final List ancestors = search.commonAncestorsOf(initJudges.getJudges(), this::nonConsensusNonAncient); ancestors.forEach(e -> { e.setConsensus(true); e.setRecTimes(null); }); initJudges = null; return true; } /** * Calculate metadata for an event and memoize it. This is done to avoid deep recursion of these * methods later. * * @param event the event to calculate metadata for */ private void calculateMetadata(@NonNull final EventImpl event) { if (notRelevantForConsensus(event) || rounds.isLastDecidedJudge(event)) { return; } lastSee(event, 0); timedStronglySeeP(event, 0); firstSelfWitnessS(event); firstWitnessS(event); } /** * Vote on all candidate witnesses in the current election round. This call could decide a * round. * * @param votingWitness the event that will vote */ private void voteInAllElections(@NonNull final EventImpl votingWitness) { final RoundElections roundElections = rounds.getElectionRound(); votingWitness.initVoting(roundElections.numElections()); final long diff = round(votingWitness) - roundElections.getRound(); if (diff <= 0) { // this should never happen, but just in case return; } if (diff == 1) { for (final Iterator it = roundElections.undecidedWitnesses(); it.hasNext(); ) { final CandidateWitness candidateWitness = it.next(); final boolean firstVote = firstVote(votingWitness, candidateWitness.getWitness()); votingWitness.setVote(candidateWitness, firstVote); logVote(votingWitness, candidateWitness, "first", diff); } return; } // if diff > 1, we are counting the votes of the witnesses in the previous round. Vote with // the majority of witnesses strongly seen. final List stronglySeen = getStronglySeenInPreviousRound(votingWitness); for (final Iterator it = roundElections.undecidedWitnesses(); it.hasNext(); ) { final CandidateWitness candidateWitness = it.next(); final CountingVote countingVote = getCountingVote(candidateWitness, stronglySeen); if (isCoinRound(diff)) { // a coin round. Don't decide. coinVote(votingWitness, candidateWitness, countingVote); logVote( votingWitness, candidateWitness, "coin-" + (countingVote.isSupermajority() ? "counting" : "sig"), diff); markerFileWriter.writeMarkerFile(COIN_ROUND_MARKER_FILE); coinRoundLogger.error( LogMarker.ERROR.getMarker(), "Coin round {}, voting witness: {}", roundElections.getRound(), votingWitness); continue; } // a normal round. Vote with the majority of those you strongly see votingWitness.setVote(candidateWitness, countingVote.getVote()); logVote(votingWitness, candidateWitness, "counting", diff); // If you strongly see a supermajority one way, then decide that way. if (countingVote.isSupermajority()) { // we've decided one famous event. Set it as famous. candidateWitness.fameDecided(votingWitness.getVote(candidateWitness)); if (roundElections.isDecided()) { // this round has been decided consensusMetrics.lastFamousInRound(candidateWitness.getWitness()); // no need to vote anymore until we create elections for the next round return; } } } } /** * Calculates a counting vote for the candidate witness by the voting witness. * *

Suppose that the election is being held for round ER, and the witness voting is in round * VR. The voting witness looks at all witness it can strongly see from round VR-1. For each of * these witnesses, it looks at their vote for the election witness. It adds up all the stake of * the witnesses voting yes, and the stake of those voting no. If either of the stake sums is a * supermajority, the fame of the election witness is decided. * *

So the outcome of this voting is two booleans: * *

    *
  1. is the witness voting yes or no *
  2. is the vote a supermajority vote *
* * @param candidateWitness the witness being voted on * @param stronglySeen the witnesses VR-1 that the voting witness can strongly see * @return the outcome of the vote */ @NonNull private CountingVote getCountingVote(final CandidateWitness candidateWitness, final List stronglySeen) { // count votes from witnesses you strongly see long yesWeight = 0; // total weight of all members voting yes long noWeight = 0; // total weight of all members voting yes for (final EventImpl w : stronglySeen) { final long weight = getWeight(w.getCreatorId()); if (w.getVote(candidateWitness)) { yesWeight += weight; } else { noWeight += weight; } } final long totalWeight = addressBook.getTotalWeight(); final boolean superMajority = Threshold.SUPER_MAJORITY.isSatisfiedBy(yesWeight, totalWeight) || Threshold.SUPER_MAJORITY.isSatisfiedBy(noWeight, totalWeight); final boolean countingVote = yesWeight >= noWeight; return CountingVote.get(countingVote, superMajority); } /** * Should this be a coin voting round * * @param diff the difference in rounds between the voting witness and the candidate witness * @return true if it should be a coin round */ private boolean isCoinRound(final long diff) { return diff % config.coinFreq() == 0; } /** * A coin voting round, very similar to a counting vote, the difference is: * *
    *
  1. A coin vote never decides fame, unlike a counting vote *
  2. If there is no yes or not supermajority, the vote will be random (based on the * signature of the event) *
* * @param votingWitness the witness that is voting * @param candidateWitness the witness being voted on * @param countingVote the counting vote */ private void coinVote( @NonNull final EventImpl votingWitness, @NonNull final CandidateWitness candidateWitness, @NonNull final CountingVote countingVote) { // a coin round. Vote randomly unless you strongly see a supermajority. Don't decide. consensusMetrics.coinRound(); final boolean vote = countingVote.isSupermajority() ? countingVote.getVote() : ConsensusUtils.coin(votingWitness); votingWitness.setVote(candidateWitness, vote); } /** Logs the outcome of voting */ private void logVote( @NonNull final EventImpl votingWitness, @NonNull final CandidateWitness candidateWitness, @NonNull final String votingType, final long diff) { logger.info( CONSENSUS_VOTING.getMarker(), "Witness {} voted on {}. vote:{} type:{} diff:{}", votingWitness, candidateWitness.getWitness(), votingWitness.getVote(candidateWitness), votingType, diff); } private boolean firstVote(@NonNull final EventImpl voting, @NonNull final EventImpl votedOn) { // first round of an election. Vote TRUE for self-ancestors of those you firstSee. Don't // decide. EventImpl w = firstSee(voting, addressBook.getIndexOfNodeId(votedOn.getCreatorId())); while (w != null && w.getRoundCreated() > voting.getRoundCreated() - 1 && selfParent(w) != null) { w = firstSelfWitnessS(selfParent(w)); } return votedOn == w; } /** * Find all the witnesses that event can strongly see, in the round before the supplied event's * round created. * * @param event the event to find who it sees * @return a list of witnesses */ @NonNull private List getStronglySeenInPreviousRound(final EventImpl event) { final int numMembers = addressBook.getSize(); final ArrayList stronglySeen = new ArrayList<>(numMembers); for (long m = 0; m < numMembers; m++) { final EventImpl s = stronglySeeS1(event, m); if (s != null) { stronglySeen.add(s); } } return stronglySeen; } /** * This round has been decided, this means that the fame of all known witnesses in that round * has been decided, and so any new witnesses discovered in the future will be guaranteed to not * be famous. * *

Since fame for this round is now decided, it is now possible to decide consensus and time * stamps for events in earlier rounds. If it's an ancestor of all the famous witnesses, then it * reaches consensus. * * @param roundElections the round information of the decided round * @return the consensus round */ private @NonNull ConsensusRound roundDecided(final RoundElections roundElections) { // if migration was enabled, we can turn it off now since we've decided fame for this round migrationMode = false; // the current round just had its fame decided. // Note: more witnesses may be added to this round in the future, but they'll all be // instantly marked as not famous. final List judges = roundElections.findAllJudges(); final long decidedRoundNumber = rounds.getElectionRoundNumber(); // Check for no judges or super majority conditions. checkJudges(judges, decidedRoundNumber); // update the round and generation values since fame has been decided for a new round rounds.currentElectionDecided(); // this updates the thread-safe values this.updateRoundGenerations(rounds.getFameDecidedBelow()); // all events that reach consensus during this method call, in consensus order final List consensusEvents = findConsensusEvents(judges, decidedRoundNumber, ConsensusUtils.generateWhitening(judges)).stream() .map(EventImpl::getBaseEvent) .toList(); // all rounds before this round are now decided, and appropriate events marked consensus consensusMetrics.consensusReachedOnRound(); // lastConsensusTime is updated above with the last transaction in the last event that reached consensus // if no events reach consensus, then we need to calculate the lastConsensusTime differently if (consensusEvents.isEmpty()) { if (lastConsensusTime == null) { // if this is the first round ever, and there are no events (which is usually the case) // we take the median of all the judge created times final List judgeTimes = judges.stream().map(EventImpl::getTimeCreated).sorted().toList(); lastConsensusTime = judgeTimes.get(judgeTimes.size() / 2); } else { // if we have reached consensus before, we simply increase the lastConsensusTime by the min amount lastConsensusTime = ConsensusUtils.calcMinTimestampForNextEvent(lastConsensusTime); } } // Future work: prior to enabling a birth round based ancient mode, we need to use real values for // previousRoundNonAncient and previousRoundNonExpired. This is currently a place holder. final long previousRoundNonAncient = ConsensusConstants.ROUND_FIRST; final long previousRoundNonExpired = ConsensusConstants.ROUND_FIRST; final long nonAncientThreshold = ancientMode.selectIndicator( getMinGenerationNonAncient(), Math.max(previousRoundNonAncient, decidedRoundNumber - config.roundsNonAncient() + 1)); final long nonExpiredThreshold = ancientMode.selectIndicator( getMinRoundGeneration(), Math.max(previousRoundNonExpired, decidedRoundNumber - config.roundsExpired() + 1)); return new ConsensusRound( addressBook, consensusEvents, recentEvents.get(recentEvents.size() - 1).getBaseEvent(), new Generations(this), new EventWindow(decidedRoundNumber, nonAncientThreshold, nonExpiredThreshold, ancientMode), new ConsensusSnapshot( decidedRoundNumber, ConsensusUtils.getHashes(judges), rounds.getMinimumJudgeInfoList(), numConsensus, lastConsensusTime), pcesMode, time.now()); } /** * Check if there are no judges or if there is no super majority of weight on judges. * * @param judges the judges for this round * @param decidedRoundNumber the round number of the decided round */ private void checkJudges(@NonNull final List judges, final long decidedRoundNumber) { final long judgeWeights = judges.stream() .mapToLong(event -> getWeight(event.getCreatorId())) .sum(); consensusMetrics.judgeWeights(judgeWeights); if (judges.isEmpty()) { markerFileWriter.writeMarkerFile(NO_JUDGES_MARKER_FILE); noJudgeLogger.error(LogMarker.ERROR.getMarker(), "no judges in round = {}", decidedRoundNumber); } else { if (!Threshold.SUPER_MAJORITY.isSatisfiedBy(judgeWeights, addressBook.getTotalWeight())) { markerFileWriter.writeMarkerFile(NO_SUPER_MAJORITY_MARKER_FILE); noSuperMajorityLogger.error( LogMarker.ERROR.getMarker(), "less than a super majority of weight on judges. round = {}, judgesWeight = {}, percentage = {}", decidedRoundNumber, judgeWeights, (double) judgeWeights / addressBook.getTotalWeight()); } } } /** * Find all events that are ancestors of the judges in round and update them. A non-consensus * event that is an ancestor of all of them should be marked as consensus, and have its * consensus roundReceived and timestamp set. This should not be called on any round greater * than R until after it has been called on round R. * * @param judges the judges for this round * @param decidedRound the info for the round with the unique famous witnesses, which is also * the round received for these events reaching consensus now * @param whitening a XOR of all judge signatures in this round */ private @NonNull List findConsensusEvents( @NonNull final List judges, final long decidedRound, @NonNull final byte[] whitening) { // the newly-consensus events where round received is "round" final List consensus = search.commonAncestorsOf(judges, this::nonConsensusNonAncient); // event has reached consensus, so set consensus timestamp, and set isConsensus to true consensus.forEach(e -> setIsConsensusTrue(e, decidedRound)); // "consensus" now has all events in history with receivedRound==round // there will never be any more events with receivedRound<=round (not even if the address // book changes) consensus.sort(new ConsensusSorter(whitening)); // Set the consensus number for every event that just became a consensus // event. Add more info about it to the hashgraph. Set event.lastInRoundReceived // to true for the last event in "consensus". setConsensusOrder(consensus); // reclaim the memory for the list of received times consensus.forEach(e -> e.setRecTimes(null)); return consensus; } /** * Set event.isConsensus to true, set its consensusTimestamp, and record speed statistics. * * @param event the event to modify, with event.getRecTimes() containing all the times judges * first saw it * @param receivedRound the round in which event was received */ private static void setIsConsensusTrue(@NonNull final EventImpl event, final long receivedRound) { event.setRoundReceived(receivedRound); event.setConsensus(true); // list of when e1 first became ancestor of each ufw // these timestamps have been sorted beforehand final List times = event.getRecTimes(); // take middle. If there are 2 middle (even length) then use the 2nd (max) of them event.setPreliminaryConsensusTimestamp(times.get(times.size() / 2)); } /** * Set event.consensusOrder for every event that just reached consensus, and update the count * numConsensus accordingly. The last event in events is marked as being the last received in * its round. Consensus timestamps are adjusted, if necessary, to ensure that each event in * consensus order is later than the previous one, by enough nanoseconds so that each * transaction can be given a later timestamp than the last. * * @param events the events to set (such that a for(EventImpl e:events) loop visits them in * consensus order) */ private void setConsensusOrder(@NonNull final Collection events) { EventImpl last = null; for (final EventImpl e : events) { last = e; // the minimum timestamp for this event final Instant minTimestamp = lastConsensusTime == null ? null : ConsensusUtils.calcMinTimestampForNextEvent(lastConsensusTime); // advance this event's consensus timestamp to be at least minTimestamp if (minTimestamp != null && e.getPreliminaryConsensusTimestamp().isBefore(minTimestamp)) { e.setPreliminaryConsensusTimestamp(minTimestamp); } e.getBaseEvent() .setConsensusData(new EventConsensusData( HapiUtils.asTimestamp(e.getPreliminaryConsensusTimestamp()), numConsensus)); lastConsensusTime = EventUtils.getLastTransTime(e.getBaseEvent()); numConsensus++; consensusMetrics.consensusReached(e); } } private boolean nonConsensusNonAncient(@NonNull final EventImpl e) { return !e.isConsensus() && !isAncient(e.getBaseEvent()); } private @Nullable EventImpl timedStronglySeeP(@Nullable final EventImpl x, final long m) { long t = System.nanoTime(); // Used to update statistic for dot product time final EventImpl result = stronglySeeP(x, m); t = System.nanoTime() - t; // nanoseconds spent doing the dot product consensusMetrics.dotProductTime(t); return result; } /** * Check if this event is relevant for consensus calculation. If an event has a round of -infinity we don't care * about what it sees. This is a performance optimization, to stop traversing the part of the graph that has no * impact on consensus. * @param e the event to check * @return true if this event is relevant for consensus */ private static boolean notRelevantForConsensus(@NonNull final EventImpl e) { return e.getRoundCreated() == ConsensusConstants.ROUND_NEGATIVE_INFINITY; } //////////////////////////////////////////////////////////////////////////////////////////////////////////////////// // Functions from SWIRLDS-TR-2020-01, verified by Coq proof //////////////////////////////////////////////////////////////////////////////////////////////////////////////////// /** * Checks if this event is a witness. The {@link EventImpl#isWitness()} is set based on this * method, so this is considered to be the definition of what a witness is. * *

(selfParent(x) = ∅) ∨ (round(x) > round(selfParent(x)) * * @param x the event to check * @return true if this event is a witness */ private boolean witness(@NonNull final EventImpl x) { return round(x) > ConsensusConstants.ROUND_NEGATIVE_INFINITY && (!x.hasSelfParent() || round(x) != round(selfParent(x))); } /** * @return the self-parent of event x, or ∅ if none or ancient */ private @Nullable EventImpl selfParent(@NonNull final EventImpl x) { return ancient(x.getSelfParent()) ? null : x.getSelfParent(); } /** * @return the other-parent of event x, or ∅ if none or ancient */ private @Nullable EventImpl otherParent(@NonNull final EventImpl x) { return ancient(x.getOtherParent()) ? null : x.getOtherParent(); } /** * Check if the event is ancient * @param x the event to check * @return true if the event is ancient */ private boolean ancient(@Nullable final EventImpl x) { return x == null || x.getGeneration() < getMinGenerationNonAncient(); } /** * The parent round (max of parents' rounds) of event x (function from SWIRLDS-TR-2020-01). This * result is not memoized. * * @param x the event being queried * @return the parent round of x */ private long parentRound(@Nullable final EventImpl x) { if (x == null) { return ConsensusConstants.ROUND_NEGATIVE_INFINITY; } return Math.max(round(selfParent(x)), round(otherParent(x))); } /** * The last event created by m that is an ancestor of x (function from SWIRLDS-TR-2020-01). This * has aggressive memoization: the first time it is called with a given x, it immediately * calculates and stores results for all m. This result is memoized. * * @param x the event being queried * @param m the member ID of the creator * @return the last event created by m that is an ancestor of x, or null if none */ private @Nullable EventImpl lastSee(@Nullable final EventImpl x, final long m) { final int numMembers; final EventImpl sp; final EventImpl op; if (x == null) { return null; } if (notRelevantForConsensus(x)) { return null; } if (x.sizeLastSee() != 0) { // return memoized answer, if available return x.getLastSee((int) m); } // memoize answers for all choices of m, then return answer for just this m numMembers = addressBook.getSize(); x.initLastSee(numMembers); op = otherParent(x); sp = selfParent(x); for (int mm = 0; mm < numMembers; mm++) { if (creatorIndexEquals(x, mm)) { x.setLastSee(mm, x); } else if (sp == null && op == null) { x.setLastSee(mm, null); } else { final EventImpl lsop = lastSee(op, mm); final EventImpl lssp = lastSee(sp, mm); final long lsopGen = lsop == null ? 0 : lsop.getGeneration(); final long lsspGen = lssp == null ? 0 : lssp.getGeneration(); if ((round(lsop) > round(lssp)) || ((lsopGen > lsspGen) && (firstSee(op, mm) == firstSee(sp, mm)))) { x.setLastSee(mm, lsop); } else { x.setLastSee(mm, lssp); } } } return x.getLastSee((int) m); } /** * The witness y created by m that is seen by event x through an event z created by m2 (function * from SWIRLDS-TR-2020-01). This result is not memoized. * * @param x the event being queried * @param m the creator of y, the event seen * @param m2 the creator of z, the intermediate event through which x sees y * @return the event y that is created by m and seen by x through an event by m2 */ private @Nullable EventImpl seeThru(@Nullable final EventImpl x, final int m, final int m2) { if (x == null) { return null; } if (notRelevantForConsensus(x)) { return null; } if (m == m2 && creatorIndexEquals(x, m2)) { return firstSelfWitnessS(selfParent(x)); } return firstSee(lastSee(x, m2), m); } /** * The witness created by m in the parent round of x that x strongly sees (function from * SWIRLDS-TR-2020-01). This result is memoized. * *

This method is called multiple times by both round() and stronglySeeP1(). A measure of the * total time spent in this method gives an indication of how much time is being devoted to what * can be thought of as a kind of generalized dot product (not a literal dot product). So it is * timed and it updates the statistic for that. * * @param x the event being queried * @param m the member ID of the creator * @return witness created by m in the parent round of x that x strongly sees, or null if none */ private @Nullable EventImpl stronglySeeP(@Nullable final EventImpl x, final long m) { if (x == null) { // if there is no event, then it can't see anything return null; } if (notRelevantForConsensus(x)) { return null; } if (x.sizeStronglySeeP() != 0) { // return memoized answer, if available return x.getStronglySeeP((int) m); } // calculate the answer, and remember it for next time // find and memoize answers for all choices of m, then return answer for just this m final int numMembers = addressBook.getSize(); // number of members final long totalWeight = addressBook.getTotalWeight(); // total stake in existence final EventImpl sp = selfParent(x); // self parent final EventImpl op = otherParent(x); // other parent final long prx = parentRound(x); // parent round of x final long prsp = parentRound(sp); // parent round of self parent of x final long prop = parentRound(op); // parent round of other parent of x x.initStronglySeeP(numMembers); for (int mm = 0; mm < numMembers; mm++) { if (stronglySeeP(sp, mm) != null && prx == prsp) { x.setStronglySeeP(mm, stronglySeeP(sp, mm)); } else if (stronglySeeP(op, mm) != null && prx == prop) { x.setStronglySeeP(mm, stronglySeeP(op, mm)); } else { // the canonical witness by mm that is seen by x thru someone else final EventImpl st = seeThru(x, mm, mm); if (round(st) != prx) { // ignore if the canonical is in the wrong round, or doesn't exist x.setStronglySeeP(mm, null); } else { long weight = 0; for (int m3 = 0; m3 < numMembers; m3++) { if (seeThru(x, mm, m3) == st) { // only count intermediates that see the canonical witness weight += getWeight(m3); } } if (Threshold.SUPER_MAJORITY.isSatisfiedBy(weight, totalWeight)) { // strongly see supermajority of // intermediates x.setStronglySeeP(mm, st); } else { x.setStronglySeeP(mm, null); } } } } return x.getStronglySeeP((int) m); } /** * The round-created for event x (first round is 1), or 0 if x is null (function from * SWIRLDS-TR-2020-01). It also stores the round number with x.setRoundCreated(). This result is * memoized. * *

If the event has a hash in the hash lists given to the ConsensusImpl constructor, then the * roundCreated is set to that round number, rather than calculating it from the parents. * *

If a parent has a round of -1, that is treated as negative infinity. So if all parents are * -1, then this one will also be -1. * * @param x the event being queried * @return the round-created for event x, or 0 if x is null */ private long round(@Nullable final EventImpl x) { // // If an event is missing (null), it must be ancient. ancient events have a round of // -infinity // if (x == null) { return ConsensusConstants.ROUND_NEGATIVE_INFINITY; } // // Is the round already memoized? If it is, return the memoized value // if (x.getRoundCreated() >= ConsensusConstants.ROUND_NEGATIVE_INFINITY) { return x.getRoundCreated(); } // // events older than all the judges in the latest decided round as well as consensus events // have a round of -infinity. this covers ancient events as well because the ancient // generation will always be older than the latest decided round generation // NOTE: during migration we just check for ancient, because we don't know the judges // if ((!migrationMode && rounds.isOlderThanDecidedRoundGeneration(x)) || (migrationMode && ancient(x)) || x.isConsensus()) { x.setRoundCreated(ConsensusConstants.ROUND_NEGATIVE_INFINITY); return ConsensusConstants.ROUND_NEGATIVE_INFINITY; } // // if this event has no parents, then it's the first round // if (!x.hasSelfParent() && !x.hasOtherParent()) { x.setRoundCreated(ConsensusConstants.ROUND_FIRST); return x.getRoundCreated(); } // roundCreated of self parent final long rsp = round(selfParent(x)); // roundCreated of other parent final long rop = round(otherParent(x)); // // if parents have unequal rounds, then copy the round of the later parent // if (rsp > rop) { x.setRoundCreated(rsp); return x.getRoundCreated(); } if (rop > rsp) { x.setRoundCreated(rop); return x.getRoundCreated(); } // // parents have equal rounds. But if both are -infinity, then this is -infinity // if (rsp == ConsensusConstants.ROUND_NEGATIVE_INFINITY) { x.setRoundCreated(ConsensusConstants.ROUND_NEGATIVE_INFINITY); return x.getRoundCreated(); } // number of members that are voting final int numMembers = addressBook.getSize(); // parents have equal rounds (not -1), so check if x can strongly see witnesses with a // supermajority of stake // sum of stake involved long weight = 0; int numStronglySeen = 0; for (int m = 0; m < numMembers; m++) { if (timedStronglySeeP(x, m) != null) { weight += getWeight(m); numStronglySeen++; } } consensusMetrics.witnessesStronglySeen(numStronglySeen); if (Threshold.SUPER_MAJORITY.isSatisfiedBy(weight, addressBook.getTotalWeight())) { // it's a supermajority, so advance to the next round x.setRoundCreated(1 + parentRound(x)); consensusMetrics.roundIncrementedByStronglySeen(); return x.getRoundCreated(); } // it's not a supermajority, so don't advance to the next round x.setRoundCreated(parentRound(x)); return x.getRoundCreated(); } /** * The self-ancestor of x in the same round that is a witness (function from * SWIRLDS-TR-2020-01). This result is memoized. * * @param x the event being queried * @return The ancestor of x in the same round that is a witness, or null if x is null */ private @Nullable EventImpl firstSelfWitnessS(@Nullable final EventImpl x) { if (x == null) { return null; } if (notRelevantForConsensus(x)) { return null; } if (x.getFirstSelfWitnessS() != null) { // if already found and memoized, return it return x.getFirstSelfWitnessS(); } // calculate, memoize, and return the result if (round(x) > round(selfParent(x))) { x.setFirstSelfWitnessS(x); } else { x.setFirstSelfWitnessS(firstSelfWitnessS(selfParent(x))); } return x.getFirstSelfWitnessS(); } /** * The earliest witness that is an ancestor of x in the same round as x (function from * SWIRLDS-TR-2020-01). This result is memoized. * * @param x the event being queried * @return the earliest witness that is an ancestor of x in the same round as x, or null if x is * null */ private @Nullable EventImpl firstWitnessS(@Nullable final EventImpl x) { if (x == null) { return null; } if (notRelevantForConsensus(x)) { return null; } if (x.getFirstWitnessS() != null) { // if already found and memoized, return it return x.getFirstWitnessS(); } // calculate, memoize, and return the result if (round(x) > parentRound(x)) { x.setFirstWitnessS(x); } else if (round(x) == round(selfParent(x))) { x.setFirstWitnessS(firstWitnessS(selfParent(x))); } else { x.setFirstWitnessS(firstWitnessS(otherParent(x))); } return x.getFirstWitnessS(); } /** * The event by m that x strongly sees in the round before the created round of x (function from * SWIRLDS-TR-2020-01). This result is not memoized. * * @param x the event being queried * @param m the member ID of the creator * @return event by m that x strongly sees in the round before the created round of x, or null * if none */ private @Nullable EventImpl stronglySeeS1(@Nullable final EventImpl x, final long m) { return timedStronglySeeP(firstWitnessS(x), m); } /** * The first witness in round r that is a self-ancestor of x, where r is the round of the last * event by m that is seen by x (function from SWIRLDS-TR-2020-01). This result is not memoized. * * @param x the event being queried * @param m the member ID of the creator * @return firstSelfWitnessS(lastSee ( x, m)), which is the first witness in round r that is a * self-ancestor of x, where r is the round of the last event by m that is seen by x, or * null if none */ private @Nullable EventImpl firstSee(@Nullable final EventImpl x, final long m) { return firstSelfWitnessS(lastSee(x, m)); } /** * Get the weigh of a node by its ID * @param nodeId the ID of the node * @return the weight of the node, or 0 if the node is not in the address book */ private long getWeight(@NonNull final NodeId nodeId) { if (!addressBook.contains(nodeId)) { return 0; } return addressBook.getAddress(nodeId).getWeight(); } /** * Get the weight of a node by its index * @param nodeIndex the index of the node * @return the weight of the node */ private long getWeight(final int nodeIndex) { return getWeight(addressBook.getNodeId(nodeIndex)); } /** * Check the index in the address book of the creator of the event * @param e the event whose creator to check * @param index the index * @return true if this creator is in the address book and has the given index */ private boolean creatorIndexEquals(@NonNull final EventImpl e, final int index) { if (!addressBook.contains(e.getCreatorId())) { return false; } return addressBook.getIndexOfNodeId(e.getCreatorId()) == index; } }





© 2015 - 2024 Weber Informatics LLC | Privacy Policy