2019-04-06 09:46:03 +08:00
|
|
|
# pylint: disable=no-name-in-module
|
2019-03-24 01:52:02 +08:00
|
|
|
import asyncio
|
2019-05-07 11:44:13 +08:00
|
|
|
|
2019-04-06 09:46:03 +08:00
|
|
|
from lru import LRU
|
2019-03-24 01:52:02 +08:00
|
|
|
|
2019-03-29 03:25:33 +08:00
|
|
|
from .pb import rpc_pb2
|
2019-03-24 01:52:02 +08:00
|
|
|
from .pubsub_notifee import PubsubNotifee
|
|
|
|
|
|
|
|
|
|
|
|
class Pubsub():
|
2019-04-02 04:55:44 +08:00
|
|
|
# pylint: disable=too-many-instance-attributes, no-member
|
2019-03-24 01:52:02 +08:00
|
|
|
|
2019-04-06 09:46:03 +08:00
|
|
|
def __init__(self, host, router, my_id, cache_size=None):
|
2019-03-24 01:52:02 +08:00
|
|
|
"""
|
|
|
|
Construct a new Pubsub object, which is responsible for handling all
|
|
|
|
Pubsub-related messages and relaying messages as appropriate to the
|
|
|
|
Pubsub router (which is responsible for choosing who to send messages to).
|
|
|
|
Since the logic for choosing peers to send pubsub messages to is
|
|
|
|
in the router, the same Pubsub impl can back floodsub, gossipsub, etc.
|
|
|
|
"""
|
|
|
|
self.host = host
|
|
|
|
self.router = router
|
|
|
|
self.my_id = my_id
|
|
|
|
|
|
|
|
# Attach this new Pubsub object to the router
|
|
|
|
self.router.attach(self)
|
|
|
|
|
|
|
|
# Register a notifee
|
|
|
|
self.peer_queue = asyncio.Queue()
|
|
|
|
self.host.get_network().notify(PubsubNotifee(self.peer_queue))
|
|
|
|
|
|
|
|
# Register stream handlers for each pubsub router protocol to handle
|
|
|
|
# the pubsub streams opened on those protocols
|
|
|
|
self.protocols = self.router.get_protocols()
|
|
|
|
for protocol in self.protocols:
|
|
|
|
self.host.set_stream_handler(protocol, self.stream_handler)
|
|
|
|
|
2019-05-07 11:44:13 +08:00
|
|
|
# Use asyncio queues for proper context switching
|
2019-03-24 01:52:02 +08:00
|
|
|
self.incoming_msgs_from_peers = asyncio.Queue()
|
|
|
|
self.outgoing_messages = asyncio.Queue()
|
|
|
|
|
2019-04-06 09:46:03 +08:00
|
|
|
# keeps track of seen messages as LRU cache
|
|
|
|
if cache_size is None:
|
|
|
|
self.cache_size = 128
|
|
|
|
else:
|
|
|
|
self.cache_size = cache_size
|
2019-05-07 11:44:13 +08:00
|
|
|
|
2019-04-06 09:46:03 +08:00
|
|
|
self.seen_messages = LRU(self.cache_size)
|
2019-03-24 01:52:02 +08:00
|
|
|
|
2019-05-07 11:44:13 +08:00
|
|
|
# Map of topics we are subscribed to blocking queues
|
2019-03-24 01:52:02 +08:00
|
|
|
# for when the given topic receives a message
|
|
|
|
self.my_topics = {}
|
|
|
|
|
|
|
|
# Map of topic to peers to keep track of what peers are subscribed to
|
|
|
|
self.peer_topics = {}
|
|
|
|
|
|
|
|
# Create peers map, which maps peer_id (as string) to stream (to a given peer)
|
|
|
|
self.peers = {}
|
|
|
|
|
|
|
|
# Call handle peer to keep waiting for updates to peer queue
|
|
|
|
asyncio.ensure_future(self.handle_peer_queue())
|
|
|
|
|
|
|
|
def get_hello_packet(self):
|
|
|
|
"""
|
|
|
|
Generate subscription message with all topics we are subscribed to
|
2019-04-02 04:23:20 +08:00
|
|
|
only send hello packet if we have subscribed topics
|
2019-03-24 01:52:02 +08:00
|
|
|
"""
|
2019-03-29 03:25:33 +08:00
|
|
|
packet = rpc_pb2.RPC()
|
2019-04-02 04:23:20 +08:00
|
|
|
if self.my_topics:
|
|
|
|
for topic_id in self.my_topics:
|
|
|
|
packet.subscriptions.extend([rpc_pb2.RPC.SubOpts(
|
|
|
|
subscribe=True, topicid=topic_id)])
|
2019-03-29 03:25:33 +08:00
|
|
|
|
|
|
|
return packet.SerializeToString()
|
2019-03-24 01:52:02 +08:00
|
|
|
|
2019-03-31 05:59:08 +08:00
|
|
|
async def continuously_read_stream(self, stream):
|
2019-03-24 01:52:02 +08:00
|
|
|
"""
|
|
|
|
Read from input stream in an infinite loop. Process
|
2019-03-31 06:49:50 +08:00
|
|
|
messages from other nodes
|
2019-03-24 01:52:02 +08:00
|
|
|
:param stream: stream to continously read from
|
|
|
|
"""
|
2019-03-30 04:23:30 +08:00
|
|
|
|
|
|
|
# TODO check on types here
|
2019-04-01 10:16:28 +08:00
|
|
|
peer_id = str(stream.mplex_conn.peer_id)
|
2019-03-30 04:23:30 +08:00
|
|
|
|
2019-03-24 01:52:02 +08:00
|
|
|
while True:
|
2019-03-29 03:25:33 +08:00
|
|
|
incoming = (await stream.read())
|
|
|
|
rpc_incoming = rpc_pb2.RPC()
|
|
|
|
rpc_incoming.ParseFromString(incoming)
|
2019-04-01 10:16:28 +08:00
|
|
|
|
2019-04-02 04:23:20 +08:00
|
|
|
should_publish = False
|
2019-04-01 10:16:28 +08:00
|
|
|
|
2019-03-31 05:59:08 +08:00
|
|
|
if rpc_incoming.publish:
|
2019-04-01 10:16:28 +08:00
|
|
|
# deal with RPC.publish
|
|
|
|
for message in rpc_incoming.publish:
|
2019-04-03 12:34:39 +08:00
|
|
|
id_in_seen_msgs = (message.seqno, message.from_id)
|
|
|
|
if id_in_seen_msgs not in self.seen_messages:
|
2019-04-02 04:23:20 +08:00
|
|
|
should_publish = True
|
2019-04-06 09:46:03 +08:00
|
|
|
self.seen_messages[id_in_seen_msgs] = 1
|
2019-05-07 11:44:13 +08:00
|
|
|
|
2019-04-02 04:55:44 +08:00
|
|
|
await self.handle_talk(message)
|
2019-03-30 04:23:30 +08:00
|
|
|
|
2019-03-31 05:59:08 +08:00
|
|
|
if rpc_incoming.subscriptions:
|
2019-04-01 10:16:28 +08:00
|
|
|
# deal with RPC.subscriptions
|
|
|
|
# We don't need to relay the subscription to our
|
|
|
|
# peers because a given node only needs its peers
|
|
|
|
# to know that it is subscribed to the topic (doesn't
|
|
|
|
# need everyone to know)
|
|
|
|
for message in rpc_incoming.subscriptions:
|
2019-07-15 16:28:29 +08:00
|
|
|
self.handle_subscription(peer_id, message)
|
2019-04-01 10:16:28 +08:00
|
|
|
|
|
|
|
if should_publish:
|
|
|
|
# relay message to peers with router
|
|
|
|
await self.router.publish(peer_id, incoming)
|
2019-03-24 01:52:02 +08:00
|
|
|
|
2019-05-07 11:44:13 +08:00
|
|
|
if rpc_incoming.control:
|
|
|
|
# Pass rpc to router so router could perform custom logic
|
|
|
|
await self.router.handle_rpc(rpc_incoming, peer_id)
|
|
|
|
|
2019-03-24 01:52:02 +08:00
|
|
|
# Force context switch
|
|
|
|
await asyncio.sleep(0)
|
|
|
|
|
|
|
|
async def stream_handler(self, stream):
|
|
|
|
"""
|
|
|
|
Stream handler for pubsub. Gets invoked whenever a new stream is created
|
|
|
|
on one of the supported pubsub protocols.
|
|
|
|
:param stream: newly created stream
|
|
|
|
"""
|
|
|
|
# Add peer
|
|
|
|
# Map peer to stream
|
|
|
|
peer_id = stream.mplex_conn.peer_id
|
|
|
|
self.peers[str(peer_id)] = stream
|
|
|
|
self.router.add_peer(peer_id, stream.get_protocol())
|
|
|
|
|
|
|
|
# Send hello packet
|
|
|
|
hello = self.get_hello_packet()
|
2019-03-31 05:59:08 +08:00
|
|
|
|
2019-03-29 03:25:33 +08:00
|
|
|
await stream.write(hello)
|
2019-03-24 01:52:02 +08:00
|
|
|
# Pass stream off to stream reader
|
2019-03-31 05:59:08 +08:00
|
|
|
asyncio.ensure_future(self.continuously_read_stream(stream))
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
async def handle_peer_queue(self):
|
|
|
|
"""
|
|
|
|
Continuously read from peer queue and each time a new peer is found,
|
|
|
|
open a stream to the peer using a supported pubsub protocol
|
|
|
|
TODO: Handle failure for when the peer does not support any of the
|
|
|
|
pubsub protocols we support
|
|
|
|
"""
|
|
|
|
while True:
|
2019-04-02 04:55:44 +08:00
|
|
|
|
2019-03-24 01:52:02 +08:00
|
|
|
peer_id = await self.peer_queue.get()
|
|
|
|
|
|
|
|
# Open a stream to peer on existing connection
|
|
|
|
# (we know connection exists since that's the only way
|
|
|
|
# an element gets added to peer_queue)
|
|
|
|
stream = await self.host.new_stream(peer_id, self.protocols)
|
|
|
|
|
|
|
|
# Add Peer
|
|
|
|
# Map peer to stream
|
|
|
|
self.peers[str(peer_id)] = stream
|
|
|
|
self.router.add_peer(peer_id, stream.get_protocol())
|
|
|
|
|
|
|
|
# Send hello packet
|
|
|
|
hello = self.get_hello_packet()
|
2019-03-29 03:25:33 +08:00
|
|
|
await stream.write(hello)
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
# Pass stream off to stream reader
|
2019-03-31 05:59:08 +08:00
|
|
|
asyncio.ensure_future(self.continuously_read_stream(stream))
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
# Force context switch
|
|
|
|
await asyncio.sleep(0)
|
|
|
|
|
2019-04-02 04:55:44 +08:00
|
|
|
def handle_subscription(self, origin_id, sub_message):
|
2019-03-24 01:52:02 +08:00
|
|
|
"""
|
|
|
|
Handle an incoming subscription message from a peer. Update internal
|
|
|
|
mapping to mark the peer as subscribed or unsubscribed to topics as
|
|
|
|
defined in the subscription message
|
2019-04-01 10:16:28 +08:00
|
|
|
:param origin_id: id of the peer who subscribe to the message
|
|
|
|
:param sub_message: RPC.SubOpts
|
2019-03-24 01:52:02 +08:00
|
|
|
"""
|
2019-04-01 10:16:28 +08:00
|
|
|
if sub_message.subscribe:
|
|
|
|
if sub_message.topicid not in self.peer_topics:
|
2019-04-02 04:55:44 +08:00
|
|
|
self.peer_topics[sub_message.topicid] = [origin_id]
|
|
|
|
elif origin_id not in self.peer_topics[sub_message.topicid]:
|
2019-04-01 10:16:28 +08:00
|
|
|
# Add peer to topic
|
2019-04-02 04:55:44 +08:00
|
|
|
self.peer_topics[sub_message.topicid].append(origin_id)
|
2019-04-01 10:16:28 +08:00
|
|
|
else:
|
2019-05-07 11:44:13 +08:00
|
|
|
if sub_message.topicid in self.peer_topics:
|
|
|
|
if origin_id in self.peer_topics[sub_message.topicid]:
|
|
|
|
self.peer_topics[sub_message.topicid].remove(origin_id)
|
2019-03-24 01:52:02 +08:00
|
|
|
|
2019-04-02 04:55:44 +08:00
|
|
|
async def handle_talk(self, publish_message):
|
2019-03-24 01:52:02 +08:00
|
|
|
"""
|
2019-04-01 10:16:28 +08:00
|
|
|
Put incoming message from a peer onto my blocking queue
|
|
|
|
:param talk: RPC.Message format
|
2019-03-24 01:52:02 +08:00
|
|
|
"""
|
|
|
|
|
|
|
|
# Check if this message has any topics that we are subscribed to
|
2019-03-31 06:49:50 +08:00
|
|
|
for topic in publish_message.topicIDs:
|
2019-03-24 01:52:02 +08:00
|
|
|
if topic in self.my_topics:
|
|
|
|
# we are subscribed to a topic this message was sent for,
|
|
|
|
# so add message to the subscription output queue
|
2019-04-03 10:34:01 +08:00
|
|
|
# for each topic
|
|
|
|
await self.my_topics[topic].put(publish_message)
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
async def subscribe(self, topic_id):
|
|
|
|
"""
|
|
|
|
Subscribe ourself to a topic
|
|
|
|
:param topic_id: topic_id to subscribe to
|
|
|
|
"""
|
2019-04-02 04:23:20 +08:00
|
|
|
|
2019-07-15 16:32:05 +08:00
|
|
|
# Already subscribed
|
|
|
|
if topic_id in self.my_topics:
|
|
|
|
return self.my_topics[topic_id]
|
|
|
|
|
2019-04-03 10:34:01 +08:00
|
|
|
# Map topic_id to blocking queue
|
|
|
|
self.my_topics[topic_id] = asyncio.Queue()
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
# Create subscribe message
|
2019-03-31 05:59:08 +08:00
|
|
|
packet = rpc_pb2.RPC()
|
|
|
|
packet.subscriptions.extend([rpc_pb2.RPC.SubOpts(
|
2019-04-02 04:55:44 +08:00
|
|
|
subscribe=True,
|
|
|
|
topicid=topic_id.encode('utf-8')
|
2019-03-31 05:59:08 +08:00
|
|
|
)])
|
2019-04-02 04:55:44 +08:00
|
|
|
|
2019-03-24 01:52:02 +08:00
|
|
|
# Send out subscribe message to all peers
|
2019-03-31 05:59:08 +08:00
|
|
|
await self.message_all_peers(packet.SerializeToString())
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
# Tell router we are joining this topic
|
2019-05-07 11:44:13 +08:00
|
|
|
await self.router.join(topic_id)
|
2019-03-24 01:52:02 +08:00
|
|
|
|
2019-04-03 10:34:01 +08:00
|
|
|
# Return the asyncio queue for messages on this topic
|
|
|
|
return self.my_topics[topic_id]
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
async def unsubscribe(self, topic_id):
|
|
|
|
"""
|
|
|
|
Unsubscribe ourself from a topic
|
|
|
|
:param topic_id: topic_id to unsubscribe from
|
|
|
|
"""
|
|
|
|
|
2019-07-18 13:26:31 +08:00
|
|
|
# Return if we already unsubscribed from the topic
|
|
|
|
if topic_id not in self.my_topics:
|
|
|
|
return
|
2019-03-24 01:52:02 +08:00
|
|
|
# Remove topic_id from map if present
|
2019-07-18 13:26:31 +08:00
|
|
|
del self.my_topics[topic_id]
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
# Create unsubscribe message
|
2019-03-31 05:59:08 +08:00
|
|
|
packet = rpc_pb2.RPC()
|
|
|
|
packet.subscriptions.extend([rpc_pb2.RPC.SubOpts(
|
2019-04-02 04:55:44 +08:00
|
|
|
subscribe=False,
|
|
|
|
topicid=topic_id.encode('utf-8')
|
2019-03-31 05:59:08 +08:00
|
|
|
)])
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
# Send out unsubscribe message to all peers
|
2019-03-31 05:59:08 +08:00
|
|
|
await self.message_all_peers(packet.SerializeToString())
|
2019-03-24 01:52:02 +08:00
|
|
|
|
|
|
|
# Tell router we are leaving this topic
|
2019-05-07 11:44:13 +08:00
|
|
|
await self.router.leave(topic_id)
|
2019-03-24 01:52:02 +08:00
|
|
|
|
2019-03-31 05:59:08 +08:00
|
|
|
async def message_all_peers(self, rpc_msg):
|
2019-03-24 01:52:02 +08:00
|
|
|
"""
|
|
|
|
Broadcast a message to peers
|
|
|
|
:param raw_msg: raw contents of the message to broadcast
|
|
|
|
"""
|
|
|
|
|
|
|
|
# Broadcast message
|
|
|
|
for peer in self.peers:
|
|
|
|
stream = self.peers[peer]
|
|
|
|
|
|
|
|
# Write message to stream
|
2019-03-31 05:59:08 +08:00
|
|
|
await stream.write(rpc_msg)
|