2019-01-22 18:49:43 +01:00
|
|
|
import asyncio
|
2019-01-31 05:13:01 +01:00
|
|
|
from binascii import hexlify
|
|
|
|
from itertools import chain
|
|
|
|
|
2019-01-22 18:49:43 +01:00
|
|
|
import typing
|
|
|
|
import logging
|
|
|
|
from lbrynet.dht import constants
|
2019-04-10 16:26:57 +02:00
|
|
|
from lbrynet.dht.error import RemoteException, TransportNotConnected
|
2019-01-22 18:49:43 +01:00
|
|
|
from lbrynet.dht.protocol.distance import Distance
|
|
|
|
|
|
|
|
from typing import TYPE_CHECKING
|
|
|
|
if TYPE_CHECKING:
|
|
|
|
from lbrynet.dht.protocol.routing_table import TreeRoutingTable
|
|
|
|
from lbrynet.dht.protocol.protocol import KademliaProtocol
|
|
|
|
from lbrynet.dht.peer import PeerManager, KademliaPeer
|
|
|
|
|
|
|
|
log = logging.getLogger(__name__)
|
|
|
|
|
|
|
|
|
|
|
|
class FindResponse:
|
|
|
|
@property
|
|
|
|
def found(self) -> bool:
|
|
|
|
raise NotImplementedError()
|
|
|
|
|
|
|
|
def get_close_triples(self) -> typing.List[typing.Tuple[bytes, str, int]]:
|
|
|
|
raise NotImplementedError()
|
|
|
|
|
|
|
|
|
|
|
|
class FindNodeResponse(FindResponse):
|
|
|
|
def __init__(self, key: bytes, close_triples: typing.List[typing.Tuple[bytes, str, int]]):
|
|
|
|
self.key = key
|
|
|
|
self.close_triples = close_triples
|
|
|
|
|
|
|
|
@property
|
|
|
|
def found(self) -> bool:
|
|
|
|
return self.key in [triple[0] for triple in self.close_triples]
|
|
|
|
|
|
|
|
def get_close_triples(self) -> typing.List[typing.Tuple[bytes, str, int]]:
|
|
|
|
return self.close_triples
|
|
|
|
|
|
|
|
|
|
|
|
class FindValueResponse(FindResponse):
|
|
|
|
def __init__(self, key: bytes, result_dict: typing.Dict):
|
|
|
|
self.key = key
|
|
|
|
self.token = result_dict[b'token']
|
|
|
|
self.close_triples: typing.List[typing.Tuple[bytes, bytes, int]] = result_dict.get(b'contacts', [])
|
|
|
|
self.found_compact_addresses = result_dict.get(key, [])
|
|
|
|
|
|
|
|
@property
|
|
|
|
def found(self) -> bool:
|
|
|
|
return len(self.found_compact_addresses) > 0
|
|
|
|
|
|
|
|
def get_close_triples(self) -> typing.List[typing.Tuple[bytes, str, int]]:
|
|
|
|
return [(node_id, address.decode(), port) for node_id, address, port in self.close_triples]
|
|
|
|
|
|
|
|
|
|
|
|
def get_shortlist(routing_table: 'TreeRoutingTable', key: bytes,
|
|
|
|
shortlist: typing.Optional[typing.List['KademliaPeer']]) -> typing.List['KademliaPeer']:
|
|
|
|
"""
|
|
|
|
If not provided, initialize the shortlist of peers to probe to the (up to) k closest peers in the routing table
|
|
|
|
|
|
|
|
:param routing_table: a TreeRoutingTable
|
|
|
|
:param key: a 48 byte hash
|
|
|
|
:param shortlist: optional manually provided shortlist, this is done during bootstrapping when there are no
|
|
|
|
peers in the routing table. During bootstrap the shortlist is set to be the seed nodes.
|
|
|
|
"""
|
|
|
|
if len(key) != constants.hash_length:
|
|
|
|
raise ValueError("invalid key length: %i" % len(key))
|
2019-05-11 09:58:50 +02:00
|
|
|
return shortlist or routing_table.find_close_peers(key)
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
|
|
|
|
class IterativeFinder:
|
|
|
|
def __init__(self, loop: asyncio.BaseEventLoop, peer_manager: 'PeerManager',
|
|
|
|
routing_table: 'TreeRoutingTable', protocol: 'KademliaProtocol', key: bytes,
|
|
|
|
bottom_out_limit: typing.Optional[int] = 2, max_results: typing.Optional[int] = constants.k,
|
|
|
|
exclude: typing.Optional[typing.List[typing.Tuple[str, int]]] = None,
|
|
|
|
shortlist: typing.Optional[typing.List['KademliaPeer']] = None):
|
|
|
|
if len(key) != constants.hash_length:
|
|
|
|
raise ValueError("invalid key length: %i" % len(key))
|
|
|
|
self.loop = loop
|
|
|
|
self.peer_manager = peer_manager
|
|
|
|
self.routing_table = routing_table
|
|
|
|
self.protocol = protocol
|
|
|
|
|
|
|
|
self.key = key
|
|
|
|
self.bottom_out_limit = bottom_out_limit
|
|
|
|
self.max_results = max_results
|
|
|
|
self.exclude = exclude or []
|
|
|
|
|
|
|
|
self.shortlist: typing.List['KademliaPeer'] = get_shortlist(routing_table, key, shortlist)
|
2019-05-11 09:58:50 +02:00
|
|
|
self.active: typing.List['KademliaPeer'] = []
|
2019-01-31 05:13:01 +01:00
|
|
|
self.contacted: typing.Set[typing.Tuple[str, int]] = set()
|
2019-01-22 18:49:43 +01:00
|
|
|
self.distance = Distance(key)
|
|
|
|
|
2019-05-11 09:58:50 +02:00
|
|
|
self.closest_peer: typing.Optional['KademliaPeer'] = None
|
2019-01-22 18:49:43 +01:00
|
|
|
self.prev_closest_peer: typing.Optional['KademliaPeer'] = None
|
|
|
|
|
|
|
|
self.iteration_queue = asyncio.Queue(loop=self.loop)
|
|
|
|
|
2019-01-31 05:13:01 +01:00
|
|
|
self.running_probes: typing.Set[asyncio.Task] = set()
|
2019-01-22 18:49:43 +01:00
|
|
|
self.iteration_count = 0
|
|
|
|
self.bottom_out_count = 0
|
|
|
|
self.running = False
|
|
|
|
self.tasks: typing.List[asyncio.Task] = []
|
|
|
|
self.delayed_calls: typing.List[asyncio.Handle] = []
|
|
|
|
|
|
|
|
async def send_probe(self, peer: 'KademliaPeer') -> FindResponse:
|
|
|
|
"""
|
|
|
|
Send the rpc request to the peer and return an object with the FindResponse interface
|
|
|
|
"""
|
|
|
|
raise NotImplementedError()
|
|
|
|
|
2019-01-31 05:13:01 +01:00
|
|
|
def search_exhausted(self):
|
|
|
|
"""
|
|
|
|
This method ends the iterator due no more peers to contact.
|
|
|
|
Override to provide last time results.
|
|
|
|
"""
|
|
|
|
self.iteration_queue.put_nowait(None)
|
|
|
|
|
2019-01-22 18:49:43 +01:00
|
|
|
def check_result_ready(self, response: FindResponse):
|
|
|
|
"""
|
2019-01-31 05:13:01 +01:00
|
|
|
Called after adding peers from an rpc result to the shortlist.
|
2019-01-22 18:49:43 +01:00
|
|
|
This method is responsible for putting a result for the generator into the Queue
|
|
|
|
"""
|
|
|
|
raise NotImplementedError()
|
|
|
|
|
|
|
|
def get_initial_result(self) -> typing.List['KademliaPeer']:
|
|
|
|
"""
|
|
|
|
Get an initial or cached result to be put into the Queue. Used for findValue requests where the blob
|
|
|
|
has peers in the local data store of blobs announced to us
|
|
|
|
"""
|
|
|
|
return []
|
|
|
|
|
|
|
|
def _is_closer(self, peer: 'KademliaPeer') -> bool:
|
2019-01-31 05:13:01 +01:00
|
|
|
return not self.closest_peer or self.distance.is_closer(peer.node_id, self.closest_peer.node_id)
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
def _update_closest(self):
|
2019-05-11 09:58:50 +02:00
|
|
|
self.active.sort(key=lambda peer: self.distance(peer.node_id))
|
|
|
|
if self.closest_peer and self.closest_peer is not self.active[0]:
|
|
|
|
if self._is_closer(self.active[0]):
|
2019-01-22 18:49:43 +01:00
|
|
|
self.prev_closest_peer = self.closest_peer
|
2019-05-11 09:58:50 +02:00
|
|
|
self.closest_peer = self.active[0]
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
async def _handle_probe_result(self, peer: 'KademliaPeer', response: FindResponse):
|
2019-05-11 09:58:50 +02:00
|
|
|
if peer not in self.active and peer.node_id:
|
|
|
|
self.active.append(peer)
|
2019-01-31 05:13:01 +01:00
|
|
|
for contact_triple in response.get_close_triples():
|
|
|
|
node_id, address, udp_port = contact_triple
|
|
|
|
if (address, udp_port) not in self.contacted: # and not self.peer_manager.is_ignored(addr_tuple)
|
|
|
|
found_peer = self.peer_manager.get_kademlia_peer(node_id, address, udp_port)
|
2019-05-11 09:58:50 +02:00
|
|
|
if found_peer not in self.active and self.peer_manager.peer_is_good(found_peer) is not False:
|
|
|
|
self.active.append(found_peer)
|
2019-01-31 05:13:01 +01:00
|
|
|
self._update_closest()
|
|
|
|
self.check_result_ready(response)
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
async def _send_probe(self, peer: 'KademliaPeer'):
|
|
|
|
try:
|
|
|
|
response = await self.send_probe(peer)
|
|
|
|
except asyncio.TimeoutError:
|
2019-05-11 09:58:50 +02:00
|
|
|
if peer in self.active:
|
|
|
|
self.active.remove(peer)
|
2019-01-22 18:49:43 +01:00
|
|
|
return
|
|
|
|
except ValueError as err:
|
|
|
|
log.warning(str(err))
|
2019-05-11 09:58:50 +02:00
|
|
|
if peer in self.active:
|
|
|
|
self.active.remove(peer)
|
2019-01-22 18:49:43 +01:00
|
|
|
return
|
2019-05-09 04:00:57 +02:00
|
|
|
except TransportNotConnected:
|
|
|
|
return self.aclose()
|
|
|
|
except RemoteException:
|
2019-01-22 18:49:43 +01:00
|
|
|
return
|
|
|
|
return await self._handle_probe_result(peer, response)
|
|
|
|
|
|
|
|
async def _search_round(self):
|
|
|
|
"""
|
|
|
|
Send up to constants.alpha (5) probes to the closest peers in the shortlist
|
|
|
|
"""
|
|
|
|
|
|
|
|
added = 0
|
2019-05-11 09:58:50 +02:00
|
|
|
for peer in chain(self.active, self.shortlist):
|
|
|
|
if added >= constants.alpha:
|
|
|
|
break
|
2019-01-31 05:13:01 +01:00
|
|
|
origin_address = (peer.address, peer.udp_port)
|
2019-05-13 07:52:24 +02:00
|
|
|
if self.peer_manager.peer_is_good(peer) is False:
|
|
|
|
self.protocol.remove_peer(peer)
|
|
|
|
continue
|
2019-05-13 07:40:04 +02:00
|
|
|
if origin_address in self.exclude:
|
2019-01-31 05:13:01 +01:00
|
|
|
continue
|
|
|
|
if peer.node_id == self.protocol.node_id:
|
|
|
|
continue
|
2019-05-11 09:58:50 +02:00
|
|
|
if origin_address == (self.protocol.external_ip, self.protocol.udp_port):
|
2019-01-31 05:13:01 +01:00
|
|
|
continue
|
2019-05-11 09:58:50 +02:00
|
|
|
if origin_address not in self.contacted:
|
|
|
|
self.contacted.add(origin_address)
|
2019-01-31 05:13:01 +01:00
|
|
|
|
|
|
|
t = self.loop.create_task(self._send_probe(peer))
|
|
|
|
|
|
|
|
def callback(_):
|
|
|
|
self.running_probes.difference_update({
|
|
|
|
probe for probe in self.running_probes if probe.done() or probe == t
|
|
|
|
})
|
2019-05-11 09:58:50 +02:00
|
|
|
if not self.running_probes:
|
2019-01-31 05:13:01 +01:00
|
|
|
self.tasks.append(self.loop.create_task(self._search_task(0.0)))
|
|
|
|
|
|
|
|
t.add_done_callback(callback)
|
|
|
|
self.running_probes.add(t)
|
|
|
|
added += 1
|
|
|
|
log.debug("running %d probes", len(self.running_probes))
|
|
|
|
if not added and not self.running_probes:
|
|
|
|
log.debug("search for %s exhausted", hexlify(self.key)[:8])
|
|
|
|
self.search_exhausted()
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
async def _search_task(self, delay: typing.Optional[float] = constants.iterative_lookup_delay):
|
|
|
|
try:
|
|
|
|
if self.running:
|
|
|
|
await self._search_round()
|
|
|
|
if self.running:
|
|
|
|
self.delayed_calls.append(self.loop.call_later(delay, self._search))
|
2019-04-10 16:26:57 +02:00
|
|
|
except (asyncio.CancelledError, StopAsyncIteration, TransportNotConnected):
|
2019-01-22 18:49:43 +01:00
|
|
|
if self.running:
|
2019-01-31 05:13:01 +01:00
|
|
|
self.loop.call_soon(self.aclose)
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
def _search(self):
|
|
|
|
self.tasks.append(self.loop.create_task(self._search_task()))
|
|
|
|
|
2019-01-31 05:13:01 +01:00
|
|
|
def __aiter__(self):
|
2019-01-22 18:49:43 +01:00
|
|
|
if self.running:
|
|
|
|
raise Exception("already running")
|
|
|
|
self.running = True
|
|
|
|
self._search()
|
|
|
|
return self
|
|
|
|
|
|
|
|
async def __anext__(self) -> typing.List['KademliaPeer']:
|
|
|
|
try:
|
|
|
|
if self.iteration_count == 0:
|
2019-01-31 05:13:01 +01:00
|
|
|
result = self.get_initial_result() or await self.iteration_queue.get()
|
|
|
|
else:
|
|
|
|
result = await self.iteration_queue.get()
|
|
|
|
if not result:
|
|
|
|
raise StopAsyncIteration
|
2019-01-22 18:49:43 +01:00
|
|
|
self.iteration_count += 1
|
|
|
|
return result
|
|
|
|
except (asyncio.CancelledError, StopAsyncIteration):
|
2019-01-31 05:13:01 +01:00
|
|
|
self.loop.call_soon(self.aclose)
|
2019-01-22 18:49:43 +01:00
|
|
|
raise
|
|
|
|
|
|
|
|
def aclose(self):
|
|
|
|
self.running = False
|
2019-01-31 05:13:01 +01:00
|
|
|
self.iteration_queue.put_nowait(None)
|
|
|
|
for task in chain(self.tasks, self.running_probes, self.delayed_calls):
|
|
|
|
task.cancel()
|
|
|
|
self.tasks.clear()
|
|
|
|
self.running_probes.clear()
|
|
|
|
self.delayed_calls.clear()
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
|
|
|
|
class IterativeNodeFinder(IterativeFinder):
|
|
|
|
def __init__(self, loop: asyncio.BaseEventLoop, peer_manager: 'PeerManager',
|
|
|
|
routing_table: 'TreeRoutingTable', protocol: 'KademliaProtocol', key: bytes,
|
|
|
|
bottom_out_limit: typing.Optional[int] = 2, max_results: typing.Optional[int] = constants.k,
|
|
|
|
exclude: typing.Optional[typing.List[typing.Tuple[str, int]]] = None,
|
|
|
|
shortlist: typing.Optional[typing.List['KademliaPeer']] = None):
|
|
|
|
super().__init__(loop, peer_manager, routing_table, protocol, key, bottom_out_limit, max_results, exclude,
|
|
|
|
shortlist)
|
|
|
|
self.yielded_peers: typing.Set['KademliaPeer'] = set()
|
|
|
|
|
|
|
|
async def send_probe(self, peer: 'KademliaPeer') -> FindNodeResponse:
|
2019-05-11 09:58:50 +02:00
|
|
|
log.debug("probing %s:%d %s", peer.address, peer.udp_port, hexlify(peer.node_id)[:8] if peer.node_id else '')
|
2019-01-22 18:49:43 +01:00
|
|
|
response = await self.protocol.get_rpc_peer(peer).find_node(self.key)
|
|
|
|
return FindNodeResponse(self.key, response)
|
|
|
|
|
2019-01-31 05:13:01 +01:00
|
|
|
def search_exhausted(self):
|
|
|
|
self.put_result(self.active, finish=True)
|
|
|
|
|
|
|
|
def put_result(self, from_iter: typing.Iterable['KademliaPeer'], finish=False):
|
2019-05-11 09:58:50 +02:00
|
|
|
not_yet_yielded = [
|
|
|
|
peer for peer in from_iter if peer not in self.yielded_peers and peer.node_id != self.protocol.node_id
|
|
|
|
]
|
2019-01-22 18:49:43 +01:00
|
|
|
not_yet_yielded.sort(key=lambda peer: self.distance(peer.node_id))
|
|
|
|
to_yield = not_yet_yielded[:min(constants.k, len(not_yet_yielded))]
|
|
|
|
if to_yield:
|
2019-05-12 05:42:19 +02:00
|
|
|
self.yielded_peers.update(to_yield)
|
2019-01-22 18:49:43 +01:00
|
|
|
self.iteration_queue.put_nowait(to_yield)
|
2019-01-31 05:13:01 +01:00
|
|
|
if finish:
|
|
|
|
self.iteration_queue.put_nowait(None)
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
def check_result_ready(self, response: FindNodeResponse):
|
|
|
|
found = response.found and self.key != self.protocol.node_id
|
|
|
|
|
|
|
|
if found:
|
2019-02-02 00:13:45 +01:00
|
|
|
log.debug("found")
|
2019-05-11 09:58:50 +02:00
|
|
|
return self.put_result(self.active, finish=True)
|
2019-01-22 18:49:43 +01:00
|
|
|
if self.prev_closest_peer and self.closest_peer and not self._is_closer(self.prev_closest_peer):
|
|
|
|
# log.info("improving, %i %i %i %i %i", len(self.shortlist), len(self.active), len(self.contacted),
|
|
|
|
# self.bottom_out_count, self.iteration_count)
|
|
|
|
self.bottom_out_count = 0
|
|
|
|
elif self.prev_closest_peer and self.closest_peer:
|
|
|
|
self.bottom_out_count += 1
|
|
|
|
log.info("bottom out %i %i %i %i", len(self.active), len(self.contacted), len(self.shortlist),
|
|
|
|
self.bottom_out_count)
|
|
|
|
if self.bottom_out_count >= self.bottom_out_limit or self.iteration_count >= self.bottom_out_limit:
|
|
|
|
log.info("limit hit")
|
2019-01-31 05:13:01 +01:00
|
|
|
self.put_result(self.active, True)
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
|
|
|
|
class IterativeValueFinder(IterativeFinder):
|
|
|
|
def __init__(self, loop: asyncio.BaseEventLoop, peer_manager: 'PeerManager',
|
|
|
|
routing_table: 'TreeRoutingTable', protocol: 'KademliaProtocol', key: bytes,
|
|
|
|
bottom_out_limit: typing.Optional[int] = 2, max_results: typing.Optional[int] = constants.k,
|
|
|
|
exclude: typing.Optional[typing.List[typing.Tuple[str, int]]] = None,
|
|
|
|
shortlist: typing.Optional[typing.List['KademliaPeer']] = None):
|
|
|
|
super().__init__(loop, peer_manager, routing_table, protocol, key, bottom_out_limit, max_results, exclude,
|
|
|
|
shortlist)
|
|
|
|
self.blob_peers: typing.Set['KademliaPeer'] = set()
|
|
|
|
|
|
|
|
async def send_probe(self, peer: 'KademliaPeer') -> FindValueResponse:
|
|
|
|
response = await self.protocol.get_rpc_peer(peer).find_value(self.key)
|
|
|
|
return FindValueResponse(self.key, response)
|
|
|
|
|
|
|
|
def check_result_ready(self, response: FindValueResponse):
|
|
|
|
if response.found:
|
|
|
|
blob_peers = [self.peer_manager.decode_tcp_peer_from_compact_address(compact_addr)
|
|
|
|
for compact_addr in response.found_compact_addresses]
|
|
|
|
to_yield = []
|
|
|
|
self.bottom_out_count = 0
|
|
|
|
for blob_peer in blob_peers:
|
|
|
|
if blob_peer not in self.blob_peers:
|
|
|
|
self.blob_peers.add(blob_peer)
|
|
|
|
to_yield.append(blob_peer)
|
|
|
|
if to_yield:
|
|
|
|
# log.info("found %i new peers for blob", len(to_yield))
|
|
|
|
self.iteration_queue.put_nowait(to_yield)
|
|
|
|
# if self.max_results and len(self.blob_peers) >= self.max_results:
|
|
|
|
# log.info("enough blob peers found")
|
|
|
|
# if not self.finished.is_set():
|
|
|
|
# self.finished.set()
|
2019-01-31 05:13:01 +01:00
|
|
|
elif self.prev_closest_peer and self.closest_peer:
|
2019-01-22 18:49:43 +01:00
|
|
|
self.bottom_out_count += 1
|
|
|
|
if self.bottom_out_count >= self.bottom_out_limit:
|
|
|
|
log.info("blob peer search bottomed out")
|
2019-01-31 05:13:01 +01:00
|
|
|
self.iteration_queue.put_nowait(None)
|
2019-01-22 18:49:43 +01:00
|
|
|
|
|
|
|
def get_initial_result(self) -> typing.List['KademliaPeer']:
|
|
|
|
if self.protocol.data_store.has_peers_for_blob(self.key):
|
|
|
|
return self.protocol.data_store.get_peers_for_blob(self.key)
|
|
|
|
return []
|