nwaku/waku/node/v2/wakunode2.nim

254 lines
8.3 KiB
Nim

import
std/[options, tables],
chronos, chronicles, stew/shims/net as stewNet,
# TODO: Why do we need eth keys?
eth/keys,
libp2p/multiaddress,
libp2p/crypto/crypto,
libp2p/protocols/protocol,
# NOTE For TopicHandler, solve with exports?
libp2p/protocols/pubsub/pubsub,
libp2p/peerinfo,
../../protocol/v2/[waku_relay, waku_store, waku_filter],
./waku_types, ./standard_setup
# Default clientId
const clientId* = "Nimbus Waku v2 node"
# key and crypto modules different
type
KeyPair* = crypto.KeyPair
PublicKey* = crypto.PublicKey
PrivateKey* = crypto.PrivateKey
# TODO Get rid of this and use waku_types one
Topic* = waku_types.Topic
Message* = seq[byte]
HistoryQuery* = object
topics*: seq[string]
HistoryResponse* = object
messages*: seq[Message]
# NOTE Any difference here in Waku vs Eth2?
# E.g. Devp2p/Libp2p support, etc.
#func asLibp2pKey*(key: keys.PublicKey): PublicKey =
# PublicKey(scheme: Secp256k1, skkey: secp.SkPublicKey(key))
func asEthKey*(key: PrivateKey): keys.PrivateKey =
keys.PrivateKey(key.skkey)
proc initAddress(T: type MultiAddress, str: string): T =
let address = MultiAddress.init(str).tryGet()
if IPFS.match(address) and matchPartial(multiaddress.TCP, address):
result = address
else:
raise newException(ValueError,
"Invalid bootstrap node multi-address")
template tcpEndPoint(address, port): auto =
MultiAddress.init(address, tcpProtocol, port)
## Public API
##
proc init*(T: type WakuNode, nodeKey: crypto.PrivateKey,
bindIp: ValidIpAddress, bindPort: Port,
extIp = none[ValidIpAddress](), extPort = none[Port](), topics = newSeq[string]()): T =
## Creates and starts a Waku node.
let
hostAddress = tcpEndPoint(bindIp, bindPort)
announcedAddresses = if extIp.isNone() or extPort.isNone(): @[]
else: @[tcpEndPoint(extIp.get(), extPort.get())]
peerInfo = PeerInfo.init(nodekey)
info "Initializing networking", hostAddress,
announcedAddresses
# XXX: Add this when we create node or start it?
peerInfo.addrs.add(hostAddress)
var switch = newStandardSwitch(some(nodekey), hostAddress, triggerSelf = true)
result = WakuNode(switch: switch, peerInfo: peerInfo)
for topic in topics:
proc handler(topic: string, data: seq[byte]) {.async, gcsafe.} =
debug "Hit handler", topic=topic, data=data
result.subscribe(topic, handler)
proc start*(node: WakuNode) {.async.} =
node.libp2pTransportLoops = await node.switch.start()
# NOTE WakuRelay is being instantiated as part of creating switch with PubSub field set
let storeProto = WakuStore.init()
node.switch.mount(storeProto)
let filterProto = WakuFilter.init()
node.switch.mount(filterProto)
# TODO Get this from WakuNode obj
let peerInfo = node.peerInfo
let id = peerInfo.peerId.pretty
info "PeerInfo", id = id, addrs = peerInfo.addrs
let listenStr = $peerInfo.addrs[0] & "/p2p/" & id
## XXX: this should be /ip4..., / stripped?
info "Listening on", full = listenStr
proc stop*(node: WakuNode) {.async.} =
let wakuRelay = node.switch.pubSub.get()
await wakuRelay.stop()
await node.switch.stop()
proc subscribe*(w: WakuNode, topic: Topic, handler: TopicHandler) =
## Subscribes to a PubSub topic. Triggers handler when receiving messages on
## this topic. TopicHandler is a method that takes a topic and some data.
##
## NOTE The data field SHOULD be decoded as a WakuMessage.
## Status: Implemented.
let wakuRelay = w.switch.pubSub.get()
# XXX Consider awaiting here
discard wakuRelay.subscribe(topic, handler)
proc subscribe*(w: WakuNode, contentFilter: waku_types.ContentFilter, handler: ContentFilterHandler) =
## Subscribes to a ContentFilter. Triggers handler when receiving messages on
## this content filter. ContentFilter is a method that takes some content
## filter, specifically with `ContentTopic`, and a `Message`. The `Message`
## has to match the `ContentTopic`.
# TODO: get some random id, or use the Filter directly as key
w.filters.add("some random id", Filter(contentFilter: contentFilter, handler: handler))
proc unsubscribe*(w: WakuNode, topic: Topic) =
echo "NYI"
## Unsubscribe from a topic.
##
## Status: Not yet implemented.
## TODO Implement.
proc unsubscribe*(w: WakuNode, contentFilter: waku_types.ContentFilter) =
echo "NYI"
## Unsubscribe from a content filter.
##
## Status: Not yet implemented.
## TODO Implement.
proc publish*(node: WakuNode, topic: Topic, message: WakuMessage) =
## Publish a `WakuMessage` to a PubSub topic. `WakuMessage` should contain a
## `contentTopic` field for light node functionality. This field may be also
## be omitted.
##
## Status: Implemented.
##
# TODO Basic getter function for relay
let wakuRelay = cast[WakuRelay](node.switch.pubSub.get())
# XXX Unclear what the purpose of this is
# Commenting out as it is later expected to be Message type, not WakuMessage
#node.messages.insert((topic, message))
debug "publish", topic=topic, contentTopic=message.contentTopic
let data = message.encode().buffer
# XXX Consider awaiting here
discard wakuRelay.publish(topic, data)
proc query*(w: WakuNode, query: HistoryQuery): HistoryResponse =
## Queries for historical messages.
##
## Status: Not yet implemented.
## TODO Implement as wrapper around `waku_store` and send RPC.
result.messages = newSeq[Message]()
for msg in w.messages:
if msg[0] notin query.topics:
continue
# XXX Unclear how this should be hooked up, Message or WakuMessage?
# result.messages.insert(msg[1])
when isMainModule:
import
std/strutils,
confutils, json_rpc/rpcserver, metrics,
./config, ./rpc/wakurpc, ../common
proc dialPeer(n: WakuNode, address: string) {.async.} =
info "dialPeer", address = address
# XXX: This turns ipfs into p2p, not quite sure why
let multiAddr = MultiAddress.initAddress(address)
info "multiAddr", ma = multiAddr
let parts = address.split("/")
let remotePeer = PeerInfo.init(parts[^1], [multiAddr])
info "Dialing peer", multiAddr
# NOTE This is dialing on WakuRelay protocol specifically
# TODO Keep track of conn and connected state somewhere (WakuRelay?)
#p.conn = await p.switch.dial(remotePeer, WakuRelayCodec)
#p.connected = true
discard n.switch.dial(remotePeer, WakuRelayCodec)
info "Post switch dial"
proc connectToNodes(n: WakuNode, nodes: openArray[string]) =
for nodeId in nodes:
info "connectToNodes", node = nodeId
# XXX: This seems...brittle
discard dialPeer(n, nodeId)
# Waku 1
# let whisperENode = ENode.fromString(nodeId).expect("correct node")
# traceAsyncErrors node.peerPool.connectToNode(newNode(whisperENode))
proc startRpc(node: WakuNode, rpcIp: ValidIpAddress, rpcPort: Port) =
let
ta = initTAddress(rpcIp, rpcPort)
rpcServer = newRpcHttpServer([ta])
setupWakuRPC(node, rpcServer)
rpcServer.start()
info "RPC Server started", ta
proc startMetricsServer(serverIp: ValidIpAddress, serverPort: Port) =
info "Starting metrics HTTP server", serverIp, serverPort
metrics.startHttpServer($serverIp, serverPort)
proc startMetricsLog() =
proc logMetrics(udata: pointer) {.closure, gcsafe.} =
{.gcsafe.}:
# TODO: libp2p_pubsub_peers is not public, so we need to make this either
# public in libp2p or do our own peer counting after all.
let
totalMessages = total_messages.value
info "Node metrics", totalMessages
discard setTimer(Moment.fromNow(2.seconds), logMetrics)
discard setTimer(Moment.fromNow(2.seconds), logMetrics)
let
conf = WakuNodeConf.load()
(extIp, extTcpPort, extUdpPort) = setupNat(conf.nat, clientId,
Port(uint16(conf.tcpPort) + conf.portsShift),
Port(uint16(conf.udpPort) + conf.portsShift))
node = WakuNode.init(conf.nodeKey, conf.libp2pAddress,
Port(uint16(conf.tcpPort) + conf.portsShift), extIp, extTcpPort, conf.topics.split(" "))
waitFor node.start()
if conf.staticnodes.len > 0:
connectToNodes(node, conf.staticnodes)
if conf.rpc:
startRpc(node, conf.rpcAddress, Port(conf.rpcPort + conf.portsShift))
if conf.logMetrics:
startMetricsLog()
when defined(insecure):
if conf.metricsServer:
startMetricsServer(conf.metricsServerAddress,
Port(conf.metricsServerPort + conf.portsShift))
runForever()