2022-11-04 09:52:27 +00:00
|
|
|
when (NimMajor, NimMinor) < (1, 4):
|
|
|
|
{.push raises: [Defect].}
|
|
|
|
else:
|
|
|
|
{.push raises: [].}
|
2021-11-01 18:02:39 +00:00
|
|
|
|
|
|
|
import
|
2023-09-26 11:30:55 +00:00
|
|
|
std/[sequtils, strutils, options, sets],
|
2021-11-01 18:02:39 +00:00
|
|
|
stew/results,
|
2023-04-17 13:21:20 +00:00
|
|
|
stew/shims/net,
|
2023-02-06 10:36:37 +00:00
|
|
|
chronos,
|
|
|
|
chronicles,
|
|
|
|
metrics,
|
2023-04-17 13:21:20 +00:00
|
|
|
libp2p/multiaddress,
|
2023-06-06 14:36:20 +00:00
|
|
|
eth/keys as eth_keys,
|
2023-02-06 10:36:37 +00:00
|
|
|
eth/p2p/discoveryv5/node,
|
|
|
|
eth/p2p/discoveryv5/protocol
|
|
|
|
import
|
2023-08-09 17:11:50 +00:00
|
|
|
./node/peer_manager/peer_manager,
|
2023-04-24 14:37:54 +00:00
|
|
|
./waku_core,
|
2023-03-07 09:52:12 +00:00
|
|
|
./waku_enr
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-03-07 09:52:12 +00:00
|
|
|
export protocol, waku_enr
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-03-06 16:18:41 +00:00
|
|
|
|
2021-11-01 18:02:39 +00:00
|
|
|
declarePublicGauge waku_discv5_discovered, "number of nodes discovered"
|
|
|
|
declarePublicGauge waku_discv5_errors, "number of waku discv5 errors", ["type"]
|
|
|
|
|
|
|
|
logScope:
|
2022-11-03 15:36:24 +00:00
|
|
|
topics = "waku discv5"
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-02-06 10:36:37 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
## Config
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
type WakuDiscoveryV5Config* = object
|
|
|
|
discv5Config*: Option[DiscoveryConfig]
|
2023-12-14 06:16:39 +00:00
|
|
|
address*: IpAddress
|
2023-06-06 14:36:20 +00:00
|
|
|
port*: Port
|
|
|
|
privateKey*: eth_keys.PrivateKey
|
|
|
|
bootstrapRecords*: seq[waku_enr.Record]
|
|
|
|
autoupdateRecord*: bool
|
2023-02-06 10:36:37 +00:00
|
|
|
|
2021-11-12 14:10:54 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
## Protocol
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-09-26 11:30:55 +00:00
|
|
|
type WakuDiscv5Predicate* = proc(record: waku_enr.Record): bool {.closure, gcsafe, raises: [].}
|
2023-02-06 10:36:37 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
type WakuDiscoveryV5* = ref object
|
|
|
|
conf: WakuDiscoveryV5Config
|
|
|
|
protocol*: protocol.Protocol
|
|
|
|
listening*: bool
|
2023-08-23 15:50:59 +00:00
|
|
|
predicate: Option[WakuDiscv5Predicate]
|
2023-11-21 20:15:39 +00:00
|
|
|
peerManager: Option[PeerManager]
|
|
|
|
topicSubscriptionQueue: AsyncEventQueue[SubscriptionEvent]
|
2023-08-23 15:50:59 +00:00
|
|
|
|
|
|
|
proc shardingPredicate*(record: Record): Option[WakuDiscv5Predicate] =
|
|
|
|
## Filter peers based on relay sharding information
|
2023-11-06 12:31:36 +00:00
|
|
|
let typedRecord = record.toTyped().valueOr:
|
|
|
|
debug "peer filtering failed", reason=error
|
|
|
|
return none(WakuDiscv5Predicate)
|
2023-08-23 15:50:59 +00:00
|
|
|
|
2023-11-06 12:31:36 +00:00
|
|
|
let nodeShard = typedRecord.relaySharding().valueOr:
|
|
|
|
debug "no relay sharding information, peer filtering disabled"
|
|
|
|
return none(WakuDiscv5Predicate)
|
|
|
|
|
2023-08-23 15:50:59 +00:00
|
|
|
debug "peer filtering updated"
|
|
|
|
|
|
|
|
let predicate = proc(record: waku_enr.Record): bool =
|
2023-11-06 12:31:36 +00:00
|
|
|
record.getCapabilities().len > 0 and #RFC 31 requirement
|
|
|
|
nodeShard.shardIds.anyIt(record.containsShard(nodeShard.clusterId, it)) #RFC 64 guideline
|
2023-08-23 15:50:59 +00:00
|
|
|
|
|
|
|
return some(predicate)
|
2021-11-12 14:10:54 +00:00
|
|
|
|
2023-09-26 11:30:55 +00:00
|
|
|
proc new*(
|
|
|
|
T: type WakuDiscoveryV5,
|
|
|
|
rng: ref HmacDrbgContext,
|
|
|
|
conf: WakuDiscoveryV5Config,
|
2023-11-21 20:15:39 +00:00
|
|
|
record: Option[waku_enr.Record],
|
|
|
|
peerManager: Option[PeerManager] = none(PeerManager),
|
|
|
|
queue: AsyncEventQueue[SubscriptionEvent] = newAsyncEventQueue[SubscriptionEvent](30),
|
2023-09-26 11:30:55 +00:00
|
|
|
): T =
|
|
|
|
let shardPredOp =
|
|
|
|
if record.isSome(): shardingPredicate(record.get())
|
|
|
|
else: none(WakuDiscv5Predicate)
|
|
|
|
|
|
|
|
var bootstrapRecords = conf.bootstrapRecords
|
|
|
|
|
|
|
|
# Remove bootstrap nodes with which we don't share shards.
|
|
|
|
if shardPredOp.isSome():
|
|
|
|
bootstrapRecords.keepIf(shardPredOp.get())
|
|
|
|
|
|
|
|
if conf.bootstrapRecords.len > 0 and bootstrapRecords.len == 0:
|
|
|
|
warn "No discv5 bootstrap nodes share this node configured shards"
|
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
let protocol = newProtocol(
|
|
|
|
rng = rng,
|
|
|
|
config = conf.discv5Config.get(protocol.defaultDiscoveryConfig),
|
|
|
|
bindPort = conf.port,
|
|
|
|
bindIp = conf.address,
|
|
|
|
privKey = conf.privateKey,
|
2023-09-26 11:30:55 +00:00
|
|
|
bootstrapRecords = bootstrapRecords,
|
2023-06-06 14:36:20 +00:00
|
|
|
enrAutoUpdate = conf.autoupdateRecord,
|
|
|
|
previousRecord = record,
|
2023-12-14 06:16:39 +00:00
|
|
|
enrIp = none(IpAddress),
|
2023-06-06 14:36:20 +00:00
|
|
|
enrTcpPort = none(Port),
|
|
|
|
enrUdpPort = none(Port),
|
|
|
|
)
|
2021-11-12 14:10:54 +00:00
|
|
|
|
2023-11-21 20:15:39 +00:00
|
|
|
WakuDiscoveryV5(
|
|
|
|
conf: conf,
|
|
|
|
protocol: protocol,
|
|
|
|
listening: false,
|
|
|
|
predicate: shardPredOp,
|
|
|
|
peerManager: peerManager,
|
|
|
|
topicSubscriptionQueue: queue,
|
|
|
|
)
|
2023-06-06 14:36:20 +00:00
|
|
|
|
2023-08-23 13:53:17 +00:00
|
|
|
proc updateENRShards(wd: WakuDiscoveryV5,
|
|
|
|
newTopics: seq[PubsubTopic], add: bool): Result[void, string] =
|
|
|
|
## Add or remove shards from the Discv5 ENR
|
2023-11-21 20:15:39 +00:00
|
|
|
let newShardOp = topicsToRelayShards(newTopics).valueOr:
|
|
|
|
return err("ENR update failed: " & error)
|
|
|
|
|
|
|
|
let newShard = newShardOp.valueOr:
|
|
|
|
return ok()
|
2023-08-23 13:53:17 +00:00
|
|
|
|
2023-11-21 20:15:39 +00:00
|
|
|
let typedRecord = wd.protocol.localNode.record.toTyped().valueOr:
|
|
|
|
return err("ENR update failed: " & $error)
|
2023-08-23 13:53:17 +00:00
|
|
|
|
|
|
|
let currentShardsOp = typedRecord.relaySharding()
|
|
|
|
|
|
|
|
let resultShard =
|
|
|
|
if add and currentShardsOp.isSome():
|
|
|
|
let currentShard = currentShardsOp.get()
|
|
|
|
|
2023-10-05 12:37:05 +00:00
|
|
|
if currentShard.clusterId != newShard.clusterId:
|
2023-11-21 20:15:39 +00:00
|
|
|
return err("ENR update failed: clusterId id mismatch")
|
|
|
|
|
|
|
|
RelayShards.init(currentShard.clusterId, currentShard.shardIds & newShard.shardIds).valueOr:
|
|
|
|
return err("ENR update failed: " & error)
|
2023-08-23 13:53:17 +00:00
|
|
|
|
|
|
|
elif not add and currentShardsOp.isSome():
|
|
|
|
let currentShard = currentShardsOp.get()
|
|
|
|
|
2023-10-05 12:37:05 +00:00
|
|
|
if currentShard.clusterId != newShard.clusterId:
|
2023-11-21 20:15:39 +00:00
|
|
|
return err("ENR update failed: clusterId id mismatch")
|
2023-08-23 13:53:17 +00:00
|
|
|
|
2023-10-05 12:37:05 +00:00
|
|
|
let currentSet = toHashSet(currentShard.shardIds)
|
|
|
|
let newSet = toHashSet(newShard.shardIds)
|
2023-08-23 13:53:17 +00:00
|
|
|
|
|
|
|
let indices = toSeq(currentSet - newSet)
|
|
|
|
|
|
|
|
if indices.len == 0:
|
2023-11-21 20:15:39 +00:00
|
|
|
return err("ENR update failed: cannot remove all shards")
|
2023-08-23 13:53:17 +00:00
|
|
|
|
2023-11-21 20:15:39 +00:00
|
|
|
RelayShards.init(currentShard.clusterId, indices).valueOr:
|
|
|
|
return err("ENR update failed: " & error)
|
2023-08-23 13:53:17 +00:00
|
|
|
|
|
|
|
elif add and currentShardsOp.isNone(): newShard
|
|
|
|
else: return ok()
|
|
|
|
|
|
|
|
let (field, value) =
|
2023-10-05 12:37:05 +00:00
|
|
|
if resultShard.shardIds.len >= ShardingIndicesListMaxLength:
|
2023-08-23 13:53:17 +00:00
|
|
|
(ShardingBitVectorEnrField, resultShard.toBitVector())
|
|
|
|
else:
|
2023-11-21 20:15:39 +00:00
|
|
|
let list = resultShard.toIndicesList().valueOr:
|
|
|
|
return err("ENR update failed: " & $error)
|
2023-08-23 13:53:17 +00:00
|
|
|
|
|
|
|
(ShardingIndicesListEnrField, list)
|
|
|
|
|
2023-11-21 20:15:39 +00:00
|
|
|
wd.protocol.updateRecord([(field, value)]).isOkOr:
|
|
|
|
return err("ENR update failed: " & $error)
|
2023-08-23 13:53:17 +00:00
|
|
|
|
|
|
|
return ok()
|
|
|
|
|
2023-08-23 15:50:59 +00:00
|
|
|
proc findRandomPeers*(wd: WakuDiscoveryV5, overridePred = none(WakuDiscv5Predicate)): Future[seq[waku_enr.Record]] {.async.} =
|
2023-03-30 07:35:13 +00:00
|
|
|
## Find random peers to connect to using Discovery v5
|
|
|
|
let discoveredNodes = await wd.protocol.queryRandom()
|
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
var discoveredRecords = discoveredNodes.mapIt(it.record)
|
|
|
|
|
|
|
|
# Filter out nodes that do not match the predicate
|
2023-08-23 15:50:59 +00:00
|
|
|
if overridePred.isSome():
|
|
|
|
discoveredRecords = discoveredRecords.filter(overridePred.get())
|
|
|
|
elif wd.predicate.isSome():
|
|
|
|
discoveredRecords = discoveredRecords.filter(wd.predicate.get())
|
2023-06-06 14:36:20 +00:00
|
|
|
|
|
|
|
return discoveredRecords
|
|
|
|
|
2023-11-21 20:15:39 +00:00
|
|
|
proc searchLoop(wd: WakuDiscoveryV5) {.async.} =
|
2023-06-27 13:50:11 +00:00
|
|
|
## Continuously add newly discovered nodes
|
|
|
|
|
2023-11-21 20:15:39 +00:00
|
|
|
let peerManager = wd.peerManager.valueOr:
|
|
|
|
return
|
|
|
|
|
2023-06-27 13:50:11 +00:00
|
|
|
info "Starting discovery v5 search"
|
|
|
|
|
|
|
|
while wd.listening:
|
|
|
|
trace "running discv5 discovery loop"
|
2023-08-23 15:50:59 +00:00
|
|
|
let discoveredRecords = await wd.findRandomPeers()
|
2023-06-27 13:50:11 +00:00
|
|
|
let discoveredPeers = discoveredRecords.mapIt(it.toRemotePeerInfo()).filterIt(it.isOk()).mapIt(it.value)
|
|
|
|
|
|
|
|
for peer in discoveredPeers:
|
|
|
|
# Peers added are filtered by the peer manager
|
|
|
|
peerManager.addPeer(peer, PeerOrigin.Discv5)
|
|
|
|
|
|
|
|
# Discovery `queryRandom` can have a synchronous fast path for example
|
|
|
|
# when no peers are in the routing table. Don't run it in continuous loop.
|
|
|
|
#
|
|
|
|
# Also, give some time to dial the discovered nodes and update stats, etc.
|
|
|
|
await sleepAsync(5.seconds)
|
|
|
|
|
2023-11-21 20:15:39 +00:00
|
|
|
proc subscriptionsListener(wd: WakuDiscoveryV5) {.async.} =
|
|
|
|
## Listen for pubsub topics subscriptions changes
|
|
|
|
|
|
|
|
let key = wd.topicSubscriptionQueue.register()
|
|
|
|
|
|
|
|
while wd.listening:
|
|
|
|
let events = await wd.topicSubscriptionQueue.waitEvents(key)
|
|
|
|
|
|
|
|
# Since we don't know the events we will receive we have to anticipate.
|
|
|
|
|
|
|
|
let subs = events.filterIt(it.kind == PubsubSub).mapIt(it.topic)
|
|
|
|
let unsubs = events.filterIt(it.kind == PubsubUnsub).mapIt(it.topic)
|
|
|
|
|
|
|
|
if subs.len == 0 and unsubs.len == 0:
|
|
|
|
continue
|
|
|
|
|
|
|
|
let unsubRes = wd.updateENRShards(unsubs, false)
|
|
|
|
let subRes = wd.updateENRShards(subs, true)
|
|
|
|
|
|
|
|
if subRes.isErr():
|
|
|
|
debug "ENR shard addition failed", reason= $subRes.error
|
|
|
|
|
|
|
|
if unsubRes.isErr():
|
|
|
|
debug "ENR shard removal failed", reason= $unsubRes.error
|
|
|
|
|
|
|
|
if subRes.isErr() and unsubRes.isErr():
|
|
|
|
continue
|
|
|
|
|
|
|
|
debug "ENR updated successfully"
|
|
|
|
|
|
|
|
wd.predicate = shardingPredicate(wd.protocol.localNode.record)
|
|
|
|
|
|
|
|
wd.topicSubscriptionQueue.unregister(key)
|
|
|
|
|
|
|
|
proc start*(wd: WakuDiscoveryV5): Future[Result[void, string]] {.async.} =
|
2023-06-27 13:50:11 +00:00
|
|
|
if wd.listening:
|
|
|
|
return err("already listening")
|
|
|
|
|
|
|
|
info "Starting discovery v5 service"
|
|
|
|
|
|
|
|
debug "start listening on udp port", address = $wd.conf.address, port = $wd.conf.port
|
|
|
|
try:
|
|
|
|
wd.protocol.open()
|
|
|
|
except CatchableError:
|
|
|
|
return err("failed to open udp port: " & getCurrentExceptionMsg())
|
|
|
|
|
|
|
|
wd.listening = true
|
|
|
|
|
|
|
|
trace "start discv5 service"
|
|
|
|
wd.protocol.start()
|
|
|
|
|
2023-11-21 20:15:39 +00:00
|
|
|
asyncSpawn wd.searchLoop()
|
|
|
|
asyncSpawn wd.subscriptionsListener()
|
|
|
|
|
2023-06-27 13:50:11 +00:00
|
|
|
debug "Successfully started discovery v5 service"
|
|
|
|
info "Discv5: discoverable ENR ", enr = wd.protocol.localNode.record.toUri()
|
|
|
|
|
2023-06-27 19:16:59 +00:00
|
|
|
ok()
|
|
|
|
|
2023-06-27 13:50:11 +00:00
|
|
|
proc stop*(wd: WakuDiscoveryV5): Future[void] {.async.} =
|
|
|
|
if not wd.listening:
|
|
|
|
return
|
|
|
|
|
|
|
|
info "Stopping discovery v5 service"
|
|
|
|
|
|
|
|
wd.listening = false
|
|
|
|
trace "Stop listening on discv5 port"
|
|
|
|
await wd.protocol.closeWait()
|
|
|
|
|
|
|
|
debug "Successfully stopped discovery v5 service"
|
2023-06-06 14:36:20 +00:00
|
|
|
|
|
|
|
## Helper functions
|
|
|
|
|
|
|
|
proc parseBootstrapAddress(address: string): Result[enr.Record, cstring] =
|
|
|
|
logScope:
|
|
|
|
address = address
|
|
|
|
|
|
|
|
if address[0] == '/':
|
|
|
|
return err("MultiAddress bootstrap addresses are not supported")
|
|
|
|
|
|
|
|
let lowerCaseAddress = toLowerAscii(address)
|
|
|
|
if lowerCaseAddress.startsWith("enr:"):
|
|
|
|
var enrRec: enr.Record
|
|
|
|
if not enrRec.fromURI(address):
|
|
|
|
return err("Invalid ENR bootstrap record")
|
|
|
|
|
|
|
|
return ok(enrRec)
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
elif lowerCaseAddress.startsWith("enode:"):
|
|
|
|
return err("ENode bootstrap addresses are not supported")
|
2023-03-30 07:35:13 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
else:
|
|
|
|
return err("Ignoring unrecognized bootstrap address type")
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
proc addBootstrapNode*(bootstrapAddr: string,
|
|
|
|
bootstrapEnrs: var seq[enr.Record]) =
|
|
|
|
# Ignore empty lines or lines starting with #
|
|
|
|
if bootstrapAddr.len == 0 or bootstrapAddr[0] == '#':
|
|
|
|
return
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
let enrRes = parseBootstrapAddress(bootstrapAddr)
|
|
|
|
if enrRes.isErr():
|
|
|
|
debug "ignoring invalid bootstrap address", reason = enrRes.error
|
|
|
|
return
|
2021-11-01 18:02:39 +00:00
|
|
|
|
2023-06-06 14:36:20 +00:00
|
|
|
bootstrapEnrs.add(enrRes.value)
|