run lint and fix errors, except mypy

This commit is contained in:
pacrob
2024-02-19 15:56:20 -07:00
parent 42605c0288
commit 94483714a3
171 changed files with 4809 additions and 2290 deletions

View File

@ -1,8 +1,12 @@
import pytest
import trio
from libp2p.tools.pubsub.dummy_account_node import DummyAccountNode
from libp2p.tools.utils import connect
from libp2p.tools.pubsub.dummy_account_node import (
DummyAccountNode,
)
from libp2p.tools.utils import (
connect,
)
async def perform_test(num_nodes, adjacency_map, action_func, assertion_func):

View File

@ -3,13 +3,19 @@ import functools
import pytest
import trio
from libp2p.peer.id import ID
from libp2p.tools.factories import PubsubFactory
from libp2p.peer.id import (
ID,
)
from libp2p.tools.factories import (
PubsubFactory,
)
from libp2p.tools.pubsub.floodsub_integration_test_settings import (
floodsub_protocol_pytest_params,
perform_test_from_obj,
)
from libp2p.tools.utils import connect
from libp2p.tools.utils import (
connect,
)
@pytest.mark.trio

View File

@ -3,10 +3,20 @@ import random
import pytest
import trio
from libp2p.pubsub.gossipsub import PROTOCOL_ID
from libp2p.tools.factories import IDFactory, PubsubFactory
from libp2p.tools.pubsub.utils import dense_connect, one_to_all_connect
from libp2p.tools.utils import connect
from libp2p.pubsub.gossipsub import (
PROTOCOL_ID,
)
from libp2p.tools.factories import (
IDFactory,
PubsubFactory,
)
from libp2p.tools.pubsub.utils import (
dense_connect,
one_to_all_connect,
)
from libp2p.tools.utils import (
connect,
)
@pytest.mark.trio
@ -353,11 +363,11 @@ async def test_mesh_heartbeat(initial_mesh_peer_count, monkeypatch):
1, heartbeat_initial_delay=100
) as pubsubs_gsub:
# It's difficult to set up the initial peer subscription condition.
# Ideally I would like to have initial mesh peer count that's below ``GossipSubDegree``
# so I can test if `mesh_heartbeat` return correct peers to GRAFT.
# The problem is that I can not set it up so that we have peers subscribe to the topic
# but not being part of our mesh peers (as these peers are the peers to GRAFT).
# So I monkeypatch the peer subscriptions and our mesh peers.
# Ideally I would like to have initial mesh peer count that's below
# ``GossipSubDegree`` so I can test if `mesh_heartbeat` return correct peers to
# GRAFT. The problem is that I can not set it up so that we have peers subscribe
# to the topic but not being part of our mesh peers (as these peers are the
# peers to GRAFT). So I monkeypatch the peer subscriptions and our mesh peers.
total_peer_count = 14
topic = "TEST_MESH_HEARTBEAT"
@ -408,9 +418,9 @@ async def test_gossip_heartbeat(initial_peer_count, monkeypatch):
async with PubsubFactory.create_batch_with_gossipsub(
1, heartbeat_initial_delay=100
) as pubsubs_gsub:
# The problem is that I can not set it up so that we have peers subscribe to the topic
# but not being part of our mesh peers (as these peers are the peers to GRAFT).
# So I monkeypatch the peer subscriptions and our mesh peers.
# The problem is that I can not set it up so that we have peers subscribe to the
# topic but not being part of our mesh peers (as these peers are the peers to
# GRAFT). So I monkeypatch the peer subscriptions and our mesh peers.
total_peer_count = 28
topic_mesh = "TEST_GOSSIP_HEARTBEAT_1"
topic_fanout = "TEST_GOSSIP_HEARTBEAT_2"
@ -455,8 +465,8 @@ async def test_gossip_heartbeat(initial_peer_count, monkeypatch):
monkeypatch.setattr(pubsubs_gsub[0].router.mcache, "window", window)
peers_to_gossip = pubsubs_gsub[0].router.gossip_heartbeat()
# If our mesh peer count is less than `GossipSubDegree`, we should gossip to up to
# `GossipSubDegree` peers (exclude mesh peers).
# If our mesh peer count is less than `GossipSubDegree`, we should gossip to up
# to `GossipSubDegree` peers (exclude mesh peers).
if topic_mesh_peer_count - initial_peer_count < pubsubs_gsub[0].router.degree:
# The same goes for fanout so it's two times the number of peers to gossip.
assert len(peers_to_gossip) == 2 * (

View File

@ -2,8 +2,12 @@ import functools
import pytest
from libp2p.tools.constants import FLOODSUB_PROTOCOL_ID
from libp2p.tools.factories import PubsubFactory
from libp2p.tools.constants import (
FLOODSUB_PROTOCOL_ID,
)
from libp2p.tools.factories import (
PubsubFactory,
)
from libp2p.tools.pubsub.floodsub_integration_test_settings import (
floodsub_protocol_pytest_params,
perform_test_from_obj,

View File

@ -1,4 +1,6 @@
from libp2p.pubsub.mcache import MessageCache
from libp2p.pubsub.mcache import (
MessageCache,
)
class Msg:

View File

@ -1,17 +1,40 @@
from contextlib import contextmanager
from typing import NamedTuple
from contextlib import (
contextmanager,
)
from typing import (
NamedTuple,
)
import pytest
import trio
from libp2p.exceptions import ValidationError
from libp2p.pubsub.pb import rpc_pb2
from libp2p.pubsub.pubsub import PUBSUB_SIGNING_PREFIX, SUBSCRIPTION_CHANNEL_SIZE
from libp2p.tools.constants import MAX_READ_LEN
from libp2p.tools.factories import IDFactory, PubsubFactory, net_stream_pair_factory
from libp2p.tools.pubsub.utils import make_pubsub_msg
from libp2p.tools.utils import connect
from libp2p.utils import encode_varint_prefixed
from libp2p.exceptions import (
ValidationError,
)
from libp2p.pubsub.pb import (
rpc_pb2,
)
from libp2p.pubsub.pubsub import (
PUBSUB_SIGNING_PREFIX,
SUBSCRIPTION_CHANNEL_SIZE,
)
from libp2p.tools.constants import (
MAX_READ_LEN,
)
from libp2p.tools.factories import (
IDFactory,
PubsubFactory,
net_stream_pair_factory,
)
from libp2p.tools.pubsub.utils import (
make_pubsub_msg,
)
from libp2p.tools.utils import (
connect,
)
from libp2p.utils import (
encode_varint_prefixed,
)
TESTING_TOPIC = "TEST_SUBSCRIBE"
TESTING_DATA = b"data"
@ -77,7 +100,8 @@ async def test_get_hello_packet():
packet = pubsubs_fsub[0].get_hello_packet()
return tuple(sub.topicid for sub in packet.subscriptions)
# Test: No subscription, so there should not be any topic ids in the hello packet.
# Test: No subscription, so there should not be any topic ids in the
# hello packet.
assert len(_get_hello_packet_topic_ids()) == 0
# Test: After subscriptions, topic ids should be in the hello packet.
@ -469,7 +493,8 @@ async def test_subscribe_and_publish_full_channel():
for data in list_data:
await pubsub.publish(TESTING_TOPIC, data)
# Publish `extra_data_0` which should be dropped since the channel is already full.
# Publish `extra_data_0` which should be dropped since the channel is
# already full.
await pubsub.publish(TESTING_TOPIC, extra_data_0)
# Consume a message and there is an empty slot in the channel.
assert (await subscription.get()).data == expected_list_data.pop(0)
@ -520,7 +545,6 @@ async def test_push_msg(monkeypatch):
@contextmanager
def mock_router_publish():
event = trio.Event()
async def router_publish(*args, **kwargs):

View File

@ -3,8 +3,12 @@ import math
import pytest
import trio
from libp2p.pubsub.pb import rpc_pb2
from libp2p.pubsub.subscription import TrioSubscriptionAPI
from libp2p.pubsub.pb import (
rpc_pb2,
)
from libp2p.pubsub.subscription import (
TrioSubscriptionAPI,
)
GET_TIMEOUT = 0.001