Add clean-up logics into TrioSubscriptionAPI

Register an `unsubscribe_fn` when initializing the TrioSubscriptionAPI.
`unsubscribe_fn` is called when subscription is unsubscribed.
This commit is contained in:
mhchia 2020-01-28 00:29:05 +08:00
parent c3ba67ea87
commit 095a848f30
No known key found for this signature in database
GPG Key ID: 389EFBEA1362589A
6 changed files with 70 additions and 16 deletions

View File

@ -24,7 +24,7 @@ class ISubscriptionAPI(
AsyncContextManager["ISubscriptionAPI"], AsyncIterable[rpc_pb2.Message] AsyncContextManager["ISubscriptionAPI"], AsyncIterable[rpc_pb2.Message]
): ):
@abstractmethod @abstractmethod
async def cancel(self) -> None: async def unsubscribe(self) -> None:
... ...
@abstractmethod @abstractmethod

View File

@ -1,3 +1,4 @@
import functools
import logging import logging
import math import math
import time import time
@ -387,9 +388,14 @@ class Pubsub(Service, IPubsub):
if topic_id in self.topic_ids: if topic_id in self.topic_ids:
return self.subscribed_topics_receive[topic_id] return self.subscribed_topics_receive[topic_id]
channels = trio.open_memory_channel[rpc_pb2.Message](math.inf) send_channel, receive_channel = trio.open_memory_channel[rpc_pb2.Message](
send_channel, receive_channel = channels math.inf
subscription = TrioSubscriptionAPI(receive_channel) )
subscription = TrioSubscriptionAPI(
receive_channel,
unsubscribe_fn=functools.partial(self.unsubscribe, topic_id),
)
self.subscribed_topics_send[topic_id] = send_channel self.subscribed_topics_send[topic_id] = send_channel
self.subscribed_topics_receive[topic_id] = subscription self.subscribed_topics_receive[topic_id] = subscription

View File

@ -5,6 +5,7 @@ import trio
from .abc import ISubscriptionAPI from .abc import ISubscriptionAPI
from .pb import rpc_pb2 from .pb import rpc_pb2
from .typing import UnsubscribeFn
class BaseSubscriptionAPI(ISubscriptionAPI): class BaseSubscriptionAPI(ISubscriptionAPI):
@ -18,19 +19,25 @@ class BaseSubscriptionAPI(ISubscriptionAPI):
exc_value: "Optional[BaseException]", exc_value: "Optional[BaseException]",
traceback: "Optional[TracebackType]", traceback: "Optional[TracebackType]",
) -> None: ) -> None:
await self.cancel() await self.unsubscribe()
class TrioSubscriptionAPI(BaseSubscriptionAPI): class TrioSubscriptionAPI(BaseSubscriptionAPI):
receive_channel: "trio.MemoryReceiveChannel[rpc_pb2.Message]" receive_channel: "trio.MemoryReceiveChannel[rpc_pb2.Message]"
unsubscribe_fn: UnsubscribeFn
def __init__( def __init__(
self, receive_channel: "trio.MemoryReceiveChannel[rpc_pb2.Message]" self,
receive_channel: "trio.MemoryReceiveChannel[rpc_pb2.Message]",
unsubscribe_fn: UnsubscribeFn,
) -> None: ) -> None:
self.receive_channel = receive_channel self.receive_channel = receive_channel
# Ignore type here since mypy complains: https://github.com/python/mypy/issues/2427
self.unsubscribe_fn = unsubscribe_fn # type: ignore
async def cancel(self) -> None: async def unsubscribe(self) -> None:
await self.receive_channel.aclose() # Ignore type here since mypy complains: https://github.com/python/mypy/issues/2427
await self.unsubscribe_fn() # type: ignore
def __aiter__(self) -> AsyncIterator[rpc_pb2.Message]: def __aiter__(self) -> AsyncIterator[rpc_pb2.Message]:
return self.receive_channel.__aiter__() return self.receive_channel.__aiter__()

View File

@ -7,3 +7,5 @@ from .pb import rpc_pb2
SyncValidatorFn = Callable[[ID, rpc_pb2.Message], bool] SyncValidatorFn = Callable[[ID, rpc_pb2.Message], bool]
AsyncValidatorFn = Callable[[ID, rpc_pb2.Message], Awaitable[bool]] AsyncValidatorFn = Callable[[ID, rpc_pb2.Message], Awaitable[bool]]
ValidatorFn = Union[SyncValidatorFn, AsyncValidatorFn] ValidatorFn = Union[SyncValidatorFn, AsyncValidatorFn]
UnsubscribeFn = Callable[[], Awaitable[None]]

View File

@ -413,7 +413,39 @@ async def test_message_all_peers(monkeypatch, is_host_secure):
@pytest.mark.trio @pytest.mark.trio
async def test_publish(monkeypatch): async def test_subscribe_and_publish():
async with PubsubFactory.create_batch_with_floodsub(1) as pubsubs_fsub:
pubsub = pubsubs_fsub[0]
list_data = [b"d0", b"d1"]
event_receive_data_started = trio.Event()
async def publish_data(topic):
await event_receive_data_started.wait()
for data in list_data:
await pubsub.publish(topic, data)
async def receive_data(topic):
i = 0
event_receive_data_started.set()
assert topic not in pubsub.topic_ids
subscription = await pubsub.subscribe(topic)
async with subscription:
assert topic in pubsub.topic_ids
async for msg in subscription:
assert msg.data == list_data[i]
i += 1
if i == len(list_data):
break
assert topic not in pubsub.topic_ids
async with trio.open_nursery() as nursery:
nursery.start_soon(receive_data, TESTING_TOPIC)
nursery.start_soon(publish_data, TESTING_TOPIC)
@pytest.mark.trio
async def test_publish_push_msg_is_called(monkeypatch):
msg_forwarders = [] msg_forwarders = []
msgs = [] msgs = []

View File

@ -11,7 +11,14 @@ GET_TIMEOUT = 0.001
def make_trio_subscription(): def make_trio_subscription():
send_channel, receive_channel = trio.open_memory_channel(math.inf) send_channel, receive_channel = trio.open_memory_channel(math.inf)
return send_channel, TrioSubscriptionAPI(receive_channel)
async def unsubscribe_fn():
await send_channel.aclose()
return (
send_channel,
TrioSubscriptionAPI(receive_channel, unsubscribe_fn=unsubscribe_fn),
)
def make_pubsub_msg(): def make_pubsub_msg():
@ -56,14 +63,14 @@ async def test_trio_subscription_iter():
@pytest.mark.trio @pytest.mark.trio
async def test_trio_subscription_cancel(): async def test_trio_subscription_unsubscribe():
send_channel, sub = make_trio_subscription() send_channel, sub = make_trio_subscription()
await sub.cancel() await sub.unsubscribe()
# Test: If the subscription is cancelled, `send_channel` should be broken. # Test: If the subscription is unsubscribed, `send_channel` should be closed.
with pytest.raises(trio.BrokenResourceError): with pytest.raises(trio.ClosedResourceError):
await send_something(send_channel) await send_something(send_channel)
# Test: No side effect when cancelled twice. # Test: No side effect when cancelled twice.
await sub.cancel() await sub.unsubscribe()
@pytest.mark.trio @pytest.mark.trio
@ -73,5 +80,5 @@ async def test_trio_subscription_async_context_manager():
# Test: `sub` is not cancelled yet, so `send_something` works fine. # Test: `sub` is not cancelled yet, so `send_something` works fine.
await send_something(send_channel) await send_something(send_channel)
# Test: `sub` is cancelled, `send_something` fails # Test: `sub` is cancelled, `send_something` fails
with pytest.raises(trio.BrokenResourceError): with pytest.raises(trio.ClosedResourceError):
await send_something(send_channel) await send_something(send_channel)