# beacon_chain # Copyright (c) 2019-2022 Status Research & Development GmbH # Licensed and distributed under either of # * MIT license (license terms in the root directory or at https://opensource.org/licenses/MIT). # * Apache v2 license (license terms in the root directory or at https://www.apache.org/licenses/LICENSE-2.0). # at your option. This file may not be copied, modified, or distributed except according to those terms. # `block_sim` is a block and attestation simulator similar to `state_sim` whose # task is to run the beacon chain without considering the network or the # wall clock. Functionally, it achieves the same as the distributed beacon chain # by producing blocks and attestations as if they were created by separate # nodes, just like a set of `beacon_node` instances would. # # Similar to `state_sim`, but uses the block and attestation pools along with # a database, as if a real node was running. import math, stats, times, strformat, tables, options, random, tables, os, confutils, chronicles, eth/db/kvstore_sqlite3, chronos/timer, eth/keys, taskpools, ../tests/testblockutil, ../beacon_chain/spec/[ beaconstate, forks, helpers, signatures, state_transition], ../beacon_chain/spec/datatypes/[phase0, altair, bellatrix], ../beacon_chain/[beacon_chain_db, beacon_clock], ../beacon_chain/eth1/eth1_monitor, ../beacon_chain/validators/validator_pool, ../beacon_chain/gossip_processing/[batch_validation, gossip_validation], ../beacon_chain/consensus_object_pools/[blockchain_dag, block_quarantine, block_clearance, attestation_pool, sync_committee_msg_pool], ./simutils type Timers = enum tBlock = "Process non-epoch slot with block" tEpoch = "Process epoch slot with block" tHashBlock = "Tree-hash block" tSignBlock = "Sign block" tAttest = "Have committee attest to block" tSyncCommittees = "Produce sync committee actions" tReplay = "Replay all produced blocks" template seconds(x: uint64): timer.Duration = timer.seconds(int(x)) func gauss(r: var Rand; mu = 0.0; sigma = 1.0): float = # TODO This is present in Nim 1.4 const K = sqrt(2 / E) var a = 0.0 b = 0.0 while true: a = rand(r, 1.0) b = (2.0 * rand(r, 1.0) - 1.0) * K if b * b <= -4.0 * a * a * ln(a): break mu + sigma * (b / a) # TODO confutils is an impenetrable black box. how can a help text be added here? cli do(slots = SLOTS_PER_EPOCH * 6, validators = SLOTS_PER_EPOCH * 400, # One per shard is minimum attesterRatio {.desc: "ratio of validators that attest in each round"} = 0.82, syncCommitteeRatio {.desc: "ratio of validators that perform sync committee actions in each round"} = 0.82, blockRatio {.desc: "ratio of slots with blocks"} = 1.0, replay = true): let (genesisState, depositContractSnapshot) = loadGenesis(validators, false) genesisBlock = get_initial_beacon_block(genesisState[]) genesisTime = float getStateField(genesisState[], genesis_time) var cfg = defaultRuntimeConfig cfg.ALTAIR_FORK_EPOCH = 32.Slot.epoch cfg.BELLATRIX_FORK_EPOCH = 96.Slot.epoch echo "Starting simulation..." let db = BeaconChainDB.new("block_sim_db") defer: db.close() ChainDAGRef.preInit(db, genesisState[], genesisState[], genesisBlock) putInitialDepositContractSnapshot(db, depositContractSnapshot) var validatorMonitor = newClone(ValidatorMonitor.init()) dag = ChainDAGRef.init(cfg, db, validatorMonitor, {}) eth1Chain = Eth1Chain.init(cfg, db) merkleizer = DepositsMerkleizer.init(depositContractSnapshot.depositContractState) taskpool = Taskpool.new() verifier = BatchVerifier(rng: keys.newRng(), taskpool: taskpool) quarantine = newClone(Quarantine.init()) attPool = AttestationPool.init(dag, quarantine) batchCrypto = BatchCrypto.new( keys.newRng(), eager = func(): bool = true, taskpool) syncCommitteePool = newClone SyncCommitteeMsgPool.init(keys.newRng()) timers: array[Timers, RunningStat] attesters: RunningStat r = initRand(1) tmpState = assignClone(dag.headState) eth1Chain.addBlock Eth1Block( number: Eth1BlockNumber 1, timestamp: Eth1BlockTimestamp genesisTime, voteData: Eth1Data( deposit_root: merkleizer.getDepositsRoot, deposit_count: merkleizer.getChunkCount)) let replayState = assignClone(dag.headState) proc handleAttestations(slot: Slot) = let attestationHead = dag.head.atSlot(slot) dag.withUpdatedState(tmpState[], attestationHead.toBlockSlotId.expect("not nil")) do: let fork = getStateField(state, fork) genesis_validators_root = getStateField(state, genesis_validators_root) committees_per_slot = get_committee_count_per_slot(state, slot.epoch, cache) for committee_index in get_committee_indices(committees_per_slot): let committee = get_beacon_committee( state, slot, committee_index, cache) for index_in_committee, validator_index in committee: if rand(r, 1.0) <= attesterRatio: let data = makeAttestationData( state, slot, committee_index, bid.root) sig = get_attestation_signature( fork, genesis_validators_root, data, MockPrivKeys[validator_index]) attestation = Attestation.init( [uint64 index_in_committee], committee.len, data, sig.toValidatorSig()).expect("valid data") attPool.addAttestation( attestation, [validator_index], sig, data.slot.start_beacon_time) do: raiseAssert "withUpdatedState failed" proc handleSyncCommitteeActions(slot: Slot) = type Aggregator = object subcommitteeIdx: SyncSubcommitteeIndex validatorIdx: ValidatorIndex selectionProof: ValidatorSig let syncCommittee = @(dag.syncCommitteeParticipants(slot + 1)) genesis_validators_root = dag.genesis_validators_root fork = dag.forkAtEpoch(slot.epoch) messagesTime = slot.attestation_deadline() contributionsTime = slot.sync_contribution_deadline() var aggregators: seq[Aggregator] for subcommitteeIdx in SyncSubcommitteeIndex: for validatorIdx in syncSubcommittee(syncCommittee, subcommitteeIdx): if rand(r, 1.0) > syncCommitteeRatio: continue let validatorPrivKey = MockPrivKeys[validatorIdx] signature = get_sync_committee_message_signature( fork, genesis_validators_root, slot, dag.head.root, validatorPrivKey) msg = SyncCommitteeMessage( slot: slot, beacon_block_root: dag.head.root, validator_index: uint64 validatorIdx, signature: signature.toValidatorSig) let res = waitFor dag.validateSyncCommitteeMessage( batchCrypto, syncCommitteePool, msg, subcommitteeIdx, messagesTime, false) doAssert res.isOk let (positions, cookedSig) = res.get() syncCommitteePool[].addSyncCommitteeMessage( msg.slot, msg.beacon_block_root, msg.validator_index, cookedSig, subcommitteeIdx, positions) let selectionProofSig = get_sync_committee_selection_proof( fork, genesis_validators_root, slot, subcommitteeIdx, validatorPrivKey).toValidatorSig if is_sync_committee_aggregator(selectionProofSig): aggregators.add Aggregator( subcommitteeIdx: subcommitteeIdx, validatorIdx: validatorIdx, selectionProof: selectionProofSig) for aggregator in aggregators: var contribution: SyncCommitteeContribution let contributionWasProduced = syncCommitteePool[].produceContribution( slot, dag.head.root, aggregator.subcommitteeIdx, contribution) if contributionWasProduced: let contributionAndProof = ContributionAndProof( aggregator_index: uint64 aggregator.validatorIdx, contribution: contribution, selection_proof: aggregator.selectionProof) validatorPrivKey = MockPrivKeys[aggregator.validatorIdx.ValidatorIndex] signedContributionAndProof = SignedContributionAndProof( message: contributionAndProof, signature: get_contribution_and_proof_signature( fork, genesis_validators_root, contributionAndProof, validatorPrivKey).toValidatorSig) res = waitFor dag.validateContribution( batchCrypto, syncCommitteePool, signedContributionAndProof, contributionsTime, false) doAssert res.isOk syncCommitteePool[].addContribution( signedContributionAndProof, res.get()[0]) proc getNewBlock[T]( state: var ForkedHashedBeaconState, slot: Slot, cache: var StateCache): T = let finalizedEpochRef = dag.getFinalizedEpochRef() proposerIdx = get_beacon_proposer_index( state, cache, getStateField(state, slot)).get() privKey = MockPrivKeys[proposerIdx] eth1ProposalData = eth1Chain.getBlockProposalData( state, finalizedEpochRef.eth1_data, finalizedEpochRef.eth1_deposit_index) sync_aggregate = when T is phase0.SignedBeaconBlock: SyncAggregate.init() elif T is altair.SignedBeaconBlock or T is bellatrix.SignedBeaconBlock: syncCommitteePool[].produceSyncAggregate(dag.head.root) else: static: doAssert false hashedState = when T is phase0.SignedBeaconBlock: addr state.phase0Data elif T is altair.SignedBeaconBlock: addr state.altairData elif T is bellatrix.SignedBeaconBlock: addr state.bellatrixData else: static: doAssert false message = makeBeaconBlock( cfg, hashedState[], proposerIdx, get_epoch_signature( getStateField(state, fork), getStateField(state, genesis_validators_root), slot.epoch, privKey).toValidatorSig(), eth1ProposalData.vote, default(GraffitiBytes), attPool.getAttestationsForBlock(state, cache), eth1ProposalData.deposits, BeaconBlockExits(), sync_aggregate, default(ExecutionPayload), noRollback, cache) var newBlock = T( message: message.get() ) let blockRoot = withTimerRet(timers[tHashBlock]): hash_tree_root(newBlock.message) newBlock.root = blockRoot # Careful, state no longer valid after here because of the await.. newBlock.signature = withTimerRet(timers[tSignBlock]): get_block_signature( getStateField(state, fork), getStateField(state, genesis_validators_root), newBlock.message.slot, blockRoot, privKey).toValidatorSig() newBlock proc proposePhase0Block(slot: Slot) = if rand(r, 1.0) > blockRatio: return dag.withUpdatedState(tmpState[], dag.getBlockIdAtSlot(slot).expect("block")) do: let newBlock = getNewBlock[phase0.SignedBeaconBlock](state, slot, cache) added = dag.addHeadBlock(verifier, newBlock) do ( blckRef: BlockRef, signedBlock: phase0.TrustedSignedBeaconBlock, epochRef: EpochRef, unrealized: FinalityCheckpoints): # Callback add to fork choice if valid attPool.addForkChoice( epochRef, blckRef, unrealized, signedBlock.message, blckRef.slot.start_beacon_time) dag.updateHead(added[], quarantine[]) if dag.needStateCachesAndForkChoicePruning(): dag.pruneStateCachesDAG() attPool.prune() do: raiseAssert "withUpdatedState failed" proc proposeAltairBlock(slot: Slot) = if rand(r, 1.0) > blockRatio: return dag.withUpdatedState(tmpState[], dag.getBlockIdAtSlot(slot).expect("block")) do: let newBlock = getNewBlock[altair.SignedBeaconBlock](state, slot, cache) added = dag.addHeadBlock(verifier, newBlock) do ( blckRef: BlockRef, signedBlock: altair.TrustedSignedBeaconBlock, epochRef: EpochRef, unrealized: FinalityCheckpoints): # Callback add to fork choice if valid attPool.addForkChoice( epochRef, blckRef, unrealized, signedBlock.message, blckRef.slot.start_beacon_time) dag.updateHead(added[], quarantine[]) if dag.needStateCachesAndForkChoicePruning(): dag.pruneStateCachesDAG() attPool.prune() do: raiseAssert "withUpdatedState failed" proc proposeBellatrixBlock(slot: Slot) = if rand(r, 1.0) > blockRatio: return dag.withUpdatedState(tmpState[], dag.getBlockIdAtSlot(slot).expect("block")) do: let newBlock = getNewBlock[bellatrix.SignedBeaconBlock](state, slot, cache) added = dag.addHeadBlock(verifier, newBlock) do ( blckRef: BlockRef, signedBlock: bellatrix.TrustedSignedBeaconBlock, epochRef: EpochRef, unrealized: FinalityCheckpoints): # Callback add to fork choice if valid attPool.addForkChoice( epochRef, blckRef, unrealized, signedBlock.message, blckRef.slot.start_beacon_time) dag.updateHead(added[], quarantine[]) if dag.needStateCachesAndForkChoicePruning(): dag.pruneStateCachesDAG() attPool.prune() do: raiseAssert "withUpdatedState failed" var lastEth1BlockAt = genesisTime eth1BlockNum = 1000 for i in 0.. now: break inc eth1BlockNum var eth1Block = Eth1Block( number: Eth1BlockNumber eth1BlockNum, timestamp: Eth1BlockTimestamp nextBlockTime, voteData: Eth1Data( block_hash: makeFakeHash(eth1BlockNum))) let newDeposits = int clamp(gauss(r, 5.0, 8.0), 0.0, 1000.0) for i in 0 ..< newDeposits: let validatorIdx = merkleizer.getChunkCount.int let d = makeDeposit(validatorIdx, {skipBlsValidation}) eth1Block.deposits.add d merkleizer.addChunk hash_tree_root(d).data eth1Block.voteData.deposit_root = merkleizer.getDepositsRoot eth1Block.voteData.deposit_count = merkleizer.getChunkCount eth1Chain.addBlock eth1Block lastEth1BlockAt = nextBlockTime if blockRatio > 0.0: withTimer(timers[t]): case dag.cfg.stateForkAtEpoch(slot.epoch) of BeaconStateFork.Bellatrix: proposeBellatrixBlock(slot) of BeaconStateFork.Altair: proposeAltairBlock(slot) of BeaconStateFork.Phase0: proposePhase0Block(slot) if attesterRatio > 0.0: withTimer(timers[tAttest]): handleAttestations(slot) if syncCommitteeRatio > 0.0: withTimer(timers[tSyncCommittees]): handleSyncCommitteeActions(slot) syncCommitteePool[].pruneData(slot) # TODO if attestation pool was smarter, it would include older attestations # too! verifyConsensus(dag.headState, attesterRatio * blockRatio) if t == tEpoch: echo &". slot: {shortLog(slot)} ", &"epoch: {shortLog(slot.epoch)}" else: write(stdout, ".") flushFile(stdout) if replay: withTimer(timers[tReplay]): var cache = StateCache() doAssert dag.updateState( replayState[], dag.getBlockIdAtSlot(Slot(slots)).expect("block"), false, cache) echo "Done!" printTimers(dag.headState, attesters, true, timers)