2019-02-05 15:40:29 +00:00
|
|
|
import
|
|
|
|
macros, tables, algorithm, deques, hashes, options, typetraits,
|
2019-04-05 08:13:22 +00:00
|
|
|
std_shims/macros_shim, chronicles, nimcrypto, chronos, eth/[rlp, common, keys, async_utils],
|
2019-05-19 18:05:02 +00:00
|
|
|
private/p2p_types, kademlia, auth, rlpxcrypt, enode, p2p_protocol_dsl
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
when useSnappy:
|
|
|
|
import snappy
|
|
|
|
const devp2pSnappyVersion* = 5
|
|
|
|
|
2019-05-19 18:05:02 +00:00
|
|
|
export
|
|
|
|
p2pProtocol
|
|
|
|
|
2019-02-05 15:40:29 +00:00
|
|
|
logScope:
|
|
|
|
topics = "rlpx"
|
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
type
|
|
|
|
ResponderWithId*[MsgType] = object
|
|
|
|
peer*: Peer
|
|
|
|
reqId*: int
|
|
|
|
|
|
|
|
ResponderWithoutId*[MsgType] = distinct Peer
|
|
|
|
|
2019-02-05 15:40:29 +00:00
|
|
|
const
|
|
|
|
devp2pVersion* = 4
|
|
|
|
maxMsgSize = 1024 * 1024
|
2019-05-29 15:52:28 +00:00
|
|
|
HandshakeTimeout = BreachOfProtocol
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-03-11 09:22:06 +00:00
|
|
|
include p2p_tracing
|
|
|
|
|
2019-02-05 15:40:29 +00:00
|
|
|
when tracingEnabled:
|
|
|
|
import
|
|
|
|
eth/common/eth_types_json_serialization
|
|
|
|
|
|
|
|
export
|
|
|
|
# XXX: This is a work-around for a Nim issue.
|
|
|
|
# See a more detailed comment in p2p_tracing.nim
|
|
|
|
init, writeValue, getOutput
|
|
|
|
|
|
|
|
var
|
|
|
|
gProtocols: seq[ProtocolInfo]
|
|
|
|
gDevp2pInfo: ProtocolInfo
|
|
|
|
|
|
|
|
# The variables above are immutable RTTI information. We need to tell
|
|
|
|
# Nim to not consider them GcSafe violations:
|
|
|
|
template allProtocols*: auto = {.gcsafe.}: gProtocols
|
|
|
|
template devp2pInfo: auto = {.gcsafe.}: gDevp2pInfo
|
|
|
|
|
2019-03-24 23:36:40 +00:00
|
|
|
chronicles.formatIt(Peer): $(it.remote)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-03-26 13:07:50 +00:00
|
|
|
proc disconnect*(peer: Peer, reason: DisconnectionReason, notifyOtherPeer = false) {.gcsafe, async.}
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
template raisePeerDisconnected(msg: string, r: DisconnectionReason) =
|
|
|
|
var e = newException(PeerDisconnected, msg)
|
|
|
|
e.reason = r
|
|
|
|
raise e
|
|
|
|
|
|
|
|
proc disconnectAndRaise(peer: Peer,
|
|
|
|
reason: DisconnectionReason,
|
|
|
|
msg: string) {.async.} =
|
|
|
|
let r = reason
|
|
|
|
await peer.disconnect(r)
|
|
|
|
raisePeerDisconnected(msg, r)
|
|
|
|
|
2019-05-29 08:16:59 +00:00
|
|
|
include p2p_backends_helpers
|
|
|
|
|
2019-02-05 15:40:29 +00:00
|
|
|
# Dispatcher
|
|
|
|
#
|
|
|
|
|
|
|
|
proc hash(d: Dispatcher): int =
|
|
|
|
hash(d.protocolOffsets)
|
|
|
|
|
|
|
|
proc `==`(lhs, rhs: Dispatcher): bool =
|
|
|
|
lhs.activeProtocols == rhs.activeProtocols
|
|
|
|
|
|
|
|
proc describeProtocols(d: Dispatcher): string =
|
|
|
|
result = ""
|
|
|
|
for protocol in d.activeProtocols:
|
|
|
|
if result.len != 0: result.add(',')
|
|
|
|
for c in protocol.name: result.add(c)
|
|
|
|
|
|
|
|
proc numProtocols(d: Dispatcher): int =
|
|
|
|
d.activeProtocols.len
|
|
|
|
|
|
|
|
proc getDispatcher(node: EthereumNode,
|
|
|
|
otherPeerCapabilities: openarray[Capability]): Dispatcher =
|
|
|
|
# TODO: sub-optimal solution until progress is made here:
|
|
|
|
# https://github.com/nim-lang/Nim/issues/7457
|
|
|
|
# We should be able to find an existing dispatcher without allocating a new one
|
|
|
|
|
|
|
|
new result
|
|
|
|
newSeq(result.protocolOffsets, allProtocols.len)
|
|
|
|
result.protocolOffsets.fill -1
|
|
|
|
|
|
|
|
var nextUserMsgId = 0x10
|
|
|
|
|
|
|
|
for localProtocol in node.protocols:
|
|
|
|
let idx = localProtocol.index
|
|
|
|
block findMatchingProtocol:
|
|
|
|
for remoteCapability in otherPeerCapabilities:
|
|
|
|
if localProtocol.name == remoteCapability.name and
|
|
|
|
localProtocol.version == remoteCapability.version:
|
|
|
|
result.protocolOffsets[idx] = nextUserMsgId
|
|
|
|
nextUserMsgId += localProtocol.messages.len
|
|
|
|
break findMatchingProtocol
|
|
|
|
|
|
|
|
template copyTo(src, dest; index: int) =
|
|
|
|
for i in 0 ..< src.len:
|
|
|
|
dest[index + i] = addr src[i]
|
|
|
|
|
|
|
|
result.messages = newSeq[ptr MessageInfo](nextUserMsgId)
|
|
|
|
devp2pInfo.messages.copyTo(result.messages, 0)
|
|
|
|
|
|
|
|
for localProtocol in node.protocols:
|
|
|
|
let idx = localProtocol.index
|
|
|
|
if result.protocolOffsets[idx] != -1:
|
|
|
|
result.activeProtocols.add localProtocol
|
|
|
|
localProtocol.messages.copyTo(result.messages,
|
|
|
|
result.protocolOffsets[idx])
|
|
|
|
|
|
|
|
proc getMsgName*(peer: Peer, msgId: int): string =
|
|
|
|
if not peer.dispatcher.isNil and
|
|
|
|
msgId < peer.dispatcher.messages.len:
|
|
|
|
return peer.dispatcher.messages[msgId].name
|
|
|
|
else:
|
|
|
|
return case msgId
|
|
|
|
of 0: "hello"
|
|
|
|
of 1: "disconnect"
|
|
|
|
of 2: "ping"
|
|
|
|
of 3: "pong"
|
|
|
|
else: $msgId
|
|
|
|
|
|
|
|
proc getMsgMetadata*(peer: Peer, msgId: int): (ProtocolInfo, ptr MessageInfo) =
|
|
|
|
doAssert msgId >= 0
|
|
|
|
|
|
|
|
if msgId <= devp2pInfo.messages[^1].id:
|
|
|
|
return (devp2pInfo, addr devp2pInfo.messages[msgId])
|
|
|
|
|
|
|
|
if msgId < peer.dispatcher.messages.len:
|
|
|
|
for i in 0 ..< allProtocols.len:
|
|
|
|
let offset = peer.dispatcher.protocolOffsets[i]
|
|
|
|
if offset != -1 and
|
|
|
|
offset + allProtocols[i].messages[^1].id >= msgId:
|
|
|
|
return (allProtocols[i], peer.dispatcher.messages[msgId])
|
|
|
|
|
|
|
|
# Protocol info objects
|
|
|
|
#
|
|
|
|
|
|
|
|
proc initProtocol(name: string, version: int,
|
|
|
|
peerInit: PeerStateInitializer,
|
|
|
|
networkInit: NetworkStateInitializer): ProtocolInfoObj =
|
|
|
|
result.name = name
|
|
|
|
result.version = version
|
|
|
|
result.messages = @[]
|
|
|
|
result.peerStateInitializer = peerInit
|
|
|
|
result.networkStateInitializer = networkInit
|
|
|
|
|
|
|
|
proc setEventHandlers(p: ProtocolInfo,
|
|
|
|
handshake: HandshakeStep,
|
|
|
|
disconnectHandler: DisconnectionHandler) =
|
|
|
|
p.handshake = handshake
|
|
|
|
p.disconnectHandler = disconnectHandler
|
|
|
|
|
|
|
|
func asCapability*(p: ProtocolInfo): Capability =
|
|
|
|
result.name = p.name
|
|
|
|
result.version = p.version
|
|
|
|
|
|
|
|
func nameStr*(p: ProtocolInfo): string =
|
|
|
|
result = newStringOfCap(3)
|
|
|
|
for c in p.name: result.add(c)
|
|
|
|
|
|
|
|
# XXX: this used to be inline, but inline procs
|
|
|
|
# cannot be passed to closure params
|
|
|
|
proc cmp*(lhs, rhs: ProtocolInfo): int =
|
|
|
|
for i in 0..2:
|
|
|
|
if lhs.name[i] != rhs.name[i]:
|
|
|
|
return int16(lhs.name[i]) - int16(rhs.name[i])
|
|
|
|
return 0
|
|
|
|
|
|
|
|
proc nextMsgResolver[MsgType](msgData: Rlp, future: FutureBase) {.gcsafe.} =
|
|
|
|
var reader = msgData
|
|
|
|
Future[MsgType](future).complete reader.readRecordType(MsgType, MsgType.rlpFieldsCount > 1)
|
|
|
|
|
|
|
|
proc registerMsg(protocol: ProtocolInfo,
|
|
|
|
id: int, name: string,
|
2019-05-29 08:16:59 +00:00
|
|
|
thunk: ThunkProc,
|
2019-02-05 15:40:29 +00:00
|
|
|
printer: MessageContentPrinter,
|
|
|
|
requestResolver: RequestResolver,
|
|
|
|
nextMsgResolver: NextMsgResolver) =
|
|
|
|
if protocol.messages.len <= id:
|
|
|
|
protocol.messages.setLen(id + 1)
|
|
|
|
protocol.messages[id] = MessageInfo(id: id,
|
|
|
|
name: name,
|
|
|
|
thunk: thunk,
|
|
|
|
printer: printer,
|
|
|
|
requestResolver: requestResolver,
|
|
|
|
nextMsgResolver: nextMsgResolver)
|
|
|
|
|
|
|
|
proc registerProtocol(protocol: ProtocolInfo) =
|
|
|
|
# TODO: This can be done at compile-time in the future
|
|
|
|
if protocol.version > 0:
|
|
|
|
let pos = lowerBound(gProtocols, protocol)
|
|
|
|
gProtocols.insert(protocol, pos)
|
|
|
|
for i in 0 ..< gProtocols.len:
|
|
|
|
gProtocols[i].index = i
|
|
|
|
else:
|
|
|
|
gDevp2pInfo = protocol
|
|
|
|
|
|
|
|
# Message composition and encryption
|
|
|
|
#
|
|
|
|
|
|
|
|
proc perPeerMsgIdImpl(peer: Peer, proto: ProtocolInfo, msgId: int): int {.inline.} =
|
|
|
|
result = msgId
|
|
|
|
if not peer.dispatcher.isNil:
|
|
|
|
result += peer.dispatcher.protocolOffsets[proto.index]
|
|
|
|
|
2019-03-11 09:22:06 +00:00
|
|
|
template getPeer(peer: Peer): auto = peer
|
2019-05-30 15:11:23 +00:00
|
|
|
template getPeer(responder: ResponderWithId): auto = responder.peer
|
|
|
|
template getPeer(responder: ResponderWithoutId): auto = Peer(responder)
|
2019-03-11 09:22:06 +00:00
|
|
|
|
2019-04-18 12:22:45 +00:00
|
|
|
proc supports*(peer: Peer, proto: ProtocolInfo): bool {.inline.} =
|
|
|
|
peer.dispatcher.protocolOffsets[proto.index] != -1
|
|
|
|
|
2019-02-05 15:40:29 +00:00
|
|
|
proc supports*(peer: Peer, Protocol: type): bool {.inline.} =
|
|
|
|
## Checks whether a Peer supports a particular protocol
|
2019-04-18 12:22:45 +00:00
|
|
|
peer.supports(Protocol.protocolInfo)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
template perPeerMsgId(peer: Peer, MsgType: type): int =
|
|
|
|
perPeerMsgIdImpl(peer, MsgType.msgProtocol.protocolInfo, MsgType.msgId)
|
|
|
|
|
|
|
|
proc invokeThunk*(peer: Peer, msgId: int, msgData: var Rlp): Future[void] =
|
|
|
|
template invalidIdError: untyped =
|
2019-04-26 13:36:54 +00:00
|
|
|
raise newException(UnsupportedMessageError,
|
2019-02-05 15:40:29 +00:00
|
|
|
"RLPx message with an invalid id " & $msgId &
|
|
|
|
" on a connection supporting " & peer.dispatcher.describeProtocols)
|
|
|
|
|
|
|
|
if msgId >= peer.dispatcher.messages.len: invalidIdError()
|
|
|
|
let thunk = peer.dispatcher.messages[msgId].thunk
|
|
|
|
if thunk == nil: invalidIdError()
|
|
|
|
|
|
|
|
return thunk(peer, msgId, msgData)
|
|
|
|
|
|
|
|
template compressMsg(peer: Peer, data: Bytes): Bytes =
|
|
|
|
when useSnappy:
|
|
|
|
if peer.snappyEnabled:
|
|
|
|
snappy.compress(data)
|
|
|
|
else: data
|
|
|
|
else:
|
|
|
|
data
|
|
|
|
|
|
|
|
proc sendMsg*(peer: Peer, data: Bytes) {.gcsafe, async.} =
|
|
|
|
try:
|
2019-03-26 13:07:50 +00:00
|
|
|
var cipherText = encryptMsg(peer.compressMsg(data), peer.secretsState)
|
2019-05-29 12:53:27 +00:00
|
|
|
var res = await peer.transport.write(cipherText)
|
|
|
|
if res != len(cipherText):
|
|
|
|
# This is ECONNRESET or EPIPE case when remote peer disconnected.
|
|
|
|
await peer.disconnect(TcpError)
|
2019-02-05 15:40:29 +00:00
|
|
|
except:
|
|
|
|
await peer.disconnect(TcpError)
|
|
|
|
raise
|
|
|
|
|
|
|
|
proc send*[Msg](peer: Peer, msg: Msg): Future[void] =
|
|
|
|
logSentMsg(peer, msg)
|
|
|
|
|
|
|
|
var rlpWriter = initRlpWriter()
|
|
|
|
rlpWriter.append perPeerMsgId(peer, Msg)
|
|
|
|
rlpWriter.appendRecordType(msg, Msg.rlpFieldsCount > 1)
|
|
|
|
peer.sendMsg rlpWriter.finish
|
|
|
|
|
2019-05-19 18:05:02 +00:00
|
|
|
proc registerRequest(peer: Peer,
|
|
|
|
timeout: Duration,
|
|
|
|
responseFuture: FutureBase,
|
|
|
|
responseMsgId: int): int =
|
2019-02-05 15:40:29 +00:00
|
|
|
inc peer.lastReqId
|
|
|
|
result = peer.lastReqId
|
|
|
|
|
2019-03-25 17:32:18 +00:00
|
|
|
let timeoutAt = Moment.fromNow(timeout)
|
2019-02-05 15:40:29 +00:00
|
|
|
let req = OutstandingRequest(id: result,
|
|
|
|
future: responseFuture,
|
|
|
|
timeoutAt: timeoutAt)
|
|
|
|
peer.outstandingRequests[responseMsgId].addLast req
|
|
|
|
|
2019-03-13 22:15:26 +00:00
|
|
|
doAssert(not peer.dispatcher.isNil)
|
2019-02-05 15:40:29 +00:00
|
|
|
let requestResolver = peer.dispatcher.messages[responseMsgId].requestResolver
|
|
|
|
proc timeoutExpired(udata: pointer) = requestResolver(nil, responseFuture)
|
|
|
|
|
|
|
|
addTimer(timeoutAt, timeoutExpired, nil)
|
|
|
|
|
|
|
|
proc resolveResponseFuture(peer: Peer, msgId: int, msg: pointer, reqId: int) =
|
|
|
|
logScope:
|
|
|
|
msg = peer.dispatcher.messages[msgId].name
|
|
|
|
msgContents = peer.dispatcher.messages[msgId].printer(msg)
|
|
|
|
receivedReqId = reqId
|
|
|
|
remotePeer = peer.remote
|
|
|
|
|
|
|
|
template resolve(future) =
|
|
|
|
(peer.dispatcher.messages[msgId].requestResolver)(msg, future)
|
|
|
|
|
|
|
|
template outstandingReqs: auto =
|
|
|
|
peer.outstandingRequests[msgId]
|
|
|
|
|
|
|
|
if reqId == -1:
|
|
|
|
# XXX: This is a response from an ETH-like protocol that doesn't feature
|
|
|
|
# request IDs. Handling the response is quite tricky here because this may
|
|
|
|
# be a late response to an already timed out request or a valid response
|
|
|
|
# from a more recent one.
|
|
|
|
#
|
|
|
|
# We can increase the robustness by recording enough features of the
|
|
|
|
# request so we can recognize the matching response, but this is not very
|
|
|
|
# easy to do because our peers are allowed to send partial responses.
|
|
|
|
#
|
|
|
|
# A more generally robust approach is to maintain a set of the wanted
|
|
|
|
# data items and then to periodically look for items that have been
|
|
|
|
# requested long time ago, but are still missing. New requests can be
|
|
|
|
# issues for such items potentially from another random peer.
|
|
|
|
var expiredRequests = 0
|
|
|
|
for req in outstandingReqs:
|
|
|
|
if not req.future.finished: break
|
|
|
|
inc expiredRequests
|
|
|
|
outstandingReqs.shrink(fromFirst = expiredRequests)
|
|
|
|
if outstandingReqs.len > 0:
|
|
|
|
let oldestReq = outstandingReqs.popFirst
|
|
|
|
resolve oldestReq.future
|
|
|
|
else:
|
|
|
|
trace "late or duplicate reply for a RLPx request"
|
|
|
|
else:
|
|
|
|
# TODO: This is not completely sound because we are still using a global
|
|
|
|
# `reqId` sequence (the problem is that we might get a response ID that
|
|
|
|
# matches a request ID for a different type of request). To make the code
|
|
|
|
# correct, we can use a separate sequence per response type, but we have
|
|
|
|
# to first verify that the other Ethereum clients are supporting this
|
|
|
|
# correctly (because then, we'll be reusing the same reqIds for different
|
|
|
|
# types of requests). Alternatively, we can assign a separate interval in
|
|
|
|
# the `reqId` space for each type of response.
|
|
|
|
if reqId > peer.lastReqId:
|
|
|
|
warn "RLPx response without a matching request"
|
|
|
|
return
|
|
|
|
|
|
|
|
var idx = 0
|
|
|
|
while idx < outstandingReqs.len:
|
|
|
|
template req: auto = outstandingReqs()[idx]
|
|
|
|
|
|
|
|
if req.future.finished:
|
2019-03-25 17:32:18 +00:00
|
|
|
doAssert req.timeoutAt <= Moment.now()
|
2019-02-05 15:40:29 +00:00
|
|
|
# Here we'll remove the expired request by swapping
|
|
|
|
# it with the last one in the deque (if necessary):
|
|
|
|
if idx != outstandingReqs.len - 1:
|
|
|
|
req = outstandingReqs.popLast
|
|
|
|
continue
|
|
|
|
else:
|
|
|
|
outstandingReqs.shrink(fromLast = 1)
|
|
|
|
# This was the last item, so we don't have any
|
|
|
|
# more work to do:
|
|
|
|
return
|
|
|
|
|
|
|
|
if req.id == reqId:
|
|
|
|
resolve req.future
|
|
|
|
# Here we'll remove the found request by swapping
|
|
|
|
# it with the last one in the deque (if necessary):
|
|
|
|
if idx != outstandingReqs.len - 1:
|
|
|
|
req = outstandingReqs.popLast
|
|
|
|
else:
|
|
|
|
outstandingReqs.shrink(fromLast = 1)
|
|
|
|
return
|
|
|
|
|
|
|
|
inc idx
|
|
|
|
|
|
|
|
debug "late or duplicate reply for a RLPx request"
|
|
|
|
|
|
|
|
proc recvMsg*(peer: Peer): Future[tuple[msgId: int, msgData: Rlp]] {.async.} =
|
|
|
|
## This procs awaits the next complete RLPx message in the TCP stream
|
|
|
|
|
|
|
|
var headerBytes: array[32, byte]
|
|
|
|
await peer.transport.readExactly(addr headerBytes[0], 32)
|
|
|
|
|
|
|
|
var msgSize: int
|
|
|
|
if decryptHeaderAndGetMsgSize(peer.secretsState,
|
|
|
|
headerBytes, msgSize) != RlpxStatus.Success:
|
|
|
|
await peer.disconnectAndRaise(BreachOfProtocol,
|
|
|
|
"Cannot decrypt RLPx frame header")
|
|
|
|
|
|
|
|
if msgSize > maxMsgSize:
|
|
|
|
await peer.disconnectAndRaise(BreachOfProtocol,
|
|
|
|
"RLPx message exceeds maximum size")
|
|
|
|
|
|
|
|
let remainingBytes = encryptedLength(msgSize) - 32
|
|
|
|
# TODO: Migrate this to a thread-local seq
|
|
|
|
# JACEK:
|
|
|
|
# or pass it in, allowing the caller to choose - they'll likely be in a
|
|
|
|
# better position to decide if buffer should be reused or not. this will
|
|
|
|
# also be useuful for chunked messages where part of the buffer may have
|
|
|
|
# been processed and needs filling in
|
|
|
|
var encryptedBytes = newSeq[byte](remainingBytes)
|
|
|
|
await peer.transport.readExactly(addr encryptedBytes[0], len(encryptedBytes))
|
|
|
|
|
|
|
|
let decryptedMaxLength = decryptedLength(msgSize)
|
|
|
|
var
|
|
|
|
decryptedBytes = newSeq[byte](decryptedMaxLength)
|
|
|
|
decryptedBytesCount = 0
|
|
|
|
|
|
|
|
if decryptBody(peer.secretsState, encryptedBytes, msgSize,
|
|
|
|
decryptedBytes, decryptedBytesCount) != RlpxStatus.Success:
|
|
|
|
await peer.disconnectAndRaise(BreachOfProtocol,
|
|
|
|
"Cannot decrypt RLPx frame body")
|
|
|
|
|
|
|
|
decryptedBytes.setLen(decryptedBytesCount)
|
|
|
|
|
|
|
|
when useSnappy:
|
|
|
|
if peer.snappyEnabled:
|
|
|
|
decryptedBytes = snappy.uncompress(decryptedBytes)
|
|
|
|
if decryptedBytes.len == 0:
|
|
|
|
await peer.disconnectAndRaise(BreachOfProtocol,
|
|
|
|
"Snappy uncompress encountered malformed data")
|
|
|
|
var rlp = rlpFromBytes(decryptedBytes.toRange)
|
|
|
|
|
|
|
|
try:
|
|
|
|
let msgid = rlp.read(int)
|
|
|
|
return (msgId, rlp)
|
|
|
|
except RlpError:
|
|
|
|
await peer.disconnectAndRaise(BreachOfProtocol,
|
|
|
|
"Cannot read RLPx message id")
|
|
|
|
|
|
|
|
proc checkedRlpRead(peer: Peer, r: var Rlp, MsgType: type): auto {.inline.} =
|
|
|
|
let tmp = r
|
|
|
|
when defined(release):
|
|
|
|
return r.read(MsgType)
|
|
|
|
else:
|
|
|
|
try:
|
|
|
|
return r.read(MsgType)
|
|
|
|
except:
|
|
|
|
# echo "Failed rlp.read:", tmp.inspect
|
|
|
|
debug "Failed rlp.read",
|
|
|
|
peer = peer,
|
|
|
|
msg = MsgType.name,
|
|
|
|
exception = getCurrentExceptionMsg()
|
|
|
|
# dataHex = r.rawData.toSeq().toHex()
|
|
|
|
|
|
|
|
raise
|
|
|
|
|
|
|
|
proc waitSingleMsg(peer: Peer, MsgType: type): Future[MsgType] {.async.} =
|
|
|
|
let wantedId = peer.perPeerMsgId(MsgType)
|
|
|
|
while true:
|
|
|
|
var (nextMsgId, nextMsgData) = await peer.recvMsg()
|
|
|
|
|
|
|
|
if nextMsgId == wantedId:
|
|
|
|
try:
|
|
|
|
result = checkedRlpRead(peer, nextMsgData, MsgType)
|
|
|
|
logReceivedMsg(peer, result)
|
|
|
|
return
|
|
|
|
except RlpError:
|
|
|
|
await peer.disconnectAndRaise(BreachOfProtocol,
|
|
|
|
"Invalid RLPx message body")
|
|
|
|
|
|
|
|
elif nextMsgId == 1: # p2p.disconnect
|
|
|
|
let reason = DisconnectionReason nextMsgData.listElem(0).toInt(uint32)
|
2019-03-26 13:07:50 +00:00
|
|
|
await peer.disconnect(reason)
|
2019-02-05 15:40:29 +00:00
|
|
|
raisePeerDisconnected("Unexpected disconnect", reason)
|
|
|
|
else:
|
|
|
|
warn "Dropped RLPX message",
|
|
|
|
msg = peer.dispatcher.messages[nextMsgId].name
|
|
|
|
|
|
|
|
proc nextMsg*(peer: Peer, MsgType: type): Future[MsgType] =
|
|
|
|
## This procs awaits a specific RLPx message.
|
|
|
|
## Any messages received while waiting will be dispatched to their
|
|
|
|
## respective handlers. The designated message handler will also run
|
|
|
|
## to completion before the future returned by `nextMsg` is resolved.
|
|
|
|
let wantedId = peer.perPeerMsgId(MsgType)
|
|
|
|
let f = peer.awaitedMessages[wantedId]
|
|
|
|
if not f.isNil:
|
|
|
|
return Future[MsgType](f)
|
|
|
|
|
2019-04-10 13:57:19 +00:00
|
|
|
initFuture result
|
2019-02-05 15:40:29 +00:00
|
|
|
peer.awaitedMessages[wantedId] = result
|
|
|
|
|
2019-04-05 08:13:22 +00:00
|
|
|
# Known fatal errors are handled inside dispatchMessages.
|
|
|
|
# Errors we are currently unaware of are caught in the dispatchMessages
|
|
|
|
# callback. There they will be logged if CatchableError and quit on Defect.
|
|
|
|
# Non fatal errors such as the current CatchableError could be moved and
|
|
|
|
# handled a layer lower for clarity (and consistency), as also the actual
|
|
|
|
# message handler code as the TODO mentions already.
|
2019-02-05 15:40:29 +00:00
|
|
|
proc dispatchMessages*(peer: Peer) {.async.} =
|
2019-04-11 13:07:07 +00:00
|
|
|
while peer.connectionState notin {Disconnecting, Disconnected}:
|
2019-04-01 14:56:52 +00:00
|
|
|
var msgId: int
|
|
|
|
var msgData: Rlp
|
|
|
|
try:
|
|
|
|
(msgId, msgData) = await peer.recvMsg()
|
2019-05-15 08:45:15 +00:00
|
|
|
except TransportError:
|
|
|
|
# Note: This will also catch TransportIncompleteError. TransportError will
|
|
|
|
# here usually occur when a read is attempted when the transport is
|
|
|
|
# already closed. TransportIncompleteError when the transport is closed
|
|
|
|
# during read.
|
2019-04-11 13:07:07 +00:00
|
|
|
case peer.connectionState
|
|
|
|
of Connected:
|
|
|
|
# Dropped connection, still need to cleanup the peer.
|
|
|
|
# This could be seen as bad behaving peer.
|
|
|
|
trace "Dropped connection", peer
|
|
|
|
await peer.disconnect(ClientQuitting, false)
|
|
|
|
return
|
|
|
|
of Disconnecting, Disconnected:
|
|
|
|
# Graceful disconnect, can still cause TransportIncompleteError as it
|
|
|
|
# could be that this loop was waiting at recvMsg().
|
|
|
|
return
|
|
|
|
else:
|
|
|
|
# Connection dropped while `Connecting` (in rlpxConnect/rlpxAccept).
|
|
|
|
return
|
|
|
|
except PeerDisconnected:
|
2019-04-01 14:56:52 +00:00
|
|
|
return
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
if msgId == 1: # p2p.disconnect
|
|
|
|
let reason = msgData.listElem(0).toInt(uint32).DisconnectionReason
|
2019-04-11 13:07:07 +00:00
|
|
|
await peer.disconnect(reason, false)
|
2019-02-05 15:40:29 +00:00
|
|
|
break
|
|
|
|
|
|
|
|
try:
|
|
|
|
await peer.invokeThunk(msgId, msgData)
|
|
|
|
except RlpError:
|
2019-06-13 13:36:02 +00:00
|
|
|
debug "RlpError, ending dispatchMessages loop", peer,
|
|
|
|
msg = peer.getMsgName(msgId)
|
2019-04-05 08:13:22 +00:00
|
|
|
await peer.disconnect(BreachOfProtocol, true)
|
2019-02-05 15:40:29 +00:00
|
|
|
return
|
2019-03-26 13:07:50 +00:00
|
|
|
except CatchableError:
|
|
|
|
warn "Error while handling RLPx message", peer,
|
|
|
|
msg = peer.getMsgName(msgId),
|
|
|
|
err = getCurrentExceptionMsg()
|
|
|
|
|
|
|
|
# TODO: Hmm, this can be safely moved into the message handler thunk.
|
|
|
|
# The documentation will need to be updated, explaning the fact that
|
|
|
|
# nextMsg will be resolved only if the message handler has executed
|
|
|
|
# successfully.
|
2019-02-05 15:40:29 +00:00
|
|
|
if peer.awaitedMessages[msgId] != nil:
|
|
|
|
let msgInfo = peer.dispatcher.messages[msgId]
|
2019-03-26 13:07:50 +00:00
|
|
|
try:
|
|
|
|
(msgInfo.nextMsgResolver)(msgData, peer.awaitedMessages[msgId])
|
|
|
|
except:
|
|
|
|
# TODO: Handling errors here must be investigated more carefully.
|
|
|
|
# They also are supposed to be handled at the call-site where
|
|
|
|
# `nextMsg` is used.
|
2019-04-05 08:13:22 +00:00
|
|
|
debug "nextMsg resolver failed, ending dispatchMessages loop", peer,
|
|
|
|
err = getCurrentExceptionMsg()
|
|
|
|
await peer.disconnect(BreachOfProtocol, true)
|
|
|
|
return
|
2019-02-05 15:40:29 +00:00
|
|
|
peer.awaitedMessages[msgId] = nil
|
|
|
|
|
2019-05-19 18:05:02 +00:00
|
|
|
template applyDecorator(p: NimNode, decorator: NimNode) =
|
|
|
|
if decorator.kind != nnkNilLit: p.addPragma decorator
|
|
|
|
|
2019-05-29 15:52:28 +00:00
|
|
|
proc p2pProtocolBackendImpl*(protocol: P2PProtocol): Backend =
|
2019-05-19 18:05:02 +00:00
|
|
|
let
|
2019-02-05 15:40:29 +00:00
|
|
|
resultIdent = ident "result"
|
|
|
|
Peer = bindSym "Peer"
|
2019-05-19 18:05:02 +00:00
|
|
|
EthereumNode = bindSym "EthereumNode"
|
|
|
|
|
2019-02-05 15:40:29 +00:00
|
|
|
initRlpWriter = bindSym "initRlpWriter"
|
2019-06-13 13:36:02 +00:00
|
|
|
safeEnterList = bindSym "safeEnterList"
|
2019-05-19 18:05:02 +00:00
|
|
|
rlpFromBytes = bindSym "rlpFromBytes"
|
2019-03-13 21:22:14 +00:00
|
|
|
append = bindSym("append", brForceOpen)
|
|
|
|
read = bindSym("read", brForceOpen)
|
2019-05-30 15:11:23 +00:00
|
|
|
checkedRlpRead = bindSym "checkedRlpRead"
|
2019-05-19 18:05:02 +00:00
|
|
|
startList = bindSym "startList"
|
2019-05-30 15:11:23 +00:00
|
|
|
safeEnterList = bindSym "safeEnterList"
|
2019-05-19 18:05:02 +00:00
|
|
|
finish = bindSym "finish"
|
|
|
|
|
|
|
|
messagePrinter = bindSym "messagePrinter"
|
|
|
|
nextMsgResolver = bindSym "nextMsgResolver"
|
2019-02-05 15:40:29 +00:00
|
|
|
registerRequest = bindSym "registerRequest"
|
|
|
|
requestResolver = bindSym "requestResolver"
|
|
|
|
resolveResponseFuture = bindSym "resolveResponseFuture"
|
|
|
|
sendMsg = bindSym "sendMsg"
|
2019-05-19 18:05:02 +00:00
|
|
|
nextMsg = bindSym "nextMsg"
|
|
|
|
initProtocol = bindSym"initProtocol"
|
|
|
|
registerMsg = bindSym "registerMsg"
|
2019-02-05 15:40:29 +00:00
|
|
|
perPeerMsgId = bindSym "perPeerMsgId"
|
|
|
|
perPeerMsgIdImpl = bindSym "perPeerMsgIdImpl"
|
|
|
|
linkSendFailureToReqFuture = bindSym "linkSendFailureToReqFuture"
|
2019-05-29 15:52:28 +00:00
|
|
|
handshakeImpl = bindSym "handshakeImpl"
|
2019-05-30 15:11:23 +00:00
|
|
|
|
|
|
|
ResponderWithId = bindSym "ResponderWithId"
|
|
|
|
ResponderWithoutId = bindSym "ResponderWithoutId"
|
|
|
|
|
|
|
|
isSubprotocol = protocol.version > 0
|
2019-05-29 15:52:28 +00:00
|
|
|
shortName = if protocol.shortName.len > 0: protocol.shortName
|
|
|
|
else: protocol.name
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
# By convention, all Ethereum protocol names must be abbreviated to 3 letters
|
2019-03-13 22:15:26 +00:00
|
|
|
doAssert shortName.len == 3
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-19 18:05:02 +00:00
|
|
|
new result
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-19 18:05:02 +00:00
|
|
|
result.registerProtocol = bindSym "registerProtocol"
|
|
|
|
result.setEventHandlers = bindSym "setEventHandlers"
|
|
|
|
result.PeerType = Peer
|
|
|
|
result.NetworkType = EthereumNode
|
2019-05-30 15:11:23 +00:00
|
|
|
result.ResponderType = if protocol.useRequestIds: ResponderWithId
|
|
|
|
else: ResponderWithoutId
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
result.implementMsg = proc (msg: Message) =
|
2019-02-05 15:40:29 +00:00
|
|
|
var
|
2019-05-19 18:05:02 +00:00
|
|
|
msgId = msg.id
|
2019-05-30 15:11:23 +00:00
|
|
|
msgIdent = msg.ident
|
|
|
|
msgName = $msgIdent
|
2019-05-19 18:05:02 +00:00
|
|
|
msgRecName = msg.recIdent
|
2019-05-29 15:52:28 +00:00
|
|
|
responseMsgId = if msg.response != nil: msg.response.id else: -1
|
2019-05-30 15:11:23 +00:00
|
|
|
ResponseRecord = if msg.response != nil: msg.response.recIdent else: nil
|
|
|
|
hasReqId = msg.hasReqId
|
|
|
|
protocol = msg.protocol
|
|
|
|
userPragmas = msg.procDef.pragma
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
# variables used in the sending procs
|
2019-05-30 15:11:23 +00:00
|
|
|
peerOrResponder = ident"peerOrResponder"
|
2019-02-05 15:40:29 +00:00
|
|
|
rlpWriter = ident"writer"
|
|
|
|
perPeerMsgIdVar = ident"perPeerMsgId"
|
|
|
|
|
|
|
|
# variables used in the receiving procs
|
|
|
|
receivedRlp = ident"rlp"
|
|
|
|
receivedMsg = ident"msg"
|
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
var
|
|
|
|
readParams = newNimNode(nnkStmtList)
|
|
|
|
paramsToWrite = newSeq[NimNode](0)
|
|
|
|
appendParams = newNimNode(nnkStmtList)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
if hasReqId:
|
2019-02-05 15:40:29 +00:00
|
|
|
# Messages using request Ids
|
2019-02-27 08:06:44 +00:00
|
|
|
readParams.add quote do:
|
2019-05-30 15:11:23 +00:00
|
|
|
let `reqIdVar` = `read`(`receivedRlp`, int)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
case msg.kind
|
2019-05-19 18:05:02 +00:00
|
|
|
of msgRequest:
|
2019-02-05 15:40:29 +00:00
|
|
|
let reqToResponseOffset = responseMsgId - msgId
|
|
|
|
let responseMsgId = quote do: `perPeerMsgIdVar` + `reqToResponseOffset`
|
|
|
|
|
|
|
|
# Each request is registered so we can resolve it when the response
|
|
|
|
# arrives. There are two types of protocols: LES-like protocols use
|
|
|
|
# explicit `reqId` sent over the wire, while the ETH wire protocol
|
|
|
|
# assumes there is one outstanding request at a time (if there are
|
|
|
|
# multiple requests we'll resolve them in FIFO order).
|
2019-05-30 15:11:23 +00:00
|
|
|
let registerRequestCall = newCall(registerRequest, peerVar,
|
2019-05-19 18:05:02 +00:00
|
|
|
msg.timeoutParam[0],
|
2019-02-05 15:40:29 +00:00
|
|
|
resultIdent,
|
|
|
|
responseMsgId)
|
2019-05-30 15:11:23 +00:00
|
|
|
if hasReqId:
|
2019-02-05 15:40:29 +00:00
|
|
|
appendParams.add quote do:
|
2019-04-10 13:57:19 +00:00
|
|
|
initFuture `resultIdent`
|
2019-05-30 15:11:23 +00:00
|
|
|
let `reqIdVar` = `registerRequestCall`
|
|
|
|
paramsToWrite.add reqIdVar
|
2019-02-05 15:40:29 +00:00
|
|
|
else:
|
|
|
|
appendParams.add quote do:
|
2019-04-10 13:57:19 +00:00
|
|
|
initFuture `resultIdent`
|
2019-02-05 15:40:29 +00:00
|
|
|
discard `registerRequestCall`
|
|
|
|
|
2019-05-19 18:05:02 +00:00
|
|
|
of msgResponse:
|
2019-05-30 15:11:23 +00:00
|
|
|
if hasReqId:
|
|
|
|
paramsToWrite.add newDotExpr(peerOrResponder, reqIdVar)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-19 18:05:02 +00:00
|
|
|
of msgHandshake, msgNotification: discard
|
2019-03-11 09:22:06 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
for param, paramType in msg.procDef.typedParams(skip = 1):
|
2019-02-05 15:40:29 +00:00
|
|
|
# This is a fragment of the sending proc that
|
|
|
|
# serializes each of the passed parameters:
|
|
|
|
paramsToWrite.add param
|
|
|
|
|
|
|
|
# The received RLP data is deserialized to a local variable of
|
|
|
|
# the message-specific type. This is done field by field here:
|
|
|
|
let msgNameLit = newLit(msgName)
|
|
|
|
readParams.add quote do:
|
2019-05-30 15:11:23 +00:00
|
|
|
`receivedMsg`.`param` = `checkedRlpRead`(`peerVar`, `receivedRlp`, `paramType`)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
let
|
|
|
|
paramCount = paramsToWrite.len
|
|
|
|
readParamsPrelude = if paramCount > 1: newCall(safeEnterList, receivedRlp)
|
|
|
|
else: newStmtList()
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
when tracingEnabled:
|
|
|
|
readParams.add newCall(bindSym"logReceivedMsg", peerVar, receivedMsg)
|
|
|
|
|
|
|
|
let callResolvedResponseFuture = if msg.kind == msgResponse:
|
|
|
|
newCall(resolveResponseFuture,
|
|
|
|
peerVar,
|
|
|
|
newCall(perPeerMsgId, peerVar, msgRecName),
|
|
|
|
newCall("addr", receivedMsg),
|
|
|
|
if hasReqId: reqIdVar else: newLit(-1))
|
|
|
|
else:
|
|
|
|
newStmtList()
|
2019-02-27 08:06:44 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
var userHandlerParams = @[peerVar]
|
|
|
|
if hasReqId: userHandlerParams.add reqIdVar
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
let awaitUserHandler = msg.genAwaitUserHandler(receivedMsg, userHandlerParams)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
let thunkName = ident(msgName & "_thunk")
|
|
|
|
var thunkProc = quote do:
|
2019-05-30 15:11:23 +00:00
|
|
|
proc `thunkName`(`peerVar`: `Peer`, _: int, data: Rlp) {.async, gcsafe.} =
|
2019-02-05 15:40:29 +00:00
|
|
|
var `receivedRlp` = data
|
2019-05-19 18:05:02 +00:00
|
|
|
var `receivedMsg` {.noinit.}: `msgRecName`
|
2019-02-05 15:40:29 +00:00
|
|
|
`readParamsPrelude`
|
|
|
|
`readParams`
|
|
|
|
`awaitUserHandler`
|
|
|
|
`callResolvedResponseFuture`
|
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
case msg.kind
|
2019-05-29 15:52:28 +00:00
|
|
|
of msgRequest: thunkProc.applyDecorator protocol.incomingRequestThunkDecorator
|
|
|
|
of msgResponse: thunkProc.applyDecorator protocol.incomingResponseThunkDecorator
|
2019-02-05 15:40:29 +00:00
|
|
|
else: discard
|
|
|
|
|
2019-05-29 15:52:28 +00:00
|
|
|
protocol.outRecvProcs.add thunkProc
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
var sendProc = msg.createSendProc(isRawSender = (msg.kind == msgHandshake))
|
|
|
|
sendProc.def.params[1][0] = peerOrResponder
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
protocol.outSendProcs.add sendProc.allDefs
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
if msg.kind == msgHandshake:
|
|
|
|
protocol.outSendProcs.add msg.genHandshakeTemplate(sendProc.def.name,
|
|
|
|
handshakeImpl, nextMsg)
|
|
|
|
let
|
|
|
|
msgBytes = ident"msgBytes"
|
|
|
|
finalizeRequest = quote do:
|
|
|
|
let `msgBytes` = `finish`(`rlpWriter`)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
var sendCall = newCall(sendMsg, peerVar, msgBytes)
|
|
|
|
let senderEpilogue = if msg.kind == msgRequest:
|
2019-02-05 15:40:29 +00:00
|
|
|
# In RLPx requests, the returned future was allocated here and passed
|
|
|
|
# to `registerRequest`. It's already assigned to the result variable
|
|
|
|
# of the proc, so we just wait for the sending operation to complete
|
|
|
|
# and we return in a normal way. (the waiting is done, so we can catch
|
|
|
|
# any possible errors).
|
|
|
|
quote: `linkSendFailureToReqFuture`(`sendCall`, `resultIdent`)
|
|
|
|
else:
|
|
|
|
# In normal RLPx messages, we are returning the future returned by the
|
|
|
|
# `sendMsg` call.
|
|
|
|
quote: return `sendCall`
|
|
|
|
|
2019-03-11 09:22:06 +00:00
|
|
|
let perPeerMsgIdValue = if isSubprotocol:
|
2019-05-30 15:11:23 +00:00
|
|
|
newCall(perPeerMsgIdImpl, peerVar, protocol.protocolInfoVar, newLit(msgId))
|
2019-02-05 15:40:29 +00:00
|
|
|
else:
|
|
|
|
newLit(msgId)
|
|
|
|
|
|
|
|
if paramCount > 1:
|
|
|
|
# In case there are more than 1 parameter,
|
|
|
|
# the params must be wrapped in a list:
|
|
|
|
appendParams = newStmtList(
|
|
|
|
newCall(startList, rlpWriter, newLit(paramCount)),
|
|
|
|
appendParams)
|
|
|
|
|
2019-05-29 15:52:28 +00:00
|
|
|
for param in paramsToWrite:
|
|
|
|
appendParams.add newCall(append, rlpWriter, param)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
let initWriter = quote do:
|
|
|
|
var `rlpWriter` = `initRlpWriter`()
|
2019-05-30 15:11:23 +00:00
|
|
|
const `perProtocolMsgIdVar` = `msgId`
|
2019-02-05 15:40:29 +00:00
|
|
|
let `perPeerMsgIdVar` = `perPeerMsgIdValue`
|
|
|
|
`append`(`rlpWriter`, `perPeerMsgIdVar`)
|
|
|
|
|
|
|
|
when tracingEnabled:
|
2019-05-30 15:11:23 +00:00
|
|
|
appendParams.add logSentMsgFields(peerVar, protocol, msgId, paramsToWrite)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
# let paramCountNode = newLit(paramCount)
|
2019-05-30 15:11:23 +00:00
|
|
|
sendProc.def.body = quote do:
|
|
|
|
let `peerVar` = getPeer(`peerOrResponder`)
|
2019-02-05 15:40:29 +00:00
|
|
|
`initWriter`
|
|
|
|
`appendParams`
|
|
|
|
`finalizeRequest`
|
|
|
|
`senderEpilogue`
|
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
if msg.kind == msgRequest:
|
|
|
|
sendProc.def.applyDecorator protocol.outgoingRequestDecorator
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-29 15:52:28 +00:00
|
|
|
protocol.outProcRegistrations.add(
|
2019-05-19 18:05:02 +00:00
|
|
|
newCall(registerMsg,
|
2019-05-29 15:52:28 +00:00
|
|
|
protocol.protocolInfoVar,
|
2019-05-30 15:11:23 +00:00
|
|
|
newLit(msgId),
|
|
|
|
newLit(msgName),
|
2019-02-05 15:40:29 +00:00
|
|
|
thunkName,
|
2019-05-19 18:05:02 +00:00
|
|
|
newTree(nnkBracketExpr, messagePrinter, msgRecName),
|
|
|
|
newTree(nnkBracketExpr, requestResolver, msgRecName),
|
|
|
|
newTree(nnkBracketExpr, nextMsgResolver, msgRecName)))
|
2019-02-05 15:40:29 +00:00
|
|
|
|
2019-05-29 15:52:28 +00:00
|
|
|
result.implementProtocolInit = proc (protocol: P2PProtocol): NimNode =
|
2019-05-19 18:05:02 +00:00
|
|
|
return newCall(initProtocol,
|
2019-05-29 15:52:28 +00:00
|
|
|
newLit(protocol.shortName),
|
|
|
|
newLit(protocol.version),
|
|
|
|
protocol.peerInit, protocol.netInit)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
p2pProtocol devp2p(version = 0, shortName = "p2p"):
|
|
|
|
proc hello(peer: Peer,
|
|
|
|
version: uint,
|
|
|
|
clientId: string,
|
|
|
|
capabilities: seq[Capability],
|
|
|
|
listenPort: uint,
|
|
|
|
nodeId: array[RawPublicKeySize, byte])
|
|
|
|
|
|
|
|
proc sendDisconnectMsg(peer: Peer, reason: DisconnectionReason)
|
|
|
|
|
|
|
|
proc ping(peer: Peer) =
|
|
|
|
discard peer.pong()
|
|
|
|
|
|
|
|
proc pong(peer: Peer) =
|
|
|
|
discard
|
|
|
|
|
|
|
|
proc removePeer(network: EthereumNode, peer: Peer) =
|
|
|
|
# It is necessary to check if peer.remote still exists. The connection might
|
|
|
|
# have been dropped already from the peers side.
|
|
|
|
# E.g. when receiving a p2p.disconnect message from a peer, a race will happen
|
|
|
|
# between which side disconnects first.
|
|
|
|
if network.peerPool != nil and not peer.remote.isNil:
|
|
|
|
network.peerPool.connectedNodes.del(peer.remote)
|
|
|
|
|
2019-04-18 12:33:38 +00:00
|
|
|
# Note: we need to do this check as disconnect (and thus removePeer)
|
|
|
|
# currently can get called before the dispatcher is initialized.
|
|
|
|
if not peer.dispatcher.isNil:
|
|
|
|
for observer in network.peerPool.observers.values:
|
|
|
|
if not observer.onPeerDisconnected.isNil:
|
|
|
|
if observer.protocol.isNil or peer.supports(observer.protocol):
|
|
|
|
observer.onPeerDisconnected(peer)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
proc callDisconnectHandlers(peer: Peer, reason: DisconnectionReason): Future[void] =
|
|
|
|
var futures = newSeqOfCap[Future[void]](allProtocols.len)
|
|
|
|
|
|
|
|
for protocol in peer.dispatcher.activeProtocols:
|
|
|
|
if protocol.disconnectHandler != nil:
|
|
|
|
futures.add((protocol.disconnectHandler)(peer, reason))
|
|
|
|
|
|
|
|
return all(futures)
|
|
|
|
|
2019-03-26 13:07:50 +00:00
|
|
|
proc disconnect*(peer: Peer, reason: DisconnectionReason, notifyOtherPeer = false) {.async.} =
|
2019-02-05 15:40:29 +00:00
|
|
|
if peer.connectionState notin {Disconnecting, Disconnected}:
|
|
|
|
peer.connectionState = Disconnecting
|
2019-04-11 13:07:07 +00:00
|
|
|
# Do this first so sub-protocols have time to clean up and stop sending
|
|
|
|
# before this node closes transport to remote peer
|
2019-04-05 08:13:22 +00:00
|
|
|
if not peer.dispatcher.isNil:
|
|
|
|
# In case of `CatchableError` in any of the handlers, this will be logged.
|
|
|
|
# Other handlers will still execute.
|
|
|
|
# In case of `Defect` in any of the handlers, program will quit.
|
|
|
|
traceAwaitErrors callDisconnectHandlers(peer, reason)
|
|
|
|
|
2019-04-11 13:07:07 +00:00
|
|
|
if notifyOtherPeer and not peer.transport.closed:
|
|
|
|
var fut = peer.sendDisconnectMsg(reason)
|
|
|
|
yield fut
|
|
|
|
if fut.failed:
|
|
|
|
debug "Failed to deliver disconnect message", peer
|
|
|
|
|
|
|
|
proc waitAndClose(peer: Peer, time: Duration) {.async.} =
|
|
|
|
await sleepAsync(time)
|
|
|
|
await peer.transport.closeWait()
|
|
|
|
|
|
|
|
# Give the peer a chance to disconnect
|
2019-05-09 10:14:47 +00:00
|
|
|
traceAsyncErrors peer.waitAndClose(2.seconds)
|
2019-04-11 13:07:07 +00:00
|
|
|
elif not peer.transport.closed:
|
2019-05-09 10:14:47 +00:00
|
|
|
peer.transport.close()
|
2019-04-11 13:07:07 +00:00
|
|
|
|
2019-04-05 08:13:22 +00:00
|
|
|
logDisconnectedPeer peer
|
|
|
|
peer.connectionState = Disconnected
|
|
|
|
removePeer(peer.network, peer)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
proc validatePubKeyInHello(msg: devp2p.hello, pubKey: PublicKey): bool =
|
|
|
|
var pk: PublicKey
|
|
|
|
recoverPublicKey(msg.nodeId, pk) == EthKeysStatus.Success and pk == pubKey
|
|
|
|
|
|
|
|
proc checkUselessPeer(peer: Peer) {.inline.} =
|
|
|
|
if peer.dispatcher.numProtocols == 0:
|
|
|
|
# XXX: Send disconnect + UselessPeer
|
|
|
|
raise newException(UselessPeerError, "Useless peer")
|
|
|
|
|
|
|
|
proc initPeerState*(peer: Peer, capabilities: openarray[Capability]) =
|
|
|
|
peer.dispatcher = getDispatcher(peer.network, capabilities)
|
|
|
|
checkUselessPeer(peer)
|
|
|
|
|
|
|
|
# The dispatcher has determined our message ID sequence.
|
|
|
|
# For each message ID, we allocate a potential slot for
|
|
|
|
# tracking responses to requests.
|
|
|
|
# (yes, some of the slots won't be used).
|
|
|
|
peer.outstandingRequests.newSeq(peer.dispatcher.messages.len)
|
|
|
|
for d in mitems(peer.outstandingRequests):
|
|
|
|
d = initDeque[OutstandingRequest]()
|
|
|
|
|
|
|
|
# Similarly, we need a bit of book-keeping data to keep track
|
|
|
|
# of the potentially concurrent calls to `nextMsg`.
|
|
|
|
peer.awaitedMessages.newSeq(peer.dispatcher.messages.len)
|
|
|
|
|
|
|
|
peer.lastReqId = 0
|
|
|
|
|
|
|
|
# Initialize all the active protocol states
|
|
|
|
newSeq(peer.protocolStates, allProtocols.len)
|
|
|
|
for protocol in peer.dispatcher.activeProtocols:
|
|
|
|
let peerStateInit = protocol.peerStateInitializer
|
|
|
|
if peerStateInit != nil:
|
|
|
|
peer.protocolStates[protocol.index] = peerStateInit(peer)
|
|
|
|
|
|
|
|
proc postHelloSteps(peer: Peer, h: devp2p.hello) {.async.} =
|
|
|
|
initPeerState(peer, h.capabilities)
|
|
|
|
|
|
|
|
# Please note that the ordering of operations here is important!
|
|
|
|
#
|
|
|
|
# We must first start all handshake procedures and give them a
|
|
|
|
# chance to send any initial packages they might require over
|
|
|
|
# the network and to yield on their `nextMsg` waits.
|
|
|
|
#
|
|
|
|
var subProtocolsHandshakes = newSeqOfCap[Future[void]](allProtocols.len)
|
|
|
|
for protocol in peer.dispatcher.activeProtocols:
|
|
|
|
if protocol.handshake != nil:
|
|
|
|
subProtocolsHandshakes.add((protocol.handshake)(peer))
|
|
|
|
|
|
|
|
# The `dispatchMesssages` loop must be started after this.
|
|
|
|
# Otherwise, we risk that some of the handshake packets sent by
|
|
|
|
# the other peer may arrrive too early and be processed before
|
|
|
|
# the handshake code got a change to wait for them.
|
|
|
|
#
|
|
|
|
var messageProcessingLoop = peer.dispatchMessages()
|
|
|
|
|
|
|
|
messageProcessingLoop.callback = proc(p: pointer) {.gcsafe.} =
|
|
|
|
if messageProcessingLoop.failed:
|
2019-03-28 11:14:55 +00:00
|
|
|
debug "Ending dispatchMessages loop", peer,
|
|
|
|
err = messageProcessingLoop.error.msg
|
2019-04-05 08:13:22 +00:00
|
|
|
traceAsyncErrors peer.disconnect(ClientQuitting)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
# The handshake may involve multiple async steps, so we wait
|
|
|
|
# here for all of them to finish.
|
|
|
|
#
|
|
|
|
await all(subProtocolsHandshakes)
|
|
|
|
|
2019-06-21 09:14:00 +00:00
|
|
|
# This is needed as a peer might have already disconnected. In this case
|
|
|
|
# we need to raise so that rlpxConnect/rlpxAccept fails.
|
|
|
|
# Disconnect is done only to run the disconnect handlers. TODO: improve this
|
|
|
|
# also TODO: Should we discern the type of error?
|
|
|
|
if messageProcessingLoop.finished:
|
|
|
|
await peer.disconnectAndRaise(ClientQuitting,
|
|
|
|
"messageProcessingLoop ended while connecting")
|
2019-02-05 15:40:29 +00:00
|
|
|
peer.connectionState = Connected
|
|
|
|
|
|
|
|
template `^`(arr): auto =
|
|
|
|
# passes a stack array with a matching `arrLen`
|
|
|
|
# variable as an open array
|
|
|
|
arr.toOpenArray(0, `arr Len` - 1)
|
|
|
|
|
|
|
|
proc check(status: AuthStatus) =
|
|
|
|
if status != AuthStatus.Success:
|
2019-03-26 13:07:50 +00:00
|
|
|
raise newException(CatchableError, "Error: " & $status)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
proc initSecretState(hs: var Handshake, authMsg, ackMsg: openarray[byte],
|
|
|
|
p: Peer) =
|
|
|
|
var secrets: ConnectionSecret
|
|
|
|
check hs.getSecrets(authMsg, ackMsg, secrets)
|
|
|
|
initSecretState(secrets, p.secretsState)
|
|
|
|
burnMem(secrets)
|
|
|
|
|
|
|
|
template checkSnappySupport(node: EthereumNode, handshake: Handshake, peer: Peer) =
|
|
|
|
when useSnappy:
|
|
|
|
peer.snappyEnabled = node.protocolVersion >= devp2pSnappyVersion.uint and
|
|
|
|
handshake.version >= devp2pSnappyVersion.uint
|
|
|
|
|
|
|
|
template getVersion(handshake: Handshake): uint =
|
|
|
|
when useSnappy:
|
|
|
|
handshake.version
|
|
|
|
else:
|
|
|
|
devp2pVersion
|
|
|
|
|
|
|
|
template baseProtocolVersion(node: EthereumNode): untyped =
|
|
|
|
when useSnappy:
|
|
|
|
node.protocolVersion
|
|
|
|
else:
|
|
|
|
devp2pVersion
|
|
|
|
|
|
|
|
template baseProtocolVersion(peer: Peer): uint =
|
|
|
|
when useSnappy:
|
|
|
|
if peer.snappyEnabled: devp2pSnappyVersion
|
|
|
|
else: devp2pVersion
|
|
|
|
else:
|
|
|
|
devp2pVersion
|
|
|
|
|
|
|
|
proc rlpxConnect*(node: EthereumNode, remote: Node): Future[Peer] {.async.} =
|
|
|
|
initTracing(devp2pInfo, node.protocols)
|
|
|
|
|
|
|
|
new result
|
|
|
|
result.network = node
|
|
|
|
result.remote = remote
|
|
|
|
|
|
|
|
let ta = initTAddress(remote.node.address.ip, remote.node.address.tcpPort)
|
|
|
|
var ok = false
|
|
|
|
try:
|
|
|
|
result.transport = await connect(ta)
|
|
|
|
var handshake = newHandshake({Initiator, EIP8}, int(node.baseProtocolVersion))
|
|
|
|
handshake.host = node.keys
|
|
|
|
|
|
|
|
var authMsg: array[AuthMessageMaxEIP8, byte]
|
|
|
|
var authMsgLen = 0
|
|
|
|
check authMessage(handshake, remote.node.pubkey, authMsg, authMsgLen)
|
2019-05-29 12:53:27 +00:00
|
|
|
var res = await result.transport.write(addr authMsg[0], authMsgLen)
|
|
|
|
if res != authMsgLen:
|
|
|
|
raisePeerDisconnected("Unexpected disconnect while authenticating",
|
|
|
|
TcpError)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
let initialSize = handshake.expectedLength
|
|
|
|
var ackMsg = newSeqOfCap[byte](1024)
|
|
|
|
ackMsg.setLen(initialSize)
|
|
|
|
|
|
|
|
await result.transport.readExactly(addr ackMsg[0], len(ackMsg))
|
|
|
|
|
|
|
|
var ret = handshake.decodeAckMessage(ackMsg)
|
|
|
|
if ret == AuthStatus.IncompleteError:
|
|
|
|
ackMsg.setLen(handshake.expectedLength)
|
|
|
|
await result.transport.readExactly(addr ackMsg[initialSize],
|
|
|
|
len(ackMsg) - initialSize)
|
|
|
|
ret = handshake.decodeAckMessage(ackMsg)
|
|
|
|
check ret
|
|
|
|
|
|
|
|
node.checkSnappySupport(handshake, result)
|
|
|
|
initSecretState(handshake, ^authMsg, ackMsg, result)
|
|
|
|
|
|
|
|
# if handshake.remoteHPubkey != remote.node.pubKey:
|
|
|
|
# raise newException(Exception, "Remote pubkey is wrong")
|
|
|
|
logConnectedPeer result
|
|
|
|
|
2019-03-26 13:07:50 +00:00
|
|
|
var sendHelloFut = result.hello(
|
|
|
|
handshake.getVersion(),
|
|
|
|
node.clientId,
|
|
|
|
node.capabilities,
|
|
|
|
uint(node.address.tcpPort),
|
|
|
|
node.keys.pubkey.getRaw())
|
|
|
|
|
|
|
|
var response = await result.handshakeImpl(
|
|
|
|
sendHelloFut,
|
|
|
|
result.waitSingleMsg(devp2p.hello),
|
|
|
|
10.seconds)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
if not validatePubKeyInHello(response, remote.node.pubKey):
|
|
|
|
warn "Remote nodeId is not its public key" # XXX: Do we care?
|
|
|
|
|
|
|
|
await postHelloSteps(result, response)
|
|
|
|
ok = true
|
|
|
|
except PeerDisconnected as e:
|
2019-06-11 12:38:02 +00:00
|
|
|
if e.reason == AlreadyConnected or e.reason == TooManyPeers:
|
|
|
|
trace "Disconnect during rlpxAccept", reason = e.reason
|
|
|
|
else:
|
|
|
|
debug "Unexpected disconnect during rlpxAccept", reason = e.reason
|
2019-02-05 15:40:29 +00:00
|
|
|
except TransportIncompleteError:
|
|
|
|
trace "Connection dropped in rlpxConnect", remote
|
|
|
|
except UselessPeerError:
|
2019-04-01 14:56:52 +00:00
|
|
|
trace "Disconnecting useless peer", peer = remote
|
2019-02-05 15:40:29 +00:00
|
|
|
except RlpTypeMismatch:
|
|
|
|
# Some peers report capabilities with names longer than 3 chars. We ignore
|
|
|
|
# those for now. Maybe we should allow this though.
|
|
|
|
debug "Rlp error in rlpxConnect"
|
|
|
|
except TransportOsError:
|
|
|
|
trace "TransportOsError", err = getCurrentExceptionMsg()
|
2019-06-11 12:38:02 +00:00
|
|
|
except CatchableError:
|
|
|
|
error "Unexpected exception in rlpxConnect", remote,
|
2019-02-05 15:40:29 +00:00
|
|
|
exc = getCurrentException().name,
|
|
|
|
err = getCurrentExceptionMsg()
|
|
|
|
|
|
|
|
if not ok:
|
|
|
|
if not isNil(result.transport):
|
|
|
|
result.transport.close()
|
|
|
|
result = nil
|
|
|
|
|
|
|
|
proc rlpxAccept*(node: EthereumNode,
|
|
|
|
transport: StreamTransport): Future[Peer] {.async.} =
|
|
|
|
initTracing(devp2pInfo, node.protocols)
|
|
|
|
|
|
|
|
new result
|
|
|
|
result.transport = transport
|
|
|
|
result.network = node
|
|
|
|
|
2019-05-30 15:11:23 +00:00
|
|
|
var handshake = newHandshake({auth.Responder})
|
2019-02-05 15:40:29 +00:00
|
|
|
handshake.host = node.keys
|
|
|
|
|
2019-04-01 14:56:52 +00:00
|
|
|
var ok = false
|
2019-02-05 15:40:29 +00:00
|
|
|
try:
|
|
|
|
let initialSize = handshake.expectedLength
|
|
|
|
var authMsg = newSeqOfCap[byte](1024)
|
|
|
|
|
|
|
|
authMsg.setLen(initialSize)
|
|
|
|
await transport.readExactly(addr authMsg[0], len(authMsg))
|
|
|
|
var ret = handshake.decodeAuthMessage(authMsg)
|
|
|
|
if ret == AuthStatus.IncompleteError: # Eip8 auth message is likely
|
|
|
|
authMsg.setLen(handshake.expectedLength)
|
|
|
|
await transport.readExactly(addr authMsg[initialSize],
|
|
|
|
len(authMsg) - initialSize)
|
|
|
|
ret = handshake.decodeAuthMessage(authMsg)
|
|
|
|
check ret
|
|
|
|
|
|
|
|
node.checkSnappySupport(handshake, result)
|
|
|
|
handshake.version = uint8(result.baseProtocolVersion)
|
|
|
|
|
|
|
|
var ackMsg: array[AckMessageMaxEIP8, byte]
|
|
|
|
var ackMsgLen: int
|
|
|
|
check handshake.ackMessage(ackMsg, ackMsgLen)
|
2019-05-29 12:53:27 +00:00
|
|
|
var res = await transport.write(addr ackMsg[0], ackMsgLen)
|
|
|
|
if res != ackMsgLen:
|
|
|
|
raisePeerDisconnected("Unexpected disconnect while authenticating",
|
|
|
|
TcpError)
|
2019-02-05 15:40:29 +00:00
|
|
|
|
|
|
|
initSecretState(handshake, authMsg, ^ackMsg, result)
|
|
|
|
|
|
|
|
let listenPort = transport.localAddress().port
|
|
|
|
|
|
|
|
logAcceptedPeer result
|
|
|
|
|
2019-03-26 13:07:50 +00:00
|
|
|
var sendHelloFut = result.hello(
|
|
|
|
result.baseProtocolVersion,
|
|
|
|
node.clientId,
|
|
|
|
node.capabilities,
|
|
|
|
listenPort.uint,
|
|
|
|
node.keys.pubkey.getRaw())
|
|
|
|
|
|
|
|
var response = await result.handshakeImpl(
|
|
|
|
sendHelloFut,
|
|
|
|
result.waitSingleMsg(devp2p.hello),
|
|
|
|
10.seconds)
|
|
|
|
|
2019-02-05 15:40:29 +00:00
|
|
|
if not validatePubKeyInHello(response, handshake.remoteHPubkey):
|
|
|
|
warn "A Remote nodeId is not its public key" # XXX: Do we care?
|
|
|
|
|
|
|
|
let remote = transport.remoteAddress()
|
|
|
|
let address = Address(ip: remote.address, tcpPort: remote.port,
|
|
|
|
udpPort: remote.port)
|
|
|
|
result.remote = newNode(initEnode(handshake.remoteHPubkey, address))
|
|
|
|
|
2019-06-11 10:46:26 +00:00
|
|
|
# In case there is an outgoing connection started with this peer we give
|
|
|
|
# precedence to that one and we disconnect here with `AlreadyConnected`
|
|
|
|
if result.remote in node.peerPool.connectedNodes or
|
|
|
|
result.remote in node.peerPool.connectingNodes:
|
|
|
|
trace "Duplicate connection in rlpxAccept"
|
|
|
|
raisePeerDisconnected("Peer already connecting or connected",
|
|
|
|
AlreadyConnected)
|
|
|
|
|
|
|
|
node.peerPool.connectingNodes.incl(result.remote)
|
|
|
|
|
2019-02-05 15:40:29 +00:00
|
|
|
await postHelloSteps(result, response)
|
2019-04-01 14:56:52 +00:00
|
|
|
ok = true
|
2019-02-05 15:40:29 +00:00
|
|
|
except PeerDisconnected as e:
|
2019-06-11 12:38:02 +00:00
|
|
|
if e.reason == AlreadyConnected or e.reason == TooManyPeers:
|
2019-04-01 14:56:52 +00:00
|
|
|
trace "Disconnect during rlpxAccept", reason = e.reason
|
2019-02-05 15:40:29 +00:00
|
|
|
else:
|
|
|
|
debug "Unexpected disconnect during rlpxAccept", reason = e.reason
|
2019-04-01 14:56:52 +00:00
|
|
|
except TransportIncompleteError:
|
|
|
|
trace "Connection dropped in rlpxAccept", remote = result.remote
|
|
|
|
except UselessPeerError:
|
|
|
|
trace "Disconnecting useless peer", peer = result.remote
|
2019-06-11 12:38:02 +00:00
|
|
|
except RlpTypeMismatch:
|
|
|
|
# Some peers report capabilities with names longer than 3 chars. We ignore
|
|
|
|
# those for now. Maybe we should allow this though.
|
|
|
|
debug "Rlp error in rlpxAccept"
|
|
|
|
except TransportOsError:
|
|
|
|
trace "TransportOsError", err = getCurrentExceptionMsg()
|
|
|
|
except CatchableError:
|
|
|
|
error "Unexpected exception in rlpxAccept",
|
|
|
|
exc = getCurrentException().name,
|
|
|
|
err = getCurrentExceptionMsg()
|
2019-04-01 14:56:52 +00:00
|
|
|
|
|
|
|
if not ok:
|
|
|
|
if not isNil(result.transport):
|
|
|
|
result.transport.close()
|
2019-02-05 15:40:29 +00:00
|
|
|
result = nil
|
|
|
|
|
|
|
|
when isMainModule:
|
|
|
|
|
|
|
|
when false:
|
|
|
|
# The assignments below can be used to investigate if the RLPx procs
|
|
|
|
# are considered GcSafe. The short answer is that they aren't, because
|
|
|
|
# they dispatch into user code that might use the GC.
|
|
|
|
type
|
|
|
|
GcSafeDispatchMsg = proc (peer: Peer, msgId: int, msgData: var Rlp)
|
|
|
|
|
|
|
|
GcSafeRecvMsg = proc (peer: Peer):
|
|
|
|
Future[tuple[msgId: int, msgData: Rlp]] {.gcsafe.}
|
|
|
|
|
|
|
|
GcSafeAccept = proc (transport: StreamTransport, myKeys: KeyPair):
|
|
|
|
Future[Peer] {.gcsafe.}
|
|
|
|
|
|
|
|
var
|
|
|
|
dispatchMsgPtr = invokeThunk
|
|
|
|
recvMsgPtr: GcSafeRecvMsg = recvMsg
|
|
|
|
acceptPtr: GcSafeAccept = rlpxAccept
|