2020-04-24 07:16:11 +00:00
|
|
|
# beacon_chain
|
|
|
|
# Copyright (c) 2018-2020 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.
|
|
|
|
|
2018-11-23 23:58:49 +00:00
|
|
|
import
|
2019-10-02 12:38:14 +00:00
|
|
|
# Standard library
|
2020-05-19 12:08:50 +00:00
|
|
|
os, tables, random, strutils, times, math,
|
2019-10-02 12:38:14 +00:00
|
|
|
|
|
|
|
# Nimble packages
|
2020-03-16 23:49:53 +00:00
|
|
|
stew/[objects, bitseqs, byteutils], stew/shims/macros,
|
2020-04-27 22:39:04 +00:00
|
|
|
chronos, confutils, metrics, json_rpc/[rpcserver, jsonmarshal],
|
2020-05-22 17:04:52 +00:00
|
|
|
chronicles,
|
2020-03-16 22:28:54 +00:00
|
|
|
json_serialization/std/[options, sets, net], serialization/errors,
|
2020-04-27 16:36:28 +00:00
|
|
|
eth/db/kvstore, eth/db/kvstore_sqlite3,
|
2020-03-16 22:28:54 +00:00
|
|
|
eth/p2p/enode, eth/[keys, async_utils], eth/p2p/discoveryv5/[protocol, enr],
|
2019-10-02 12:38:14 +00:00
|
|
|
|
|
|
|
# Local modules
|
2020-05-06 13:23:45 +00:00
|
|
|
spec/[datatypes, digest, crypto, beaconstate, helpers, network],
|
|
|
|
spec/presets/custom,
|
2020-04-05 09:50:31 +00:00
|
|
|
conf, time, beacon_chain_db, validator_pool, extras,
|
2020-02-05 20:40:14 +00:00
|
|
|
attestation_pool, block_pool, eth2_network, eth2_discovery,
|
2020-05-22 17:04:52 +00:00
|
|
|
beacon_node_common, beacon_node_types,
|
|
|
|
nimbus_binary_common,
|
2020-05-27 11:36:02 +00:00
|
|
|
mainchain_monitor, version, ssz,
|
2020-04-01 09:59:55 +00:00
|
|
|
sync_protocol, request_manager, validator_keygen, interop, statusbar,
|
2020-05-06 13:23:45 +00:00
|
|
|
sync_manager, state_transition,
|
2020-05-22 17:04:52 +00:00
|
|
|
validator_duties, validator_api
|
2018-11-23 23:58:49 +00:00
|
|
|
|
|
|
|
const
|
2020-05-27 17:06:28 +00:00
|
|
|
genesisFile* = "genesis.ssz"
|
2019-10-02 12:38:14 +00:00
|
|
|
hasPrompt = not defined(withoutPrompt)
|
2019-03-18 03:54:08 +00:00
|
|
|
|
2020-02-19 08:58:10 +00:00
|
|
|
type
|
2020-05-06 13:23:45 +00:00
|
|
|
RpcServer* = RpcHttpServer
|
2020-02-19 08:58:10 +00:00
|
|
|
KeyPair = eth2_network.KeyPair
|
2020-03-16 22:28:54 +00:00
|
|
|
|
2020-05-19 18:57:35 +00:00
|
|
|
# "state" is already taken by BeaconState
|
|
|
|
BeaconNodeStatus* = enum
|
|
|
|
Starting, Running, Stopping
|
|
|
|
|
|
|
|
# this needs to be global, so it can be set in the Ctrl+C signal handler
|
|
|
|
var status = BeaconNodeStatus.Starting
|
|
|
|
|
2020-03-16 22:28:54 +00:00
|
|
|
template init(T: type RpcHttpServer, ip: IpAddress, port: Port): T =
|
|
|
|
newRpcHttpServer([initTAddress(ip, port)])
|
2020-02-19 08:58:10 +00:00
|
|
|
|
2019-10-24 06:51:27 +00:00
|
|
|
# https://github.com/ethereum/eth2.0-metrics/blob/master/metrics.md#interop-metrics
|
2019-10-25 17:15:12 +00:00
|
|
|
declareGauge beacon_slot,
|
|
|
|
"Latest slot of the beacon chain state"
|
|
|
|
declareGauge beacon_head_slot,
|
|
|
|
"Slot of the head block of the beacon chain"
|
2019-09-07 17:48:05 +00:00
|
|
|
|
2019-10-24 06:51:27 +00:00
|
|
|
# Metrics for tracking attestation and beacon block loss
|
2019-10-25 17:15:12 +00:00
|
|
|
declareCounter beacon_attestations_received,
|
|
|
|
"Number of beacon chain attestations received by this peer"
|
2019-10-24 06:51:27 +00:00
|
|
|
|
2020-05-11 06:25:49 +00:00
|
|
|
declareHistogram beacon_attestation_received_seconds_from_slot_start,
|
|
|
|
"Interval between slot start and attestation receival", buckets = [2.0, 4.0, 6.0, 8.0, 10.0, 12.0, 14.0, Inf]
|
|
|
|
|
2019-09-12 01:45:04 +00:00
|
|
|
logScope: topics = "beacnde"
|
|
|
|
|
2020-05-27 17:06:28 +00:00
|
|
|
proc getStateFromSnapshot(conf: BeaconNodeConf): NilableBeaconStateRef =
|
|
|
|
var
|
|
|
|
genesisPath = conf.dataDir/genesisFile
|
|
|
|
snapshotContents: TaintedString
|
|
|
|
writeGenesisFile = false
|
|
|
|
|
|
|
|
if conf.stateSnapshot.isSome:
|
|
|
|
let
|
|
|
|
snapshotPath = conf.stateSnapshot.get.string
|
|
|
|
snapshotExt = splitFile(snapshotPath).ext
|
|
|
|
|
|
|
|
if cmpIgnoreCase(snapshotExt, ".ssz") != 0:
|
|
|
|
error "The supplied state snapshot must be a SSZ file",
|
|
|
|
suppliedPath = snapshotPath
|
|
|
|
quit 1
|
|
|
|
|
|
|
|
snapshotContents = readFile(snapshotPath)
|
|
|
|
if fileExists(genesisPath):
|
|
|
|
let genesisContents = readFile(genesisPath)
|
|
|
|
if snapshotContents != genesisContents:
|
|
|
|
error "Data directory not empty. Existing genesis state differs from supplied snapshot",
|
|
|
|
dataDir = conf.dataDir.string, snapshot = snapshotPath
|
|
|
|
quit 1
|
|
|
|
else:
|
|
|
|
debug "No previous genesis state. Importing snapshot",
|
|
|
|
genesisPath, dataDir = conf.dataDir.string
|
|
|
|
writeGenesisFile = true
|
|
|
|
genesisPath = snapshotPath
|
|
|
|
else:
|
|
|
|
try:
|
|
|
|
snapshotContents = readFile(genesisPath)
|
|
|
|
except CatchableError as err:
|
|
|
|
error "Failed to read genesis file", err = err.msg
|
|
|
|
quit 1
|
|
|
|
|
|
|
|
result = try:
|
|
|
|
newClone(SSZ.decode(snapshotContents, BeaconState))
|
|
|
|
except SerializationError:
|
|
|
|
error "Failed to import genesis file", path = genesisPath
|
|
|
|
quit 1
|
|
|
|
|
|
|
|
info "Loaded genesis state", path = genesisPath
|
|
|
|
|
|
|
|
if writeGenesisFile:
|
|
|
|
try:
|
|
|
|
notice "Writing genesis to data directory", path = conf.dataDir/genesisFile
|
|
|
|
writeFile(conf.dataDir/genesisFile, snapshotContents.string)
|
|
|
|
except CatchableError as err:
|
|
|
|
error "Failed to persist genesis file to data dir",
|
|
|
|
err = err.msg, genesisFile = conf.dataDir/genesisFile
|
|
|
|
quit 1
|
|
|
|
|
2020-04-15 02:41:22 +00:00
|
|
|
proc enrForkIdFromState(state: BeaconState): ENRForkID =
|
|
|
|
let
|
|
|
|
forkVer = state.fork.current_version
|
|
|
|
forkDigest = compute_fork_digest(forkVer, state.genesis_validators_root)
|
|
|
|
|
|
|
|
ENRForkID(
|
|
|
|
fork_digest: forkDigest,
|
|
|
|
next_fork_version: forkVer,
|
|
|
|
next_fork_epoch: FAR_FUTURE_EPOCH)
|
|
|
|
|
2019-03-05 22:54:08 +00:00
|
|
|
proc init*(T: type BeaconNode, conf: BeaconNodeConf): Future[BeaconNode] {.async.} =
|
2020-01-17 13:44:01 +00:00
|
|
|
let
|
2020-02-05 20:40:14 +00:00
|
|
|
netKeys = getPersistentNetKeys(conf)
|
|
|
|
nickname = if conf.nodeName == "auto": shortForm(netKeys)
|
2020-01-17 13:44:01 +00:00
|
|
|
else: conf.nodeName
|
2020-04-23 06:27:35 +00:00
|
|
|
db = BeaconChainDB.init(kvStore SqStoreRef.init(conf.databaseDir, "nbc").tryGet())
|
2020-01-17 13:44:01 +00:00
|
|
|
|
|
|
|
var mainchainMonitor: MainchainMonitor
|
|
|
|
|
|
|
|
if not BlockPool.isInitialized(db):
|
|
|
|
# Fresh start - need to load a genesis state from somewhere
|
2020-04-22 23:35:55 +00:00
|
|
|
var genesisState = conf.getStateFromSnapshot()
|
2020-01-17 13:44:01 +00:00
|
|
|
|
|
|
|
# Try file from command line first
|
2020-04-22 23:35:55 +00:00
|
|
|
if genesisState.isNil:
|
2020-01-17 13:44:01 +00:00
|
|
|
# Didn't work, try creating a genesis state using main chain monitor
|
|
|
|
# TODO Could move this to a separate "GenesisMonitor" process or task
|
|
|
|
# that would do only this - see
|
2020-03-24 11:13:07 +00:00
|
|
|
if conf.web3Url.len > 0 and conf.depositContractAddress.len > 0:
|
2020-01-17 13:44:01 +00:00
|
|
|
mainchainMonitor = MainchainMonitor.init(
|
2020-03-24 11:13:07 +00:00
|
|
|
web3Provider(conf.web3Url),
|
|
|
|
conf.depositContractAddress,
|
|
|
|
Eth2Digest())
|
2020-01-17 13:44:01 +00:00
|
|
|
mainchainMonitor.start()
|
2019-10-25 14:53:31 +00:00
|
|
|
else:
|
2020-01-17 13:44:01 +00:00
|
|
|
error "No initial state, need genesis state or deposit contract address"
|
2019-10-25 14:53:31 +00:00
|
|
|
quit 1
|
|
|
|
|
2020-04-22 23:35:55 +00:00
|
|
|
genesisState = await mainchainMonitor.getGenesis()
|
2019-10-25 14:53:31 +00:00
|
|
|
|
2020-04-22 23:35:55 +00:00
|
|
|
# This is needed to prove the not nil property from here on
|
|
|
|
if genesisState == nil:
|
|
|
|
doAssert false
|
|
|
|
else:
|
|
|
|
if genesisState.slot != GENESIS_SLOT:
|
|
|
|
# TODO how to get a block from a non-genesis state?
|
|
|
|
error "Starting from non-genesis state not supported",
|
|
|
|
stateSlot = genesisState.slot,
|
2020-04-29 20:12:07 +00:00
|
|
|
stateRoot = hash_tree_root(genesisState[])
|
2020-04-22 23:35:55 +00:00
|
|
|
quit 1
|
2019-02-28 21:21:29 +00:00
|
|
|
|
2020-04-23 18:58:54 +00:00
|
|
|
let tailBlock = get_initial_beacon_block(genesisState[])
|
2019-01-25 14:17:35 +00:00
|
|
|
|
2020-04-22 23:35:55 +00:00
|
|
|
try:
|
2020-04-28 08:08:32 +00:00
|
|
|
BlockPool.preInit(db, genesisState[], tailBlock)
|
2020-04-22 23:35:55 +00:00
|
|
|
doAssert BlockPool.isInitialized(db), "preInit should have initialized db"
|
|
|
|
except CatchableError as e:
|
|
|
|
error "Failed to initialize database", err = e.msg
|
|
|
|
quit 1
|
2020-01-17 13:44:01 +00:00
|
|
|
|
|
|
|
# TODO check that genesis given on command line (if any) matches database
|
2020-05-09 12:43:15 +00:00
|
|
|
let blockPool = BlockPool.init(
|
|
|
|
db,
|
|
|
|
if conf.verifyFinalization:
|
|
|
|
{verifyFinalization}
|
|
|
|
else:
|
|
|
|
{})
|
2020-01-17 13:44:01 +00:00
|
|
|
|
2020-03-24 11:13:07 +00:00
|
|
|
if mainchainMonitor.isNil and
|
|
|
|
conf.web3Url.len > 0 and
|
|
|
|
conf.depositContractAddress.len > 0:
|
2020-01-17 13:44:01 +00:00
|
|
|
mainchainMonitor = MainchainMonitor.init(
|
2020-03-24 11:13:07 +00:00
|
|
|
web3Provider(conf.web3Url),
|
|
|
|
conf.depositContractAddress,
|
2020-01-17 13:44:01 +00:00
|
|
|
blockPool.headState.data.data.eth1_data.block_hash)
|
2020-02-07 07:13:38 +00:00
|
|
|
# TODO if we don't have any validators attached, we don't need a mainchain
|
|
|
|
# monitor
|
2020-01-17 13:44:01 +00:00
|
|
|
mainchainMonitor.start()
|
|
|
|
|
2020-03-16 22:28:54 +00:00
|
|
|
let rpcServer = if conf.rpcEnabled:
|
|
|
|
RpcServer.init(conf.rpcAddress, conf.rpcPort)
|
|
|
|
else:
|
|
|
|
nil
|
|
|
|
|
2020-04-15 02:41:22 +00:00
|
|
|
let
|
2020-04-28 08:08:32 +00:00
|
|
|
enrForkId = enrForkIdFromState(blockPool.headState.data.data)
|
2020-04-15 02:41:22 +00:00
|
|
|
topicBeaconBlocks = getBeaconBlocksTopic(enrForkId.forkDigest)
|
|
|
|
topicAggregateAndProofs = getAggregateAndProofsTopic(enrForkId.forkDigest)
|
|
|
|
network = await createEth2Node(conf, enrForkId)
|
|
|
|
|
2020-01-17 13:44:01 +00:00
|
|
|
var res = BeaconNode(
|
|
|
|
nickname: nickname,
|
|
|
|
network: network,
|
2020-02-05 20:40:14 +00:00
|
|
|
netKeys: netKeys,
|
2020-01-17 13:44:01 +00:00
|
|
|
requestManager: RequestManager.init(network),
|
|
|
|
db: db,
|
|
|
|
config: conf,
|
|
|
|
attachedValidators: ValidatorPool.init(),
|
|
|
|
blockPool: blockPool,
|
|
|
|
attestationPool: AttestationPool.init(blockPool),
|
|
|
|
mainchainMonitor: mainchainMonitor,
|
2020-04-28 08:08:32 +00:00
|
|
|
beaconClock: BeaconClock.init(blockPool.headState.data.data),
|
2020-03-16 22:28:54 +00:00
|
|
|
rpcServer: rpcServer,
|
2020-04-15 02:41:22 +00:00
|
|
|
forkDigest: enrForkId.forkDigest,
|
|
|
|
topicBeaconBlocks: topicBeaconBlocks,
|
|
|
|
topicAggregateAndProofs: topicAggregateAndProofs,
|
2020-01-17 13:44:01 +00:00
|
|
|
)
|
2018-12-19 12:58:53 +00:00
|
|
|
|
2019-03-22 15:49:37 +00:00
|
|
|
# TODO sync is called when a remote peer is connected - is that the right
|
|
|
|
# time to do so?
|
2020-04-15 02:41:22 +00:00
|
|
|
network.initBeaconSync(blockPool, enrForkId.forkDigest,
|
2019-12-16 18:08:50 +00:00
|
|
|
proc(signedBlock: SignedBeaconBlock) =
|
2020-05-03 17:44:04 +00:00
|
|
|
if signedBlock.message.slot.isEpoch:
|
2019-12-13 11:54:48 +00:00
|
|
|
# TODO this is a hack to make sure that lmd ghost is run regularly
|
|
|
|
# while syncing blocks - it's poor form to keep it here though -
|
|
|
|
# the logic should be moved elsewhere
|
|
|
|
# TODO why only when syncing? well, because the way the code is written
|
|
|
|
# we require a connection to a boot node to start, and that boot
|
|
|
|
# node will start syncing as part of connection setup - it looks
|
|
|
|
# like it needs to finish syncing before the slot timer starts
|
|
|
|
# ticking which is a problem: all the synced blocks will be added
|
|
|
|
# to the block pool without any periodic head updates while this
|
|
|
|
# process is ongoing (during a blank start for example), which
|
|
|
|
# leads to an unhealthy buildup of blocks in the non-finalized part
|
|
|
|
# of the block pool
|
|
|
|
# TODO is it a problem that someone sending us a block can force
|
|
|
|
# a potentially expensive head resolution?
|
2020-01-17 13:44:01 +00:00
|
|
|
discard res.updateHead()
|
2019-12-13 11:54:48 +00:00
|
|
|
|
2020-01-17 13:44:01 +00:00
|
|
|
onBeaconBlock(res, signedBlock))
|
2019-04-06 07:46:07 +00:00
|
|
|
|
2020-01-17 13:44:01 +00:00
|
|
|
return res
|
2019-09-07 17:48:05 +00:00
|
|
|
|
2018-12-19 12:58:53 +00:00
|
|
|
proc connectToNetwork(node: BeaconNode) {.async.} =
|
2020-03-24 09:54:17 +00:00
|
|
|
await node.network.connectToNetwork()
|
2019-03-05 22:54:08 +00:00
|
|
|
|
2020-03-23 11:26:44 +00:00
|
|
|
let addressFile = node.config.dataDir / "beacon_node.address"
|
|
|
|
writeFile(addressFile, node.network.announcedENR.toURI)
|
2018-12-19 12:58:53 +00:00
|
|
|
|
2020-05-13 08:36:33 +00:00
|
|
|
func verifyFinalization(node: BeaconNode, slot: Slot) =
|
|
|
|
# Epoch must be >= 4 to check finalization
|
|
|
|
const SETTLING_TIME_OFFSET = 1'u64
|
|
|
|
let epoch = slot.compute_epoch_at_slot()
|
|
|
|
|
|
|
|
# Don't static-assert this -- if this isn't called, don't require it
|
|
|
|
doAssert SLOTS_PER_EPOCH > SETTLING_TIME_OFFSET
|
|
|
|
|
|
|
|
# Intentionally, loudly assert. Point is to fail visibly and unignorably
|
|
|
|
# during testing.
|
|
|
|
if epoch >= 4 and slot mod SLOTS_PER_EPOCH > SETTLING_TIME_OFFSET:
|
|
|
|
let finalizedEpoch =
|
|
|
|
node.blockPool.finalizedHead.blck.slot.compute_epoch_at_slot()
|
|
|
|
# Finalization rule 234, that has the most lag slots among the cases, sets
|
|
|
|
# state.finalized_checkpoint = old_previous_justified_checkpoint.epoch + 3
|
|
|
|
# and then state.slot gets incremented, to increase the maximum offset, if
|
|
|
|
# finalization occurs every slot, to 4 slots vs scheduledSlot.
|
|
|
|
doAssert finalizedEpoch + 4 >= epoch
|
|
|
|
|
2019-03-22 15:49:37 +00:00
|
|
|
proc onSlotStart(node: BeaconNode, lastSlot, scheduledSlot: Slot) {.gcsafe, async.} =
|
|
|
|
## Called at the beginning of a slot - usually every slot, but sometimes might
|
|
|
|
## skip a few in case we're running late.
|
|
|
|
## lastSlot: the last slot that we sucessfully processed, so we know where to
|
|
|
|
## start work from
|
|
|
|
## scheduledSlot: the slot that we were aiming for, in terms of timing
|
|
|
|
|
2019-09-12 01:45:04 +00:00
|
|
|
logScope: pcs = "slot_start"
|
|
|
|
|
2019-03-22 15:49:37 +00:00
|
|
|
let
|
|
|
|
# The slot we should be at, according to the clock
|
2019-08-16 11:16:56 +00:00
|
|
|
beaconTime = node.beaconClock.now()
|
|
|
|
wallSlot = beaconTime.toSlot()
|
2019-03-22 15:49:37 +00:00
|
|
|
|
2019-12-23 15:34:09 +00:00
|
|
|
info "Slot start",
|
2019-08-15 16:01:55 +00:00
|
|
|
lastSlot = shortLog(lastSlot),
|
|
|
|
scheduledSlot = shortLog(scheduledSlot),
|
2019-09-12 01:45:04 +00:00
|
|
|
beaconTime = shortLog(beaconTime),
|
|
|
|
peers = node.network.peersCount,
|
2019-12-23 15:34:09 +00:00
|
|
|
headSlot = shortLog(node.blockPool.head.blck.slot),
|
|
|
|
headEpoch = shortLog(node.blockPool.head.blck.slot.compute_epoch_at_slot()),
|
|
|
|
headRoot = shortLog(node.blockPool.head.blck.root),
|
|
|
|
finalizedSlot = shortLog(node.blockPool.finalizedHead.blck.slot),
|
|
|
|
finalizedRoot = shortLog(node.blockPool.finalizedHead.blck.root),
|
2020-04-13 15:17:24 +00:00
|
|
|
finalizedEpoch = shortLog(node.blockPool.finalizedHead.blck.slot.compute_epoch_at_slot()),
|
2019-09-12 01:45:04 +00:00
|
|
|
cat = "scheduling"
|
2019-03-22 15:49:37 +00:00
|
|
|
|
2020-02-17 18:24:14 +00:00
|
|
|
# Check before any re-scheduling of onSlotStart()
|
2020-05-13 08:36:33 +00:00
|
|
|
# Offset backwards slightly to allow this epoch's finalization check to occur
|
|
|
|
if scheduledSlot > 3 and node.config.stopAtEpoch > 0'u64 and
|
|
|
|
(scheduledSlot - 3).compute_epoch_at_slot() >= node.config.stopAtEpoch:
|
2020-02-17 18:24:14 +00:00
|
|
|
info "Stopping at pre-chosen epoch",
|
2020-02-17 21:22:50 +00:00
|
|
|
chosenEpoch = node.config.stopAtEpoch,
|
2020-02-17 18:24:14 +00:00
|
|
|
epoch = scheduledSlot.compute_epoch_at_slot(),
|
|
|
|
slot = scheduledSlot
|
|
|
|
|
|
|
|
# Brute-force, but ensure it's reliably enough to run in CI.
|
|
|
|
quit(0)
|
|
|
|
|
2019-08-16 11:16:56 +00:00
|
|
|
if not wallSlot.afterGenesis or (wallSlot.slot < lastSlot):
|
2019-12-23 15:34:09 +00:00
|
|
|
let
|
|
|
|
slot =
|
|
|
|
if wallSlot.afterGenesis: wallSlot.slot
|
|
|
|
else: GENESIS_SLOT
|
|
|
|
nextSlot = slot + 1 # At least GENESIS_SLOT + 1!
|
|
|
|
|
2019-03-22 15:49:37 +00:00
|
|
|
# This can happen if the system clock changes time for example, and it's
|
|
|
|
# pretty bad
|
|
|
|
# TODO shut down? time either was or is bad, and PoS relies on accuracy..
|
|
|
|
warn "Beacon clock time moved back, rescheduling slot actions",
|
2019-08-16 11:16:56 +00:00
|
|
|
beaconTime = shortLog(beaconTime),
|
|
|
|
lastSlot = shortLog(lastSlot),
|
2019-09-12 01:45:04 +00:00
|
|
|
scheduledSlot = shortLog(scheduledSlot),
|
2019-12-23 15:34:09 +00:00
|
|
|
nextSlot = shortLog(nextSlot),
|
2019-09-12 01:45:04 +00:00
|
|
|
cat = "clock_drift" # tag "scheduling|clock_drift"?
|
2019-03-22 15:49:37 +00:00
|
|
|
|
|
|
|
addTimer(saturate(node.beaconClock.fromNow(nextSlot))) do (p: pointer):
|
|
|
|
asyncCheck node.onSlotStart(slot, nextSlot)
|
|
|
|
|
|
|
|
return
|
|
|
|
|
2019-08-16 11:16:56 +00:00
|
|
|
let
|
|
|
|
slot = wallSlot.slot # afterGenesis == true!
|
|
|
|
nextSlot = slot + 1
|
|
|
|
|
2019-09-07 17:48:05 +00:00
|
|
|
beacon_slot.set slot.int64
|
|
|
|
|
2020-05-13 08:36:33 +00:00
|
|
|
if node.config.verifyFinalization:
|
|
|
|
verifyFinalization(node, scheduledSlot)
|
|
|
|
|
2019-03-22 15:49:37 +00:00
|
|
|
if slot > lastSlot + SLOTS_PER_EPOCH:
|
|
|
|
# We've fallen behind more than an epoch - there's nothing clever we can
|
|
|
|
# do here really, except skip all the work and try again later.
|
|
|
|
# TODO how long should the period be? Using an epoch because that's roughly
|
|
|
|
# how long attestations remain interesting
|
|
|
|
# TODO should we shut down instead? clearly we're unable to keep up
|
2019-12-23 15:34:09 +00:00
|
|
|
warn "Unable to keep up, skipping ahead",
|
2019-08-15 16:01:55 +00:00
|
|
|
lastSlot = shortLog(lastSlot),
|
|
|
|
slot = shortLog(slot),
|
2019-12-23 15:34:09 +00:00
|
|
|
nextSlot = shortLog(nextSlot),
|
2019-09-12 01:45:04 +00:00
|
|
|
scheduledSlot = shortLog(scheduledSlot),
|
|
|
|
cat = "overload"
|
2019-03-22 15:49:37 +00:00
|
|
|
|
|
|
|
addTimer(saturate(node.beaconClock.fromNow(nextSlot))) do (p: pointer):
|
|
|
|
# We pass the current slot here to indicate that work should be skipped!
|
|
|
|
asyncCheck node.onSlotStart(slot, nextSlot)
|
|
|
|
return
|
|
|
|
|
|
|
|
# Whatever we do during the slot, we need to know the head, because this will
|
|
|
|
# give us a state to work with and thus a shuffling.
|
|
|
|
# TODO typically, what consitutes correct actions stays constant between slot
|
|
|
|
# updates and is stable across some epoch transitions as well - see how
|
|
|
|
# we can avoid recalculating everything here
|
|
|
|
# TODO if the head is very old, that is indicative of something being very
|
|
|
|
# wrong - us being out of sync or disconnected from the network - need
|
|
|
|
# to consider what to do in that case:
|
|
|
|
# * nothing - the other parts of the application will reconnect and
|
|
|
|
# start listening to broadcasts, learn a new head etc..
|
|
|
|
# risky, because the network might stall if everyone does
|
|
|
|
# this, because no blocks will be produced
|
|
|
|
# * shut down - this allows the user to notice and take action, but is
|
|
|
|
# kind of harsh
|
|
|
|
# * keep going - we create blocks and attestations as usual and send them
|
|
|
|
# out - if network conditions improve, fork choice should
|
|
|
|
# eventually select the correct head and the rest will
|
|
|
|
# disappear naturally - risky because user is not aware,
|
|
|
|
# and might lose stake on canonical chain but "just works"
|
|
|
|
# when reconnected..
|
2020-04-20 17:28:12 +00:00
|
|
|
var head = node.updateHead()
|
|
|
|
|
|
|
|
# TODO is the slot of the clock or the head block more interesting? provide
|
|
|
|
# rationale in comment
|
|
|
|
beacon_head_slot.set slot.int64
|
|
|
|
|
|
|
|
# Time passes in here..
|
|
|
|
head = await node.handleValidatorDuties(head, lastSlot, slot)
|
2019-03-22 15:49:37 +00:00
|
|
|
|
|
|
|
let
|
|
|
|
nextSlotStart = saturate(node.beaconClock.fromNow(nextSlot))
|
|
|
|
|
2019-12-23 15:34:09 +00:00
|
|
|
info "Slot end",
|
|
|
|
slot = shortLog(slot),
|
|
|
|
nextSlot = shortLog(nextSlot),
|
|
|
|
headSlot = shortLog(node.blockPool.head.blck.slot),
|
|
|
|
headEpoch = shortLog(node.blockPool.head.blck.slot.compute_epoch_at_slot()),
|
|
|
|
headRoot = shortLog(node.blockPool.head.blck.root),
|
|
|
|
finalizedSlot = shortLog(node.blockPool.finalizedHead.blck.slot),
|
|
|
|
finalizedEpoch = shortLog(node.blockPool.finalizedHead.blck.slot.compute_epoch_at_slot()),
|
|
|
|
finalizedRoot = shortLog(node.blockPool.finalizedHead.blck.root),
|
|
|
|
cat = "scheduling"
|
|
|
|
|
2020-05-06 10:01:19 +00:00
|
|
|
when declared(GC_fullCollect):
|
|
|
|
# The slots in the beacon node work as frames in a game: we want to make
|
|
|
|
# sure that we're ready for the next one and don't get stuck in lengthy
|
|
|
|
# garbage collection tasks when time is of essence in the middle of a slot -
|
|
|
|
# while this does not guarantee that we'll never collect during a slot, it
|
|
|
|
# makes sure that all the scratch space we used during slot tasks (logging,
|
|
|
|
# temporary buffers etc) gets recycled for the next slot that is likely to
|
|
|
|
# need similar amounts of memory.
|
|
|
|
GC_fullCollect()
|
|
|
|
|
2019-03-22 15:49:37 +00:00
|
|
|
addTimer(nextSlotStart) do (p: pointer):
|
|
|
|
asyncCheck node.onSlotStart(slot, nextSlot)
|
|
|
|
|
2019-12-02 14:42:57 +00:00
|
|
|
proc handleMissingBlocks(node: BeaconNode) =
|
2019-04-26 16:38:56 +00:00
|
|
|
let missingBlocks = node.blockPool.checkMissing()
|
2019-03-28 14:03:19 +00:00
|
|
|
if missingBlocks.len > 0:
|
2019-12-02 14:42:57 +00:00
|
|
|
var left = missingBlocks.len
|
|
|
|
|
2019-03-28 14:03:19 +00:00
|
|
|
info "Requesting detected missing blocks", missingBlocks
|
2019-12-16 18:08:50 +00:00
|
|
|
node.requestManager.fetchAncestorBlocks(missingBlocks) do (b: SignedBeaconBlock):
|
2019-12-02 14:42:57 +00:00
|
|
|
onBeaconBlock(node, b)
|
|
|
|
|
|
|
|
# TODO instead of waiting for a full second to try the next missing block
|
|
|
|
# fetching, we'll do it here again in case we get all blocks we asked
|
|
|
|
# for (there might be new parents to fetch). of course, this is not
|
|
|
|
# good because the onSecond fetching also kicks in regardless but
|
|
|
|
# whatever - this is just a quick fix for making the testnet easier
|
|
|
|
# work with while the sync problem is dealt with more systematically
|
2020-04-20 14:59:18 +00:00
|
|
|
# dec left
|
|
|
|
# if left == 0:
|
|
|
|
# discard setTimer(Moment.now()) do (p: pointer):
|
|
|
|
# handleMissingBlocks(node)
|
2019-12-02 14:42:57 +00:00
|
|
|
|
2020-06-03 08:46:29 +00:00
|
|
|
proc onSecond(node: BeaconNode) {.async.} =
|
|
|
|
## This procedure will be called once per second.
|
|
|
|
if not(node.syncManager.inProgress):
|
|
|
|
node.handleMissingBlocks()
|
|
|
|
|
|
|
|
proc runOnSecondLoop(node: BeaconNode) {.async.} =
|
|
|
|
var sleepTime = chronos.seconds(1)
|
|
|
|
while true:
|
|
|
|
await chronos.sleepAsync(sleepTime)
|
|
|
|
let start = chronos.now(chronos.Moment)
|
|
|
|
await node.onSecond()
|
|
|
|
let finish = chronos.now(chronos.Moment)
|
|
|
|
debug "onSecond task completed", elapsed = $(finish - start)
|
|
|
|
if finish - start > chronos.seconds(1):
|
|
|
|
sleepTime = chronos.seconds(0)
|
|
|
|
else:
|
|
|
|
sleepTime = chronos.seconds(1) - (finish - start)
|
2019-03-27 20:17:01 +00:00
|
|
|
|
2020-06-03 08:46:29 +00:00
|
|
|
proc runForwardSyncLoop(node: BeaconNode) {.async.} =
|
2020-04-20 14:59:18 +00:00
|
|
|
proc getLocalHeadSlot(): Slot =
|
|
|
|
result = node.blockPool.head.blck.slot
|
|
|
|
|
|
|
|
proc getLocalWallSlot(): Slot {.gcsafe.} =
|
2020-06-03 08:46:29 +00:00
|
|
|
let epoch = node.beaconClock.now().toSlot().slot.compute_epoch_at_slot() +
|
|
|
|
1'u64
|
2020-04-20 14:59:18 +00:00
|
|
|
result = epoch.compute_start_slot_at_epoch()
|
|
|
|
|
2020-05-28 05:02:28 +00:00
|
|
|
proc updateLocalBlocks(list: openarray[SignedBeaconBlock]): Result[void, BlockError] =
|
2020-04-20 14:59:18 +00:00
|
|
|
debug "Forward sync imported blocks", count = len(list),
|
2020-04-23 15:31:00 +00:00
|
|
|
local_head_slot = getLocalHeadSlot()
|
2020-05-19 12:08:50 +00:00
|
|
|
let sm = now(chronos.Moment)
|
2020-04-20 14:59:18 +00:00
|
|
|
for blk in list:
|
2020-05-28 05:02:28 +00:00
|
|
|
let res = node.storeBlock(blk)
|
|
|
|
# We going to ignore `BlockError.Old` errors because we have working
|
|
|
|
# backward sync and it can happens that we can perform overlapping
|
|
|
|
# requests.
|
|
|
|
if res.isErr and res.error != BlockError.Old:
|
|
|
|
return res
|
2020-04-20 14:59:18 +00:00
|
|
|
discard node.updateHead()
|
2020-05-19 12:08:50 +00:00
|
|
|
|
|
|
|
let dur = now(chronos.Moment) - sm
|
|
|
|
let secs = float(chronos.seconds(1).nanoseconds)
|
|
|
|
var storeSpeed = 0.0
|
|
|
|
if not(dur.isZero()):
|
|
|
|
let v = float(len(list)) * (secs / float(dur.nanoseconds))
|
|
|
|
# We doing round manually because stdlib.round is deprecated
|
|
|
|
storeSpeed = round(v * 10000) / 10000
|
|
|
|
|
2020-04-23 15:31:00 +00:00
|
|
|
info "Forward sync blocks got imported sucessfully", count = len(list),
|
2020-05-19 12:08:50 +00:00
|
|
|
local_head_slot = getLocalHeadSlot(), store_speed = storeSpeed
|
2020-05-28 05:02:28 +00:00
|
|
|
ok()
|
2020-04-20 14:59:18 +00:00
|
|
|
|
2020-04-23 15:31:00 +00:00
|
|
|
proc scoreCheck(peer: Peer): bool =
|
2020-05-28 05:02:28 +00:00
|
|
|
if peer.score < PeerScoreLowLimit:
|
2020-04-23 15:31:00 +00:00
|
|
|
try:
|
|
|
|
debug "Peer score is too low, removing it from PeerPool", peer = peer,
|
2020-05-28 05:02:28 +00:00
|
|
|
peer_score = peer.score, score_low_limit = PeerScoreLowLimit,
|
|
|
|
score_high_limit = PeerScoreHighLimit
|
2020-04-23 15:31:00 +00:00
|
|
|
except:
|
|
|
|
discard
|
|
|
|
result = false
|
|
|
|
else:
|
|
|
|
result = true
|
|
|
|
|
|
|
|
node.network.peerPool.setScoreCheck(scoreCheck)
|
|
|
|
|
2020-06-03 08:46:29 +00:00
|
|
|
node.syncManager = newSyncManager[Peer, PeerID](
|
2020-04-20 14:59:18 +00:00
|
|
|
node.network.peerPool, getLocalHeadSlot, getLocalWallSlot,
|
2020-05-08 06:17:40 +00:00
|
|
|
updateLocalBlocks,
|
2020-05-19 12:08:50 +00:00
|
|
|
# 4 blocks per chunk is the optimal value right now, because our current
|
|
|
|
# syncing speed is around 4 blocks per second. So there no need to request
|
|
|
|
# more then 4 blocks right now. As soon as `store_speed` value become
|
|
|
|
# significantly more then 4 blocks per second you can increase this
|
|
|
|
# value appropriately.
|
|
|
|
chunkSize = 4
|
2020-04-20 14:59:18 +00:00
|
|
|
)
|
|
|
|
|
2020-06-03 08:46:29 +00:00
|
|
|
await node.syncManager.sync()
|
2020-04-20 14:59:18 +00:00
|
|
|
|
2020-03-22 16:20:46 +00:00
|
|
|
proc currentSlot(node: BeaconNode): Slot =
|
2020-03-16 22:28:54 +00:00
|
|
|
node.beaconClock.now.slotOrZero
|
|
|
|
|
|
|
|
proc connectedPeersCount(node: BeaconNode): int =
|
|
|
|
libp2p_peers.value.int
|
|
|
|
|
|
|
|
proc fromJson(n: JsonNode; argName: string; result: var Slot) =
|
|
|
|
var i: int
|
|
|
|
fromJson(n, argName, i)
|
|
|
|
result = Slot(i)
|
|
|
|
|
|
|
|
proc installBeaconApiHandlers(rpcServer: RpcServer, node: BeaconNode) =
|
|
|
|
rpcServer.rpc("getBeaconHead") do () -> Slot:
|
2020-05-14 09:18:08 +00:00
|
|
|
return node.blockPool.head.blck.slot
|
|
|
|
|
|
|
|
rpcServer.rpc("getChainHead") do () -> JsonNode:
|
|
|
|
let
|
|
|
|
head = node.blockPool.head
|
|
|
|
finalized = node.blockPool.headState.data.data.finalized_checkpoint
|
|
|
|
justified = node.blockPool.headState.data.data.current_justified_checkpoint
|
|
|
|
return %* {
|
|
|
|
"head_slot": head.blck.slot,
|
|
|
|
"head_block_root": head.blck.root.data.toHex(),
|
|
|
|
"finalized_slot": finalized.epoch * SLOTS_PER_EPOCH,
|
|
|
|
"finalized_block_root": finalized.root.data.toHex(),
|
|
|
|
"justified_slot": justified.epoch * SLOTS_PER_EPOCH,
|
|
|
|
"justified_block_root": justified.root.data.toHex(),
|
|
|
|
}
|
|
|
|
|
|
|
|
rpcServer.rpc("getSyncing") do () -> bool:
|
|
|
|
let
|
|
|
|
beaconTime = node.beaconClock.now()
|
|
|
|
wallSlot = currentSlot(node)
|
|
|
|
headSlot = node.blockPool.head.blck.slot
|
|
|
|
# FIXME: temporary hack: If more than 1 block away from expected head, then we are "syncing"
|
|
|
|
return (headSlot + 1) < wallSlot
|
2020-03-16 22:28:54 +00:00
|
|
|
|
|
|
|
template requireOneOf(x, y: distinct Option) =
|
|
|
|
if x.isNone xor y.isNone:
|
|
|
|
raise newException(CatchableError,
|
|
|
|
"Please specify one of " & astToStr(x) & " or " & astToStr(y))
|
|
|
|
|
|
|
|
template jsonResult(x: auto): auto =
|
2020-03-17 20:06:26 +00:00
|
|
|
StringOfJson(Json.encode(x))
|
2020-03-16 22:28:54 +00:00
|
|
|
|
|
|
|
rpcServer.rpc("getBeaconBlock") do (slot: Option[Slot],
|
2020-03-17 20:06:26 +00:00
|
|
|
root: Option[Eth2Digest]) -> StringOfJson:
|
2020-03-16 22:28:54 +00:00
|
|
|
requireOneOf(slot, root)
|
|
|
|
var blockHash: Eth2Digest
|
|
|
|
if root.isSome:
|
|
|
|
blockHash = root.get
|
|
|
|
else:
|
|
|
|
let foundRef = node.blockPool.getBlockByPreciseSlot(slot.get)
|
2020-03-18 19:38:34 +00:00
|
|
|
if foundRef != nil:
|
|
|
|
blockHash = foundRef.root
|
2020-03-16 22:28:54 +00:00
|
|
|
else:
|
2020-03-17 20:06:26 +00:00
|
|
|
return StringOfJson("null")
|
2020-03-16 22:28:54 +00:00
|
|
|
|
|
|
|
let dbBlock = node.db.getBlock(blockHash)
|
|
|
|
if dbBlock.isSome:
|
|
|
|
return jsonResult(dbBlock.get)
|
|
|
|
else:
|
2020-03-17 20:06:26 +00:00
|
|
|
return StringOfJson("null")
|
2020-03-16 22:28:54 +00:00
|
|
|
|
|
|
|
rpcServer.rpc("getBeaconState") do (slot: Option[Slot],
|
2020-03-17 20:06:26 +00:00
|
|
|
root: Option[Eth2Digest]) -> StringOfJson:
|
2020-03-16 22:28:54 +00:00
|
|
|
requireOneOf(slot, root)
|
|
|
|
if slot.isSome:
|
|
|
|
let blk = node.blockPool.head.blck.atSlot(slot.get)
|
2020-04-28 08:08:32 +00:00
|
|
|
node.blockPool.withState(node.blockPool.tmpState, blk):
|
2020-03-16 22:28:54 +00:00
|
|
|
return jsonResult(state)
|
|
|
|
else:
|
2020-04-28 08:08:32 +00:00
|
|
|
let tmp = BeaconStateRef() # TODO use tmpState - but load the entire StateData!
|
|
|
|
let state = node.db.getState(root.get, tmp[], noRollback)
|
|
|
|
if state:
|
|
|
|
return jsonResult(tmp[])
|
2020-03-16 22:28:54 +00:00
|
|
|
else:
|
2020-03-17 20:06:26 +00:00
|
|
|
return StringOfJson("null")
|
2020-03-16 22:28:54 +00:00
|
|
|
|
|
|
|
rpcServer.rpc("getNetworkPeerId") do () -> string:
|
2020-03-22 20:54:47 +00:00
|
|
|
return $publicKey(node.network)
|
2020-03-16 22:28:54 +00:00
|
|
|
|
|
|
|
rpcServer.rpc("getNetworkPeers") do () -> seq[string]:
|
|
|
|
for peerId, peer in node.network.peerPool:
|
|
|
|
result.add $peerId
|
|
|
|
|
|
|
|
rpcServer.rpc("getNetworkEnr") do () -> string:
|
2020-04-08 21:09:52 +00:00
|
|
|
return $node.network.discovery.localNode.record
|
2020-03-16 22:28:54 +00:00
|
|
|
|
|
|
|
proc installDebugApiHandlers(rpcServer: RpcServer, node: BeaconNode) =
|
2020-05-14 09:18:08 +00:00
|
|
|
rpcServer.rpc("getNodeVersion") do () -> string:
|
|
|
|
return "Nimbus/" & fullVersionStr
|
|
|
|
|
2020-03-16 23:49:53 +00:00
|
|
|
rpcServer.rpc("getSpecPreset") do () -> JsonNode:
|
|
|
|
var res = newJObject()
|
|
|
|
genCode:
|
|
|
|
for setting in BeaconChainConstants:
|
|
|
|
let
|
|
|
|
settingSym = ident($setting)
|
|
|
|
settingKey = newLit(toLowerAscii($setting))
|
|
|
|
yield quote do:
|
|
|
|
res[`settingKey`] = %`settingSym`
|
|
|
|
|
|
|
|
return res
|
2020-03-16 22:28:54 +00:00
|
|
|
|
|
|
|
proc installRpcHandlers(rpcServer: RpcServer, node: BeaconNode) =
|
2020-05-22 17:04:52 +00:00
|
|
|
# TODO: remove this if statement later - here just to test the config option for now
|
2020-05-27 17:06:28 +00:00
|
|
|
if node.config.validatorApi:
|
2020-05-22 17:04:52 +00:00
|
|
|
rpcServer.installValidatorApiHandlers(node)
|
2020-03-16 22:28:54 +00:00
|
|
|
rpcServer.installBeaconApiHandlers(node)
|
|
|
|
rpcServer.installDebugApiHandlers(node)
|
|
|
|
|
2020-05-14 11:19:10 +00:00
|
|
|
proc installAttestationHandlers(node: BeaconNode) =
|
2020-03-31 18:39:02 +00:00
|
|
|
proc attestationHandler(attestation: Attestation) =
|
|
|
|
# Avoid double-counting attestation-topic attestations on shared codepath
|
|
|
|
# when they're reflected through beacon blocks
|
|
|
|
beacon_attestations_received.inc()
|
2020-05-14 11:19:10 +00:00
|
|
|
beacon_attestation_received_seconds_from_slot_start.observe(
|
|
|
|
node.beaconClock.now.int64 -
|
|
|
|
(attestation.data.slot.int64 * SECONDS_PER_SLOT.int64))
|
2020-05-11 06:25:49 +00:00
|
|
|
|
2020-03-31 18:39:02 +00:00
|
|
|
node.onAttestation(attestation)
|
|
|
|
|
|
|
|
var attestationSubscriptions: seq[Future[void]] = @[]
|
2020-05-14 11:19:10 +00:00
|
|
|
|
|
|
|
# https://github.com/ethereum/eth2.0-specs/blob/v0.11.1/specs/phase0/p2p-interface.md#mainnet-3
|
2020-03-31 18:39:02 +00:00
|
|
|
for it in 0'u64 ..< ATTESTATION_SUBNET_COUNT.uint64:
|
|
|
|
closureScope:
|
|
|
|
let ci = it
|
|
|
|
attestationSubscriptions.add(node.network.subscribe(
|
2020-05-14 11:19:10 +00:00
|
|
|
getMainnetAttestationTopic(node.forkDigest, ci), attestationHandler,
|
|
|
|
# This proc needs to be within closureScope; don't lift out of loop.
|
2020-03-31 18:39:02 +00:00
|
|
|
proc(attestation: Attestation): bool =
|
|
|
|
# https://github.com/ethereum/eth2.0-specs/blob/v0.11.1/specs/phase0/p2p-interface.md#attestation-subnets
|
|
|
|
let (afterGenesis, slot) = node.beaconClock.now().toSlot()
|
|
|
|
if not afterGenesis:
|
|
|
|
return false
|
|
|
|
node.attestationPool.isValidAttestation(attestation, slot, ci, {})))
|
2020-05-14 11:19:10 +00:00
|
|
|
|
|
|
|
# https://github.com/ethereum/eth2.0-specs/blob/v0.11.1/specs/phase0/p2p-interface.md#interop-3
|
|
|
|
attestationSubscriptions.add(node.network.subscribe(
|
|
|
|
getInteropAttestationTopic(node.forkDigest), attestationHandler,
|
|
|
|
proc(attestation: Attestation): bool =
|
|
|
|
# https://github.com/ethereum/eth2.0-specs/blob/v0.11.1/specs/phase0/p2p-interface.md#attestation-subnets
|
|
|
|
let (afterGenesis, slot) = node.beaconClock.now().toSlot()
|
|
|
|
if not afterGenesis:
|
|
|
|
return false
|
|
|
|
# isValidAttestation checks attestation.data.index == topicCommitteeIndex
|
|
|
|
# which doesn't make sense here, so rig that check to vacuously pass.
|
|
|
|
node.attestationPool.isValidAttestation(
|
|
|
|
attestation, slot, attestation.data.index, {})))
|
|
|
|
|
2020-03-31 18:39:02 +00:00
|
|
|
waitFor allFutures(attestationSubscriptions)
|
2018-12-28 16:51:40 +00:00
|
|
|
|
2020-05-19 18:57:35 +00:00
|
|
|
proc stop*(node: BeaconNode) =
|
|
|
|
status = BeaconNodeStatus.Stopping
|
|
|
|
info "Graceful shutdown"
|
|
|
|
waitFor node.network.stop()
|
|
|
|
|
2020-05-14 11:19:10 +00:00
|
|
|
proc run*(node: BeaconNode) =
|
2020-05-19 18:57:35 +00:00
|
|
|
if status == BeaconNodeStatus.Starting:
|
|
|
|
# it might have been set to "Stopping" with Ctrl+C
|
|
|
|
status = BeaconNodeStatus.Running
|
|
|
|
|
|
|
|
if node.rpcServer != nil:
|
|
|
|
node.rpcServer.installRpcHandlers(node)
|
|
|
|
node.rpcServer.start()
|
|
|
|
|
|
|
|
waitFor node.network.subscribe(node.topicBeaconBlocks) do (signedBlock: SignedBeaconBlock):
|
|
|
|
onBeaconBlock(node, signedBlock)
|
|
|
|
do (signedBlock: SignedBeaconBlock) -> bool:
|
|
|
|
let (afterGenesis, slot) = node.beaconClock.now.toSlot()
|
|
|
|
if not afterGenesis:
|
|
|
|
return false
|
|
|
|
node.blockPool.isValidBeaconBlock(signedBlock, slot, {})
|
2020-05-14 11:19:10 +00:00
|
|
|
|
2020-05-19 18:57:35 +00:00
|
|
|
installAttestationHandlers(node)
|
2020-05-14 11:19:10 +00:00
|
|
|
|
2020-05-19 18:57:35 +00:00
|
|
|
let
|
2020-05-22 17:04:52 +00:00
|
|
|
curSlot = node.beaconClock.now().slotOrZero()
|
2020-05-19 18:57:35 +00:00
|
|
|
nextSlot = curSlot + 1 # No earlier than GENESIS_SLOT + 1
|
|
|
|
fromNow = saturate(node.beaconClock.fromNow(nextSlot))
|
|
|
|
|
|
|
|
info "Scheduling first slot action",
|
|
|
|
beaconTime = shortLog(node.beaconClock.now()),
|
|
|
|
nextSlot = shortLog(nextSlot),
|
|
|
|
fromNow = shortLog(fromNow),
|
|
|
|
cat = "scheduling"
|
2020-05-14 11:19:10 +00:00
|
|
|
|
2020-05-19 18:57:35 +00:00
|
|
|
addTimer(fromNow) do (p: pointer):
|
|
|
|
asyncCheck node.onSlotStart(curSlot, nextSlot)
|
2019-02-28 21:21:29 +00:00
|
|
|
|
2020-06-03 08:46:29 +00:00
|
|
|
node.onSecondLoop = runOnSecondLoop(node)
|
|
|
|
node.forwardSyncLoop = runForwardSyncLoop(node)
|
2019-03-27 20:17:01 +00:00
|
|
|
|
2020-05-19 18:57:35 +00:00
|
|
|
# main event loop
|
|
|
|
while status == BeaconNodeStatus.Running:
|
|
|
|
try:
|
|
|
|
poll()
|
|
|
|
except CatchableError as e:
|
|
|
|
debug "Exception in poll()", exc = e.name, err = e.msg
|
2020-04-20 14:59:18 +00:00
|
|
|
|
2020-05-19 18:57:35 +00:00
|
|
|
# time to say goodbye
|
|
|
|
node.stop()
|
2018-11-23 23:58:49 +00:00
|
|
|
|
2018-12-19 12:58:53 +00:00
|
|
|
var gPidFile: string
|
|
|
|
proc createPidFile(filename: string) =
|
|
|
|
createDir splitFile(filename).dir
|
2019-07-07 09:53:58 +00:00
|
|
|
writeFile filename, $os.getCurrentProcessId()
|
2018-12-19 12:58:53 +00:00
|
|
|
gPidFile = filename
|
|
|
|
addQuitProc proc {.noconv.} = removeFile gPidFile
|
|
|
|
|
2019-11-25 12:47:29 +00:00
|
|
|
proc start(node: BeaconNode) =
|
2019-03-20 11:52:30 +00:00
|
|
|
# TODO: while it's nice to cheat by waiting for connections here, we
|
|
|
|
# actually need to make this part of normal application flow -
|
|
|
|
# losing all connections might happen at any time and we should be
|
|
|
|
# prepared to handle it.
|
|
|
|
waitFor node.connectToNetwork()
|
|
|
|
|
2019-11-25 12:47:29 +00:00
|
|
|
let
|
|
|
|
head = node.blockPool.head
|
|
|
|
finalizedHead = node.blockPool.finalizedHead
|
|
|
|
|
2019-03-20 11:52:30 +00:00
|
|
|
info "Starting beacon node",
|
2019-11-12 00:05:35 +00:00
|
|
|
version = fullVersionStr,
|
2019-08-16 11:16:56 +00:00
|
|
|
timeSinceFinalization =
|
2019-11-25 12:47:29 +00:00
|
|
|
int64(finalizedHead.slot.toBeaconTime()) -
|
2019-03-22 15:49:37 +00:00
|
|
|
int64(node.beaconClock.now()),
|
2019-11-25 12:47:29 +00:00
|
|
|
headSlot = shortLog(head.blck.slot),
|
|
|
|
headRoot = shortLog(head.blck.root),
|
|
|
|
finalizedSlot = shortLog(finalizedHead.blck.slot),
|
|
|
|
finalizedRoot = shortLog(finalizedHead.blck.root),
|
2019-03-20 11:52:30 +00:00
|
|
|
SLOTS_PER_EPOCH,
|
|
|
|
SECONDS_PER_SLOT,
|
2019-09-12 01:45:04 +00:00
|
|
|
SPEC_VERSION,
|
2019-10-22 21:18:45 +00:00
|
|
|
dataDir = node.config.dataDir.string,
|
2019-09-12 01:45:04 +00:00
|
|
|
cat = "init",
|
|
|
|
pcs = "start_beacon_node"
|
2019-03-20 11:52:30 +00:00
|
|
|
|
2019-11-25 12:47:29 +00:00
|
|
|
let
|
|
|
|
bs = BlockSlot(blck: head.blck, slot: head.blck.slot)
|
|
|
|
|
2019-12-19 13:02:28 +00:00
|
|
|
node.blockPool.withState(node.blockPool.tmpState, bs):
|
2020-04-28 08:08:32 +00:00
|
|
|
node.addLocalValidators(state)
|
2019-11-25 12:47:29 +00:00
|
|
|
|
2019-03-20 11:52:30 +00:00
|
|
|
node.run()
|
|
|
|
|
2019-10-03 01:51:44 +00:00
|
|
|
func formatGwei(amount: uint64): string =
|
|
|
|
# TODO This is implemented in a quite a silly way.
|
|
|
|
# Better routines for formatting decimal numbers
|
|
|
|
# should exists somewhere else.
|
|
|
|
let
|
|
|
|
eth = amount div 1000000000
|
|
|
|
remainder = amount mod 1000000000
|
|
|
|
|
|
|
|
result = $eth
|
|
|
|
if remainder != 0:
|
|
|
|
result.add '.'
|
|
|
|
result.add $remainder
|
|
|
|
while result[^1] == '0':
|
|
|
|
result.setLen(result.len - 1)
|
|
|
|
|
2019-10-02 12:38:14 +00:00
|
|
|
when hasPrompt:
|
|
|
|
from unicode import Rune
|
|
|
|
import terminal, prompt
|
|
|
|
|
|
|
|
proc providePromptCompletions*(line: seq[Rune], cursorPos: int): seq[string] =
|
|
|
|
# TODO
|
|
|
|
# The completions should be generated with the general-purpose command-line
|
|
|
|
# parsing API of Confutils
|
|
|
|
result = @[]
|
|
|
|
|
2019-10-03 01:51:44 +00:00
|
|
|
proc processPromptCommands(p: ptr Prompt) {.thread.} =
|
|
|
|
while true:
|
|
|
|
var cmd = p[].readLine()
|
|
|
|
case cmd
|
|
|
|
of "quit":
|
|
|
|
quit 0
|
|
|
|
else:
|
|
|
|
p[].writeLine("Unknown command: " & cmd)
|
2019-10-02 12:38:14 +00:00
|
|
|
|
2019-10-03 01:51:44 +00:00
|
|
|
proc initPrompt(node: BeaconNode) =
|
2019-10-28 23:04:52 +00:00
|
|
|
if isatty(stdout) and node.config.statusBarEnabled:
|
2019-10-03 01:51:44 +00:00
|
|
|
enableTrueColors()
|
|
|
|
|
|
|
|
# TODO: nim-prompt seems to have threading issues at the moment
|
|
|
|
# which result in sporadic crashes. We should introduce a
|
|
|
|
# lock that guards the access to the internal prompt line
|
|
|
|
# variable.
|
|
|
|
#
|
|
|
|
# var p = Prompt.init("nimbus > ", providePromptCompletions)
|
|
|
|
# p.useHistoryFile()
|
|
|
|
|
|
|
|
proc dataResolver(expr: string): string =
|
|
|
|
# TODO:
|
|
|
|
# We should introduce a general API for resolving dot expressions
|
|
|
|
# such as `db.latest_block.slot` or `metrics.connected_peers`.
|
|
|
|
# Such an API can be shared between the RPC back-end, CLI tools
|
|
|
|
# such as ncli, a potential GraphQL back-end and so on.
|
|
|
|
# The status bar feature would allow the user to specify an
|
|
|
|
# arbitrary expression that is resolvable through this API.
|
|
|
|
case expr.toLowerAscii
|
|
|
|
of "connected_peers":
|
2020-03-16 22:28:54 +00:00
|
|
|
$(node.connectedPeersCount)
|
2019-10-03 01:51:44 +00:00
|
|
|
|
|
|
|
of "last_finalized_epoch":
|
|
|
|
var head = node.blockPool.finalizedHead
|
|
|
|
# TODO: Should we display a state root instead?
|
2019-10-07 08:29:39 +00:00
|
|
|
$(head.slot.epoch) & " (" & shortLog(head.blck.root) & ")"
|
|
|
|
|
|
|
|
of "epoch":
|
|
|
|
$node.beaconClock.now.slotOrZero.epoch
|
|
|
|
|
|
|
|
of "epoch_slot":
|
|
|
|
$(node.beaconClock.now.slotOrZero mod SLOTS_PER_EPOCH)
|
|
|
|
|
|
|
|
of "slots_per_epoch":
|
|
|
|
$SLOTS_PER_EPOCH
|
|
|
|
|
2019-10-29 19:48:32 +00:00
|
|
|
of "slot":
|
2020-03-16 22:28:54 +00:00
|
|
|
$node.currentSlot
|
2019-10-29 19:48:32 +00:00
|
|
|
|
2019-10-07 08:29:39 +00:00
|
|
|
of "slot_trailing_digits":
|
|
|
|
var slotStr = $node.beaconClock.now.slotOrZero
|
|
|
|
if slotStr.len > 3: slotStr = slotStr[^3..^1]
|
|
|
|
slotStr
|
2019-10-03 01:51:44 +00:00
|
|
|
|
|
|
|
of "attached_validators_balance":
|
|
|
|
var balance = uint64(0)
|
2019-11-25 12:47:29 +00:00
|
|
|
# TODO slow linear scan!
|
2019-12-19 13:02:28 +00:00
|
|
|
for idx, b in node.blockPool.headState.data.data.balances:
|
2019-11-25 12:47:29 +00:00
|
|
|
if node.getAttachedValidator(
|
2020-04-28 08:08:32 +00:00
|
|
|
node.blockPool.headState.data.data, ValidatorIndex(idx)) != nil:
|
2019-11-25 12:47:29 +00:00
|
|
|
balance += b
|
2019-10-03 01:51:44 +00:00
|
|
|
formatGwei(balance)
|
|
|
|
|
|
|
|
else:
|
|
|
|
# We ignore typos for now and just render the expression
|
|
|
|
# as it was written. TODO: come up with a good way to show
|
|
|
|
# an error message to the user.
|
|
|
|
"$" & expr
|
|
|
|
|
|
|
|
var statusBar = StatusBarView.init(
|
2019-10-28 23:04:52 +00:00
|
|
|
node.config.statusBarContents,
|
2019-10-03 01:51:44 +00:00
|
|
|
dataResolver)
|
2019-10-02 12:38:14 +00:00
|
|
|
|
2019-10-29 01:22:06 +00:00
|
|
|
when compiles(defaultChroniclesStream.output.writer):
|
|
|
|
defaultChroniclesStream.output.writer =
|
2020-04-22 05:53:02 +00:00
|
|
|
proc (logLevel: LogLevel, msg: LogOutputStr) {.gcsafe, raises: [Defect].} =
|
|
|
|
try:
|
|
|
|
# p.hidePrompt
|
|
|
|
erase statusBar
|
|
|
|
# p.writeLine msg
|
|
|
|
stdout.write msg
|
|
|
|
render statusBar
|
|
|
|
# p.showPrompt
|
|
|
|
except Exception as e: # render raises Exception
|
2020-03-24 11:13:07 +00:00
|
|
|
logLoggingFailure(cstring(msg), e)
|
2019-10-03 01:51:44 +00:00
|
|
|
|
|
|
|
proc statusBarUpdatesPollingLoop() {.async.} =
|
|
|
|
while true:
|
|
|
|
update statusBar
|
2019-11-25 12:47:29 +00:00
|
|
|
await sleepAsync(chronos.seconds(1))
|
2019-10-03 01:51:44 +00:00
|
|
|
|
|
|
|
traceAsyncErrors statusBarUpdatesPollingLoop()
|
|
|
|
|
|
|
|
# var t: Thread[ptr Prompt]
|
|
|
|
# createThread(t, processPromptCommands, addr p)
|
2019-10-02 12:38:14 +00:00
|
|
|
|
2020-03-24 11:13:07 +00:00
|
|
|
programMain:
|
2020-05-27 17:06:28 +00:00
|
|
|
let config = makeBannerAndConfig(clientId, BeaconNodeConf)
|
2020-02-18 00:32:12 +00:00
|
|
|
|
2020-05-22 17:04:52 +00:00
|
|
|
setupMainProc(config.logLevel)
|
2019-01-16 23:01:15 +00:00
|
|
|
|
2018-12-19 12:58:53 +00:00
|
|
|
case config.cmd
|
2019-03-19 17:22:17 +00:00
|
|
|
of createTestnet:
|
|
|
|
var deposits: seq[Deposit]
|
2019-03-27 12:06:06 +00:00
|
|
|
for i in config.firstValidator.int ..< config.totalValidators.int:
|
2019-03-19 17:22:17 +00:00
|
|
|
let depositFile = config.validatorsDir /
|
|
|
|
validatorFileBaseName(i) & ".deposit.json"
|
2019-06-19 13:41:54 +00:00
|
|
|
try:
|
|
|
|
deposits.add Json.loadFile(depositFile, Deposit)
|
|
|
|
except SerializationError as err:
|
|
|
|
stderr.write "Error while loading a deposit file:\n"
|
|
|
|
stderr.write err.formatMsg(depositFile), "\n"
|
2019-09-01 15:02:49 +00:00
|
|
|
stderr.write "Please regenerate the deposit files by running makeDeposits again\n"
|
2019-06-19 13:41:54 +00:00
|
|
|
quit 1
|
2019-03-19 17:22:17 +00:00
|
|
|
|
2019-10-29 16:46:41 +00:00
|
|
|
let
|
2019-09-02 10:31:14 +00:00
|
|
|
startTime = uint64(times.toUnix(times.getTime()) + config.genesisOffset)
|
2019-10-29 16:46:41 +00:00
|
|
|
outGenesis = config.outputGenesis.string
|
2020-03-24 11:13:07 +00:00
|
|
|
eth1Hash = if config.web3Url.len == 0: eth1BlockHash
|
|
|
|
else: waitFor getLatestEth1BlockHash(config.web3Url)
|
2019-10-29 16:46:41 +00:00
|
|
|
var
|
2019-09-02 10:31:14 +00:00
|
|
|
initialState = initialize_beacon_state_from_eth1(
|
2020-03-05 12:52:10 +00:00
|
|
|
eth1Hash, startTime, deposits, {skipBlsValidation, skipMerkleValidation})
|
2019-09-02 10:31:14 +00:00
|
|
|
|
|
|
|
# https://github.com/ethereum/eth2.0-pm/tree/6e41fcf383ebeb5125938850d8e9b4e9888389b4/interop/mocked_start#create-genesis-state
|
|
|
|
initialState.genesis_time = startTime
|
2019-07-01 13:20:55 +00:00
|
|
|
|
|
|
|
doAssert initialState.validators.len > 0
|
2019-03-19 17:22:17 +00:00
|
|
|
|
2019-10-29 16:46:41 +00:00
|
|
|
let outGenesisExt = splitFile(outGenesis).ext
|
|
|
|
if cmpIgnoreCase(outGenesisExt, ".json") == 0:
|
|
|
|
Json.saveFile(outGenesis, initialState, pretty = true)
|
|
|
|
echo "Wrote ", outGenesis
|
2019-03-19 17:22:17 +00:00
|
|
|
|
2019-10-29 16:46:41 +00:00
|
|
|
let outSszGenesis = outGenesis.changeFileExt "ssz"
|
2020-04-29 20:12:07 +00:00
|
|
|
SSZ.saveFile(outSszGenesis, initialState[])
|
2019-10-29 16:46:41 +00:00
|
|
|
echo "Wrote ", outSszGenesis
|
2019-09-08 15:32:38 +00:00
|
|
|
|
2019-10-28 23:04:52 +00:00
|
|
|
let bootstrapFile = config.outputBootstrapFile.string
|
2019-09-27 16:05:17 +00:00
|
|
|
if bootstrapFile.len > 0:
|
2020-02-11 16:58:29 +00:00
|
|
|
let
|
|
|
|
networkKeys = getPersistentNetKeys(config)
|
2020-04-22 13:12:18 +00:00
|
|
|
metadata = getPersistentNetMetadata(config)
|
2020-02-19 08:58:10 +00:00
|
|
|
bootstrapEnr = enr.Record.init(
|
|
|
|
1, # sequence number
|
|
|
|
networkKeys.seckey.asEthKey,
|
2020-03-31 10:02:13 +00:00
|
|
|
some(config.bootstrapAddress),
|
|
|
|
config.bootstrapPort,
|
2020-04-15 02:41:22 +00:00
|
|
|
config.bootstrapPort,
|
2020-04-23 18:58:54 +00:00
|
|
|
[toFieldPair("eth2", SSZ.encode(enrForkIdFromState initialState[])),
|
2020-04-22 13:12:18 +00:00
|
|
|
toFieldPair("attnets", SSZ.encode(metadata.attnets))])
|
2020-02-19 08:58:10 +00:00
|
|
|
|
2020-05-09 14:47:14 +00:00
|
|
|
writeFile(bootstrapFile, bootstrapEnr.tryGet().toURI)
|
2019-09-27 16:05:17 +00:00
|
|
|
echo "Wrote ", bootstrapFile
|
|
|
|
|
2019-03-25 23:26:11 +00:00
|
|
|
of importValidator:
|
2019-03-18 03:54:08 +00:00
|
|
|
template reportFailureFor(keyExpr) =
|
|
|
|
error "Failed to import validator key", key = keyExpr
|
|
|
|
programResult = 1
|
|
|
|
|
2019-10-28 23:04:52 +00:00
|
|
|
if config.keyFiles.len == 0:
|
|
|
|
stderr.write "Please specify at least one keyfile to import."
|
|
|
|
quit 1
|
|
|
|
|
2019-03-19 19:50:22 +00:00
|
|
|
for keyFile in config.keyFiles:
|
2019-03-18 03:54:08 +00:00
|
|
|
try:
|
2019-03-25 23:26:11 +00:00
|
|
|
saveValidatorKey(keyFile.string.extractFilename,
|
|
|
|
readFile(keyFile.string), config)
|
2019-03-18 03:54:08 +00:00
|
|
|
except:
|
2019-03-19 19:50:22 +00:00
|
|
|
reportFailureFor keyFile.string
|
2019-03-18 03:54:08 +00:00
|
|
|
|
2018-12-19 12:58:53 +00:00
|
|
|
of noCommand:
|
2020-04-07 16:04:22 +00:00
|
|
|
debug "Launching beacon node",
|
|
|
|
version = fullVersionStr,
|
|
|
|
cmdParams = commandLineParams(),
|
|
|
|
config
|
|
|
|
|
2018-12-28 16:51:40 +00:00
|
|
|
createPidFile(config.dataDir.string / "beacon_node.pid")
|
2018-12-19 12:58:53 +00:00
|
|
|
|
2020-05-20 08:58:48 +00:00
|
|
|
if config.dumpEnabled:
|
|
|
|
createDir(config.dumpDir)
|
|
|
|
createDir(config.dumpDir / "incoming")
|
|
|
|
|
2019-03-05 22:54:08 +00:00
|
|
|
var node = waitFor BeaconNode.init(config)
|
2020-05-19 18:57:35 +00:00
|
|
|
|
2020-05-22 17:04:52 +00:00
|
|
|
ctrlCHandling: status = BeaconNodeStatus.Stopping
|
2020-05-19 18:57:35 +00:00
|
|
|
|
2020-01-17 13:44:01 +00:00
|
|
|
when hasPrompt:
|
|
|
|
initPrompt(node)
|
|
|
|
|
|
|
|
when useInsecureFeatures:
|
2020-03-16 22:28:54 +00:00
|
|
|
if config.metricsEnabled:
|
|
|
|
let metricsAddress = config.metricsAddress
|
2020-01-17 13:44:01 +00:00
|
|
|
info "Starting metrics HTTP server",
|
2020-03-16 22:28:54 +00:00
|
|
|
address = metricsAddress, port = config.metricsPort
|
|
|
|
metrics.startHttpServer($metricsAddress, config.metricsPort)
|
2018-12-19 12:58:53 +00:00
|
|
|
|
2019-03-22 14:35:20 +00:00
|
|
|
if node.nickname != "":
|
2019-11-25 12:47:29 +00:00
|
|
|
dynamicLogScope(node = node.nickname): node.start()
|
2019-03-20 11:52:30 +00:00
|
|
|
else:
|
2019-11-25 12:47:29 +00:00
|
|
|
node.start()
|
2019-09-01 15:02:49 +00:00
|
|
|
|
|
|
|
of makeDeposits:
|
2019-11-05 18:16:10 +00:00
|
|
|
createDir(config.depositsDir)
|
|
|
|
|
2019-10-29 02:43:23 +00:00
|
|
|
let
|
|
|
|
quickstartDeposits = generateDeposits(
|
|
|
|
config.totalQuickstartDeposits, config.depositsDir, false)
|
|
|
|
|
|
|
|
randomDeposits = generateDeposits(
|
|
|
|
config.totalRandomDeposits, config.depositsDir, true,
|
|
|
|
firstIdx = config.totalQuickstartDeposits)
|
2019-09-01 15:02:49 +00:00
|
|
|
|
2020-03-24 11:13:07 +00:00
|
|
|
if config.web3Url.len > 0 and config.depositContractAddress.len > 0:
|
|
|
|
if config.minDelay > config.maxDelay:
|
|
|
|
echo "The minimum delay should not be larger than the maximum delay"
|
|
|
|
quit 1
|
|
|
|
|
|
|
|
var delayGenerator: DelayGenerator
|
|
|
|
if config.maxDelay > 0.0:
|
|
|
|
delayGenerator = proc (): chronos.Duration {.gcsafe.} =
|
|
|
|
chronos.milliseconds (rand(config.minDelay..config.maxDelay)*1000).int
|
|
|
|
|
2019-12-02 23:27:59 +00:00
|
|
|
info "Sending deposits",
|
2020-03-24 11:13:07 +00:00
|
|
|
web3 = config.web3Url,
|
2019-12-02 23:27:59 +00:00
|
|
|
depositContract = config.depositContractAddress
|
|
|
|
|
2019-09-01 15:02:49 +00:00
|
|
|
waitFor sendDeposits(
|
2019-10-29 02:43:23 +00:00
|
|
|
quickstartDeposits & randomDeposits,
|
2020-03-24 11:13:07 +00:00
|
|
|
config.web3Url,
|
2019-11-05 18:16:10 +00:00
|
|
|
config.depositContractAddress,
|
2020-03-24 11:13:07 +00:00
|
|
|
config.depositPrivateKey,
|
|
|
|
delayGenerator)
|