Merge pull request #66 from zixuanzh/mplex

Refactor Muxed_Connection to Mplex
This commit is contained in:
ZX 2018-11-21 00:45:25 -05:00 committed by GitHub
commit 5548041a37
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
14 changed files with 76 additions and 83 deletions

View File

@ -1,45 +0,0 @@
from .muxed_connection import MuxedConn
class Multiplex(object):
"""
muxing logic currently lives in MuxedConn
reference: https://github.com/whyrusleeping/go-smux-multiplex/blob/master/multiplex.go
"""
def __init__(self, conn, initiator):
"""
:param conn: an instance of raw connection
:param initiator: boolean to prevent multiplex with self
"""
self.muxed_conn = MuxedConn(conn, initiator)
def close(self):
"""
close the stream muxer and underlying raw connection
"""
return self.muxed_conn.close()
def is_closed(self):
"""
check connection is fully closed
:return: true if successful
"""
return self.muxed_conn.is_closed()
def open_stream(self, protocol_id, stream_name):
"""
creates a new muxed_stream
:return: a new stream
"""
return self.muxed_conn.open_stream(protocol_id, stream_name)
def accept_stream(self, _muxed_stream):
"""
accepts a muxed stream opened by the other end
:param _muxed_stream: stream to be accepted
:return: the accepted stream
"""
pass
# def new_conn(raw_conn, is_server):
# pass

View File

@ -9,6 +9,5 @@ class RawConnection(IRawConnection):
self.reader = reader self.reader = reader
self.writer = writer self.writer = writer
def close(self): def close(self):
self.writer.close() self.writer.close()

View File

@ -1,10 +1,10 @@
import asyncio import asyncio
from .utils import encode_uvarint, decode_uvarint from .utils import encode_uvarint, decode_uvarint
from .muxed_connection_interface import IMuxedConn from .mplex_stream import MplexStream
from .muxed_stream import MuxedStream from ..muxed_connection_interface import IMuxedConn
class MuxedConn(IMuxedConn): class Mplex(IMuxedConn):
""" """
reference: https://github.com/libp2p/go-mplex/blob/master/multiplex.go reference: https://github.com/libp2p/go-mplex/blob/master/multiplex.go
""" """
@ -19,6 +19,7 @@ class MuxedConn(IMuxedConn):
self.buffers = {} self.buffers = {}
self.streams = {} self.streams = {}
self.stream_queue = asyncio.Queue() self.stream_queue = asyncio.Queue()
self.conn_lock = asyncio.Lock()
# The initiator need not read upon construction time. # The initiator need not read upon construction time.
# It should read when the user decides that it wants to read from the constructed stream. # It should read when the user decides that it wants to read from the constructed stream.
@ -57,7 +58,7 @@ class MuxedConn(IMuxedConn):
:param multi_addr: multi_addr that stream connects to :param multi_addr: multi_addr that stream connects to
:return: a new stream :return: a new stream
""" """
stream = MuxedStream(stream_id, multi_addr, self) stream = MplexStream(stream_id, multi_addr, self)
self.streams[stream_id] = stream self.streams[stream_id] = stream
return stream return stream
@ -69,7 +70,7 @@ class MuxedConn(IMuxedConn):
# TODO update to pull out protocol_id from message # TODO update to pull out protocol_id from message
protocol_id = "/echo/1.0.0" protocol_id = "/echo/1.0.0"
stream_id = await self.stream_queue.get() stream_id = await self.stream_queue.get()
stream = MuxedStream(stream_id, False, self) stream = MplexStream(stream_id, False, self)
return stream, stream_id, protocol_id return stream, stream_id, protocol_id
async def send_message(self, flag, data, stream_id): async def send_message(self, flag, data, stream_id):

View File

@ -1,28 +1,28 @@
from .muxed_stream_interface import IMuxedStream import asyncio
from .constants import HEADER_TAGS from .constants import HEADER_TAGS
from ..muxed_stream_interface import IMuxedStream
class MuxedStream(IMuxedStream): class MplexStream(IMuxedStream):
""" """
reference: https://github.com/libp2p/go-mplex/blob/master/stream.go reference: https://github.com/libp2p/go-mplex/blob/master/stream.go
""" """
def __init__(self, stream_id, initiator, muxed_conn): def __init__(self, stream_id, initiator, mplex_conn):
""" """
create new MuxedStream in muxer create new MuxedStream in muxer
:param stream_id: stream stream id :param stream_id: stream stream id
:param initiator: boolean if this is an initiator :param initiator: boolean if this is an initiator
:param muxed_conn: muxed connection of this muxed_stream :param mplex_conn: muxed connection of this muxed_stream
""" """
self.stream_id = stream_id self.stream_id = stream_id
self.initiator = initiator self.initiator = initiator
self.muxed_conn = muxed_conn self.mplex_conn = mplex_conn
self.read_deadline = None self.read_deadline = None
self.write_deadline = None self.write_deadline = None
self.local_closed = False self.local_closed = False
self.remote_closed = False self.remote_closed = False
self.stream_lock = asyncio.Lock()
def get_flag(self, action): def get_flag(self, action):
""" """
@ -40,50 +40,60 @@ class MuxedStream(IMuxedStream):
read messages associated with stream from buffer til end of file read messages associated with stream from buffer til end of file
:return: bytes of input :return: bytes of input
""" """
return await self.muxed_conn.read_buffer(self.stream_id) return await self.mplex_conn.read_buffer(self.stream_id)
async def write(self, data): async def write(self, data):
""" """
write to stream write to stream
:return: number of bytes written :return: number of bytes written
""" """
return await self.muxed_conn.send_message(self.get_flag("MESSAGE"), data, self.stream_id) return await self.mplex_conn.send_message(self.get_flag("MESSAGE"), data, self.stream_id)
async def close(self): async def close(self):
""" """
close stream Closing a stream closes it for writing and closes the remote end for reading
but allows writing in the other direction.
:return: true if successful :return: true if successful
""" """
# TODO error handling with timeout
# TODO understand better how mutexes are used from go repo
await self.mplex_conn.send_message(self.get_flag("CLOSE"), None, self.stream_id)
if self.local_closed and self.remote_closed: remote_lock = ""
async with self.stream_lock:
if self.local_closed:
return True return True
await self.muxed_conn.send_message(self.get_flag("CLOSE"), None, self.stream_id)
self.muxed_conn.streams.pop(self.stream_id)
self.local_closed = True self.local_closed = True
self.remote_closed = True remote_lock = self.remote_closed
if remote_lock:
async with self.mplex_conn.conn_lock:
self.mplex_conn.streams.pop(self.stream_id)
return True return True
def reset(self): async def reset(self):
""" """
closes both ends of the stream closes both ends of the stream
tells this remote side to hang up tells this remote side to hang up
:return: true if successful :return: true if successful
""" """
# TODO behavior not fully understood # TODO understand better how mutexes are used here
pass # TODO understand the difference between close and reset
# if self.local_closed and self.remote_closed: async with self.stream_lock:
# return True if self.remote_closed and self.local_closed:
# return True
# self.muxed_conn.send_message(self.get_flag("RESET"), None, self.id)
# self.muxed_conn.streams.pop(self.id, None) if not self.remote_closed:
# await self.mplex_conn.send_message(self.get_flag("RESET"), None, self.stream_id)
# self.local_closed = True
# self.remote_closed = True self.local_closed = True
# self.remote_closed = True
# return True
async with self.mplex_conn.conn_lock:
self.mplex_conn.streams.pop(self.stream_id, None)
return True
# TODO deadline not in use # TODO deadline not in use
def set_deadline(self, ttl): def set_deadline(self, ttl):

View File

View File

@ -0,0 +1,28 @@
import asyncio
import pytest
# from network.connection.raw_connection import RawConnection
async def handle_echo(reader, writer):
data = await reader.read(100)
writer.write(data)
await writer.drain()
writer.close()
@pytest.mark.asyncio
# TODO: this test should develop out into a fuller test between MPlex modules communicating with each other.
async def test_simple_echo():
server_ip = '127.0.0.1'
server_port = 8888
await asyncio.start_server(handle_echo, server_ip, server_port)
reader, writer = await asyncio.open_connection(server_ip, server_port)
# raw_connection = RawConnection(server_ip, server_port, reader, writer)
test_message = "hello world"
writer.write(test_message.encode())
response = (await reader.read()).decode()
assert response == (test_message)

View File

@ -1,4 +1,4 @@
from muxer.mplex.muxed_connection import MuxedConn from stream_muxer.mplex.mplex import Mplex
class TransportUpgrader(): class TransportUpgrader():
@ -24,4 +24,4 @@ class TransportUpgrader():
# For PoC, no security, default to mplex # For PoC, no security, default to mplex
# TODO do exchange to determine multiplexer # TODO do exchange to determine multiplexer
return MuxedConn(conn, initiator) return Mplex(conn, initiator)