2016-10-07 20:01:59 +02:00
|
|
|
import logging
|
2017-01-04 01:13:16 +01:00
|
|
|
import socket
|
|
|
|
import errno
|
2015-08-20 17:27:15 +02:00
|
|
|
|
2018-03-28 02:56:34 +02:00
|
|
|
from twisted.internet import protocol, defer
|
2018-02-22 17:29:10 +01:00
|
|
|
from lbrynet.core.call_later_manager import CallLaterManager
|
2015-08-20 17:27:15 +02:00
|
|
|
|
|
|
|
import constants
|
|
|
|
import encoding
|
|
|
|
import msgtypes
|
|
|
|
import msgformat
|
2017-10-10 19:09:25 +02:00
|
|
|
from error import BUILTIN_EXCEPTIONS, UnknownRemoteException, TimeoutError
|
2015-08-20 17:27:15 +02:00
|
|
|
|
2016-10-07 20:01:59 +02:00
|
|
|
log = logging.getLogger(__name__)
|
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
|
|
|
|
class KademliaProtocol(protocol.DatagramProtocol):
|
|
|
|
""" Implements all low-level network-related functions of a Kademlia node """
|
2017-05-25 20:01:39 +02:00
|
|
|
|
2017-03-31 19:32:43 +02:00
|
|
|
msgSizeLimit = constants.udpDatagramMaxSize - 26
|
2015-08-20 17:27:15 +02:00
|
|
|
|
2017-05-25 20:01:39 +02:00
|
|
|
def __init__(self, node):
|
2015-08-20 17:27:15 +02:00
|
|
|
self._node = node
|
2017-05-25 20:01:39 +02:00
|
|
|
self._encoder = encoding.Bencode()
|
|
|
|
self._translator = msgformat.DefaultFormat()
|
2015-08-20 17:27:15 +02:00
|
|
|
self._sentMessages = {}
|
|
|
|
self._partialMessages = {}
|
|
|
|
self._partialMessagesProgress = {}
|
2017-05-25 20:01:39 +02:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
def sendRPC(self, contact, method, args, rawResponse=False):
|
2018-05-23 23:32:55 +02:00
|
|
|
"""
|
|
|
|
Sends an RPC to the specified contact
|
2015-08-20 17:27:15 +02:00
|
|
|
|
|
|
|
@param contact: The contact (remote node) to send the RPC to
|
|
|
|
@type contact: kademlia.contacts.Contact
|
|
|
|
@param method: The name of remote method to invoke
|
|
|
|
@type method: str
|
|
|
|
@param args: A list of (non-keyword) arguments to pass to the remote
|
|
|
|
method, in the correct order
|
|
|
|
@type args: tuple
|
|
|
|
@param rawResponse: If this is set to C{True}, the caller of this RPC
|
|
|
|
will receive a tuple containing the actual response
|
|
|
|
message object and the originating address tuple as
|
|
|
|
a result; in other words, it will not be
|
|
|
|
interpreted by this class. Unless something special
|
|
|
|
needs to be done with the metadata associated with
|
|
|
|
the message, this should remain C{False}.
|
|
|
|
@type rawResponse: bool
|
|
|
|
|
|
|
|
@return: This immediately returns a deferred object, which will return
|
|
|
|
the result of the RPC call, or raise the relevant exception
|
|
|
|
if the remote node raised one. If C{rawResponse} is set to
|
|
|
|
C{True}, however, it will always return the actual response
|
|
|
|
message (which may be a C{ResponseMessage} or an
|
|
|
|
C{ErrorMessage}).
|
|
|
|
@rtype: twisted.internet.defer.Deferred
|
|
|
|
"""
|
2017-10-10 19:15:25 +02:00
|
|
|
msg = msgtypes.RequestMessage(self._node.node_id, method, args)
|
2015-08-20 17:27:15 +02:00
|
|
|
msgPrimitive = self._translator.toPrimitive(msg)
|
|
|
|
encodedMsg = self._encoder.encode(msgPrimitive)
|
|
|
|
|
2017-10-10 19:18:00 +02:00
|
|
|
if args:
|
2018-05-23 23:32:55 +02:00
|
|
|
log.debug("%s:%i SEND CALL %s(%s) TO %s:%i", self._node.externalIP, self._node.port, method,
|
|
|
|
args[0].encode('hex'), contact.address, contact.port)
|
2017-10-10 19:18:00 +02:00
|
|
|
else:
|
2018-05-23 23:32:55 +02:00
|
|
|
log.debug("%s:%i SEND CALL %s TO %s:%i", self._node.externalIP, self._node.port, method,
|
|
|
|
contact.address, contact.port)
|
2017-04-10 16:51:49 +02:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
df = defer.Deferred()
|
|
|
|
if rawResponse:
|
|
|
|
df._rpcRawResponse = True
|
|
|
|
|
2018-05-23 23:32:55 +02:00
|
|
|
def _remove_contact(failure): # remove the contact from the routing table and track the failure
|
|
|
|
try:
|
|
|
|
self._node.removeContact(contact)
|
|
|
|
except (ValueError, IndexError):
|
|
|
|
pass
|
|
|
|
contact.update_last_failed()
|
|
|
|
return failure
|
|
|
|
|
|
|
|
def _update_contact(result): # refresh the contact in the routing table
|
|
|
|
contact.update_last_replied()
|
|
|
|
d = self._node.addContact(contact)
|
|
|
|
d.addCallback(lambda _: result)
|
|
|
|
return d
|
|
|
|
|
|
|
|
df.addCallbacks(_update_contact, _remove_contact)
|
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
# Set the RPC timeout timer
|
2018-02-22 17:29:10 +01:00
|
|
|
timeoutCall, cancelTimeout = self._node.reactor_callLater(constants.rpcTimeout, self._msgTimeout, msg.id)
|
2018-05-23 23:32:55 +02:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
# Transmit the data
|
|
|
|
self._send(encodedMsg, msg.id, (contact.address, contact.port))
|
2018-05-23 23:32:55 +02:00
|
|
|
self._sentMessages[msg.id] = (contact, df, timeoutCall, cancelTimeout, method, args)
|
|
|
|
|
2018-02-22 17:29:10 +01:00
|
|
|
df.addErrback(cancelTimeout)
|
2015-08-20 17:27:15 +02:00
|
|
|
return df
|
|
|
|
|
2017-05-25 20:01:39 +02:00
|
|
|
def startProtocol(self):
|
|
|
|
log.info("DHT listening on UDP %i", self._node.port)
|
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
def datagramReceived(self, datagram, address):
|
|
|
|
""" Handles and parses incoming RPC messages (and responses)
|
|
|
|
|
|
|
|
@note: This is automatically called by Twisted when the protocol
|
|
|
|
receives a UDP datagram
|
|
|
|
"""
|
2017-05-25 20:01:39 +02:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
if datagram[0] == '\x00' and datagram[25] == '\x00':
|
|
|
|
totalPackets = (ord(datagram[1]) << 8) | ord(datagram[2])
|
|
|
|
msgID = datagram[5:25]
|
|
|
|
seqNumber = (ord(datagram[3]) << 8) | ord(datagram[4])
|
|
|
|
if msgID not in self._partialMessages:
|
|
|
|
self._partialMessages[msgID] = {}
|
|
|
|
self._partialMessages[msgID][seqNumber] = datagram[26:]
|
|
|
|
if len(self._partialMessages[msgID]) == totalPackets:
|
|
|
|
keys = self._partialMessages[msgID].keys()
|
|
|
|
keys.sort()
|
|
|
|
data = ''
|
|
|
|
for key in keys:
|
|
|
|
data += self._partialMessages[msgID][key]
|
|
|
|
datagram = data
|
|
|
|
del self._partialMessages[msgID]
|
|
|
|
else:
|
|
|
|
return
|
|
|
|
try:
|
|
|
|
msgPrimitive = self._encoder.decode(datagram)
|
2017-10-25 02:12:05 +02:00
|
|
|
message = self._translator.fromPrimitive(msgPrimitive)
|
2018-02-20 19:43:36 +01:00
|
|
|
except (encoding.DecodeError, ValueError) as err:
|
2015-08-20 17:27:15 +02:00
|
|
|
# We received some rubbish here
|
2018-04-19 21:46:56 +02:00
|
|
|
log.warning("Error decoding datagram %s from %s:%i - %s", datagram.encode('hex'),
|
|
|
|
address[0], address[1], err)
|
2015-08-20 17:27:15 +02:00
|
|
|
return
|
2018-03-07 15:21:53 +01:00
|
|
|
except (IndexError, KeyError):
|
2016-10-07 20:01:59 +02:00
|
|
|
log.warning("Couldn't decode dht datagram from %s", address)
|
|
|
|
return
|
2016-11-03 16:43:24 +01:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
if isinstance(message, msgtypes.RequestMessage):
|
|
|
|
# This is an RPC method request
|
2018-05-23 23:32:55 +02:00
|
|
|
remoteContact = self._node.contact_manager.make_contact(message.nodeID, address[0], address[1], self)
|
|
|
|
remoteContact.update_last_requested()
|
|
|
|
# only add a requesting contact to the routing table if it has replied to one of our requests
|
|
|
|
if remoteContact.contact_is_good is True:
|
|
|
|
df = self._node.addContact(remoteContact)
|
|
|
|
else:
|
|
|
|
df = defer.succeed(None)
|
|
|
|
df.addCallback(lambda _: self._handleRPC(remoteContact, message.id, message.request, message.args))
|
|
|
|
# if the contact is not known to be bad (yet) and we haven't yet queried it, send it a ping so that it
|
|
|
|
# will be added to our routing table if successful
|
|
|
|
if remoteContact.contact_is_good is None and remoteContact.lastReplied is None:
|
|
|
|
df.addCallback(lambda _: self._ping_queue.enqueue_maybe_ping(remoteContact))
|
|
|
|
elif isinstance(message, msgtypes.ErrorMessage):
|
|
|
|
# The RPC request raised a remote exception; raise it locally
|
|
|
|
if message.exceptionType in BUILTIN_EXCEPTIONS:
|
|
|
|
exception_type = BUILTIN_EXCEPTIONS[message.exceptionType]
|
|
|
|
else:
|
|
|
|
exception_type = UnknownRemoteException
|
|
|
|
remoteException = exception_type(message.response)
|
|
|
|
log.error("DHT RECV REMOTE EXCEPTION FROM %s:%i: %s", address[0],
|
|
|
|
address[1], remoteException)
|
|
|
|
if message.id in self._sentMessages:
|
|
|
|
# Cancel timeout timer for this RPC
|
|
|
|
remoteContact, df, timeoutCall, timeoutCanceller, method = self._sentMessages[message.id][0:5]
|
|
|
|
timeoutCanceller()
|
|
|
|
del self._sentMessages[message.id]
|
2017-05-25 20:01:39 +02:00
|
|
|
|
2018-05-23 23:32:55 +02:00
|
|
|
# reject replies coming from a different address than what we sent our request to
|
|
|
|
if (remoteContact.address, remoteContact.port) != address:
|
|
|
|
log.warning("Sent request to node %s at %s:%i, got reply from %s:%i",
|
|
|
|
remoteContact.log_id(), remoteContact.address,
|
|
|
|
remoteContact.port, address[0], address[1])
|
|
|
|
df.errback(TimeoutError(remoteContact.id))
|
|
|
|
return
|
|
|
|
|
|
|
|
# this error is returned by nodes that can be contacted but have an old
|
|
|
|
# and broken version of the ping command, if they return it the node can
|
|
|
|
# be contacted, so we'll treat it as a successful ping
|
|
|
|
old_ping_error = "ping() got an unexpected keyword argument '_rpcNodeContact'"
|
|
|
|
if isinstance(remoteException, TypeError) and \
|
|
|
|
remoteException.message == old_ping_error:
|
|
|
|
log.debug("old pong error")
|
|
|
|
df.callback('pong')
|
|
|
|
else:
|
|
|
|
df.errback(remoteException)
|
2015-08-20 17:27:15 +02:00
|
|
|
elif isinstance(message, msgtypes.ResponseMessage):
|
|
|
|
# Find the message that triggered this response
|
2017-04-10 16:51:49 +02:00
|
|
|
if message.id in self._sentMessages:
|
2015-08-20 17:27:15 +02:00
|
|
|
# Cancel timeout timer for this RPC
|
2018-05-23 23:32:55 +02:00
|
|
|
remoteContact, df, timeoutCall, timeoutCanceller, method = self._sentMessages[message.id][0:5]
|
|
|
|
timeoutCanceller()
|
2015-08-20 17:27:15 +02:00
|
|
|
del self._sentMessages[message.id]
|
2018-05-23 23:32:55 +02:00
|
|
|
log.debug("%s:%i RECV response to %s from %s:%i", self._node.externalIP, self._node.port,
|
|
|
|
method, remoteContact.address, remoteContact.port)
|
|
|
|
|
|
|
|
# When joining the network we made Contact objects for the seed nodes with node ids set to None
|
|
|
|
# Thus, the sent_to_id will also be None, and the contact objects need the ids to be manually set.
|
|
|
|
# These replies have be distinguished from those where the node id in the datagram does not match
|
|
|
|
# the node id of the node we sent a message to (these messages are treated as an error)
|
|
|
|
if remoteContact.id and remoteContact.id != message.nodeID: # sent_to_id will be None for bootstrap
|
|
|
|
log.debug("mismatch: (%s) %s:%i (%s vs %s)", method, remoteContact.address, remoteContact.port,
|
|
|
|
remoteContact.log_id(False), message.nodeID.encode('hex'))
|
|
|
|
df.errback(TimeoutError(remoteContact.id))
|
|
|
|
return
|
|
|
|
elif not remoteContact.id:
|
|
|
|
remoteContact.set_id(message.nodeID)
|
2015-08-20 17:27:15 +02:00
|
|
|
|
|
|
|
if hasattr(df, '_rpcRawResponse'):
|
2016-11-03 16:43:24 +01:00
|
|
|
# The RPC requested that the raw response message
|
|
|
|
# and originating address be returned; do not
|
|
|
|
# interpret it
|
2015-08-20 17:27:15 +02:00
|
|
|
df.callback((message, address))
|
|
|
|
else:
|
|
|
|
# We got a result from the RPC
|
|
|
|
df.callback(message.response)
|
|
|
|
else:
|
|
|
|
# If the original message isn't found, it must have timed out
|
2017-03-31 19:32:43 +02:00
|
|
|
# TODO: we should probably do something with this...
|
2015-08-20 17:27:15 +02:00
|
|
|
pass
|
|
|
|
|
|
|
|
def _send(self, data, rpcID, address):
|
|
|
|
""" Transmit the specified data over UDP, breaking it up into several
|
|
|
|
packets if necessary
|
2016-11-03 16:43:24 +01:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
If the data is spread over multiple UDP datagrams, the packets have the
|
|
|
|
following structure::
|
|
|
|
| | | | | |||||||||||| 0x00 |
|
|
|
|
|Transmision|Total number|Sequence number| RPC ID |Header end|
|
|
|
|
| type ID | of packets |of this packet | | indicator|
|
|
|
|
| (1 byte) | (2 bytes) | (2 bytes) |(20 bytes)| (1 byte) |
|
|
|
|
| | | | | |||||||||||| |
|
2016-11-03 16:43:24 +01:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
@note: The header used for breaking up large data segments will
|
|
|
|
possibly be moved out of the KademliaProtocol class in the
|
|
|
|
future, into something similar to a message translator/encoder
|
2016-12-14 00:08:29 +01:00
|
|
|
class (see C{kademlia.msgformat} and C{kademlia.encoding}).
|
2015-08-20 17:27:15 +02:00
|
|
|
"""
|
2017-05-25 20:01:39 +02:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
if len(data) > self.msgSizeLimit:
|
2016-11-30 21:20:45 +01:00
|
|
|
# We have to spread the data over multiple UDP datagrams,
|
|
|
|
# and provide sequencing information
|
|
|
|
#
|
|
|
|
# 1st byte is transmission type id, bytes 2 & 3 are the
|
|
|
|
# total number of packets in this transmission, bytes 4 &
|
|
|
|
# 5 are the sequence number for this specific packet
|
2015-08-20 17:27:15 +02:00
|
|
|
totalPackets = len(data) / self.msgSizeLimit
|
|
|
|
if len(data) % self.msgSizeLimit > 0:
|
|
|
|
totalPackets += 1
|
|
|
|
encTotalPackets = chr(totalPackets >> 8) + chr(totalPackets & 0xff)
|
|
|
|
seqNumber = 0
|
|
|
|
startPos = 0
|
|
|
|
while seqNumber < totalPackets:
|
2017-03-31 19:32:43 +02:00
|
|
|
packetData = data[startPos:startPos + self.msgSizeLimit]
|
2015-08-20 17:27:15 +02:00
|
|
|
encSeqNumber = chr(seqNumber >> 8) + chr(seqNumber & 0xff)
|
|
|
|
txData = '\x00%s%s%s\x00%s' % (encTotalPackets, encSeqNumber, rpcID, packetData)
|
2016-12-16 06:44:35 +01:00
|
|
|
self._scheduleSendNext(txData, address)
|
2015-08-20 17:27:15 +02:00
|
|
|
|
|
|
|
startPos += self.msgSizeLimit
|
|
|
|
seqNumber += 1
|
|
|
|
else:
|
2016-12-16 06:44:35 +01:00
|
|
|
self._scheduleSendNext(data, address)
|
2015-08-20 17:27:15 +02:00
|
|
|
|
2016-12-16 06:44:35 +01:00
|
|
|
def _scheduleSendNext(self, txData, address):
|
|
|
|
"""Schedule the sending of the next UDP packet """
|
2018-04-19 20:47:21 +02:00
|
|
|
delayed_call, _ = self._node.reactor_callSoon(self._write, txData, address)
|
2016-12-16 06:44:35 +01:00
|
|
|
|
2018-03-28 03:08:01 +02:00
|
|
|
def _write(self, txData, address):
|
2015-08-20 17:27:15 +02:00
|
|
|
if self.transport:
|
2017-01-04 01:13:16 +01:00
|
|
|
try:
|
|
|
|
self.transport.write(txData, address)
|
|
|
|
except socket.error as err:
|
2017-02-11 15:49:59 +01:00
|
|
|
if err.errno == errno.EWOULDBLOCK:
|
|
|
|
# i'm scared this may swallow important errors, but i get a million of these
|
|
|
|
# on Linux and it doesnt seem to affect anything -grin
|
2018-03-27 21:13:01 +02:00
|
|
|
log.warning("Can't send data to dht: EWOULDBLOCK")
|
2017-07-13 20:50:16 +02:00
|
|
|
elif err.errno == errno.ENETUNREACH:
|
|
|
|
# this should probably try to retransmit when the network connection is back
|
|
|
|
log.error("Network is unreachable")
|
2017-02-11 15:49:59 +01:00
|
|
|
else:
|
2017-07-13 20:50:16 +02:00
|
|
|
log.error("DHT socket error: %s (%i)", err.message, err.errno)
|
2017-01-04 01:13:16 +01:00
|
|
|
raise err
|
2018-02-20 19:43:36 +01:00
|
|
|
else:
|
|
|
|
log.warning("transport not connected!")
|
2015-08-20 17:27:15 +02:00
|
|
|
|
|
|
|
def _sendResponse(self, contact, rpcID, response):
|
|
|
|
""" Send a RPC response to the specified contact
|
|
|
|
"""
|
2017-10-10 19:15:25 +02:00
|
|
|
msg = msgtypes.ResponseMessage(rpcID, self._node.node_id, response)
|
2015-08-20 17:27:15 +02:00
|
|
|
msgPrimitive = self._translator.toPrimitive(msg)
|
|
|
|
encodedMsg = self._encoder.encode(msgPrimitive)
|
|
|
|
self._send(encodedMsg, rpcID, (contact.address, contact.port))
|
|
|
|
|
|
|
|
def _sendError(self, contact, rpcID, exceptionType, exceptionMessage):
|
|
|
|
""" Send an RPC error message to the specified contact
|
|
|
|
"""
|
2017-10-10 19:15:25 +02:00
|
|
|
msg = msgtypes.ErrorMessage(rpcID, self._node.node_id, exceptionType, exceptionMessage)
|
2015-08-20 17:27:15 +02:00
|
|
|
msgPrimitive = self._translator.toPrimitive(msg)
|
|
|
|
encodedMsg = self._encoder.encode(msgPrimitive)
|
|
|
|
self._send(encodedMsg, rpcID, (contact.address, contact.port))
|
|
|
|
|
|
|
|
def _handleRPC(self, senderContact, rpcID, method, args):
|
|
|
|
""" Executes a local function in response to an RPC request """
|
2017-03-31 19:32:43 +02:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
# Set up the deferred callchain
|
|
|
|
def handleError(f):
|
|
|
|
self._sendError(senderContact, rpcID, f.type, f.getErrorMessage())
|
|
|
|
|
|
|
|
def handleResult(result):
|
|
|
|
self._sendResponse(senderContact, rpcID, result)
|
|
|
|
|
|
|
|
df = defer.Deferred()
|
|
|
|
df.addCallback(handleResult)
|
|
|
|
df.addErrback(handleError)
|
|
|
|
|
|
|
|
# Execute the RPC
|
|
|
|
func = getattr(self._node, method, None)
|
2018-05-23 23:32:55 +02:00
|
|
|
if callable(func) and hasattr(func, "rpcmethod"):
|
2015-08-20 17:27:15 +02:00
|
|
|
# Call the exposed Node method and return the result to the deferred callback chain
|
2017-10-10 19:18:00 +02:00
|
|
|
if args:
|
2018-05-23 23:32:55 +02:00
|
|
|
log.debug("%s:%i RECV CALL %s(%s) %s:%i", self._node.externalIP, self._node.port, method,
|
|
|
|
args[0].encode('hex'), senderContact.address, senderContact.port)
|
2017-10-10 19:18:00 +02:00
|
|
|
else:
|
2018-05-23 23:32:55 +02:00
|
|
|
log.debug("%s:%i RECV CALL %s %s:%i", self._node.externalIP, self._node.port, method,
|
|
|
|
senderContact.address, senderContact.port)
|
2015-08-20 17:27:15 +02:00
|
|
|
try:
|
2017-10-10 19:18:38 +02:00
|
|
|
if method != 'ping':
|
2018-05-23 23:32:55 +02:00
|
|
|
result = func(senderContact, *args)
|
2017-10-10 19:18:38 +02:00
|
|
|
else:
|
|
|
|
result = func()
|
2015-08-20 17:27:15 +02:00
|
|
|
except Exception, e:
|
2018-05-23 23:32:55 +02:00
|
|
|
log.exception("error handling request for %s:%i %s", senderContact.address,
|
|
|
|
senderContact.port, method)
|
2017-10-10 19:17:36 +02:00
|
|
|
df.errback(e)
|
2015-08-20 17:27:15 +02:00
|
|
|
else:
|
|
|
|
df.callback(result)
|
|
|
|
else:
|
|
|
|
# No such exposed method
|
2017-10-10 19:17:36 +02:00
|
|
|
df.errback(AttributeError('Invalid method: %s' % method))
|
2018-05-23 23:32:55 +02:00
|
|
|
return df
|
2015-08-20 17:27:15 +02:00
|
|
|
|
|
|
|
def _msgTimeout(self, messageID):
|
|
|
|
""" Called when an RPC request message times out """
|
|
|
|
# Find the message that timed out
|
2017-10-10 19:29:29 +02:00
|
|
|
if messageID not in self._sentMessages:
|
2015-08-20 17:27:15 +02:00
|
|
|
# This should never be reached
|
2016-11-03 16:43:24 +01:00
|
|
|
log.error("deferred timed out, but is not present in sent messages list!")
|
2016-12-14 20:57:19 +01:00
|
|
|
return
|
2018-05-23 23:32:55 +02:00
|
|
|
remoteContact, df, timeout_call, timeout_canceller, method, args = self._sentMessages[messageID]
|
2016-12-14 20:57:19 +01:00
|
|
|
if self._partialMessages.has_key(messageID):
|
|
|
|
# We are still receiving this message
|
2018-05-23 23:32:55 +02:00
|
|
|
self._msgTimeoutInProgress(messageID, timeout_canceller, remoteContact, df, method, args)
|
2016-12-14 20:57:19 +01:00
|
|
|
return
|
|
|
|
del self._sentMessages[messageID]
|
|
|
|
# The message's destination node is now considered to be dead;
|
|
|
|
# raise an (asynchronous) TimeoutError exception and update the host node
|
2018-05-23 23:32:55 +02:00
|
|
|
df.errback(TimeoutError(remoteContact.id))
|
2016-12-14 20:57:19 +01:00
|
|
|
|
2018-05-23 23:32:55 +02:00
|
|
|
def _msgTimeoutInProgress(self, messageID, timeoutCanceller, remoteContact, df, method, args):
|
2016-12-14 20:57:19 +01:00
|
|
|
# See if any progress has been made; if not, kill the message
|
|
|
|
if self._hasProgressBeenMade(messageID):
|
|
|
|
# Reset the RPC timeout timer
|
2018-05-23 23:32:55 +02:00
|
|
|
timeoutCanceller()
|
|
|
|
timeoutCall, cancelTimeout = self._node.reactor_callLater(constants.rpcTimeout, self._msgTimeout, messageID)
|
|
|
|
self._sentMessages[messageID] = (remoteContact, df, timeoutCall, cancelTimeout, method, args)
|
2016-12-14 20:57:19 +01:00
|
|
|
else:
|
|
|
|
# No progress has been made
|
2017-10-25 02:05:30 +02:00
|
|
|
if messageID in self._partialMessagesProgress:
|
|
|
|
del self._partialMessagesProgress[messageID]
|
|
|
|
if messageID in self._partialMessages:
|
|
|
|
del self._partialMessages[messageID]
|
2018-05-23 23:32:55 +02:00
|
|
|
df.errback(TimeoutError(remoteContact.id))
|
2016-12-14 20:57:19 +01:00
|
|
|
|
|
|
|
def _hasProgressBeenMade(self, messageID):
|
|
|
|
return (
|
|
|
|
self._partialMessagesProgress.has_key(messageID) and
|
|
|
|
(
|
|
|
|
len(self._partialMessagesProgress[messageID]) !=
|
|
|
|
len(self._partialMessages[messageID])
|
|
|
|
)
|
|
|
|
)
|
2015-08-20 17:27:15 +02:00
|
|
|
|
|
|
|
def stopProtocol(self):
|
|
|
|
""" Called when the transport is disconnected.
|
2016-11-03 16:43:24 +01:00
|
|
|
|
2015-08-20 17:27:15 +02:00
|
|
|
Will only be called once, after all ports are disconnected.
|
|
|
|
"""
|
2017-04-10 16:51:49 +02:00
|
|
|
log.info('Stopping DHT')
|
2018-02-22 17:29:10 +01:00
|
|
|
CallLaterManager.stop()
|
2017-04-10 16:51:49 +02:00
|
|
|
log.info('DHT stopped')
|