Update tests in test_tcp.py
Besides, run `make format`
This commit is contained in:
parent
1e600ea7e0
commit
79fcdf3a02
@ -1,7 +1,7 @@
|
|||||||
from typing import TYPE_CHECKING, Any, Awaitable, List, Set, Tuple
|
from typing import TYPE_CHECKING, Any, Awaitable, List, Set, Tuple
|
||||||
|
|
||||||
import trio
|
|
||||||
from async_service import Service
|
from async_service import Service
|
||||||
|
import trio
|
||||||
|
|
||||||
from libp2p.network.connection.net_connection_interface import INetConn
|
from libp2p.network.connection.net_connection_interface import INetConn
|
||||||
from libp2p.network.stream.net_stream import NetStream
|
from libp2p.network.stream.net_stream import NetStream
|
||||||
|
@ -2,7 +2,6 @@ import logging
|
|||||||
from typing import Dict, List, Optional
|
from typing import Dict, List, Optional
|
||||||
|
|
||||||
from async_service import Service
|
from async_service import Service
|
||||||
|
|
||||||
from multiaddr import Multiaddr
|
from multiaddr import Multiaddr
|
||||||
import trio
|
import trio
|
||||||
|
|
||||||
@ -205,7 +204,7 @@ class Swarm(INetwork, Service):
|
|||||||
|
|
||||||
logger.debug("successfully opened connection to peer %s", peer_id)
|
logger.debug("successfully opened connection to peer %s", peer_id)
|
||||||
# FIXME: This is a intentional barrier to prevent from the handler exiting and
|
# FIXME: This is a intentional barrier to prevent from the handler exiting and
|
||||||
# closing the connection.
|
# closing the connection. Probably change to `Service.manager.wait_finished`?
|
||||||
await trio.sleep_forever()
|
await trio.sleep_forever()
|
||||||
|
|
||||||
try:
|
try:
|
||||||
@ -229,16 +228,6 @@ class Swarm(INetwork, Service):
|
|||||||
async def close(self) -> None:
|
async def close(self) -> None:
|
||||||
# TODO: Prevent from new listeners and conns being added.
|
# TODO: Prevent from new listeners and conns being added.
|
||||||
# Reference: https://github.com/libp2p/go-libp2p-swarm/blob/8be680aef8dea0a4497283f2f98470c2aeae6b65/swarm.go#L124-L134 # noqa: E501
|
# Reference: https://github.com/libp2p/go-libp2p-swarm/blob/8be680aef8dea0a4497283f2f98470c2aeae6b65/swarm.go#L124-L134 # noqa: E501
|
||||||
|
|
||||||
# Close listeners
|
|
||||||
# await asyncio.gather(
|
|
||||||
# *[listener.close() for listener in self.listeners.values()]
|
|
||||||
# )
|
|
||||||
|
|
||||||
# # Close connections
|
|
||||||
# await asyncio.gather(
|
|
||||||
# *[connection.close() for connection in self.connections.values()]
|
|
||||||
# )
|
|
||||||
await self.manager.stop()
|
await self.manager.stop()
|
||||||
await self.manager.wait_finished()
|
await self.manager.wait_finished()
|
||||||
logger.debug("swarm successfully closed")
|
logger.debug("swarm successfully closed")
|
||||||
|
@ -1,11 +1,11 @@
|
|||||||
import math
|
|
||||||
import asyncio
|
import asyncio
|
||||||
import logging
|
import logging
|
||||||
|
import math
|
||||||
from typing import Any # noqa: F401
|
from typing import Any # noqa: F401
|
||||||
from typing import Awaitable, Dict, List, Optional, Tuple
|
from typing import Awaitable, Dict, List, Optional, Tuple
|
||||||
|
|
||||||
import trio
|
|
||||||
from async_service import Service
|
from async_service import Service
|
||||||
|
import trio
|
||||||
|
|
||||||
from libp2p.exceptions import ParseError
|
from libp2p.exceptions import ParseError
|
||||||
from libp2p.io.exceptions import IncompleteReadError
|
from libp2p.io.exceptions import IncompleteReadError
|
||||||
|
@ -1,9 +1,9 @@
|
|||||||
import trio
|
from contextlib import AsyncExitStack, asynccontextmanager
|
||||||
from contextlib import asynccontextmanager, AsyncExitStack
|
|
||||||
from typing import Any, AsyncIterator, Dict, Tuple, cast
|
from typing import Any, AsyncIterator, Dict, Tuple, cast
|
||||||
|
|
||||||
import factory
|
|
||||||
from async_service import background_trio_service
|
from async_service import background_trio_service
|
||||||
|
import factory
|
||||||
|
import trio
|
||||||
|
|
||||||
from libp2p import generate_new_rsa_identity, generate_peer_id_from
|
from libp2p import generate_new_rsa_identity, generate_peer_id_from
|
||||||
from libp2p.crypto.keys import KeyPair
|
from libp2p.crypto.keys import KeyPair
|
||||||
|
@ -1,7 +1,7 @@
|
|||||||
import trio
|
|
||||||
from typing import List, Sequence, Tuple
|
from typing import List, Sequence, Tuple
|
||||||
|
|
||||||
import multiaddr
|
import multiaddr
|
||||||
|
import trio
|
||||||
|
|
||||||
from libp2p import new_node
|
from libp2p import new_node
|
||||||
from libp2p.host.basic_host import BasicHost
|
from libp2p.host.basic_host import BasicHost
|
||||||
|
@ -25,7 +25,8 @@ class TCPListener(IListener):
|
|||||||
self.server = None
|
self.server = None
|
||||||
self.handler = handler_function
|
self.handler = handler_function
|
||||||
|
|
||||||
async def listen(self, maddr: Multiaddr, nursery: trio.Nursery) -> bool:
|
# TODO: Fix handling?
|
||||||
|
async def listen(self, maddr: Multiaddr, nursery: trio.Nursery) -> None:
|
||||||
"""
|
"""
|
||||||
put listener in listening mode and wait for incoming connections.
|
put listener in listening mode and wait for incoming connections.
|
||||||
|
|
||||||
@ -50,16 +51,13 @@ class TCPListener(IListener):
|
|||||||
socket = listeners[0].socket
|
socket = listeners[0].socket
|
||||||
self.multiaddrs.append(_multiaddr_from_socket(socket))
|
self.multiaddrs.append(_multiaddr_from_socket(socket))
|
||||||
|
|
||||||
return True
|
|
||||||
|
|
||||||
def get_addrs(self) -> List[Multiaddr]:
|
def get_addrs(self) -> List[Multiaddr]:
|
||||||
"""
|
"""
|
||||||
retrieve list of addresses the listener is listening on.
|
retrieve list of addresses the listener is listening on.
|
||||||
|
|
||||||
:return: return list of addrs
|
:return: return list of addrs
|
||||||
"""
|
"""
|
||||||
# TODO check if server is listening
|
return tuple(self.multiaddrs)
|
||||||
return self.multiaddrs
|
|
||||||
|
|
||||||
async def close(self) -> None:
|
async def close(self) -> None:
|
||||||
"""close the listener such that no more connections can be open on this
|
"""close the listener such that no more connections can be open on this
|
||||||
|
@ -1,5 +1,5 @@
|
|||||||
import trio
|
|
||||||
import pytest
|
import pytest
|
||||||
|
import trio
|
||||||
from trio.testing import wait_all_tasks_blocked
|
from trio.testing import wait_all_tasks_blocked
|
||||||
|
|
||||||
from libp2p.network.exceptions import SwarmException
|
from libp2p.network.exceptions import SwarmException
|
||||||
|
@ -1,6 +1,5 @@
|
|||||||
import trio
|
|
||||||
|
|
||||||
import pytest
|
import pytest
|
||||||
|
import trio
|
||||||
|
|
||||||
|
|
||||||
@pytest.mark.trio
|
@pytest.mark.trio
|
||||||
|
@ -7,11 +7,10 @@ from libp2p.stream_muxer.mplex.exceptions import (
|
|||||||
MplexStreamEOF,
|
MplexStreamEOF,
|
||||||
MplexStreamReset,
|
MplexStreamReset,
|
||||||
)
|
)
|
||||||
from libp2p.tools.constants import MAX_READ_LEN, LISTEN_MADDR
|
from libp2p.tools.constants import LISTEN_MADDR, MAX_READ_LEN
|
||||||
from libp2p.tools.factories import SwarmFactory
|
from libp2p.tools.factories import SwarmFactory
|
||||||
from libp2p.tools.utils import connect_swarm
|
from libp2p.tools.utils import connect_swarm
|
||||||
|
|
||||||
|
|
||||||
DATA = b"data_123"
|
DATA = b"data_123"
|
||||||
|
|
||||||
|
|
||||||
|
@ -1,20 +1,47 @@
|
|||||||
import asyncio
|
from multiaddr import Multiaddr
|
||||||
|
|
||||||
import pytest
|
import pytest
|
||||||
|
import trio
|
||||||
|
|
||||||
from libp2p.transport.tcp.tcp import _multiaddr_from_socket
|
from libp2p.network.connection.raw_connection import RawConnection
|
||||||
|
from libp2p.tools.constants import LISTEN_MADDR, MAX_READ_LEN
|
||||||
|
from libp2p.transport.tcp.tcp import TCP
|
||||||
|
|
||||||
|
|
||||||
@pytest.mark.asyncio
|
@pytest.mark.trio
|
||||||
async def test_multiaddr_from_socket():
|
async def test_tcp_listener(nursery):
|
||||||
def handler(r, w):
|
transport = TCP()
|
||||||
pass
|
|
||||||
|
|
||||||
server = await asyncio.start_server(handler, "127.0.0.1", 8000)
|
async def handler(tcp_stream):
|
||||||
assert str(_multiaddr_from_socket(server.sockets[0])) == "/ip4/127.0.0.1/tcp/8000"
|
...
|
||||||
|
|
||||||
server = await asyncio.start_server(handler, "127.0.0.1", 0)
|
listener = transport.create_listener(handler)
|
||||||
addr = _multiaddr_from_socket(server.sockets[0])
|
assert len(listener.get_addrs()) == 0
|
||||||
assert addr.value_for_protocol("ip4") == "127.0.0.1"
|
await listener.listen(LISTEN_MADDR, nursery)
|
||||||
port = addr.value_for_protocol("tcp")
|
assert len(listener.get_addrs()) == 1
|
||||||
assert int(port) > 0
|
await listener.listen(LISTEN_MADDR, nursery)
|
||||||
|
assert len(listener.get_addrs()) == 2
|
||||||
|
|
||||||
|
|
||||||
|
@pytest.mark.trio
|
||||||
|
async def test_tcp_dial(nursery):
|
||||||
|
transport = TCP()
|
||||||
|
raw_conn_other_side = None
|
||||||
|
|
||||||
|
async def handler(tcp_stream):
|
||||||
|
nonlocal raw_conn_other_side
|
||||||
|
raw_conn_other_side = RawConnection(tcp_stream, False)
|
||||||
|
await trio.sleep_forever()
|
||||||
|
|
||||||
|
# Test: OSError is raised when trying to dial to a port which no one is not listening to.
|
||||||
|
with pytest.raises(OSError):
|
||||||
|
await transport.dial(Multiaddr("/ip4/127.0.0.1/tcp/1"))
|
||||||
|
|
||||||
|
listener = transport.create_listener(handler)
|
||||||
|
await listener.listen(LISTEN_MADDR, nursery)
|
||||||
|
assert len(listener.multiaddrs) == 1
|
||||||
|
listen_addr = listener.multiaddrs[0]
|
||||||
|
raw_conn = await transport.dial(listen_addr)
|
||||||
|
|
||||||
|
data = b"123"
|
||||||
|
await raw_conn_other_side.write(data)
|
||||||
|
assert (await raw_conn.read(len(data))) == data
|
||||||
|
Loading…
x
Reference in New Issue
Block a user