2018-04-27 08:53:53 +00:00
|
|
|
# Nimbus
|
|
|
|
# Copyright (c) 2018 Status Research & Development GmbH
|
|
|
|
# Licensed under either of
|
|
|
|
# * Apache License, version 2.0, ([LICENSE-APACHE](LICENSE-APACHE))
|
|
|
|
# * MIT license ([LICENSE-MIT](LICENSE-MIT))
|
|
|
|
# at your option.
|
|
|
|
# This file may not be copied, modified, or distributed except according to
|
|
|
|
# those terms.
|
|
|
|
|
2021-04-21 10:15:06 +00:00
|
|
|
import
|
|
|
|
../nimbus/vm_compile_info
|
|
|
|
|
2018-07-22 21:34:43 +00:00
|
|
|
import
|
2022-12-02 04:39:12 +00:00
|
|
|
std/[os, strutils, net],
|
2022-04-06 14:11:13 +00:00
|
|
|
chronicles,
|
|
|
|
chronos,
|
2022-12-02 04:39:12 +00:00
|
|
|
eth/[keys, net/nat],
|
2022-04-06 14:11:13 +00:00
|
|
|
eth/p2p as eth_p2p,
|
|
|
|
json_rpc/rpcserver,
|
|
|
|
metrics,
|
|
|
|
metrics/[chronos_httpserver, chronicles_support],
|
2021-09-11 14:58:01 +00:00
|
|
|
stew/shims/net as stewNet,
|
2022-07-27 16:07:54 +00:00
|
|
|
websock/websock as ws,
|
2022-12-02 04:39:12 +00:00
|
|
|
"."/[config, constants, version, rpc, common],
|
|
|
|
./db/select_backend,
|
2022-04-06 14:11:13 +00:00
|
|
|
./graphql/ethapi,
|
2022-12-02 04:39:12 +00:00
|
|
|
./core/[chain, sealer, clique/clique_desc,
|
|
|
|
clique/clique_sealer, tx_pool, block_import],
|
|
|
|
./rpc/merge/merger,
|
2023-03-13 18:18:30 +00:00
|
|
|
./sync/[legacy, full, protocol, snap, stateless,
|
2023-04-12 12:39:11 +00:00
|
|
|
protocol/les_protocol, handlers, peers],
|
|
|
|
./evm/async/data_sources/json_rpc_data_source
|
2018-07-26 20:08:43 +00:00
|
|
|
|
2021-12-05 11:20:27 +00:00
|
|
|
when defined(evmc_enabled):
|
|
|
|
import transaction/evmc_dynamic_loader
|
|
|
|
|
2018-06-20 17:27:32 +00:00
|
|
|
## TODO:
|
|
|
|
## * No IPv6 support
|
|
|
|
## * No multiple bind addresses support
|
|
|
|
## * No database support
|
|
|
|
|
|
|
|
type
|
|
|
|
NimbusState = enum
|
2020-05-21 01:33:11 +00:00
|
|
|
Starting, Running, Stopping
|
2018-06-20 17:27:32 +00:00
|
|
|
|
2020-03-25 18:00:04 +00:00
|
|
|
NimbusNode = ref object
|
2021-09-07 13:45:01 +00:00
|
|
|
rpcServer: RpcHttpServer
|
2021-10-05 23:31:35 +00:00
|
|
|
engineApiServer: RpcHttpServer
|
2022-01-24 13:08:33 +00:00
|
|
|
engineApiWsServer: RpcWebSocketServer
|
2021-09-07 13:45:01 +00:00
|
|
|
ethNode: EthereumNode
|
|
|
|
state: NimbusState
|
|
|
|
graphqlServer: GraphqlHttpServerRef
|
|
|
|
wsRpcServer: RpcWebSocketServer
|
|
|
|
sealingEngine: SealingEngineRef
|
|
|
|
ctx: EthContext
|
2022-12-02 04:39:12 +00:00
|
|
|
chainRef: ChainRef
|
2022-01-23 11:39:43 +00:00
|
|
|
txPool: TxPoolRef
|
2022-04-13 09:10:43 +00:00
|
|
|
networkLoop: Future[void]
|
2022-08-12 15:42:07 +00:00
|
|
|
dbBackend: ChainDB
|
2022-08-26 09:36:04 +00:00
|
|
|
peerManager: PeerManagerRef
|
2023-01-20 15:01:29 +00:00
|
|
|
legaSyncRef: LegacySyncRef
|
2022-11-14 14:13:00 +00:00
|
|
|
snapSyncRef: SnapSyncRef
|
|
|
|
fullSyncRef: FullSyncRef
|
2023-03-13 18:18:30 +00:00
|
|
|
statelessSyncRef: StatelessSyncRef
|
2022-11-14 07:32:33 +00:00
|
|
|
merger: MergerRef
|
2018-06-20 17:27:32 +00:00
|
|
|
|
2022-12-02 04:39:12 +00:00
|
|
|
proc importBlocks(conf: NimbusConf, com: CommonRef) =
|
2021-09-16 15:59:46 +00:00
|
|
|
if string(conf.blocksFile).len > 0:
|
2021-05-17 11:43:44 +00:00
|
|
|
# success or not, we quit after importing blocks
|
2022-12-02 04:39:12 +00:00
|
|
|
if not importRlpBlock(string conf.blocksFile, com):
|
2021-05-17 11:43:44 +00:00
|
|
|
quit(QuitFailure)
|
|
|
|
else:
|
|
|
|
quit(QuitSuccess)
|
2021-03-18 15:05:15 +00:00
|
|
|
|
2022-10-10 02:31:28 +00:00
|
|
|
proc basicServices(nimbus: NimbusNode,
|
|
|
|
conf: NimbusConf,
|
2022-12-02 04:39:12 +00:00
|
|
|
com: CommonRef) =
|
2022-10-10 02:31:28 +00:00
|
|
|
# app wide TxPool singleton
|
|
|
|
# TODO: disable some of txPool internal mechanism if
|
|
|
|
# the engineSigner is zero.
|
2022-12-02 04:39:12 +00:00
|
|
|
nimbus.txPool = TxPoolRef.new(com, conf.engineSigner)
|
2022-10-10 02:31:28 +00:00
|
|
|
|
|
|
|
# chainRef: some name to avoid module-name/filed/function misunderstandings
|
2022-12-02 04:39:12 +00:00
|
|
|
nimbus.chainRef = newChain(com)
|
2022-10-10 02:31:28 +00:00
|
|
|
if conf.verifyFrom.isSome:
|
|
|
|
let verifyFrom = conf.verifyFrom.get()
|
|
|
|
nimbus.chainRef.extraValidation = 0 < verifyFrom
|
|
|
|
nimbus.chainRef.verifyFrom = verifyFrom
|
|
|
|
|
2022-11-14 07:32:33 +00:00
|
|
|
# this is temporary workaround to track POS transition
|
|
|
|
# until we have proper chain config and hard fork module
|
|
|
|
# see issue #640
|
2022-12-02 04:39:12 +00:00
|
|
|
nimbus.merger = MergerRef.new(com.db)
|
2022-11-14 07:32:33 +00:00
|
|
|
|
2021-09-16 15:59:46 +00:00
|
|
|
proc manageAccounts(nimbus: NimbusNode, conf: NimbusConf) =
|
2021-09-11 14:58:01 +00:00
|
|
|
if string(conf.keyStore).len > 0:
|
|
|
|
let res = nimbus.ctx.am.loadKeystores(string conf.keyStore)
|
2021-09-07 13:45:01 +00:00
|
|
|
if res.isErr:
|
2022-07-27 16:07:54 +00:00
|
|
|
fatal "Load keystore error", msg = res.error()
|
2021-09-07 13:45:01 +00:00
|
|
|
quit(QuitFailure)
|
|
|
|
|
2021-09-11 14:58:01 +00:00
|
|
|
if string(conf.importKey).len > 0:
|
|
|
|
let res = nimbus.ctx.am.importPrivateKey(string conf.importKey)
|
2021-09-07 13:45:01 +00:00
|
|
|
if res.isErr:
|
2022-07-27 16:07:54 +00:00
|
|
|
fatal "Import private key error", msg = res.error()
|
2021-09-07 13:45:01 +00:00
|
|
|
quit(QuitFailure)
|
2021-03-18 15:05:15 +00:00
|
|
|
|
2021-09-16 15:59:46 +00:00
|
|
|
proc setupP2P(nimbus: NimbusNode, conf: NimbusConf,
|
2022-10-10 02:31:28 +00:00
|
|
|
protocols: set[ProtocolFlag]) =
|
2018-06-20 17:27:32 +00:00
|
|
|
## Creating P2P Server
|
2022-07-27 16:07:54 +00:00
|
|
|
let kpres = nimbus.ctx.getNetKeys(conf.netKey, conf.dataDir.string)
|
2021-09-07 13:45:01 +00:00
|
|
|
if kpres.isErr:
|
2022-07-27 16:07:54 +00:00
|
|
|
fatal "Get network keys error", msg = kpres.error
|
2021-09-07 13:45:01 +00:00
|
|
|
quit(QuitFailure)
|
|
|
|
|
|
|
|
let keypair = kpres.get()
|
2021-09-11 14:58:01 +00:00
|
|
|
var address = Address(
|
|
|
|
ip: conf.listenAddress,
|
|
|
|
tcpPort: conf.tcpPort,
|
|
|
|
udpPort: conf.udpPort
|
|
|
|
)
|
|
|
|
|
|
|
|
if conf.nat.hasExtIp:
|
|
|
|
# any required port redirection is assumed to be done by hand
|
|
|
|
address.ip = conf.nat.extIp
|
2019-04-17 01:56:28 +00:00
|
|
|
else:
|
|
|
|
# automated NAT traversal
|
2021-09-11 14:58:01 +00:00
|
|
|
let extIP = getExternalIP(conf.nat.nat)
|
2019-04-17 23:17:06 +00:00
|
|
|
# This external IP only appears in the logs, so don't worry about dynamic
|
|
|
|
# IPs. Don't remove it either, because the above call does initialisation
|
|
|
|
# and discovery for NAT-related objects.
|
2019-04-17 01:56:28 +00:00
|
|
|
if extIP.isSome:
|
|
|
|
address.ip = extIP.get()
|
|
|
|
let extPorts = redirectPorts(tcpPort = address.tcpPort,
|
2021-09-11 14:58:01 +00:00
|
|
|
udpPort = address.udpPort,
|
2022-03-27 11:21:15 +00:00
|
|
|
description = NimbusName & " " & NimbusVersion)
|
2019-04-17 01:56:28 +00:00
|
|
|
if extPorts.isSome:
|
|
|
|
(address.tcpPort, address.udpPort) = extPorts.get()
|
2018-06-20 17:27:32 +00:00
|
|
|
|
2022-03-16 08:01:35 +00:00
|
|
|
let bootstrapNodes = conf.getBootNodes()
|
|
|
|
|
|
|
|
nimbus.ethNode = newEthereumNode(
|
2022-10-10 02:31:28 +00:00
|
|
|
keypair, address, conf.networkId, conf.agentString,
|
2022-03-16 08:01:35 +00:00
|
|
|
addAllCapabilities = false, minPeers = conf.maxPeers,
|
|
|
|
bootstrapNodes = bootstrapNodes,
|
|
|
|
bindUdpPort = conf.udpPort, bindTcpPort = conf.tcpPort,
|
2022-07-27 16:07:54 +00:00
|
|
|
bindIp = conf.listenAddress,
|
|
|
|
rng = nimbus.ctx.rng)
|
2022-03-16 08:01:35 +00:00
|
|
|
|
2019-04-23 13:49:49 +00:00
|
|
|
# Add protocol capabilities based on protocol flags
|
2023-01-20 15:01:29 +00:00
|
|
|
for w in protocols:
|
|
|
|
case w: # handle all possibilities
|
|
|
|
of ProtocolFlag.Eth:
|
|
|
|
nimbus.ethNode.addEthHandlerCapability(
|
|
|
|
nimbus.ethNode.peerPool,
|
|
|
|
nimbus.chainRef,
|
|
|
|
nimbus.txPool)
|
|
|
|
of ProtocolFlag.Les:
|
|
|
|
nimbus.ethNode.addCapability les
|
|
|
|
of ProtocolFlag.Snap:
|
|
|
|
nimbus.ethNode.addSnapHandlerCapability(
|
|
|
|
nimbus.ethNode.peerPool,
|
|
|
|
nimbus.chainRef)
|
2023-03-02 09:57:58 +00:00
|
|
|
# Cannot do without minimal `eth` capability
|
|
|
|
if ProtocolFlag.Eth notin protocols:
|
|
|
|
nimbus.ethNode.addEthHandlerCapability(
|
|
|
|
nimbus.ethNode.peerPool,
|
|
|
|
nimbus.chainRef)
|
2018-06-20 17:27:32 +00:00
|
|
|
|
2022-05-13 16:30:10 +00:00
|
|
|
# Early-initialise "--snap-sync" before starting any network connections.
|
2023-01-20 15:01:29 +00:00
|
|
|
block:
|
2023-03-02 09:57:58 +00:00
|
|
|
let
|
|
|
|
exCtrlFile = if conf.syncCtrlFile.isNone: none(string)
|
|
|
|
else: some(conf.syncCtrlFile.get.string)
|
|
|
|
tickerOK = conf.logLevel in {
|
|
|
|
LogLevel.INFO, LogLevel.DEBUG, LogLevel.TRACE}
|
2022-07-21 12:14:41 +00:00
|
|
|
case conf.syncMode:
|
|
|
|
of SyncMode.Full:
|
2022-11-14 14:13:00 +00:00
|
|
|
nimbus.fullSyncRef = FullSyncRef.init(
|
|
|
|
nimbus.ethNode, nimbus.chainRef, nimbus.ctx.rng, conf.maxPeers,
|
2023-03-02 09:57:58 +00:00
|
|
|
tickerOK, exCtrlFile)
|
2023-04-06 19:42:07 +00:00
|
|
|
of SyncMode.Snap:
|
2023-01-20 15:01:29 +00:00
|
|
|
# Minimal capability needed for sync only
|
|
|
|
if ProtocolFlag.Snap notin protocols:
|
|
|
|
nimbus.ethNode.addSnapHandlerCapability(
|
|
|
|
nimbus.ethNode.peerPool)
|
2022-11-14 14:13:00 +00:00
|
|
|
nimbus.snapSyncRef = SnapSyncRef.init(
|
|
|
|
nimbus.ethNode, nimbus.chainRef, nimbus.ctx.rng, conf.maxPeers,
|
2023-04-06 19:42:07 +00:00
|
|
|
nimbus.dbBackend, tickerOK, exCtrlFile)
|
2023-03-13 18:18:30 +00:00
|
|
|
of SyncMode.Stateless:
|
|
|
|
# FIXME-Adam: what needs to go here?
|
|
|
|
nimbus.statelessSyncRef = StatelessSyncRef.init()
|
2022-07-21 12:14:41 +00:00
|
|
|
of SyncMode.Default:
|
2023-01-20 15:01:29 +00:00
|
|
|
nimbus.legaSyncRef = LegacySyncRef.new(
|
|
|
|
nimbus.ethNode, nimbus.chainRef)
|
2022-05-09 14:04:48 +00:00
|
|
|
|
2021-09-16 15:59:46 +00:00
|
|
|
# Connect directly to the static nodes
|
|
|
|
let staticPeers = conf.getStaticPeers()
|
2022-08-26 09:36:04 +00:00
|
|
|
if staticPeers.len > 0:
|
|
|
|
nimbus.peerManager = PeerManagerRef.new(
|
|
|
|
nimbus.ethNode.peerPool,
|
|
|
|
conf.reconnectInterval,
|
|
|
|
conf.reconnectMaxRetry,
|
|
|
|
staticPeers
|
|
|
|
)
|
|
|
|
nimbus.peerManager.start()
|
2021-09-16 15:59:46 +00:00
|
|
|
|
2022-03-16 08:01:35 +00:00
|
|
|
# Start Eth node
|
2022-03-23 14:07:11 +00:00
|
|
|
if conf.maxPeers > 0:
|
2022-07-21 12:14:41 +00:00
|
|
|
var waitForPeers = true
|
|
|
|
case conf.syncMode:
|
2023-04-06 19:42:07 +00:00
|
|
|
of SyncMode.Snap, SyncMode.Stateless:
|
2022-07-21 12:14:41 +00:00
|
|
|
waitForPeers = false
|
|
|
|
of SyncMode.Full, SyncMode.Default:
|
|
|
|
discard
|
2022-04-13 09:10:43 +00:00
|
|
|
nimbus.networkLoop = nimbus.ethNode.connectToNetwork(
|
2022-05-09 14:04:48 +00:00
|
|
|
enableDiscovery = conf.discovery != DiscoveryType.None,
|
2022-07-21 12:14:41 +00:00
|
|
|
waitForPeers = waitForPeers)
|
2021-09-16 15:59:46 +00:00
|
|
|
|
2023-04-12 12:39:11 +00:00
|
|
|
proc maybeStatelessAsyncDataSource*(nimbus: NimbusNode, conf: NimbusConf): Option[AsyncDataSource] =
|
|
|
|
if conf.syncMode == SyncMode.Stateless:
|
|
|
|
let rpcClient = waitFor(makeAnRpcClient(conf.statelessModeDataSourceUrl))
|
|
|
|
let asyncDataSource = realAsyncDataSource(nimbus.ethNode.peerPool, rpcClient, false)
|
|
|
|
some(asyncDataSource)
|
|
|
|
else:
|
|
|
|
none[AsyncDataSource]()
|
|
|
|
|
2021-09-16 15:59:46 +00:00
|
|
|
proc localServices(nimbus: NimbusNode, conf: NimbusConf,
|
2022-12-02 04:39:12 +00:00
|
|
|
com: CommonRef, protocols: set[ProtocolFlag]) =
|
2021-09-16 15:59:46 +00:00
|
|
|
# metrics logging
|
|
|
|
if conf.logMetricsEnabled:
|
|
|
|
# https://github.com/nim-lang/Nim/issues/17369
|
|
|
|
var logMetrics: proc(udata: pointer) {.gcsafe, raises: [Defect].}
|
|
|
|
logMetrics = proc(udata: pointer) =
|
|
|
|
{.gcsafe.}:
|
|
|
|
let registry = defaultRegistry
|
|
|
|
info "metrics", registry
|
|
|
|
discard setTimer(Moment.fromNow(conf.logMetricsInterval.seconds), logMetrics)
|
|
|
|
discard setTimer(Moment.fromNow(conf.logMetricsInterval.seconds), logMetrics)
|
2022-07-18 04:35:50 +00:00
|
|
|
|
2022-07-27 16:07:54 +00:00
|
|
|
# Provide JWT authentication handler for rpcHttpServer
|
2022-07-18 04:35:50 +00:00
|
|
|
let jwtKey = block:
|
|
|
|
# Create or load shared secret
|
|
|
|
let rc = nimbus.ctx.rng.jwtSharedSecret(conf)
|
|
|
|
if rc.isErr:
|
2022-07-27 16:07:54 +00:00
|
|
|
fatal "Failed create or load shared secret",
|
2022-07-18 04:35:50 +00:00
|
|
|
msg = $(rc.unsafeError) # avoid side effects
|
|
|
|
quit(QuitFailure)
|
|
|
|
rc.value
|
2022-07-19 08:15:18 +00:00
|
|
|
let allowedOrigins = conf.getAllowedOrigins()
|
2022-07-18 04:35:50 +00:00
|
|
|
|
|
|
|
# Provide JWT authentication handler for rpcHttpServer
|
|
|
|
let httpJwtAuthHook = httpJwtAuth(jwtKey)
|
2022-07-19 08:15:18 +00:00
|
|
|
let httpCorsHook = httpCors(allowedOrigins)
|
2022-07-18 04:35:50 +00:00
|
|
|
|
2021-09-11 14:58:01 +00:00
|
|
|
# Creating RPC Server
|
|
|
|
if conf.rpcEnabled:
|
2022-07-18 04:35:50 +00:00
|
|
|
let enableAuthHook = conf.engineApiEnabled and
|
|
|
|
conf.engineApiPort == conf.rpcPort
|
|
|
|
|
|
|
|
let hooks = if enableAuthHook:
|
2022-07-19 08:15:18 +00:00
|
|
|
@[httpJwtAuthHook, httpCorsHook]
|
2022-07-18 04:35:50 +00:00
|
|
|
else:
|
2022-07-19 08:15:18 +00:00
|
|
|
@[httpCorsHook]
|
2022-07-18 04:35:50 +00:00
|
|
|
|
|
|
|
nimbus.rpcServer = newRpcHttpServer(
|
|
|
|
[initTAddress(conf.rpcAddress, conf.rpcPort)],
|
|
|
|
authHooks = hooks
|
|
|
|
)
|
2021-09-07 15:00:21 +00:00
|
|
|
setupCommonRpc(nimbus.ethNode, conf, nimbus.rpcServer)
|
2020-07-22 16:51:26 +00:00
|
|
|
|
2021-09-11 14:58:01 +00:00
|
|
|
# Enable RPC APIs based on RPC flags and protocol flags
|
2021-09-16 15:59:46 +00:00
|
|
|
let rpcFlags = conf.getRpcFlags()
|
2022-01-24 13:08:33 +00:00
|
|
|
if (RpcFlag.Eth in rpcFlags and ProtocolFlag.Eth in protocols) or
|
|
|
|
(conf.engineApiPort == conf.rpcPort):
|
2022-12-02 04:39:12 +00:00
|
|
|
setupEthRpc(nimbus.ethNode, nimbus.ctx, com, nimbus.txPool, nimbus.rpcServer)
|
2021-09-16 15:59:46 +00:00
|
|
|
if RpcFlag.Debug in rpcFlags:
|
2022-12-02 04:39:12 +00:00
|
|
|
setupDebugRpc(com, nimbus.rpcServer)
|
2021-08-05 07:51:28 +00:00
|
|
|
|
2018-06-20 17:27:32 +00:00
|
|
|
nimbus.rpcServer.rpc("admin_quit") do() -> string:
|
2019-07-10 21:23:11 +00:00
|
|
|
{.gcsafe.}:
|
|
|
|
nimbus.state = Stopping
|
2018-06-20 17:27:32 +00:00
|
|
|
result = "EXITING"
|
2021-09-11 14:58:01 +00:00
|
|
|
|
2018-06-20 17:27:32 +00:00
|
|
|
nimbus.rpcServer.start()
|
2020-03-25 18:00:04 +00:00
|
|
|
|
2022-07-18 04:35:50 +00:00
|
|
|
# Provide JWT authentication handler for rpcWebsocketServer
|
|
|
|
let wsJwtAuthHook = wsJwtAuth(jwtKey)
|
2022-07-19 08:15:18 +00:00
|
|
|
let wsCorsHook = wsCors(allowedOrigins)
|
2022-04-06 14:11:13 +00:00
|
|
|
|
2021-09-11 14:58:01 +00:00
|
|
|
# Creating Websocket RPC Server
|
|
|
|
if conf.wsEnabled:
|
2022-07-18 04:35:50 +00:00
|
|
|
let enableAuthHook = conf.engineApiWsEnabled and
|
|
|
|
conf.engineApiWsPort == conf.wsPort
|
|
|
|
|
|
|
|
let hooks = if enableAuthHook:
|
2022-07-19 08:15:18 +00:00
|
|
|
@[wsJwtAuthHook, wsCorsHook]
|
2022-07-18 04:35:50 +00:00
|
|
|
else:
|
2022-07-19 08:15:18 +00:00
|
|
|
@[wsCorsHook]
|
2022-07-18 04:35:50 +00:00
|
|
|
|
2022-04-06 14:11:13 +00:00
|
|
|
# Construct server object
|
|
|
|
nimbus.wsRpcServer = newRpcWebSocketServer(
|
|
|
|
initTAddress(conf.wsAddress, conf.wsPort),
|
2022-07-27 16:07:54 +00:00
|
|
|
authHooks = hooks,
|
|
|
|
# yuck, we should remove this ugly cast when
|
|
|
|
# we fix nim-websock
|
|
|
|
rng = cast[ws.Rng](nimbus.ctx.rng)
|
2022-07-18 04:35:50 +00:00
|
|
|
)
|
2021-09-11 14:58:01 +00:00
|
|
|
setupCommonRpc(nimbus.ethNode, conf, nimbus.wsRpcServer)
|
|
|
|
|
|
|
|
# Enable Websocket RPC APIs based on RPC flags and protocol flags
|
2021-09-16 15:59:46 +00:00
|
|
|
let wsFlags = conf.getWsFlags()
|
2022-01-24 13:08:33 +00:00
|
|
|
if (RpcFlag.Eth in wsFlags and ProtocolFlag.Eth in protocols) or
|
|
|
|
(conf.engineApiWsPort == conf.wsPort):
|
2022-12-02 04:39:12 +00:00
|
|
|
setupEthRpc(nimbus.ethNode, nimbus.ctx, com, nimbus.txPool, nimbus.wsRpcServer)
|
2021-09-16 15:59:46 +00:00
|
|
|
if RpcFlag.Debug in wsFlags:
|
2022-12-02 04:39:12 +00:00
|
|
|
setupDebugRpc(com, nimbus.wsRpcServer)
|
2021-09-11 14:58:01 +00:00
|
|
|
|
|
|
|
nimbus.wsRpcServer.start()
|
|
|
|
|
|
|
|
if conf.graphqlEnabled:
|
2022-07-19 08:15:18 +00:00
|
|
|
nimbus.graphqlServer = setupGraphqlHttpServer(
|
|
|
|
conf,
|
2022-12-02 04:39:12 +00:00
|
|
|
com,
|
2022-07-19 08:15:18 +00:00
|
|
|
nimbus.ethNode,
|
|
|
|
nimbus.txPool,
|
|
|
|
@[httpCorsHook]
|
|
|
|
)
|
2021-04-24 04:01:09 +00:00
|
|
|
nimbus.graphqlServer.start()
|
|
|
|
|
2021-08-24 07:34:58 +00:00
|
|
|
if conf.engineSigner != ZERO_ADDRESS:
|
2022-03-08 07:51:27 +00:00
|
|
|
let res = nimbus.ctx.am.getAccount(conf.engineSigner)
|
|
|
|
if res.isErr:
|
|
|
|
error "Failed to get account",
|
|
|
|
msg = res.error,
|
|
|
|
hint = "--key-store or --import-key"
|
|
|
|
quit(QuitFailure)
|
|
|
|
|
2021-09-16 15:59:46 +00:00
|
|
|
let rs = validateSealer(conf, nimbus.ctx, nimbus.chainRef)
|
2021-08-24 07:34:58 +00:00
|
|
|
if rs.isErr:
|
2022-07-27 16:07:54 +00:00
|
|
|
fatal "Engine signer validation error", msg = rs.error
|
2021-08-24 07:34:58 +00:00
|
|
|
quit(QuitFailure)
|
2021-10-05 23:31:35 +00:00
|
|
|
|
|
|
|
proc signFunc(signer: EthAddress, message: openArray[byte]): Result[RawSignature, cstring] {.gcsafe.} =
|
|
|
|
let
|
|
|
|
hashData = keccakHash(message)
|
|
|
|
acc = nimbus.ctx.am.getAccount(signer).tryGet()
|
|
|
|
rawSign = sign(acc.privateKey, SkMessage(hashData.data)).toRaw
|
|
|
|
|
|
|
|
ok(rawSign)
|
|
|
|
|
|
|
|
nimbus.chainRef.clique.authorize(conf.engineSigner, signFunc)
|
2022-04-13 09:10:43 +00:00
|
|
|
|
2022-07-27 16:07:54 +00:00
|
|
|
# always create sealing engine instance but not always run it
|
2022-04-13 09:10:43 +00:00
|
|
|
# e.g. engine api need sealing engine without it running
|
|
|
|
var initialState = EngineStopped
|
2022-12-02 04:39:12 +00:00
|
|
|
if com.forkGTE(MergeFork):
|
2022-04-13 09:10:43 +00:00
|
|
|
initialState = EnginePostMerge
|
|
|
|
nimbus.sealingEngine = SealingEngineRef.new(
|
|
|
|
nimbus.chainRef, nimbus.ctx, conf.engineSigner,
|
|
|
|
nimbus.txPool, initialState
|
|
|
|
)
|
|
|
|
|
|
|
|
# only run sealing engine if there is a signer
|
|
|
|
if conf.engineSigner != ZERO_ADDRESS:
|
2021-08-24 07:34:58 +00:00
|
|
|
nimbus.sealingEngine.start()
|
|
|
|
|
2022-04-13 09:10:43 +00:00
|
|
|
if conf.engineApiEnabled:
|
2023-04-12 12:39:11 +00:00
|
|
|
let maybeAsyncDataSource = maybeStatelessAsyncDataSource(nimbus, conf)
|
2022-04-13 09:10:43 +00:00
|
|
|
if conf.engineApiPort != conf.rpcPort:
|
2022-07-18 04:35:50 +00:00
|
|
|
nimbus.engineApiServer = newRpcHttpServer(
|
|
|
|
[initTAddress(conf.engineApiAddress, conf.engineApiPort)],
|
2022-07-19 08:15:18 +00:00
|
|
|
authHooks = @[httpJwtAuthHook, httpCorsHook]
|
2022-07-18 04:35:50 +00:00
|
|
|
)
|
2023-04-12 12:39:11 +00:00
|
|
|
setupEngineAPI(nimbus.sealingEngine, nimbus.engineApiServer, nimbus.merger, maybeAsyncDataSource)
|
2022-12-02 04:39:12 +00:00
|
|
|
setupEthRpc(nimbus.ethNode, nimbus.ctx, com, nimbus.txPool, nimbus.engineApiServer)
|
2022-04-13 09:10:43 +00:00
|
|
|
nimbus.engineApiServer.start()
|
|
|
|
else:
|
2023-04-12 12:39:11 +00:00
|
|
|
setupEngineAPI(nimbus.sealingEngine, nimbus.rpcServer, nimbus.merger, maybeAsyncDataSource)
|
2022-04-13 09:10:43 +00:00
|
|
|
|
|
|
|
info "Starting engine API server", port = conf.engineApiPort
|
|
|
|
|
|
|
|
if conf.engineApiWsEnabled:
|
2023-04-12 12:39:11 +00:00
|
|
|
let maybeAsyncDataSource = maybeStatelessAsyncDataSource(nimbus, conf)
|
2022-04-13 09:10:43 +00:00
|
|
|
if conf.engineApiWsPort != conf.wsPort:
|
|
|
|
nimbus.engineApiWsServer = newRpcWebSocketServer(
|
|
|
|
initTAddress(conf.engineApiWsAddress, conf.engineApiWsPort),
|
2022-07-19 08:15:18 +00:00
|
|
|
authHooks = @[wsJwtAuthHook, wsCorsHook]
|
2022-07-18 04:35:50 +00:00
|
|
|
)
|
2023-04-12 12:39:11 +00:00
|
|
|
setupEngineAPI(nimbus.sealingEngine, nimbus.engineApiWsServer, nimbus.merger, maybeAsyncDataSource)
|
2022-12-02 04:39:12 +00:00
|
|
|
setupEthRpc(nimbus.ethNode, nimbus.ctx, com, nimbus.txPool, nimbus.engineApiWsServer)
|
2022-04-13 09:10:43 +00:00
|
|
|
nimbus.engineApiWsServer.start()
|
|
|
|
else:
|
2023-04-12 12:39:11 +00:00
|
|
|
setupEngineAPI(nimbus.sealingEngine, nimbus.wsRpcServer, nimbus.merger, maybeAsyncDataSource)
|
2022-04-13 09:10:43 +00:00
|
|
|
|
|
|
|
info "Starting WebSocket engine API server", port = conf.engineApiWsPort
|
2022-01-24 13:08:33 +00:00
|
|
|
|
2019-07-16 10:43:05 +00:00
|
|
|
# metrics server
|
2021-09-11 14:58:01 +00:00
|
|
|
if conf.metricsEnabled:
|
|
|
|
info "Starting metrics HTTP server", address = conf.metricsAddress, port = conf.metricsPort
|
|
|
|
startMetricsHttpServer($conf.metricsAddress, conf.metricsPort)
|
2019-06-26 12:51:59 +00:00
|
|
|
|
2021-09-16 15:59:46 +00:00
|
|
|
proc start(nimbus: NimbusNode, conf: NimbusConf) =
|
|
|
|
## logging
|
|
|
|
setLogLevel(conf.logLevel)
|
|
|
|
if conf.logFile.isSome:
|
|
|
|
let logFile = string conf.logFile.get()
|
|
|
|
defaultChroniclesStream.output.outFile = nil # to avoid closing stdout
|
|
|
|
discard defaultChroniclesStream.output.open(logFile, fmAppend)
|
2019-04-23 13:49:49 +00:00
|
|
|
|
2021-12-05 11:20:27 +00:00
|
|
|
when defined(evmc_enabled):
|
|
|
|
evmcSetLibraryPath(conf.evm)
|
EVMC: Option `--evm`, load third-party EVM as a shared library
This patch adds:
- Load and use a third-party EVM in a shared library, instead of Nimbus EVM.
- New option `--evm` to specify which library to load.
- The library and this loader conforms to the [EVMC]
(https://evmc.ethereum.org/) 9.x specification.
Any third-party EVM which is compatible with EVMC version 9.x and supports EVM1
contract code will be accepted. The operating system's shared library format
applies. These are `.so*` files on Linux, `.dll` files on Windows and `.dylib`
files on Mac.
The alternative EVM can be selected in two ways:
- Nimbus command line option `--evm:<path>`.
- Environment variable `NIMBUS_EVM=<path>`.
The reason for an environment variable is this allows all the test programs to
run with a third-party EVM as well. Some don't parse command line options.
There are some limitations to be aware of:
- The third-party EVM must use EVMC version 9.x, no other major version.
EVMC 9.x supports EIP-1559 / London fork and older transactions.
- Nested `*CALL` and `CREATE*` operations don't use the third-party EVM yet.
These call the built-in Nimbus EVM. This mixing of different EVMs between
levels is explicitly allowed in specs, so there is no problem doing it.
- The third-party EVM doesn't need to support precompiles, because those are
nested calls, which use the built-in Nimbus EVM.
- Third-party EVMs execute contracts correctly, but fail the final `rootHash`
match. The reason is that some account state changes, which are correct, are
currently inside the Nimbus EVM and need to be moved to EVMC host logic.
*This is a known work in progress*. The EVM execution itself is fine.
Test results using "evmone" third-party EVM:
- [evmone](https://github.com/ethereum/evmone) has been tested. Only on
Linux but it "should" work on Windows and Mac equally well.
- [Version 0.8.1](https://github.com/ethereum/evmone/releases/tag/v0.8.1) was
used because it is compatible with EVMC 9.x, which is required for the
EIP-1559 / London fork, which Nimbus supports. Version 0.8.0 could be used
but it looks like an important bug was fixed in 0.8.1.
- evmone runs fine and the trace output looks good. The calls and arguments
are the same as the built-in Nimbus EVM for tests that have been checked
manually, except evmone skips some calls that can be safely skipped.
- The final `rootHash` is incorrect, due to the *work in progress* mentioned
above which is not part of the evmone execution. Due to this, it's possible
to try evmone and verify expected behaviours, which also validates our own
EVMC implementation, but it can't be used as a full substitute yet.
Signed-off-by: Jamie Lokier <jamie@shareable.org>
2021-12-05 11:20:27 +00:00
|
|
|
|
2021-09-16 15:59:46 +00:00
|
|
|
createDir(string conf.dataDir)
|
2022-08-12 15:42:07 +00:00
|
|
|
nimbus.dbBackend = newChainDB(string conf.dataDir)
|
|
|
|
let trieDB = trieDB nimbus.dbBackend
|
2022-12-02 04:39:12 +00:00
|
|
|
let com = CommonRef.new(trieDB,
|
2021-09-16 15:59:46 +00:00
|
|
|
conf.pruneMode == PruneMode.Full,
|
|
|
|
conf.networkId,
|
|
|
|
conf.networkParams
|
|
|
|
)
|
2018-07-12 11:14:04 +00:00
|
|
|
|
2022-12-02 04:39:12 +00:00
|
|
|
com.initializeEmptyDb()
|
2021-09-16 15:59:46 +00:00
|
|
|
let protocols = conf.getProtocolFlags()
|
|
|
|
|
|
|
|
case conf.cmd
|
|
|
|
of NimbusCmd.`import`:
|
2022-12-02 04:39:12 +00:00
|
|
|
importBlocks(conf, com)
|
2021-09-16 15:59:46 +00:00
|
|
|
else:
|
2022-12-02 04:39:12 +00:00
|
|
|
basicServices(nimbus, conf, com)
|
2021-09-16 15:59:46 +00:00
|
|
|
manageAccounts(nimbus, conf)
|
2022-10-10 02:31:28 +00:00
|
|
|
setupP2P(nimbus, conf, protocols)
|
2022-12-02 04:39:12 +00:00
|
|
|
localServices(nimbus, conf, com, protocols)
|
2021-09-16 15:59:46 +00:00
|
|
|
|
2023-01-20 15:01:29 +00:00
|
|
|
if conf.maxPeers > 0:
|
2022-07-21 12:14:41 +00:00
|
|
|
case conf.syncMode:
|
|
|
|
of SyncMode.Default:
|
2023-01-20 15:01:29 +00:00
|
|
|
nimbus.legaSyncRef.start
|
2023-01-18 15:00:14 +00:00
|
|
|
nimbus.ethNode.setEthHandlerNewBlocksAndHashes(
|
2022-12-05 02:42:09 +00:00
|
|
|
legacy.newBlockHandler,
|
|
|
|
legacy.newBlockHashesHandler,
|
2023-01-20 15:01:29 +00:00
|
|
|
cast[pointer](nimbus.legaSyncRef))
|
|
|
|
of SyncMode.Full:
|
|
|
|
nimbus.fullSyncRef.start
|
2023-03-13 18:18:30 +00:00
|
|
|
of SyncMode.Stateless:
|
|
|
|
nimbus.statelessSyncRef.start
|
2023-04-06 19:42:07 +00:00
|
|
|
of SyncMode.Snap:
|
2023-01-20 15:01:29 +00:00
|
|
|
nimbus.snapSyncRef.start
|
2021-09-16 15:59:46 +00:00
|
|
|
|
|
|
|
if nimbus.state == Starting:
|
|
|
|
# it might have been set to "Stopping" with Ctrl+C
|
|
|
|
nimbus.state = Running
|
2018-06-20 17:27:32 +00:00
|
|
|
|
2021-09-11 14:58:01 +00:00
|
|
|
proc stop*(nimbus: NimbusNode, conf: NimbusConf) {.async, gcsafe.} =
|
2018-12-06 23:16:34 +00:00
|
|
|
trace "Graceful shutdown"
|
2021-09-11 14:58:01 +00:00
|
|
|
if conf.rpcEnabled:
|
2021-11-30 07:13:20 +00:00
|
|
|
await nimbus.rpcServer.stop()
|
2022-06-13 10:20:12 +00:00
|
|
|
# nimbus.engineApiServer can be nil if conf.engineApiPort == conf.rpcPort
|
|
|
|
if conf.engineApiEnabled and nimbus.engineApiServer.isNil.not:
|
2022-04-08 04:54:11 +00:00
|
|
|
await nimbus.engineApiServer.stop()
|
2021-09-11 14:58:01 +00:00
|
|
|
if conf.wsEnabled:
|
2021-09-16 15:59:46 +00:00
|
|
|
nimbus.wsRpcServer.stop()
|
2022-06-13 10:20:12 +00:00
|
|
|
# nimbus.engineApiWsServer can be nil if conf.engineApiWsPort == conf.wsPort
|
|
|
|
if conf.engineApiWsEnabled and nimbus.engineApiWsServer.isNil.not:
|
2022-01-24 13:08:33 +00:00
|
|
|
nimbus.engineApiWsServer.stop()
|
2021-09-11 14:58:01 +00:00
|
|
|
if conf.graphqlEnabled:
|
2021-04-24 04:01:09 +00:00
|
|
|
await nimbus.graphqlServer.stop()
|
2021-08-24 07:34:58 +00:00
|
|
|
if conf.engineSigner != ZERO_ADDRESS:
|
|
|
|
await nimbus.sealingEngine.stop()
|
2022-08-26 09:36:04 +00:00
|
|
|
if conf.maxPeers > 0:
|
|
|
|
await nimbus.networkLoop.cancelAndWait()
|
|
|
|
if nimbus.peerManager.isNil.not:
|
|
|
|
await nimbus.peerManager.stop()
|
2023-03-13 18:18:30 +00:00
|
|
|
if nimbus.statelessSyncRef.isNil.not:
|
|
|
|
nimbus.statelessSyncRef.stop()
|
2022-11-14 14:13:00 +00:00
|
|
|
if nimbus.snapSyncRef.isNil.not:
|
|
|
|
nimbus.snapSyncRef.stop()
|
|
|
|
if nimbus.fullSyncRef.isNil.not:
|
|
|
|
nimbus.fullSyncRef.stop()
|
2018-06-20 17:27:32 +00:00
|
|
|
|
2021-09-11 14:58:01 +00:00
|
|
|
proc process*(nimbus: NimbusNode, conf: NimbusConf) =
|
2020-05-21 01:33:11 +00:00
|
|
|
# Main event loop
|
|
|
|
while nimbus.state == Running:
|
|
|
|
try:
|
|
|
|
poll()
|
|
|
|
except CatchableError as e:
|
|
|
|
debug "Exception in poll()", exc = e.name, err = e.msg
|
2020-07-21 08:12:59 +00:00
|
|
|
discard e # silence warning when chronicles not activated
|
2018-06-20 17:27:32 +00:00
|
|
|
|
2019-07-10 21:23:11 +00:00
|
|
|
# Stop loop
|
2021-09-11 14:58:01 +00:00
|
|
|
waitFor nimbus.stop(conf)
|
2018-04-27 08:53:53 +00:00
|
|
|
|
|
|
|
when isMainModule:
|
2021-09-07 13:45:01 +00:00
|
|
|
var nimbus = NimbusNode(state: Starting, ctx: newEthContext())
|
2020-03-25 18:00:04 +00:00
|
|
|
|
|
|
|
## Ctrl+C handling
|
|
|
|
proc controlCHandler() {.noconv.} =
|
|
|
|
when defined(windows):
|
|
|
|
# workaround for https://github.com/nim-lang/Nim/issues/4057
|
|
|
|
setupForeignThreadGc()
|
|
|
|
nimbus.state = Stopping
|
|
|
|
echo "\nCtrl+C pressed. Waiting for a graceful shutdown."
|
|
|
|
setControlCHook(controlCHandler)
|
|
|
|
|
2019-07-10 21:23:11 +00:00
|
|
|
## Show logs on stdout until we get the user's logging choice
|
2019-04-17 01:56:28 +00:00
|
|
|
discard defaultChroniclesStream.output.open(stdout)
|
|
|
|
|
2018-06-20 17:27:32 +00:00
|
|
|
## Processing command line arguments
|
2021-09-11 14:58:01 +00:00
|
|
|
let conf = makeConfig()
|
2019-07-10 21:23:11 +00:00
|
|
|
|
2021-09-11 14:58:01 +00:00
|
|
|
nimbus.start(conf)
|
|
|
|
nimbus.process(conf)
|