Compare commits
61 Commits
main
...
to_asyncio
Author | SHA1 | Date |
---|---|---|
|
da9bc1237d | |
|
ab11ee4fbe | |
|
466dce8aed | |
|
808dd9d73c | |
|
aef306465d | |
|
7459a4127c | |
|
fc77e6eca5 | |
|
26526b86c3 | |
|
d079675dd4 | |
|
c2acc4f55c | |
|
326b258fd5 | |
|
4f4c7e6b67 | |
|
c05d08e426 | |
|
02062c5dc0 | |
|
72c4a9d20b | |
|
ccc3b1fce1 | |
|
11c4e65757 | |
|
33ac3ca99f | |
|
9ada628a57 | |
|
d2c3e32bf1 | |
|
51944a0b99 | |
|
024e8015da | |
|
aaed3a4a37 | |
|
edffd5e367 | |
|
4ca81e39e6 | |
|
dd7aca539f | |
|
735dc9056a | |
|
e949839edf | |
|
6194ac891c | |
|
6554e324f2 | |
|
076caeb596 | |
|
faa678e209 | |
|
c5d68f6b58 | |
|
506aefb917 | |
|
7436d52f37 | |
|
80b074e3e7 | |
|
e97efb7099 | |
|
81b11fd665 | |
|
aa2b1fbf8b | |
|
82c12253e5 | |
|
7f451409ec | |
|
9be6f6d3e9 | |
|
9d2c7ae3cf | |
|
a81a1be40c | |
|
c85575e6ce | |
|
aa98cbd848 | |
|
a890e9aa83 | |
|
1592f7e6be | |
|
1c9293e69d | |
|
ec13c1b31d | |
|
7ce366097d | |
|
6cedda008a | |
|
207175d78e | |
|
57b5e51099 | |
|
b72c8dce9b | |
|
bfa4d71009 | |
|
434e22680e | |
|
636c19866c | |
|
e9f2fecd66 | |
|
547cf5a210 | |
|
b5e3fa7370 |
|
@ -317,7 +317,6 @@ def test_subactor_breakpoint(
|
||||||
|
|
||||||
assert in_prompt_msg(
|
assert in_prompt_msg(
|
||||||
child, [
|
child, [
|
||||||
'MessagingError:',
|
|
||||||
'RemoteActorError:',
|
'RemoteActorError:',
|
||||||
"('breakpoint_forever'",
|
"('breakpoint_forever'",
|
||||||
'bdb.BdbQuit',
|
'bdb.BdbQuit',
|
||||||
|
|
|
@ -121,9 +121,11 @@ def test_shield_pause(
|
||||||
child.pid,
|
child.pid,
|
||||||
signal.SIGINT,
|
signal.SIGINT,
|
||||||
)
|
)
|
||||||
|
from tractor._supervise import _shutdown_msg
|
||||||
expect(
|
expect(
|
||||||
child,
|
child,
|
||||||
'Shutting down actor runtime',
|
# 'Shutting down actor runtime',
|
||||||
|
_shutdown_msg,
|
||||||
timeout=6,
|
timeout=6,
|
||||||
)
|
)
|
||||||
assert_before(
|
assert_before(
|
||||||
|
|
|
@ -0,0 +1,113 @@
|
||||||
|
'''
|
||||||
|
Unit-ish tests for specific IPC transport protocol backends.
|
||||||
|
|
||||||
|
'''
|
||||||
|
from __future__ import annotations
|
||||||
|
from pathlib import Path
|
||||||
|
|
||||||
|
import pytest
|
||||||
|
import trio
|
||||||
|
import tractor
|
||||||
|
from tractor import (
|
||||||
|
Actor,
|
||||||
|
_state,
|
||||||
|
_addr,
|
||||||
|
)
|
||||||
|
|
||||||
|
|
||||||
|
@pytest.fixture
|
||||||
|
def bindspace_dir_str() -> str:
|
||||||
|
|
||||||
|
bs_dir_str: str = '/run/user/1000/doggy'
|
||||||
|
bs_dir = Path(bs_dir_str)
|
||||||
|
assert not bs_dir.is_dir()
|
||||||
|
|
||||||
|
yield bs_dir_str
|
||||||
|
|
||||||
|
# delete it on suite teardown.
|
||||||
|
# ?TODO? should we support this internally
|
||||||
|
# or is leaking it ok?
|
||||||
|
if bs_dir.is_dir():
|
||||||
|
bs_dir.rmdir()
|
||||||
|
|
||||||
|
|
||||||
|
def test_uds_bindspace_created_implicitly(
|
||||||
|
debug_mode: bool,
|
||||||
|
bindspace_dir_str: str,
|
||||||
|
):
|
||||||
|
registry_addr: tuple = (
|
||||||
|
f'{bindspace_dir_str}',
|
||||||
|
'registry@doggy.sock',
|
||||||
|
)
|
||||||
|
bs_dir_str: str = registry_addr[0]
|
||||||
|
|
||||||
|
# XXX, ensure bindspace-dir DNE beforehand!
|
||||||
|
assert not Path(bs_dir_str).is_dir()
|
||||||
|
|
||||||
|
async def main():
|
||||||
|
async with tractor.open_nursery(
|
||||||
|
enable_transports=['uds'],
|
||||||
|
registry_addrs=[registry_addr],
|
||||||
|
debug_mode=debug_mode,
|
||||||
|
) as _an:
|
||||||
|
|
||||||
|
# XXX MUST be created implicitly by
|
||||||
|
# `.ipc._uds.start_listener()`!
|
||||||
|
assert Path(bs_dir_str).is_dir()
|
||||||
|
|
||||||
|
root: Actor = tractor.current_actor()
|
||||||
|
assert root.is_registrar
|
||||||
|
|
||||||
|
assert registry_addr in root.reg_addrs
|
||||||
|
assert (
|
||||||
|
registry_addr
|
||||||
|
in
|
||||||
|
_state._runtime_vars['_registry_addrs']
|
||||||
|
)
|
||||||
|
assert (
|
||||||
|
_addr.wrap_address(registry_addr)
|
||||||
|
in
|
||||||
|
root.registry_addrs
|
||||||
|
)
|
||||||
|
|
||||||
|
trio.run(main)
|
||||||
|
|
||||||
|
|
||||||
|
def test_uds_double_listen_raises_connerr(
|
||||||
|
debug_mode: bool,
|
||||||
|
bindspace_dir_str: str,
|
||||||
|
):
|
||||||
|
registry_addr: tuple = (
|
||||||
|
f'{bindspace_dir_str}',
|
||||||
|
'registry@doggy.sock',
|
||||||
|
)
|
||||||
|
|
||||||
|
async def main():
|
||||||
|
async with tractor.open_nursery(
|
||||||
|
enable_transports=['uds'],
|
||||||
|
registry_addrs=[registry_addr],
|
||||||
|
debug_mode=debug_mode,
|
||||||
|
) as _an:
|
||||||
|
|
||||||
|
# runtime up
|
||||||
|
root: Actor = tractor.current_actor()
|
||||||
|
|
||||||
|
from tractor.ipc._uds import (
|
||||||
|
start_listener,
|
||||||
|
UDSAddress,
|
||||||
|
)
|
||||||
|
ya_bound_addr: UDSAddress = root.registry_addrs[0]
|
||||||
|
try:
|
||||||
|
await start_listener(
|
||||||
|
addr=ya_bound_addr,
|
||||||
|
)
|
||||||
|
except ConnectionError as connerr:
|
||||||
|
assert type(src_exc := connerr.__context__) is OSError
|
||||||
|
assert 'Address already in use' in src_exc.args
|
||||||
|
# complete, exit test.
|
||||||
|
|
||||||
|
else:
|
||||||
|
pytest.fail('It dint raise a connerr !?')
|
||||||
|
|
||||||
|
|
||||||
|
trio.run(main)
|
|
@ -573,6 +573,8 @@ def test_basic_interloop_channel_stream(
|
||||||
fan_out: bool,
|
fan_out: bool,
|
||||||
):
|
):
|
||||||
async def main():
|
async def main():
|
||||||
|
# TODO, figure out min timeout here!
|
||||||
|
with trio.fail_after(6):
|
||||||
async with tractor.open_nursery() as an:
|
async with tractor.open_nursery() as an:
|
||||||
portal = await an.run_in_actor(
|
portal = await an.run_in_actor(
|
||||||
stream_from_aio,
|
stream_from_aio,
|
||||||
|
@ -1088,6 +1090,108 @@ def test_sigint_closes_lifetime_stack(
|
||||||
trio.run(main)
|
trio.run(main)
|
||||||
|
|
||||||
|
|
||||||
|
|
||||||
|
# ?TODO asyncio.Task fn-deco?
|
||||||
|
# -[ ] do sig checkingat import time like @context?
|
||||||
|
# -[ ] maybe name it @aio_task ??
|
||||||
|
# -[ ] chan: to_asyncio.InterloopChannel ??
|
||||||
|
async def raise_before_started(
|
||||||
|
# from_trio: asyncio.Queue,
|
||||||
|
# to_trio: trio.abc.SendChannel,
|
||||||
|
chan: to_asyncio.LinkedTaskChannel,
|
||||||
|
|
||||||
|
) -> None:
|
||||||
|
'''
|
||||||
|
`asyncio.Task` entry point which RTEs before calling
|
||||||
|
`to_trio.send_nowait()`.
|
||||||
|
|
||||||
|
'''
|
||||||
|
await asyncio.sleep(0.2)
|
||||||
|
raise RuntimeError('Some shite went wrong before `.send_nowait()`!!')
|
||||||
|
|
||||||
|
# to_trio.send_nowait('Uhh we shouldve RTE-d ^^ ??')
|
||||||
|
chan.started_nowait('Uhh we shouldve RTE-d ^^ ??')
|
||||||
|
await asyncio.sleep(float('inf'))
|
||||||
|
|
||||||
|
|
||||||
|
@tractor.context
|
||||||
|
async def caching_ep(
|
||||||
|
ctx: tractor.Context,
|
||||||
|
):
|
||||||
|
|
||||||
|
log = tractor.log.get_logger('caching_ep')
|
||||||
|
log.info('syncing via `ctx.started()`')
|
||||||
|
await ctx.started()
|
||||||
|
|
||||||
|
# XXX, allocate the `open_channel_from()` inside
|
||||||
|
# a `.trionics.maybe_open_context()`.
|
||||||
|
chan: to_asyncio.LinkedTaskChannel
|
||||||
|
async with (
|
||||||
|
tractor.trionics.maybe_open_context(
|
||||||
|
acm_func=tractor.to_asyncio.open_channel_from,
|
||||||
|
kwargs={
|
||||||
|
'target': raise_before_started,
|
||||||
|
# ^XXX, kwarg to `open_channel_from()`
|
||||||
|
},
|
||||||
|
|
||||||
|
# lock around current actor task access
|
||||||
|
key=tractor.current_actor().uid,
|
||||||
|
|
||||||
|
) as (cache_hit, (clients, chan)),
|
||||||
|
):
|
||||||
|
if cache_hit:
|
||||||
|
log.error(
|
||||||
|
'Re-using cached `.open_from_channel()` call!\n'
|
||||||
|
)
|
||||||
|
|
||||||
|
else:
|
||||||
|
log.info(
|
||||||
|
'Allocating SHOULD-FAIL `.open_from_channel()`\n'
|
||||||
|
)
|
||||||
|
|
||||||
|
await trio.sleep_forever()
|
||||||
|
|
||||||
|
|
||||||
|
def test_aio_side_raises_before_started(
|
||||||
|
reg_addr: tuple[str, int],
|
||||||
|
debug_mode: bool,
|
||||||
|
loglevel: str,
|
||||||
|
):
|
||||||
|
'''
|
||||||
|
Simulates connection-err from `piker.brokers.ib.api`..
|
||||||
|
|
||||||
|
Ensure any error raised by child-`asyncio.Task` BEFORE
|
||||||
|
`chan.started()`
|
||||||
|
|
||||||
|
'''
|
||||||
|
# delay = 999 if debug_mode else 1
|
||||||
|
async def main():
|
||||||
|
with trio.fail_after(3):
|
||||||
|
an: tractor.ActorNursery
|
||||||
|
async with tractor.open_nursery(
|
||||||
|
debug_mode=debug_mode,
|
||||||
|
loglevel=loglevel,
|
||||||
|
) as an:
|
||||||
|
p: tractor.Portal = await an.start_actor(
|
||||||
|
'lchan_cacher_that_raises_fast',
|
||||||
|
enable_modules=[__name__],
|
||||||
|
infect_asyncio=True,
|
||||||
|
)
|
||||||
|
async with p.open_context(
|
||||||
|
caching_ep,
|
||||||
|
) as (ctx, first):
|
||||||
|
assert not first
|
||||||
|
|
||||||
|
with pytest.raises(
|
||||||
|
expected_exception=(RemoteActorError),
|
||||||
|
) as excinfo:
|
||||||
|
trio.run(main)
|
||||||
|
|
||||||
|
# ensure `asyncio.Task` exception is bubbled
|
||||||
|
# allll the way erp!!
|
||||||
|
rae = excinfo.value
|
||||||
|
assert rae.boxed_type is RuntimeError
|
||||||
|
|
||||||
# TODO: debug_mode tests once we get support for `asyncio`!
|
# TODO: debug_mode tests once we get support for `asyncio`!
|
||||||
#
|
#
|
||||||
# -[ ] need tests to wrap both scripts:
|
# -[ ] need tests to wrap both scripts:
|
||||||
|
|
|
@ -410,7 +410,6 @@ def test_peer_canceller(
|
||||||
'''
|
'''
|
||||||
async def main():
|
async def main():
|
||||||
async with tractor.open_nursery(
|
async with tractor.open_nursery(
|
||||||
# NOTE: to halt the peer tasks on ctxc, uncomment this.
|
|
||||||
debug_mode=debug_mode,
|
debug_mode=debug_mode,
|
||||||
) as an:
|
) as an:
|
||||||
canceller: Portal = await an.start_actor(
|
canceller: Portal = await an.start_actor(
|
||||||
|
|
|
@ -1,5 +1,6 @@
|
||||||
'''
|
'''
|
||||||
Async context manager cache api testing: ``trionics.maybe_open_context():``
|
Suites for our `.trionics.maybe_open_context()` multi-task
|
||||||
|
shared-cached `@acm` API.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
from contextlib import asynccontextmanager as acm
|
from contextlib import asynccontextmanager as acm
|
||||||
|
@ -9,6 +10,15 @@ from typing import Awaitable
|
||||||
import pytest
|
import pytest
|
||||||
import trio
|
import trio
|
||||||
import tractor
|
import tractor
|
||||||
|
from tractor.trionics import (
|
||||||
|
maybe_open_context,
|
||||||
|
)
|
||||||
|
from tractor.log import (
|
||||||
|
get_console_log,
|
||||||
|
get_logger,
|
||||||
|
)
|
||||||
|
log = get_logger(__name__)
|
||||||
|
|
||||||
|
|
||||||
|
|
||||||
_resource: int = 0
|
_resource: int = 0
|
||||||
|
@ -52,7 +62,7 @@ def test_resource_only_entered_once(key_on):
|
||||||
# different task names per task will be used
|
# different task names per task will be used
|
||||||
kwargs = {'task_name': name}
|
kwargs = {'task_name': name}
|
||||||
|
|
||||||
async with tractor.trionics.maybe_open_context(
|
async with maybe_open_context(
|
||||||
maybe_increment_counter,
|
maybe_increment_counter,
|
||||||
kwargs=kwargs,
|
kwargs=kwargs,
|
||||||
key=key,
|
key=key,
|
||||||
|
@ -72,11 +82,13 @@ def test_resource_only_entered_once(key_on):
|
||||||
with trio.move_on_after(0.5):
|
with trio.move_on_after(0.5):
|
||||||
async with (
|
async with (
|
||||||
tractor.open_root_actor(),
|
tractor.open_root_actor(),
|
||||||
trio.open_nursery() as n,
|
trio.open_nursery() as tn,
|
||||||
):
|
):
|
||||||
|
|
||||||
for i in range(10):
|
for i in range(10):
|
||||||
n.start_soon(enter_cached_mngr, f'task_{i}')
|
tn.start_soon(
|
||||||
|
enter_cached_mngr,
|
||||||
|
f'task_{i}',
|
||||||
|
)
|
||||||
await trio.sleep(0.001)
|
await trio.sleep(0.001)
|
||||||
|
|
||||||
trio.run(main)
|
trio.run(main)
|
||||||
|
@ -98,21 +110,32 @@ async def streamer(
|
||||||
|
|
||||||
|
|
||||||
@acm
|
@acm
|
||||||
async def open_stream() -> Awaitable[tractor.MsgStream]:
|
async def open_stream() -> Awaitable[
|
||||||
|
tuple[
|
||||||
|
tractor.ActorNursery,
|
||||||
|
tractor.MsgStream,
|
||||||
|
]
|
||||||
|
]:
|
||||||
try:
|
try:
|
||||||
async with tractor.open_nursery() as an:
|
async with tractor.open_nursery() as an:
|
||||||
portal = await an.start_actor(
|
portal = await an.start_actor(
|
||||||
'streamer',
|
'streamer',
|
||||||
enable_modules=[__name__],
|
enable_modules=[__name__],
|
||||||
)
|
)
|
||||||
|
try:
|
||||||
async with (
|
async with (
|
||||||
portal.open_context(streamer) as (ctx, first),
|
portal.open_context(streamer) as (ctx, first),
|
||||||
ctx.open_stream() as stream,
|
ctx.open_stream() as stream,
|
||||||
):
|
):
|
||||||
yield stream
|
print('Entered open_stream() caller')
|
||||||
|
yield an, stream
|
||||||
|
print('Exited open_stream() caller')
|
||||||
|
|
||||||
print('Cancelling streamer')
|
finally:
|
||||||
|
print(
|
||||||
|
'Cancelling streamer with,\n'
|
||||||
|
'=> `Portal.cancel_actor()`'
|
||||||
|
)
|
||||||
await portal.cancel_actor()
|
await portal.cancel_actor()
|
||||||
print('Cancelled streamer')
|
print('Cancelled streamer')
|
||||||
|
|
||||||
|
@ -127,11 +150,15 @@ async def open_stream() -> Awaitable[tractor.MsgStream]:
|
||||||
|
|
||||||
@acm
|
@acm
|
||||||
async def maybe_open_stream(taskname: str):
|
async def maybe_open_stream(taskname: str):
|
||||||
async with tractor.trionics.maybe_open_context(
|
async with maybe_open_context(
|
||||||
# NOTE: all secondary tasks should cache hit on the same key
|
# NOTE: all secondary tasks should cache hit on the same key
|
||||||
acm_func=open_stream,
|
acm_func=open_stream,
|
||||||
) as (cache_hit, stream):
|
) as (
|
||||||
|
cache_hit,
|
||||||
|
(an, stream)
|
||||||
|
):
|
||||||
|
# when the actor + portal + ctx + stream has already been
|
||||||
|
# allocated we want to just bcast to this task.
|
||||||
if cache_hit:
|
if cache_hit:
|
||||||
print(f'{taskname} loaded from cache')
|
print(f'{taskname} loaded from cache')
|
||||||
|
|
||||||
|
@ -139,10 +166,43 @@ async def maybe_open_stream(taskname: str):
|
||||||
# if this feed is already allocated by the first
|
# if this feed is already allocated by the first
|
||||||
# task that entereed
|
# task that entereed
|
||||||
async with stream.subscribe() as bstream:
|
async with stream.subscribe() as bstream:
|
||||||
yield bstream
|
yield an, bstream
|
||||||
|
print(
|
||||||
|
f'cached task exited\n'
|
||||||
|
f')>\n'
|
||||||
|
f' |_{taskname}\n'
|
||||||
|
)
|
||||||
|
|
||||||
|
# we should always unreg the "cloned" bcrc for this
|
||||||
|
# consumer-task
|
||||||
|
assert id(bstream) not in bstream._state.subs
|
||||||
|
|
||||||
else:
|
else:
|
||||||
# yield the actual stream
|
# yield the actual stream
|
||||||
yield stream
|
try:
|
||||||
|
yield an, stream
|
||||||
|
finally:
|
||||||
|
print(
|
||||||
|
f'NON-cached task exited\n'
|
||||||
|
f')>\n'
|
||||||
|
f' |_{taskname}\n'
|
||||||
|
)
|
||||||
|
|
||||||
|
first_bstream = stream._broadcaster
|
||||||
|
bcrx_state = first_bstream._state
|
||||||
|
subs: dict[int, int] = bcrx_state.subs
|
||||||
|
if len(subs) == 1:
|
||||||
|
assert id(first_bstream) in subs
|
||||||
|
# ^^TODO! the bcrx should always de-allocate all subs,
|
||||||
|
# including the implicit first one allocated on entry
|
||||||
|
# by the first subscribing peer task, no?
|
||||||
|
#
|
||||||
|
# -[ ] adjust `MsgStream.subscribe()` to do this mgmt!
|
||||||
|
# |_ allows reverting `MsgStream.receive()` to the
|
||||||
|
# non-bcaster method.
|
||||||
|
# |_ we can decide whether to reset `._broadcaster`?
|
||||||
|
#
|
||||||
|
# await tractor.pause(shield=True)
|
||||||
|
|
||||||
|
|
||||||
def test_open_local_sub_to_stream(
|
def test_open_local_sub_to_stream(
|
||||||
|
@ -159,16 +219,24 @@ def test_open_local_sub_to_stream(
|
||||||
|
|
||||||
if debug_mode:
|
if debug_mode:
|
||||||
timeout = 999
|
timeout = 999
|
||||||
|
print(f'IN debug_mode, setting large timeout={timeout!r}..')
|
||||||
|
|
||||||
async def main():
|
async def main():
|
||||||
|
|
||||||
full = list(range(1000))
|
full = list(range(1000))
|
||||||
|
an: tractor.ActorNursery|None = None
|
||||||
|
num_tasks: int = 10
|
||||||
|
|
||||||
async def get_sub_and_pull(taskname: str):
|
async def get_sub_and_pull(taskname: str):
|
||||||
|
|
||||||
|
nonlocal an
|
||||||
|
|
||||||
stream: tractor.MsgStream
|
stream: tractor.MsgStream
|
||||||
async with (
|
async with (
|
||||||
maybe_open_stream(taskname) as stream,
|
maybe_open_stream(taskname) as (
|
||||||
|
an,
|
||||||
|
stream,
|
||||||
|
),
|
||||||
):
|
):
|
||||||
if '0' in taskname:
|
if '0' in taskname:
|
||||||
assert isinstance(stream, tractor.MsgStream)
|
assert isinstance(stream, tractor.MsgStream)
|
||||||
|
@ -180,34 +248,159 @@ def test_open_local_sub_to_stream(
|
||||||
|
|
||||||
first = await stream.receive()
|
first = await stream.receive()
|
||||||
print(f'{taskname} started with value {first}')
|
print(f'{taskname} started with value {first}')
|
||||||
seq = []
|
seq: list[int] = []
|
||||||
async for msg in stream:
|
async for msg in stream:
|
||||||
seq.append(msg)
|
seq.append(msg)
|
||||||
|
|
||||||
assert set(seq).issubset(set(full))
|
assert set(seq).issubset(set(full))
|
||||||
|
|
||||||
|
# end of @acm block
|
||||||
print(f'{taskname} finished')
|
print(f'{taskname} finished')
|
||||||
|
|
||||||
|
root: tractor.Actor
|
||||||
with trio.fail_after(timeout) as cs:
|
with trio.fail_after(timeout) as cs:
|
||||||
# TODO: turns out this isn't multi-task entrant XD
|
# TODO: turns out this isn't multi-task entrant XD
|
||||||
# We probably need an indepotent entry semantic?
|
# We probably need an indepotent entry semantic?
|
||||||
async with tractor.open_root_actor(
|
async with tractor.open_root_actor(
|
||||||
debug_mode=debug_mode,
|
debug_mode=debug_mode,
|
||||||
):
|
# maybe_enable_greenback=True,
|
||||||
|
#
|
||||||
|
# ^TODO? doesn't seem to mk breakpoint() usage work
|
||||||
|
# bc each bg task needs to open a portal??
|
||||||
|
# - [ ] we should consider making this part of
|
||||||
|
# our taskman defaults?
|
||||||
|
# |_see https://github.com/goodboy/tractor/pull/363
|
||||||
|
#
|
||||||
|
) as root:
|
||||||
|
assert root.is_registrar
|
||||||
|
|
||||||
async with (
|
async with (
|
||||||
trio.open_nursery() as tn,
|
trio.open_nursery() as tn,
|
||||||
):
|
):
|
||||||
for i in range(10):
|
for i in range(num_tasks):
|
||||||
tn.start_soon(
|
tn.start_soon(
|
||||||
get_sub_and_pull,
|
get_sub_and_pull,
|
||||||
f'task_{i}',
|
f'task_{i}',
|
||||||
)
|
)
|
||||||
await trio.sleep(0.001)
|
await trio.sleep(0.001)
|
||||||
|
|
||||||
print('all consumer tasks finished')
|
print('all consumer tasks finished!')
|
||||||
|
|
||||||
|
# ?XXX, ensure actor-nursery is shutdown or we might
|
||||||
|
# hang here due to a minor task deadlock/race-condition?
|
||||||
|
#
|
||||||
|
# - seems that all we need is a checkpoint to ensure
|
||||||
|
# the last suspended task, which is inside
|
||||||
|
# `.maybe_open_context()`, can do the
|
||||||
|
# `Portal.cancel_actor()` call?
|
||||||
|
#
|
||||||
|
# - if that bg task isn't resumed, then this blocks
|
||||||
|
# timeout might hit before that?
|
||||||
|
#
|
||||||
|
if root.ipc_server.has_peers():
|
||||||
|
await trio.lowlevel.checkpoint()
|
||||||
|
|
||||||
|
# alt approach, cancel the entire `an`
|
||||||
|
# await tractor.pause()
|
||||||
|
# await an.cancel()
|
||||||
|
|
||||||
|
# end of runtime scope
|
||||||
|
print('root actor terminated.')
|
||||||
|
|
||||||
if cs.cancelled_caught:
|
if cs.cancelled_caught:
|
||||||
pytest.fail(
|
pytest.fail(
|
||||||
'Should NOT time out in `open_root_actor()` ?'
|
'Should NOT time out in `open_root_actor()` ?'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
print('exiting main.')
|
||||||
|
|
||||||
|
trio.run(main)
|
||||||
|
|
||||||
|
|
||||||
|
|
||||||
|
@acm
|
||||||
|
async def cancel_outer_cs(
|
||||||
|
cs: trio.CancelScope|None = None,
|
||||||
|
delay: float = 0,
|
||||||
|
):
|
||||||
|
# on first task delay this enough to block
|
||||||
|
# the 2nd task but then cancel it mid sleep
|
||||||
|
# so that the tn.start() inside the key-err handler block
|
||||||
|
# is cancelled and would previously corrupt the
|
||||||
|
# mutext state.
|
||||||
|
log.info(f'task entering sleep({delay})')
|
||||||
|
await trio.sleep(delay)
|
||||||
|
if cs:
|
||||||
|
log.info('task calling cs.cancel()')
|
||||||
|
cs.cancel()
|
||||||
|
trio.lowlevel.checkpoint()
|
||||||
|
yield
|
||||||
|
await trio.sleep_forever()
|
||||||
|
|
||||||
|
|
||||||
|
def test_lock_not_corrupted_on_fast_cancel(
|
||||||
|
debug_mode: bool,
|
||||||
|
loglevel: str,
|
||||||
|
):
|
||||||
|
'''
|
||||||
|
Verify that if the caching-task (the first to enter
|
||||||
|
`maybe_open_context()`) is cancelled mid-cache-miss, the embedded
|
||||||
|
mutex can never be left in a corrupted state.
|
||||||
|
|
||||||
|
That is, the lock is always eventually released ensuring a peer
|
||||||
|
(cache-hitting) task will never,
|
||||||
|
|
||||||
|
- be left to inf-block/hang on the `lock.acquire()`.
|
||||||
|
- try to release the lock when still owned by the caching-task
|
||||||
|
due to it having erronously exited without calling
|
||||||
|
`lock.release()`.
|
||||||
|
|
||||||
|
|
||||||
|
'''
|
||||||
|
delay: float = 1.
|
||||||
|
|
||||||
|
async def use_moc(
|
||||||
|
cs: trio.CancelScope|None,
|
||||||
|
delay: float,
|
||||||
|
):
|
||||||
|
log.info('task entering moc')
|
||||||
|
async with maybe_open_context(
|
||||||
|
cancel_outer_cs,
|
||||||
|
kwargs={
|
||||||
|
'cs': cs,
|
||||||
|
'delay': delay,
|
||||||
|
},
|
||||||
|
) as (cache_hit, _null):
|
||||||
|
if cache_hit:
|
||||||
|
log.info('2nd task entered')
|
||||||
|
else:
|
||||||
|
log.info('1st task entered')
|
||||||
|
|
||||||
|
await trio.sleep_forever()
|
||||||
|
|
||||||
|
async def main():
|
||||||
|
with trio.fail_after(delay + 2):
|
||||||
|
async with (
|
||||||
|
tractor.open_root_actor(
|
||||||
|
debug_mode=debug_mode,
|
||||||
|
loglevel=loglevel,
|
||||||
|
),
|
||||||
|
trio.open_nursery() as tn,
|
||||||
|
):
|
||||||
|
get_console_log('info')
|
||||||
|
log.info('yo starting')
|
||||||
|
cs = tn.cancel_scope
|
||||||
|
tn.start_soon(
|
||||||
|
use_moc,
|
||||||
|
cs,
|
||||||
|
delay,
|
||||||
|
name='child',
|
||||||
|
)
|
||||||
|
with trio.CancelScope() as rent_cs:
|
||||||
|
await use_moc(
|
||||||
|
cs=rent_cs,
|
||||||
|
delay=delay,
|
||||||
|
)
|
||||||
|
|
||||||
|
|
||||||
trio.run(main)
|
trio.run(main)
|
||||||
|
|
|
@ -117,11 +117,9 @@ def test_acm_embedded_nursery_propagates_enter_err(
|
||||||
async with (
|
async with (
|
||||||
trio.open_nursery() as tn,
|
trio.open_nursery() as tn,
|
||||||
tractor.trionics.maybe_raise_from_masking_exc(
|
tractor.trionics.maybe_raise_from_masking_exc(
|
||||||
tn=tn,
|
|
||||||
unmask_from=(
|
unmask_from=(
|
||||||
trio.Cancelled
|
(trio.Cancelled,) if unmask_from_canc
|
||||||
if unmask_from_canc
|
else ()
|
||||||
else None
|
|
||||||
),
|
),
|
||||||
)
|
)
|
||||||
):
|
):
|
||||||
|
@ -136,7 +134,6 @@ def test_acm_embedded_nursery_propagates_enter_err(
|
||||||
with tractor.devx.maybe_open_crash_handler(
|
with tractor.devx.maybe_open_crash_handler(
|
||||||
pdb=debug_mode,
|
pdb=debug_mode,
|
||||||
) as bxerr:
|
) as bxerr:
|
||||||
if bxerr:
|
|
||||||
assert not bxerr.value
|
assert not bxerr.value
|
||||||
|
|
||||||
async with (
|
async with (
|
||||||
|
@ -145,6 +142,7 @@ def test_acm_embedded_nursery_propagates_enter_err(
|
||||||
assert not tn.cancel_scope.cancel_called
|
assert not tn.cancel_scope.cancel_called
|
||||||
assert 0
|
assert 0
|
||||||
|
|
||||||
|
if debug_mode:
|
||||||
assert (
|
assert (
|
||||||
(err := bxerr.value)
|
(err := bxerr.value)
|
||||||
and
|
and
|
||||||
|
|
|
@ -101,6 +101,9 @@ from ._state import (
|
||||||
debug_mode,
|
debug_mode,
|
||||||
_ctxvar_Context,
|
_ctxvar_Context,
|
||||||
)
|
)
|
||||||
|
from .trionics import (
|
||||||
|
collapse_eg,
|
||||||
|
)
|
||||||
# ------ - ------
|
# ------ - ------
|
||||||
if TYPE_CHECKING:
|
if TYPE_CHECKING:
|
||||||
from ._portal import Portal
|
from ._portal import Portal
|
||||||
|
@ -151,7 +154,7 @@ class Context:
|
||||||
2 cancel-scope-linked, communicating and parallel executing
|
2 cancel-scope-linked, communicating and parallel executing
|
||||||
`Task`s. Contexts are allocated on each side of any task
|
`Task`s. Contexts are allocated on each side of any task
|
||||||
RPC-linked msg dialog, i.e. for every request to a remote
|
RPC-linked msg dialog, i.e. for every request to a remote
|
||||||
actor from a `Portal`. On the "callee" side a context is
|
actor from a `Portal`. On the "child" side a context is
|
||||||
always allocated inside `._rpc._invoke()`.
|
always allocated inside `._rpc._invoke()`.
|
||||||
|
|
||||||
TODO: more detailed writeup on cancellation, error and
|
TODO: more detailed writeup on cancellation, error and
|
||||||
|
@ -219,8 +222,8 @@ class Context:
|
||||||
# `._runtime.invoke()`.
|
# `._runtime.invoke()`.
|
||||||
_remote_func_type: str | None = None
|
_remote_func_type: str | None = None
|
||||||
|
|
||||||
# NOTE: (for now) only set (a portal) on the caller side since
|
# NOTE: (for now) only set (a portal) on the parent side since
|
||||||
# the callee doesn't generally need a ref to one and should
|
# the child doesn't generally need a ref to one and should
|
||||||
# normally need to explicitly ask for handle to its peer if
|
# normally need to explicitly ask for handle to its peer if
|
||||||
# more the the `Context` is needed?
|
# more the the `Context` is needed?
|
||||||
_portal: Portal | None = None
|
_portal: Portal | None = None
|
||||||
|
@ -249,12 +252,12 @@ class Context:
|
||||||
_outcome_msg: Return|Error|ContextCancelled = Unresolved
|
_outcome_msg: Return|Error|ContextCancelled = Unresolved
|
||||||
|
|
||||||
# on a clean exit there should be a final value
|
# on a clean exit there should be a final value
|
||||||
# delivered from the far end "callee" task, so
|
# delivered from the far end "child" task, so
|
||||||
# this value is only set on one side.
|
# this value is only set on one side.
|
||||||
# _result: Any | int = None
|
# _result: Any | int = None
|
||||||
_result: PayloadT|Unresolved = Unresolved
|
_result: PayloadT|Unresolved = Unresolved
|
||||||
|
|
||||||
# if the local "caller" task errors this value is always set
|
# if the local "parent" task errors this value is always set
|
||||||
# to the error that was captured in the
|
# to the error that was captured in the
|
||||||
# `Portal.open_context().__aexit__()` teardown block OR, in
|
# `Portal.open_context().__aexit__()` teardown block OR, in
|
||||||
# 2 special cases when an (maybe) expected remote error
|
# 2 special cases when an (maybe) expected remote error
|
||||||
|
@ -290,7 +293,7 @@ class Context:
|
||||||
# a `ContextCancelled` due to a call to `.cancel()` triggering
|
# a `ContextCancelled` due to a call to `.cancel()` triggering
|
||||||
# "graceful closure" on either side:
|
# "graceful closure" on either side:
|
||||||
# - `._runtime._invoke()` will check this flag before engaging
|
# - `._runtime._invoke()` will check this flag before engaging
|
||||||
# the crash handler REPL in such cases where the "callee"
|
# the crash handler REPL in such cases where the "child"
|
||||||
# raises the cancellation,
|
# raises the cancellation,
|
||||||
# - `.devx.debug.lock_stdio_for_peer()` will set it to `False` if
|
# - `.devx.debug.lock_stdio_for_peer()` will set it to `False` if
|
||||||
# the global tty-lock has been configured to filter out some
|
# the global tty-lock has been configured to filter out some
|
||||||
|
@ -304,8 +307,8 @@ class Context:
|
||||||
_stream_opened: bool = False
|
_stream_opened: bool = False
|
||||||
_stream: MsgStream|None = None
|
_stream: MsgStream|None = None
|
||||||
|
|
||||||
# caller of `Portal.open_context()` for
|
# the parent-task's calling-fn's frame-info, the frame above
|
||||||
# logging purposes mostly
|
# `Portal.open_context()`, for introspection/logging.
|
||||||
_caller_info: CallerInfo|None = None
|
_caller_info: CallerInfo|None = None
|
||||||
|
|
||||||
# overrun handling machinery
|
# overrun handling machinery
|
||||||
|
@ -526,11 +529,11 @@ class Context:
|
||||||
'''
|
'''
|
||||||
Exactly the value of `self._scope.cancelled_caught`
|
Exactly the value of `self._scope.cancelled_caught`
|
||||||
(delegation) and should only be (able to be read as)
|
(delegation) and should only be (able to be read as)
|
||||||
`True` for a `.side == "caller"` ctx wherein the
|
`True` for a `.side == "parent"` ctx wherein the
|
||||||
`Portal.open_context()` block was exited due to a call to
|
`Portal.open_context()` block was exited due to a call to
|
||||||
`._scope.cancel()` - which should only ocurr in 2 cases:
|
`._scope.cancel()` - which should only ocurr in 2 cases:
|
||||||
|
|
||||||
- a caller side calls `.cancel()`, the far side cancels
|
- a parent side calls `.cancel()`, the far side cancels
|
||||||
and delivers back a `ContextCancelled` (making
|
and delivers back a `ContextCancelled` (making
|
||||||
`.cancel_acked == True`) and `._scope.cancel()` is
|
`.cancel_acked == True`) and `._scope.cancel()` is
|
||||||
called by `._maybe_cancel_and_set_remote_error()` which
|
called by `._maybe_cancel_and_set_remote_error()` which
|
||||||
|
@ -539,20 +542,20 @@ class Context:
|
||||||
=> `._scope.cancelled_caught == True` by normal `trio`
|
=> `._scope.cancelled_caught == True` by normal `trio`
|
||||||
cs semantics.
|
cs semantics.
|
||||||
|
|
||||||
- a caller side is delivered a `._remote_error:
|
- a parent side is delivered a `._remote_error:
|
||||||
RemoteActorError` via `._deliver_msg()` and a transitive
|
RemoteActorError` via `._deliver_msg()` and a transitive
|
||||||
call to `_maybe_cancel_and_set_remote_error()` calls
|
call to `_maybe_cancel_and_set_remote_error()` calls
|
||||||
`._scope.cancel()` and that cancellation eventually
|
`._scope.cancel()` and that cancellation eventually
|
||||||
results in `trio.Cancelled`(s) caught in the
|
results in `trio.Cancelled`(s) caught in the
|
||||||
`.open_context()` handling around the @acm's `yield`.
|
`.open_context()` handling around the @acm's `yield`.
|
||||||
|
|
||||||
Only as an FYI, in the "callee" side case it can also be
|
Only as an FYI, in the "child" side case it can also be
|
||||||
set but never is readable by any task outside the RPC
|
set but never is readable by any task outside the RPC
|
||||||
machinery in `._invoke()` since,:
|
machinery in `._invoke()` since,:
|
||||||
- when a callee side calls `.cancel()`, `._scope.cancel()`
|
- when a child side calls `.cancel()`, `._scope.cancel()`
|
||||||
is called immediately and handled specially inside
|
is called immediately and handled specially inside
|
||||||
`._invoke()` to raise a `ContextCancelled` which is then
|
`._invoke()` to raise a `ContextCancelled` which is then
|
||||||
sent to the caller side.
|
sent to the parent side.
|
||||||
|
|
||||||
However, `._scope.cancelled_caught` can NEVER be
|
However, `._scope.cancelled_caught` can NEVER be
|
||||||
accessed/read as `True` by any RPC invoked task since it
|
accessed/read as `True` by any RPC invoked task since it
|
||||||
|
@ -663,7 +666,7 @@ class Context:
|
||||||
when called/closed by actor local task(s).
|
when called/closed by actor local task(s).
|
||||||
|
|
||||||
NOTEs:
|
NOTEs:
|
||||||
- It is expected that the caller has previously unwrapped
|
- It is expected that the parent has previously unwrapped
|
||||||
the remote error using a call to `unpack_error()` and
|
the remote error using a call to `unpack_error()` and
|
||||||
provides that output exception value as the input
|
provides that output exception value as the input
|
||||||
`error` argument *here*.
|
`error` argument *here*.
|
||||||
|
@ -673,7 +676,7 @@ class Context:
|
||||||
`Portal.open_context()` (ideally) we want to interrupt
|
`Portal.open_context()` (ideally) we want to interrupt
|
||||||
any ongoing local tasks operating within that
|
any ongoing local tasks operating within that
|
||||||
`Context`'s cancel-scope so as to be notified ASAP of
|
`Context`'s cancel-scope so as to be notified ASAP of
|
||||||
the remote error and engage any caller handling (eg.
|
the remote error and engage any parent handling (eg.
|
||||||
for cross-process task supervision).
|
for cross-process task supervision).
|
||||||
|
|
||||||
- In some cases we may want to raise the remote error
|
- In some cases we may want to raise the remote error
|
||||||
|
@ -740,6 +743,8 @@ class Context:
|
||||||
# cancelled, NOT their reported canceller. IOW in the
|
# cancelled, NOT their reported canceller. IOW in the
|
||||||
# latter case we're cancelled by someone else getting
|
# latter case we're cancelled by someone else getting
|
||||||
# cancelled.
|
# cancelled.
|
||||||
|
#
|
||||||
|
# !TODO, switching to `Actor.aid` here!
|
||||||
if (canc := error.canceller) == self._actor.uid:
|
if (canc := error.canceller) == self._actor.uid:
|
||||||
whom: str = 'us'
|
whom: str = 'us'
|
||||||
self._canceller = canc
|
self._canceller = canc
|
||||||
|
@ -881,6 +886,11 @@ class Context:
|
||||||
|
|
||||||
@property
|
@property
|
||||||
def repr_caller(self) -> str:
|
def repr_caller(self) -> str:
|
||||||
|
'''
|
||||||
|
Render a "namespace-path" style representation of the calling
|
||||||
|
task-fn.
|
||||||
|
|
||||||
|
'''
|
||||||
ci: CallerInfo|None = self._caller_info
|
ci: CallerInfo|None = self._caller_info
|
||||||
if ci:
|
if ci:
|
||||||
return (
|
return (
|
||||||
|
@ -894,7 +904,7 @@ class Context:
|
||||||
def repr_api(self) -> str:
|
def repr_api(self) -> str:
|
||||||
return 'Portal.open_context()'
|
return 'Portal.open_context()'
|
||||||
|
|
||||||
# TODO: use `.dev._frame_stack` scanning to find caller!
|
# TODO: use `.dev._frame_stack` scanning to find caller fn!
|
||||||
# ci: CallerInfo|None = self._caller_info
|
# ci: CallerInfo|None = self._caller_info
|
||||||
# if ci:
|
# if ci:
|
||||||
# return (
|
# return (
|
||||||
|
@ -929,7 +939,7 @@ class Context:
|
||||||
=> That is, an IPC `Context` (this) **does not**
|
=> That is, an IPC `Context` (this) **does not**
|
||||||
have the same semantics as a `trio.CancelScope`.
|
have the same semantics as a `trio.CancelScope`.
|
||||||
|
|
||||||
If the caller (who entered the `Portal.open_context()`)
|
If the parent (who entered the `Portal.open_context()`)
|
||||||
desires that the internal block's cancel-scope be
|
desires that the internal block's cancel-scope be
|
||||||
cancelled it should open its own `trio.CancelScope` and
|
cancelled it should open its own `trio.CancelScope` and
|
||||||
manage it as needed.
|
manage it as needed.
|
||||||
|
@ -940,7 +950,7 @@ class Context:
|
||||||
self.cancel_called = True
|
self.cancel_called = True
|
||||||
|
|
||||||
header: str = (
|
header: str = (
|
||||||
f'Cancelling ctx from {side.upper()}-side\n'
|
f'Cancelling ctx from {side!r}-side\n'
|
||||||
)
|
)
|
||||||
reminfo: str = (
|
reminfo: str = (
|
||||||
# ' =>\n'
|
# ' =>\n'
|
||||||
|
@ -948,7 +958,7 @@ class Context:
|
||||||
f'\n'
|
f'\n'
|
||||||
f'c)=> {self.chan.uid}\n'
|
f'c)=> {self.chan.uid}\n'
|
||||||
f' |_[{self.dst_maddr}\n'
|
f' |_[{self.dst_maddr}\n'
|
||||||
f' >>{self.repr_rpc}\n'
|
f' >> {self.repr_rpc}\n'
|
||||||
# f' >> {self._nsf}() -> {codec}[dict]:\n\n'
|
# f' >> {self._nsf}() -> {codec}[dict]:\n\n'
|
||||||
# TODO: pull msg-type from spec re #320
|
# TODO: pull msg-type from spec re #320
|
||||||
)
|
)
|
||||||
|
@ -1012,7 +1022,7 @@ class Context:
|
||||||
# `_invoke()` RPC task.
|
# `_invoke()` RPC task.
|
||||||
#
|
#
|
||||||
# NOTE: on this side we ALWAYS cancel the local scope
|
# NOTE: on this side we ALWAYS cancel the local scope
|
||||||
# since the caller expects a `ContextCancelled` to be sent
|
# since the parent expects a `ContextCancelled` to be sent
|
||||||
# from `._runtime._invoke()` back to the other side. The
|
# from `._runtime._invoke()` back to the other side. The
|
||||||
# logic for catching the result of the below
|
# logic for catching the result of the below
|
||||||
# `._scope.cancel()` is inside the `._runtime._invoke()`
|
# `._scope.cancel()` is inside the `._runtime._invoke()`
|
||||||
|
@ -1185,8 +1195,8 @@ class Context:
|
||||||
|
|
||||||
) -> Any|Exception:
|
) -> Any|Exception:
|
||||||
'''
|
'''
|
||||||
From some (caller) side task, wait for and return the final
|
From some (parent) side task, wait for and return the final
|
||||||
result from the remote (callee) side's task.
|
result from the remote (child) side's task.
|
||||||
|
|
||||||
This provides a mechanism for one task running in some actor to wait
|
This provides a mechanism for one task running in some actor to wait
|
||||||
on another task at the other side, in some other actor, to terminate.
|
on another task at the other side, in some other actor, to terminate.
|
||||||
|
@ -1595,7 +1605,7 @@ class Context:
|
||||||
raise err
|
raise err
|
||||||
|
|
||||||
# TODO: maybe a flag to by-pass encode op if already done
|
# TODO: maybe a flag to by-pass encode op if already done
|
||||||
# here in caller?
|
# here in parent?
|
||||||
await self.chan.send(started_msg)
|
await self.chan.send(started_msg)
|
||||||
|
|
||||||
# set msg-related internal runtime-state
|
# set msg-related internal runtime-state
|
||||||
|
@ -1671,7 +1681,7 @@ class Context:
|
||||||
|
|
||||||
XXX RULES XXX
|
XXX RULES XXX
|
||||||
------ - ------
|
------ - ------
|
||||||
- NEVER raise remote errors from this method; a runtime task caller.
|
- NEVER raise remote errors from this method; a calling runtime-task.
|
||||||
An error "delivered" to a ctx should always be raised by
|
An error "delivered" to a ctx should always be raised by
|
||||||
the corresponding local task operating on the
|
the corresponding local task operating on the
|
||||||
`Portal`/`Context` APIs.
|
`Portal`/`Context` APIs.
|
||||||
|
@ -1747,7 +1757,7 @@ class Context:
|
||||||
|
|
||||||
else:
|
else:
|
||||||
report = (
|
report = (
|
||||||
'Queueing OVERRUN msg on caller task:\n\n'
|
'Queueing OVERRUN msg on parent task:\n\n'
|
||||||
+ report
|
+ report
|
||||||
)
|
)
|
||||||
log.debug(report)
|
log.debug(report)
|
||||||
|
@ -1943,12 +1953,12 @@ async def open_context_from_portal(
|
||||||
IPC protocol.
|
IPC protocol.
|
||||||
|
|
||||||
The yielded `tuple` is a pair delivering a `tractor.Context`
|
The yielded `tuple` is a pair delivering a `tractor.Context`
|
||||||
and any first value "sent" by the "callee" task via a call
|
and any first value "sent" by the "child" task via a call
|
||||||
to `Context.started(<value: Any>)`; this side of the
|
to `Context.started(<value: Any>)`; this side of the
|
||||||
context does not unblock until the "callee" task calls
|
context does not unblock until the "child" task calls
|
||||||
`.started()` in similar style to `trio.Nursery.start()`.
|
`.started()` in similar style to `trio.Nursery.start()`.
|
||||||
When the "callee" (side that is "called"/started by a call
|
When the "child" (side that is "called"/started by a call
|
||||||
to *this* method) returns, the caller side (this) unblocks
|
to *this* method) returns, the parent side (this) unblocks
|
||||||
and any final value delivered from the other end can be
|
and any final value delivered from the other end can be
|
||||||
retrieved using the `Contex.wait_for_result()` api.
|
retrieved using the `Contex.wait_for_result()` api.
|
||||||
|
|
||||||
|
@ -1961,7 +1971,7 @@ async def open_context_from_portal(
|
||||||
__tracebackhide__: bool = hide_tb
|
__tracebackhide__: bool = hide_tb
|
||||||
|
|
||||||
# denote this frame as a "runtime frame" for stack
|
# denote this frame as a "runtime frame" for stack
|
||||||
# introspection where we report the caller code in logging
|
# introspection where we report the parent code in logging
|
||||||
# and error message content.
|
# and error message content.
|
||||||
# NOTE: 2 bc of the wrapping `@acm`
|
# NOTE: 2 bc of the wrapping `@acm`
|
||||||
__runtimeframe__: int = 2 # noqa
|
__runtimeframe__: int = 2 # noqa
|
||||||
|
@ -2020,13 +2030,11 @@ async def open_context_from_portal(
|
||||||
# placeholder for any exception raised in the runtime
|
# placeholder for any exception raised in the runtime
|
||||||
# or by user tasks which cause this context's closure.
|
# or by user tasks which cause this context's closure.
|
||||||
scope_err: BaseException|None = None
|
scope_err: BaseException|None = None
|
||||||
ctxc_from_callee: ContextCancelled|None = None
|
ctxc_from_child: ContextCancelled|None = None
|
||||||
try:
|
try:
|
||||||
async with (
|
async with (
|
||||||
trio.open_nursery(
|
collapse_eg(),
|
||||||
strict_exception_groups=False,
|
trio.open_nursery() as tn,
|
||||||
) as tn,
|
|
||||||
|
|
||||||
msgops.maybe_limit_plds(
|
msgops.maybe_limit_plds(
|
||||||
ctx=ctx,
|
ctx=ctx,
|
||||||
spec=ctx_meta.get('pld_spec'),
|
spec=ctx_meta.get('pld_spec'),
|
||||||
|
@ -2101,7 +2109,7 @@ async def open_context_from_portal(
|
||||||
# that we can re-use it around the `yield` ^ here
|
# that we can re-use it around the `yield` ^ here
|
||||||
# or vice versa?
|
# or vice versa?
|
||||||
#
|
#
|
||||||
# maybe TODO NOTE: between the caller exiting and
|
# maybe TODO NOTE: between the parent exiting and
|
||||||
# arriving here the far end may have sent a ctxc-msg or
|
# arriving here the far end may have sent a ctxc-msg or
|
||||||
# other error, so the quetion is whether we should check
|
# other error, so the quetion is whether we should check
|
||||||
# for it here immediately and maybe raise so as to engage
|
# for it here immediately and maybe raise so as to engage
|
||||||
|
@ -2167,16 +2175,16 @@ async def open_context_from_portal(
|
||||||
# request in which case we DO let the error bubble to the
|
# request in which case we DO let the error bubble to the
|
||||||
# opener.
|
# opener.
|
||||||
#
|
#
|
||||||
# 2-THIS "caller" task somewhere invoked `Context.cancel()`
|
# 2-THIS "parent" task somewhere invoked `Context.cancel()`
|
||||||
# and received a `ContextCanclled` from the "callee"
|
# and received a `ContextCanclled` from the "child"
|
||||||
# task, in which case we mask the `ContextCancelled` from
|
# task, in which case we mask the `ContextCancelled` from
|
||||||
# bubbling to this "caller" (much like how `trio.Nursery`
|
# bubbling to this "parent" (much like how `trio.Nursery`
|
||||||
# swallows any `trio.Cancelled` bubbled by a call to
|
# swallows any `trio.Cancelled` bubbled by a call to
|
||||||
# `Nursery.cancel_scope.cancel()`)
|
# `Nursery.cancel_scope.cancel()`)
|
||||||
except ContextCancelled as ctxc:
|
except ContextCancelled as ctxc:
|
||||||
scope_err = ctxc
|
scope_err = ctxc
|
||||||
ctx._local_error: BaseException = scope_err
|
ctx._local_error: BaseException = scope_err
|
||||||
ctxc_from_callee = ctxc
|
ctxc_from_child = ctxc
|
||||||
|
|
||||||
# XXX TODO XXX: FIX THIS debug_mode BUGGGG!!!
|
# XXX TODO XXX: FIX THIS debug_mode BUGGGG!!!
|
||||||
# using this code and then resuming the REPL will
|
# using this code and then resuming the REPL will
|
||||||
|
@ -2213,11 +2221,11 @@ async def open_context_from_portal(
|
||||||
# the above `._scope` can be cancelled due to:
|
# the above `._scope` can be cancelled due to:
|
||||||
# 1. an explicit self cancel via `Context.cancel()` or
|
# 1. an explicit self cancel via `Context.cancel()` or
|
||||||
# `Actor.cancel()`,
|
# `Actor.cancel()`,
|
||||||
# 2. any "callee"-side remote error, possibly also a cancellation
|
# 2. any "child"-side remote error, possibly also a cancellation
|
||||||
# request by some peer,
|
# request by some peer,
|
||||||
# 3. any "caller" (aka THIS scope's) local error raised in the above `yield`
|
# 3. any "parent" (aka THIS scope's) local error raised in the above `yield`
|
||||||
except (
|
except (
|
||||||
# CASE 3: standard local error in this caller/yieldee
|
# CASE 3: standard local error in this parent/yieldee
|
||||||
Exception,
|
Exception,
|
||||||
|
|
||||||
# CASES 1 & 2: can manifest as a `ctx._scope_nursery`
|
# CASES 1 & 2: can manifest as a `ctx._scope_nursery`
|
||||||
|
@ -2231,9 +2239,9 @@ async def open_context_from_portal(
|
||||||
# any `Context._maybe_raise_remote_err()` call.
|
# any `Context._maybe_raise_remote_err()` call.
|
||||||
#
|
#
|
||||||
# 2.-`BaseExceptionGroup[ContextCancelled | RemoteActorError]`
|
# 2.-`BaseExceptionGroup[ContextCancelled | RemoteActorError]`
|
||||||
# from any error delivered from the "callee" side
|
# from any error delivered from the "child" side
|
||||||
# AND a group-exc is only raised if there was > 1
|
# AND a group-exc is only raised if there was > 1
|
||||||
# tasks started *here* in the "caller" / opener
|
# tasks started *here* in the "parent" / opener
|
||||||
# block. If any one of those tasks calls
|
# block. If any one of those tasks calls
|
||||||
# `.wait_for_result()` or `MsgStream.receive()`
|
# `.wait_for_result()` or `MsgStream.receive()`
|
||||||
# `._maybe_raise_remote_err()` will be transitively
|
# `._maybe_raise_remote_err()` will be transitively
|
||||||
|
@ -2246,8 +2254,8 @@ async def open_context_from_portal(
|
||||||
trio.Cancelled, # NOTE: NOT from inside the ctx._scope
|
trio.Cancelled, # NOTE: NOT from inside the ctx._scope
|
||||||
KeyboardInterrupt,
|
KeyboardInterrupt,
|
||||||
|
|
||||||
) as caller_err:
|
) as rent_err:
|
||||||
scope_err = caller_err
|
scope_err = rent_err
|
||||||
ctx._local_error: BaseException = scope_err
|
ctx._local_error: BaseException = scope_err
|
||||||
|
|
||||||
# XXX: ALWAYS request the context to CANCEL ON any ERROR.
|
# XXX: ALWAYS request the context to CANCEL ON any ERROR.
|
||||||
|
@ -2257,7 +2265,7 @@ async def open_context_from_portal(
|
||||||
# await debug.pause()
|
# await debug.pause()
|
||||||
# log.cancel(
|
# log.cancel(
|
||||||
match scope_err:
|
match scope_err:
|
||||||
case trio.Cancelled:
|
case trio.Cancelled():
|
||||||
logmeth = log.cancel
|
logmeth = log.cancel
|
||||||
|
|
||||||
# XXX explicitly report on any non-graceful-taskc cases
|
# XXX explicitly report on any non-graceful-taskc cases
|
||||||
|
@ -2286,9 +2294,9 @@ async def open_context_from_portal(
|
||||||
'Calling `ctx.cancel()`!\n'
|
'Calling `ctx.cancel()`!\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# we don't need to cancel the callee if it already
|
# we don't need to cancel the child if it already
|
||||||
# told us it's cancelled ;p
|
# told us it's cancelled ;p
|
||||||
if ctxc_from_callee is None:
|
if ctxc_from_child is None:
|
||||||
try:
|
try:
|
||||||
await ctx.cancel()
|
await ctx.cancel()
|
||||||
except (
|
except (
|
||||||
|
@ -2319,8 +2327,8 @@ async def open_context_from_portal(
|
||||||
# via a call to
|
# via a call to
|
||||||
# `Context._maybe_cancel_and_set_remote_error()`.
|
# `Context._maybe_cancel_and_set_remote_error()`.
|
||||||
# As per `Context._deliver_msg()`, that error IS
|
# As per `Context._deliver_msg()`, that error IS
|
||||||
# ALWAYS SET any time "callee" side fails and causes "caller
|
# ALWAYS SET any time "child" side fails and causes
|
||||||
# side" cancellation via a `ContextCancelled` here.
|
# "parent side" cancellation via a `ContextCancelled` here.
|
||||||
try:
|
try:
|
||||||
result_or_err: Exception|Any = await ctx.wait_for_result()
|
result_or_err: Exception|Any = await ctx.wait_for_result()
|
||||||
except BaseException as berr:
|
except BaseException as berr:
|
||||||
|
@ -2356,7 +2364,7 @@ async def open_context_from_portal(
|
||||||
)
|
)
|
||||||
case (None, _):
|
case (None, _):
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Context returned final result from callee task:\n'
|
'Context returned final result from child task:\n'
|
||||||
f'<= peer: {uid}\n'
|
f'<= peer: {uid}\n'
|
||||||
f' |_ {nsf}()\n\n'
|
f' |_ {nsf}()\n\n'
|
||||||
|
|
||||||
|
@ -2451,7 +2459,7 @@ async def open_context_from_portal(
|
||||||
)
|
)
|
||||||
|
|
||||||
# TODO: should we add a `._cancel_req_received`
|
# TODO: should we add a `._cancel_req_received`
|
||||||
# flag to determine if the callee manually called
|
# flag to determine if the child manually called
|
||||||
# `ctx.cancel()`?
|
# `ctx.cancel()`?
|
||||||
# -[ ] going to need a cid check no?
|
# -[ ] going to need a cid check no?
|
||||||
|
|
||||||
|
@ -2507,7 +2515,7 @@ def mk_context(
|
||||||
recv_chan: trio.MemoryReceiveChannel
|
recv_chan: trio.MemoryReceiveChannel
|
||||||
send_chan, recv_chan = trio.open_memory_channel(msg_buffer_size)
|
send_chan, recv_chan = trio.open_memory_channel(msg_buffer_size)
|
||||||
|
|
||||||
# TODO: only scan caller-info if log level so high!
|
# TODO: only scan parent-info if log level so high!
|
||||||
from .devx._frame_stack import find_caller_info
|
from .devx._frame_stack import find_caller_info
|
||||||
caller_info: CallerInfo|None = find_caller_info()
|
caller_info: CallerInfo|None = find_caller_info()
|
||||||
|
|
||||||
|
|
|
@ -28,7 +28,10 @@ from typing import (
|
||||||
from contextlib import asynccontextmanager as acm
|
from contextlib import asynccontextmanager as acm
|
||||||
|
|
||||||
from tractor.log import get_logger
|
from tractor.log import get_logger
|
||||||
from .trionics import gather_contexts
|
from .trionics import (
|
||||||
|
gather_contexts,
|
||||||
|
collapse_eg,
|
||||||
|
)
|
||||||
from .ipc import _connect_chan, Channel
|
from .ipc import _connect_chan, Channel
|
||||||
from ._addr import (
|
from ._addr import (
|
||||||
UnwrappedAddress,
|
UnwrappedAddress,
|
||||||
|
@ -87,7 +90,6 @@ async def get_registry(
|
||||||
yield regstr_ptl
|
yield regstr_ptl
|
||||||
|
|
||||||
|
|
||||||
|
|
||||||
@acm
|
@acm
|
||||||
async def get_root(
|
async def get_root(
|
||||||
**kwargs,
|
**kwargs,
|
||||||
|
@ -253,9 +255,12 @@ async def find_actor(
|
||||||
for addr in registry_addrs
|
for addr in registry_addrs
|
||||||
)
|
)
|
||||||
portals: list[Portal]
|
portals: list[Portal]
|
||||||
async with gather_contexts(
|
async with (
|
||||||
|
collapse_eg(),
|
||||||
|
gather_contexts(
|
||||||
mngrs=maybe_portals,
|
mngrs=maybe_portals,
|
||||||
) as portals:
|
) as portals,
|
||||||
|
):
|
||||||
# log.runtime(
|
# log.runtime(
|
||||||
# 'Gathered portals:\n'
|
# 'Gathered portals:\n'
|
||||||
# f'{portals}'
|
# f'{portals}'
|
||||||
|
|
|
@ -21,7 +21,7 @@ Sub-process entry points.
|
||||||
from __future__ import annotations
|
from __future__ import annotations
|
||||||
from functools import partial
|
from functools import partial
|
||||||
import multiprocessing as mp
|
import multiprocessing as mp
|
||||||
import os
|
# import os
|
||||||
from typing import (
|
from typing import (
|
||||||
Any,
|
Any,
|
||||||
TYPE_CHECKING,
|
TYPE_CHECKING,
|
||||||
|
@ -38,6 +38,7 @@ from .devx import (
|
||||||
_frame_stack,
|
_frame_stack,
|
||||||
pformat,
|
pformat,
|
||||||
)
|
)
|
||||||
|
# from .msg import pretty_struct
|
||||||
from .to_asyncio import run_as_asyncio_guest
|
from .to_asyncio import run_as_asyncio_guest
|
||||||
from ._addr import UnwrappedAddress
|
from ._addr import UnwrappedAddress
|
||||||
from ._runtime import (
|
from ._runtime import (
|
||||||
|
@ -127,20 +128,13 @@ def _trio_main(
|
||||||
|
|
||||||
if actor.loglevel is not None:
|
if actor.loglevel is not None:
|
||||||
get_console_log(actor.loglevel)
|
get_console_log(actor.loglevel)
|
||||||
actor_info: str = (
|
|
||||||
f'|_{actor}\n'
|
|
||||||
f' uid: {actor.uid}\n'
|
|
||||||
f' pid: {os.getpid()}\n'
|
|
||||||
f' parent_addr: {parent_addr}\n'
|
|
||||||
f' loglevel: {actor.loglevel}\n'
|
|
||||||
)
|
|
||||||
log.info(
|
log.info(
|
||||||
'Starting new `trio` subactor\n'
|
f'Starting `trio` subactor from parent @ '
|
||||||
|
f'{parent_addr}\n'
|
||||||
+
|
+
|
||||||
pformat.nest_from_op(
|
pformat.nest_from_op(
|
||||||
input_op='>(', # see syntax ideas above
|
input_op='>(', # see syntax ideas above
|
||||||
text=actor_info,
|
text=f'{actor}',
|
||||||
nest_indent=2, # since "complete"
|
|
||||||
)
|
)
|
||||||
)
|
)
|
||||||
logmeth = log.info
|
logmeth = log.info
|
||||||
|
@ -149,7 +143,7 @@ def _trio_main(
|
||||||
+
|
+
|
||||||
pformat.nest_from_op(
|
pformat.nest_from_op(
|
||||||
input_op=')>', # like a "closed-to-play"-icon from super perspective
|
input_op=')>', # like a "closed-to-play"-icon from super perspective
|
||||||
text=actor_info,
|
text=f'{actor}',
|
||||||
nest_indent=1,
|
nest_indent=1,
|
||||||
)
|
)
|
||||||
)
|
)
|
||||||
|
@ -167,7 +161,7 @@ def _trio_main(
|
||||||
+
|
+
|
||||||
pformat.nest_from_op(
|
pformat.nest_from_op(
|
||||||
input_op='c)>', # closed due to cancel (see above)
|
input_op='c)>', # closed due to cancel (see above)
|
||||||
text=actor_info,
|
text=f'{actor}',
|
||||||
)
|
)
|
||||||
)
|
)
|
||||||
except BaseException as err:
|
except BaseException as err:
|
||||||
|
@ -177,7 +171,7 @@ def _trio_main(
|
||||||
+
|
+
|
||||||
pformat.nest_from_op(
|
pformat.nest_from_op(
|
||||||
input_op='x)>', # closed by error
|
input_op='x)>', # closed by error
|
||||||
text=actor_info,
|
text=f'{actor}',
|
||||||
)
|
)
|
||||||
)
|
)
|
||||||
# NOTE since we raise a tb will already be shown on the
|
# NOTE since we raise a tb will already be shown on the
|
||||||
|
|
|
@ -39,7 +39,10 @@ import warnings
|
||||||
|
|
||||||
import trio
|
import trio
|
||||||
|
|
||||||
from .trionics import maybe_open_nursery
|
from .trionics import (
|
||||||
|
maybe_open_nursery,
|
||||||
|
collapse_eg,
|
||||||
|
)
|
||||||
from ._state import (
|
from ._state import (
|
||||||
current_actor,
|
current_actor,
|
||||||
)
|
)
|
||||||
|
@ -115,6 +118,10 @@ class Portal:
|
||||||
|
|
||||||
@property
|
@property
|
||||||
def chan(self) -> Channel:
|
def chan(self) -> Channel:
|
||||||
|
'''
|
||||||
|
Ref to this ctx's underlying `tractor.ipc.Channel`.
|
||||||
|
|
||||||
|
'''
|
||||||
return self._chan
|
return self._chan
|
||||||
|
|
||||||
@property
|
@property
|
||||||
|
@ -174,10 +181,17 @@ class Portal:
|
||||||
|
|
||||||
# not expecting a "main" result
|
# not expecting a "main" result
|
||||||
if self._expect_result_ctx is None:
|
if self._expect_result_ctx is None:
|
||||||
|
peer_id: str = f'{self.channel.aid.reprol()!r}'
|
||||||
log.warning(
|
log.warning(
|
||||||
f"Portal for {self.channel.aid} not expecting a final"
|
f'Portal to peer {peer_id} will not deliver a final result?\n'
|
||||||
" result?\nresult() should only be called if subactor"
|
f'\n'
|
||||||
" was spawned with `ActorNursery.run_in_actor()`")
|
f'Context.result() can only be called by the parent of '
|
||||||
|
f'a sub-actor when it was spawned with '
|
||||||
|
f'`ActorNursery.run_in_actor()`'
|
||||||
|
f'\n'
|
||||||
|
f'Further this `ActorNursery`-method-API will deprecated in the'
|
||||||
|
f'near fututre!\n'
|
||||||
|
)
|
||||||
return NoResult
|
return NoResult
|
||||||
|
|
||||||
# expecting a "main" result
|
# expecting a "main" result
|
||||||
|
@ -210,6 +224,7 @@ class Portal:
|
||||||
typname: str = type(self).__name__
|
typname: str = type(self).__name__
|
||||||
log.warning(
|
log.warning(
|
||||||
f'`{typname}.result()` is DEPRECATED!\n'
|
f'`{typname}.result()` is DEPRECATED!\n'
|
||||||
|
f'\n'
|
||||||
f'Use `{typname}.wait_for_result()` instead!\n'
|
f'Use `{typname}.wait_for_result()` instead!\n'
|
||||||
)
|
)
|
||||||
return await self.wait_for_result(
|
return await self.wait_for_result(
|
||||||
|
@ -221,8 +236,10 @@ class Portal:
|
||||||
# terminate all locally running async generator
|
# terminate all locally running async generator
|
||||||
# IPC calls
|
# IPC calls
|
||||||
if self._streams:
|
if self._streams:
|
||||||
log.cancel(
|
peer_id: str = f'{self.channel.aid.reprol()!r}'
|
||||||
f"Cancelling all streams with {self.channel.aid}")
|
report: str = (
|
||||||
|
f'Cancelling all msg-streams with {peer_id}\n'
|
||||||
|
)
|
||||||
for stream in self._streams.copy():
|
for stream in self._streams.copy():
|
||||||
try:
|
try:
|
||||||
await stream.aclose()
|
await stream.aclose()
|
||||||
|
@ -231,10 +248,18 @@ class Portal:
|
||||||
# (unless of course at some point down the road we
|
# (unless of course at some point down the road we
|
||||||
# won't expect this to always be the case or need to
|
# won't expect this to always be the case or need to
|
||||||
# detect it for respawning purposes?)
|
# detect it for respawning purposes?)
|
||||||
log.debug(f"{stream} was already closed.")
|
report += (
|
||||||
|
f'->) {stream!r} already closed\n'
|
||||||
|
)
|
||||||
|
|
||||||
|
log.cancel(report)
|
||||||
|
|
||||||
async def aclose(self):
|
async def aclose(self):
|
||||||
log.debug(f"Closing {self}")
|
log.debug(
|
||||||
|
f'Closing portal\n'
|
||||||
|
f'>}}\n'
|
||||||
|
f'|_{self}\n'
|
||||||
|
)
|
||||||
# TODO: once we move to implementing our own `ReceiveChannel`
|
# TODO: once we move to implementing our own `ReceiveChannel`
|
||||||
# (including remote task cancellation inside its `.aclose()`)
|
# (including remote task cancellation inside its `.aclose()`)
|
||||||
# we'll need to .aclose all those channels here
|
# we'll need to .aclose all those channels here
|
||||||
|
@ -260,23 +285,22 @@ class Portal:
|
||||||
__runtimeframe__: int = 1 # noqa
|
__runtimeframe__: int = 1 # noqa
|
||||||
|
|
||||||
chan: Channel = self.channel
|
chan: Channel = self.channel
|
||||||
|
peer_id: str = f'{self.channel.aid.reprol()!r}'
|
||||||
if not chan.connected():
|
if not chan.connected():
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'This channel is already closed, skipping cancel request..'
|
'Peer {peer_id} is already disconnected\n'
|
||||||
|
'-> skipping cancel request..\n'
|
||||||
)
|
)
|
||||||
return False
|
return False
|
||||||
|
|
||||||
reminfo: str = (
|
|
||||||
f'c)=> {self.channel.aid}\n'
|
|
||||||
f' |_{chan}\n'
|
|
||||||
)
|
|
||||||
log.cancel(
|
log.cancel(
|
||||||
f'Requesting actor-runtime cancel for peer\n\n'
|
f'Sending actor-runtime-cancel-req to peer\n'
|
||||||
f'{reminfo}'
|
f'\n'
|
||||||
|
f'c)=> {peer_id}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# XXX the one spot we set it?
|
# XXX the one spot we set it?
|
||||||
self.channel._cancel_called: bool = True
|
chan._cancel_called: bool = True
|
||||||
try:
|
try:
|
||||||
# send cancel cmd - might not get response
|
# send cancel cmd - might not get response
|
||||||
# XXX: sure would be nice to make this work with
|
# XXX: sure would be nice to make this work with
|
||||||
|
@ -297,8 +321,9 @@ class Portal:
|
||||||
# may timeout and we never get an ack (obvi racy)
|
# may timeout and we never get an ack (obvi racy)
|
||||||
# but that doesn't mean it wasn't cancelled.
|
# but that doesn't mean it wasn't cancelled.
|
||||||
log.debug(
|
log.debug(
|
||||||
'May have failed to cancel peer?\n'
|
f'May have failed to cancel peer?\n'
|
||||||
f'{reminfo}'
|
f'\n'
|
||||||
|
f'c)=?> {peer_id}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# if we get here some weird cancellation case happened
|
# if we get here some weird cancellation case happened
|
||||||
|
@ -316,22 +341,22 @@ class Portal:
|
||||||
|
|
||||||
TransportClosed,
|
TransportClosed,
|
||||||
) as tpt_err:
|
) as tpt_err:
|
||||||
report: str = (
|
ipc_borked_report: str = (
|
||||||
f'IPC chan for actor already closed or broken?\n\n'
|
f'IPC for actor already closed/broken?\n\n'
|
||||||
f'{self.channel.aid}\n'
|
f'\n'
|
||||||
f' |_{self.channel}\n'
|
f'c)=x> {peer_id}\n'
|
||||||
)
|
)
|
||||||
match tpt_err:
|
match tpt_err:
|
||||||
case TransportClosed():
|
case TransportClosed():
|
||||||
log.debug(report)
|
log.debug(ipc_borked_report)
|
||||||
case _:
|
case _:
|
||||||
report += (
|
ipc_borked_report += (
|
||||||
f'\n'
|
f'\n'
|
||||||
f'Unhandled low-level transport-closed/error during\n'
|
f'Unhandled low-level transport-closed/error during\n'
|
||||||
f'Portal.cancel_actor()` request?\n'
|
f'Portal.cancel_actor()` request?\n'
|
||||||
f'<{type(tpt_err).__name__}( {tpt_err} )>\n'
|
f'<{type(tpt_err).__name__}( {tpt_err} )>\n'
|
||||||
)
|
)
|
||||||
log.warning(report)
|
log.warning(ipc_borked_report)
|
||||||
|
|
||||||
return False
|
return False
|
||||||
|
|
||||||
|
@ -488,10 +513,13 @@ class Portal:
|
||||||
with trio.CancelScope(shield=True):
|
with trio.CancelScope(shield=True):
|
||||||
await ctx.cancel()
|
await ctx.cancel()
|
||||||
|
|
||||||
except trio.ClosedResourceError:
|
except trio.ClosedResourceError as cre:
|
||||||
# if the far end terminates before we send a cancel the
|
# if the far end terminates before we send a cancel the
|
||||||
# underlying transport-channel may already be closed.
|
# underlying transport-channel may already be closed.
|
||||||
log.cancel(f'Context {ctx} was already closed?')
|
log.cancel(
|
||||||
|
f'Context.cancel() -> {cre!r}\n'
|
||||||
|
f'cid: {ctx.cid!r} already closed?\n'
|
||||||
|
)
|
||||||
|
|
||||||
# XXX: should this always be done?
|
# XXX: should this always be done?
|
||||||
# await recv_chan.aclose()
|
# await recv_chan.aclose()
|
||||||
|
@ -558,14 +586,13 @@ async def open_portal(
|
||||||
assert actor
|
assert actor
|
||||||
was_connected: bool = False
|
was_connected: bool = False
|
||||||
|
|
||||||
async with maybe_open_nursery(
|
async with (
|
||||||
|
collapse_eg(),
|
||||||
|
maybe_open_nursery(
|
||||||
tn,
|
tn,
|
||||||
shield=shield,
|
shield=shield,
|
||||||
strict_exception_groups=False,
|
) as tn,
|
||||||
# ^XXX^ TODO? soo roll our own then ??
|
):
|
||||||
# -> since we kinda want the "if only one `.exception` then
|
|
||||||
# just raise that" interface?
|
|
||||||
) as tn:
|
|
||||||
|
|
||||||
if not channel.connected():
|
if not channel.connected():
|
||||||
await channel.connect()
|
await channel.connect()
|
||||||
|
|
145
tractor/_root.py
145
tractor/_root.py
|
@ -37,16 +37,11 @@ import warnings
|
||||||
|
|
||||||
import trio
|
import trio
|
||||||
|
|
||||||
from ._runtime import (
|
from . import _runtime
|
||||||
Actor,
|
|
||||||
Arbiter,
|
|
||||||
# TODO: rename and make a non-actor subtype?
|
|
||||||
# Arbiter as Registry,
|
|
||||||
async_main,
|
|
||||||
)
|
|
||||||
from .devx import (
|
from .devx import (
|
||||||
debug,
|
debug,
|
||||||
_frame_stack,
|
_frame_stack,
|
||||||
|
pformat as _pformat,
|
||||||
)
|
)
|
||||||
from . import _spawn
|
from . import _spawn
|
||||||
from . import _state
|
from . import _state
|
||||||
|
@ -63,6 +58,7 @@ from ._addr import (
|
||||||
)
|
)
|
||||||
from .trionics import (
|
from .trionics import (
|
||||||
is_multi_cancelled,
|
is_multi_cancelled,
|
||||||
|
collapse_eg,
|
||||||
)
|
)
|
||||||
from ._exceptions import (
|
from ._exceptions import (
|
||||||
RuntimeFailure,
|
RuntimeFailure,
|
||||||
|
@ -101,7 +97,7 @@ async def maybe_block_bp(
|
||||||
):
|
):
|
||||||
logger.info(
|
logger.info(
|
||||||
f'Found `greenback` installed @ {maybe_mod}\n'
|
f'Found `greenback` installed @ {maybe_mod}\n'
|
||||||
'Enabling `tractor.pause_from_sync()` support!\n'
|
f'Enabling `tractor.pause_from_sync()` support!\n'
|
||||||
)
|
)
|
||||||
os.environ['PYTHONBREAKPOINT'] = (
|
os.environ['PYTHONBREAKPOINT'] = (
|
||||||
'tractor.devx.debug._sync_pause_from_builtin'
|
'tractor.devx.debug._sync_pause_from_builtin'
|
||||||
|
@ -196,13 +192,19 @@ async def open_root_actor(
|
||||||
# read-only state to sublayers?
|
# read-only state to sublayers?
|
||||||
# extra_rt_vars: dict|None = None,
|
# extra_rt_vars: dict|None = None,
|
||||||
|
|
||||||
) -> Actor:
|
) -> _runtime.Actor:
|
||||||
'''
|
'''
|
||||||
Runtime init entry point for ``tractor``.
|
Initialize the `tractor` runtime by starting a "root actor" in
|
||||||
|
a parent-most Python process.
|
||||||
|
|
||||||
|
All (disjoint) actor-process-trees-as-programs are created via
|
||||||
|
this entrypoint.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
# XXX NEVER allow nested actor-trees!
|
# XXX NEVER allow nested actor-trees!
|
||||||
if already_actor := _state.current_actor(err_on_no_runtime=False):
|
if already_actor := _state.current_actor(
|
||||||
|
err_on_no_runtime=False,
|
||||||
|
):
|
||||||
rtvs: dict[str, Any] = _state._runtime_vars
|
rtvs: dict[str, Any] = _state._runtime_vars
|
||||||
root_mailbox: list[str, int] = rtvs['_root_mailbox']
|
root_mailbox: list[str, int] = rtvs['_root_mailbox']
|
||||||
registry_addrs: list[list[str, int]] = rtvs['_registry_addrs']
|
registry_addrs: list[list[str, int]] = rtvs['_registry_addrs']
|
||||||
|
@ -272,14 +274,20 @@ async def open_root_actor(
|
||||||
DeprecationWarning,
|
DeprecationWarning,
|
||||||
stacklevel=2,
|
stacklevel=2,
|
||||||
)
|
)
|
||||||
registry_addrs = [arbiter_addr]
|
uw_reg_addrs = [arbiter_addr]
|
||||||
|
|
||||||
if not registry_addrs:
|
uw_reg_addrs = registry_addrs
|
||||||
registry_addrs: list[UnwrappedAddress] = default_lo_addrs(
|
if not uw_reg_addrs:
|
||||||
|
uw_reg_addrs: list[UnwrappedAddress] = default_lo_addrs(
|
||||||
enable_transports
|
enable_transports
|
||||||
)
|
)
|
||||||
|
|
||||||
assert registry_addrs
|
# must exist by now since all below code is dependent
|
||||||
|
assert uw_reg_addrs
|
||||||
|
registry_addrs: list[Address] = [
|
||||||
|
wrap_address(uw_addr)
|
||||||
|
for uw_addr in uw_reg_addrs
|
||||||
|
]
|
||||||
|
|
||||||
loglevel = (
|
loglevel = (
|
||||||
loglevel
|
loglevel
|
||||||
|
@ -328,10 +336,10 @@ async def open_root_actor(
|
||||||
enable_stack_on_sig()
|
enable_stack_on_sig()
|
||||||
|
|
||||||
# closed into below ping task-func
|
# closed into below ping task-func
|
||||||
ponged_addrs: list[UnwrappedAddress] = []
|
ponged_addrs: list[Address] = []
|
||||||
|
|
||||||
async def ping_tpt_socket(
|
async def ping_tpt_socket(
|
||||||
addr: UnwrappedAddress,
|
addr: Address,
|
||||||
timeout: float = 1,
|
timeout: float = 1,
|
||||||
) -> None:
|
) -> None:
|
||||||
'''
|
'''
|
||||||
|
@ -351,17 +359,22 @@ async def open_root_actor(
|
||||||
# be better to eventually have a "discovery" protocol
|
# be better to eventually have a "discovery" protocol
|
||||||
# with basic handshake instead?
|
# with basic handshake instead?
|
||||||
with trio.move_on_after(timeout):
|
with trio.move_on_after(timeout):
|
||||||
async with _connect_chan(addr):
|
async with _connect_chan(addr.unwrap()):
|
||||||
ponged_addrs.append(addr)
|
ponged_addrs.append(addr)
|
||||||
|
|
||||||
except OSError:
|
except OSError:
|
||||||
# TODO: make this a "discovery" log level?
|
# ?TODO, make this a "discovery" log level?
|
||||||
logger.info(
|
logger.info(
|
||||||
f'No actor registry found @ {addr}\n'
|
f'No root-actor registry found @ {addr!r}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
# !TODO, this is basically just another (abstract)
|
||||||
|
# happy-eyeballs, so we should try for formalize it somewhere
|
||||||
|
# in a `.[_]discovery` ya?
|
||||||
|
#
|
||||||
async with trio.open_nursery() as tn:
|
async with trio.open_nursery() as tn:
|
||||||
for addr in registry_addrs:
|
for uw_addr in uw_reg_addrs:
|
||||||
|
addr: Address = wrap_address(uw_addr)
|
||||||
tn.start_soon(
|
tn.start_soon(
|
||||||
ping_tpt_socket,
|
ping_tpt_socket,
|
||||||
addr,
|
addr,
|
||||||
|
@ -383,31 +396,35 @@ async def open_root_actor(
|
||||||
f'Registry(s) seem(s) to exist @ {ponged_addrs}'
|
f'Registry(s) seem(s) to exist @ {ponged_addrs}'
|
||||||
)
|
)
|
||||||
|
|
||||||
actor = Actor(
|
actor = _runtime.Actor(
|
||||||
name=name or 'anonymous',
|
name=name or 'anonymous',
|
||||||
uuid=mk_uuid(),
|
uuid=mk_uuid(),
|
||||||
registry_addrs=ponged_addrs,
|
registry_addrs=ponged_addrs,
|
||||||
loglevel=loglevel,
|
loglevel=loglevel,
|
||||||
enable_modules=enable_modules,
|
enable_modules=enable_modules,
|
||||||
)
|
)
|
||||||
# DO NOT use the registry_addrs as the transport server
|
# **DO NOT** use the registry_addrs as the
|
||||||
# addrs for this new non-registar, root-actor.
|
# ipc-transport-server's bind-addrs as this is
|
||||||
|
# a new NON-registrar, ROOT-actor.
|
||||||
|
#
|
||||||
|
# XXX INSTEAD, bind random addrs using the same tpt
|
||||||
|
# proto.
|
||||||
for addr in ponged_addrs:
|
for addr in ponged_addrs:
|
||||||
waddr: Address = wrap_address(addr)
|
|
||||||
trans_bind_addrs.append(
|
trans_bind_addrs.append(
|
||||||
waddr.get_random(bindspace=waddr.bindspace)
|
addr.get_random(
|
||||||
|
bindspace=addr.bindspace,
|
||||||
|
)
|
||||||
)
|
)
|
||||||
|
|
||||||
# Start this local actor as the "registrar", aka a regular
|
# Start this local actor as the "registrar", aka a regular
|
||||||
# actor who manages the local registry of "mailboxes" of
|
# actor who manages the local registry of "mailboxes" of
|
||||||
# other process-tree-local sub-actors.
|
# other process-tree-local sub-actors.
|
||||||
else:
|
else:
|
||||||
|
|
||||||
# NOTE that if the current actor IS THE REGISTAR, the
|
# NOTE that if the current actor IS THE REGISTAR, the
|
||||||
# following init steps are taken:
|
# following init steps are taken:
|
||||||
# - the tranport layer server is bound to each addr
|
# - the tranport layer server is bound to each addr
|
||||||
# pair defined in provided registry_addrs, or the default.
|
# pair defined in provided registry_addrs, or the default.
|
||||||
trans_bind_addrs = registry_addrs
|
trans_bind_addrs = uw_reg_addrs
|
||||||
|
|
||||||
# - it is normally desirable for any registrar to stay up
|
# - it is normally desirable for any registrar to stay up
|
||||||
# indefinitely until either all registered (child/sub)
|
# indefinitely until either all registered (child/sub)
|
||||||
|
@ -418,7 +435,8 @@ async def open_root_actor(
|
||||||
# https://github.com/goodboy/tractor/pull/348
|
# https://github.com/goodboy/tractor/pull/348
|
||||||
# https://github.com/goodboy/tractor/issues/296
|
# https://github.com/goodboy/tractor/issues/296
|
||||||
|
|
||||||
actor = Arbiter(
|
# TODO: rename as `RootActor` or is that even necessary?
|
||||||
|
actor = _runtime.Arbiter(
|
||||||
name=name or 'registrar',
|
name=name or 'registrar',
|
||||||
uuid=mk_uuid(),
|
uuid=mk_uuid(),
|
||||||
registry_addrs=registry_addrs,
|
registry_addrs=registry_addrs,
|
||||||
|
@ -430,6 +448,16 @@ async def open_root_actor(
|
||||||
# `.trio.run()`.
|
# `.trio.run()`.
|
||||||
actor._infected_aio = _state._runtime_vars['_is_infected_aio']
|
actor._infected_aio = _state._runtime_vars['_is_infected_aio']
|
||||||
|
|
||||||
|
# NOTE, only set the loopback addr for the
|
||||||
|
# process-tree-global "root" mailbox since all sub-actors
|
||||||
|
# should be able to speak to their root actor over that
|
||||||
|
# channel.
|
||||||
|
raddrs: list[Address] = _state._runtime_vars['_root_addrs']
|
||||||
|
raddrs.extend(trans_bind_addrs)
|
||||||
|
# TODO, remove once we have also removed all usage;
|
||||||
|
# eventually all (root-)registry apis should expect > 1 addr.
|
||||||
|
_state._runtime_vars['_root_mailbox'] = raddrs[0]
|
||||||
|
|
||||||
# Start up main task set via core actor-runtime nurseries.
|
# Start up main task set via core actor-runtime nurseries.
|
||||||
try:
|
try:
|
||||||
# assign process-local actor
|
# assign process-local actor
|
||||||
|
@ -437,21 +465,27 @@ async def open_root_actor(
|
||||||
|
|
||||||
# start local channel-server and fake the portal API
|
# start local channel-server and fake the portal API
|
||||||
# NOTE: this won't block since we provide the nursery
|
# NOTE: this won't block since we provide the nursery
|
||||||
ml_addrs_str: str = '\n'.join(
|
report: str = f'Starting actor-runtime for {actor.aid.reprol()!r}\n'
|
||||||
f'@{addr}' for addr in trans_bind_addrs
|
if reg_addrs := actor.registry_addrs:
|
||||||
|
report += (
|
||||||
|
'-> Opening new registry @ '
|
||||||
|
+
|
||||||
|
'\n'.join(
|
||||||
|
f'{addr}' for addr in reg_addrs
|
||||||
)
|
)
|
||||||
logger.info(
|
|
||||||
f'Starting local {actor.uid} on the following transport addrs:\n'
|
|
||||||
f'{ml_addrs_str}'
|
|
||||||
)
|
)
|
||||||
|
logger.info(f'{report}\n')
|
||||||
|
|
||||||
# start the actor runtime in a new task
|
# start runtime in a bg sub-task, yield to caller.
|
||||||
async with trio.open_nursery(
|
async with (
|
||||||
strict_exception_groups=False,
|
collapse_eg(),
|
||||||
# ^XXX^ TODO? instead unpack any RAE as per "loose" style?
|
trio.open_nursery() as root_tn,
|
||||||
) as nursery:
|
|
||||||
|
|
||||||
# ``_runtime.async_main()`` creates an internal nursery
|
# XXX, finally-footgun below?
|
||||||
|
# -> see note on why shielding.
|
||||||
|
# maybe_raise_from_masking_exc(),
|
||||||
|
):
|
||||||
|
# `_runtime.async_main()` creates an internal nursery
|
||||||
# and blocks here until any underlying actor(-process)
|
# and blocks here until any underlying actor(-process)
|
||||||
# tree has terminated thereby conducting so called
|
# tree has terminated thereby conducting so called
|
||||||
# "end-to-end" structured concurrency throughout an
|
# "end-to-end" structured concurrency throughout an
|
||||||
|
@ -459,9 +493,9 @@ async def open_root_actor(
|
||||||
# "actor runtime" primitives are SC-compat and thus all
|
# "actor runtime" primitives are SC-compat and thus all
|
||||||
# transitively spawned actors/processes must be as
|
# transitively spawned actors/processes must be as
|
||||||
# well.
|
# well.
|
||||||
await nursery.start(
|
await root_tn.start(
|
||||||
partial(
|
partial(
|
||||||
async_main,
|
_runtime.async_main,
|
||||||
actor,
|
actor,
|
||||||
accept_addrs=trans_bind_addrs,
|
accept_addrs=trans_bind_addrs,
|
||||||
parent_addr=None
|
parent_addr=None
|
||||||
|
@ -509,7 +543,7 @@ async def open_root_actor(
|
||||||
raise
|
raise
|
||||||
|
|
||||||
finally:
|
finally:
|
||||||
# NOTE: not sure if we'll ever need this but it's
|
# NOTE/TODO?, not sure if we'll ever need this but it's
|
||||||
# possibly better for even more determinism?
|
# possibly better for even more determinism?
|
||||||
# logger.cancel(
|
# logger.cancel(
|
||||||
# f'Waiting on {len(nurseries)} nurseries in root..')
|
# f'Waiting on {len(nurseries)} nurseries in root..')
|
||||||
|
@ -518,11 +552,20 @@ async def open_root_actor(
|
||||||
# for an in nurseries:
|
# for an in nurseries:
|
||||||
# tempn.start_soon(an.exited.wait)
|
# tempn.start_soon(an.exited.wait)
|
||||||
|
|
||||||
|
op_nested_actor_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op='>) ',
|
||||||
|
text=actor.pformat(),
|
||||||
|
nest_prefix='|_',
|
||||||
|
)
|
||||||
logger.info(
|
logger.info(
|
||||||
f'Closing down root actor\n'
|
f'Closing down root actor\n'
|
||||||
f'>)\n'
|
f'{op_nested_actor_repr}'
|
||||||
f'|_{actor}\n'
|
|
||||||
)
|
)
|
||||||
|
# XXX, THIS IS A *finally-footgun*!
|
||||||
|
# -> though already shields iternally it can
|
||||||
|
# taskc here and mask underlying errors raised in
|
||||||
|
# the try-block above?
|
||||||
|
with trio.CancelScope(shield=True):
|
||||||
await actor.cancel(None) # self cancel
|
await actor.cancel(None) # self cancel
|
||||||
finally:
|
finally:
|
||||||
# revert all process-global runtime state
|
# revert all process-global runtime state
|
||||||
|
@ -536,10 +579,16 @@ async def open_root_actor(
|
||||||
_state._current_actor = None
|
_state._current_actor = None
|
||||||
_state._last_actor_terminated = actor
|
_state._last_actor_terminated = actor
|
||||||
|
|
||||||
logger.runtime(
|
sclang_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op=')>',
|
||||||
|
text=actor.pformat(),
|
||||||
|
nest_prefix='|_',
|
||||||
|
nest_indent=1,
|
||||||
|
)
|
||||||
|
|
||||||
|
logger.info(
|
||||||
f'Root actor terminated\n'
|
f'Root actor terminated\n'
|
||||||
f')>\n'
|
f'{sclang_repr}'
|
||||||
f' |_{actor}\n'
|
|
||||||
)
|
)
|
||||||
|
|
||||||
|
|
||||||
|
|
180
tractor/_rpc.py
180
tractor/_rpc.py
|
@ -64,6 +64,7 @@ from .trionics import (
|
||||||
from .devx import (
|
from .devx import (
|
||||||
debug,
|
debug,
|
||||||
add_div,
|
add_div,
|
||||||
|
pformat as _pformat,
|
||||||
)
|
)
|
||||||
from . import _state
|
from . import _state
|
||||||
from .log import get_logger
|
from .log import get_logger
|
||||||
|
@ -72,7 +73,7 @@ from .msg import (
|
||||||
MsgCodec,
|
MsgCodec,
|
||||||
PayloadT,
|
PayloadT,
|
||||||
NamespacePath,
|
NamespacePath,
|
||||||
# pretty_struct,
|
pretty_struct,
|
||||||
_ops as msgops,
|
_ops as msgops,
|
||||||
)
|
)
|
||||||
from tractor.msg.types import (
|
from tractor.msg.types import (
|
||||||
|
@ -220,11 +221,18 @@ async def _invoke_non_context(
|
||||||
task_status.started(ctx)
|
task_status.started(ctx)
|
||||||
result = await coro
|
result = await coro
|
||||||
fname: str = func.__name__
|
fname: str = func.__name__
|
||||||
|
|
||||||
|
op_nested_task: str = _pformat.nest_from_op(
|
||||||
|
input_op=f')> cid: {ctx.cid!r}',
|
||||||
|
text=f'{ctx._task}',
|
||||||
|
nest_indent=1, # under >
|
||||||
|
)
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'RPC complete:\n'
|
f'RPC task complete\n'
|
||||||
f'task: {ctx._task}\n'
|
f'\n'
|
||||||
f'|_cid={ctx.cid}\n'
|
f'{op_nested_task}\n'
|
||||||
f'|_{fname}() -> {pformat(result)}\n'
|
f'\n'
|
||||||
|
f')> {fname}() -> {pformat(result)}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# NOTE: only send result if we know IPC isn't down
|
# NOTE: only send result if we know IPC isn't down
|
||||||
|
@ -276,6 +284,10 @@ async def _errors_relayed_via_ipc(
|
||||||
try:
|
try:
|
||||||
yield # run RPC invoke body
|
yield # run RPC invoke body
|
||||||
|
|
||||||
|
except TransportClosed:
|
||||||
|
log.exception('Tpt disconnect during remote-exc relay?')
|
||||||
|
raise
|
||||||
|
|
||||||
# box and ship RPC errors for wire-transit via
|
# box and ship RPC errors for wire-transit via
|
||||||
# the task's requesting parent IPC-channel.
|
# the task's requesting parent IPC-channel.
|
||||||
except (
|
except (
|
||||||
|
@ -311,6 +323,9 @@ async def _errors_relayed_via_ipc(
|
||||||
and debug_kbis
|
and debug_kbis
|
||||||
)
|
)
|
||||||
)
|
)
|
||||||
|
# TODO? better then `debug_filter` below?
|
||||||
|
# and
|
||||||
|
# not isinstance(err, TransportClosed)
|
||||||
):
|
):
|
||||||
# XXX QUESTION XXX: is there any case where we'll
|
# XXX QUESTION XXX: is there any case where we'll
|
||||||
# want to debug IPC disconnects as a default?
|
# want to debug IPC disconnects as a default?
|
||||||
|
@ -319,13 +334,25 @@ async def _errors_relayed_via_ipc(
|
||||||
# recovery logic - the only case is some kind of
|
# recovery logic - the only case is some kind of
|
||||||
# strange bug in our transport layer itself? Going
|
# strange bug in our transport layer itself? Going
|
||||||
# to keep this open ended for now.
|
# to keep this open ended for now.
|
||||||
log.debug(
|
|
||||||
'RPC task crashed, attempting to enter debugger\n'
|
if _state.debug_mode():
|
||||||
f'|_{ctx}'
|
log.exception(
|
||||||
|
f'RPC task crashed!\n'
|
||||||
|
f'Attempting to enter debugger\n'
|
||||||
|
f'\n'
|
||||||
|
f'{ctx}'
|
||||||
)
|
)
|
||||||
|
|
||||||
entered_debug = await debug._maybe_enter_pm(
|
entered_debug = await debug._maybe_enter_pm(
|
||||||
err,
|
err,
|
||||||
api_frame=inspect.currentframe(),
|
api_frame=inspect.currentframe(),
|
||||||
|
|
||||||
|
# don't REPL any psuedo-expected tpt-disconnect
|
||||||
|
# debug_filter=lambda exc: (
|
||||||
|
# type (exc) not in {
|
||||||
|
# TransportClosed,
|
||||||
|
# }
|
||||||
|
# ),
|
||||||
)
|
)
|
||||||
if not entered_debug:
|
if not entered_debug:
|
||||||
# if we prolly should have entered the REPL but
|
# if we prolly should have entered the REPL but
|
||||||
|
@ -442,7 +469,7 @@ async def _invoke(
|
||||||
kwargs: dict[str, Any],
|
kwargs: dict[str, Any],
|
||||||
|
|
||||||
is_rpc: bool = True,
|
is_rpc: bool = True,
|
||||||
hide_tb: bool = True,
|
hide_tb: bool = False,
|
||||||
return_msg_type: Return|CancelAck = Return,
|
return_msg_type: Return|CancelAck = Return,
|
||||||
|
|
||||||
task_status: TaskStatus[
|
task_status: TaskStatus[
|
||||||
|
@ -646,8 +673,7 @@ async def _invoke(
|
||||||
# scope ensures unasking of the `await coro` below
|
# scope ensures unasking of the `await coro` below
|
||||||
# *should* never be interfered with!!
|
# *should* never be interfered with!!
|
||||||
maybe_raise_from_masking_exc(
|
maybe_raise_from_masking_exc(
|
||||||
tn=tn,
|
unmask_from=(Cancelled,),
|
||||||
unmask_from=Cancelled,
|
|
||||||
) as _mbme, # maybe boxed masked exc
|
) as _mbme, # maybe boxed masked exc
|
||||||
):
|
):
|
||||||
ctx._scope_nursery = tn
|
ctx._scope_nursery = tn
|
||||||
|
@ -664,9 +690,23 @@ async def _invoke(
|
||||||
ctx._result = res
|
ctx._result = res
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Sending result msg and exiting {ctx.side!r}\n'
|
f'Sending result msg and exiting {ctx.side!r}\n'
|
||||||
f'{return_msg}\n'
|
f'\n'
|
||||||
|
f'{pretty_struct.pformat(return_msg)}\n'
|
||||||
)
|
)
|
||||||
|
try:
|
||||||
await chan.send(return_msg)
|
await chan.send(return_msg)
|
||||||
|
except TransportClosed:
|
||||||
|
log.exception(
|
||||||
|
f"Failed send final result to 'parent'-side of IPC-ctx!\n"
|
||||||
|
f'\n'
|
||||||
|
f'{chan}\n'
|
||||||
|
f'Channel already disconnected ??\n'
|
||||||
|
f'\n'
|
||||||
|
f'{pretty_struct.pformat(return_msg)}'
|
||||||
|
)
|
||||||
|
# ?TODO? will this ever be true though?
|
||||||
|
if chan.connected():
|
||||||
|
raise
|
||||||
|
|
||||||
# NOTE: this happens IFF `ctx._scope.cancel()` is
|
# NOTE: this happens IFF `ctx._scope.cancel()` is
|
||||||
# called by any of,
|
# called by any of,
|
||||||
|
@ -756,7 +796,6 @@ async def _invoke(
|
||||||
BaseExceptionGroup,
|
BaseExceptionGroup,
|
||||||
BaseException,
|
BaseException,
|
||||||
trio.Cancelled,
|
trio.Cancelled,
|
||||||
|
|
||||||
) as _scope_err:
|
) as _scope_err:
|
||||||
scope_err = _scope_err
|
scope_err = _scope_err
|
||||||
if (
|
if (
|
||||||
|
@ -832,12 +871,12 @@ async def _invoke(
|
||||||
else:
|
else:
|
||||||
descr_str += f'\n{merr!r}\n'
|
descr_str += f'\n{merr!r}\n'
|
||||||
else:
|
else:
|
||||||
descr_str += f'\nand final result {ctx.outcome!r}\n'
|
descr_str += f'\nwith final result {ctx.outcome!r}\n'
|
||||||
|
|
||||||
logmeth(
|
logmeth(
|
||||||
message
|
f'{message}\n'
|
||||||
+
|
f'\n'
|
||||||
descr_str
|
f'{descr_str}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
|
||||||
|
@ -1004,8 +1043,6 @@ async def process_messages(
|
||||||
cid=cid,
|
cid=cid,
|
||||||
kwargs=kwargs,
|
kwargs=kwargs,
|
||||||
):
|
):
|
||||||
kwargs |= {'req_chan': chan}
|
|
||||||
|
|
||||||
# XXX NOTE XXX don't start entire actor
|
# XXX NOTE XXX don't start entire actor
|
||||||
# runtime cancellation if this actor is
|
# runtime cancellation if this actor is
|
||||||
# currently in debug mode!
|
# currently in debug mode!
|
||||||
|
@ -1024,14 +1061,14 @@ async def process_messages(
|
||||||
cid,
|
cid,
|
||||||
chan,
|
chan,
|
||||||
actor.cancel,
|
actor.cancel,
|
||||||
kwargs,
|
kwargs | {'req_chan': chan},
|
||||||
is_rpc=False,
|
is_rpc=False,
|
||||||
return_msg_type=CancelAck,
|
return_msg_type=CancelAck,
|
||||||
)
|
)
|
||||||
|
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Cancelling IPC transport msg-loop with peer:\n'
|
'Cancelling RPC-msg-loop with peer\n'
|
||||||
f'|_{chan}\n'
|
f'->c}} {chan.aid.reprol()}@[{chan.maddr}]\n'
|
||||||
)
|
)
|
||||||
loop_cs.cancel()
|
loop_cs.cancel()
|
||||||
break
|
break
|
||||||
|
@ -1044,7 +1081,7 @@ async def process_messages(
|
||||||
):
|
):
|
||||||
target_cid: str = kwargs['cid']
|
target_cid: str = kwargs['cid']
|
||||||
kwargs |= {
|
kwargs |= {
|
||||||
'requesting_uid': chan.uid,
|
'requesting_aid': chan.aid,
|
||||||
'ipc_msg': msg,
|
'ipc_msg': msg,
|
||||||
|
|
||||||
# XXX NOTE! ONLY the rpc-task-owning
|
# XXX NOTE! ONLY the rpc-task-owning
|
||||||
|
@ -1080,21 +1117,34 @@ async def process_messages(
|
||||||
ns=ns,
|
ns=ns,
|
||||||
func=funcname,
|
func=funcname,
|
||||||
kwargs=kwargs, # type-spec this? see `msg.types`
|
kwargs=kwargs, # type-spec this? see `msg.types`
|
||||||
uid=actorid,
|
uid=actor_uuid,
|
||||||
):
|
):
|
||||||
|
if actor_uuid != chan.aid.uid:
|
||||||
|
raise RuntimeError(
|
||||||
|
f'IPC <Start> msg <-> chan.aid mismatch!?\n'
|
||||||
|
f'Channel.aid = {chan.aid!r}\n'
|
||||||
|
f'Start.uid = {actor_uuid!r}\n'
|
||||||
|
)
|
||||||
|
# await debug.pause()
|
||||||
|
op_repr: str = 'Start <=) '
|
||||||
|
req_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op=op_repr,
|
||||||
|
op_suffix='',
|
||||||
|
nest_prefix='',
|
||||||
|
text=f'{chan}',
|
||||||
|
|
||||||
|
nest_indent=len(op_repr)-1,
|
||||||
|
rm_from_first_ln='<',
|
||||||
|
# ^XXX, subtract -1 to account for
|
||||||
|
# <Channel
|
||||||
|
# ^_chevron to be stripped
|
||||||
|
)
|
||||||
start_status: str = (
|
start_status: str = (
|
||||||
'Handling RPC `Start` request\n'
|
'Handling RPC request\n'
|
||||||
f'<= peer: {actorid}\n\n'
|
f'{req_repr}\n'
|
||||||
f' |_{chan}\n'
|
f'\n'
|
||||||
f' |_cid: {cid}\n\n'
|
f'->{{ ipc-context-id: {cid!r}\n'
|
||||||
# f' |_{ns}.{funcname}({kwargs})\n'
|
f'->{{ nsp for fn: `{ns}.{funcname}({kwargs})`\n'
|
||||||
f'>> {actor.uid}\n'
|
|
||||||
f' |_{actor}\n'
|
|
||||||
f' -> nsp: `{ns}.{funcname}({kwargs})`\n'
|
|
||||||
|
|
||||||
# f' |_{ns}.{funcname}({kwargs})\n\n'
|
|
||||||
|
|
||||||
# f'{pretty_struct.pformat(msg)}\n'
|
|
||||||
)
|
)
|
||||||
|
|
||||||
# runtime-internal endpoint: `Actor.<funcname>`
|
# runtime-internal endpoint: `Actor.<funcname>`
|
||||||
|
@ -1123,10 +1173,6 @@ async def process_messages(
|
||||||
await chan.send(err_msg)
|
await chan.send(err_msg)
|
||||||
continue
|
continue
|
||||||
|
|
||||||
start_status += (
|
|
||||||
f' -> func: {func}\n'
|
|
||||||
)
|
|
||||||
|
|
||||||
# schedule a task for the requested RPC function
|
# schedule a task for the requested RPC function
|
||||||
# in the actor's main "service nursery".
|
# in the actor's main "service nursery".
|
||||||
#
|
#
|
||||||
|
@ -1134,7 +1180,7 @@ async def process_messages(
|
||||||
# supervision isolation? would avoid having to
|
# supervision isolation? would avoid having to
|
||||||
# manage RPC tasks individually in `._rpc_tasks`
|
# manage RPC tasks individually in `._rpc_tasks`
|
||||||
# table?
|
# table?
|
||||||
start_status += ' -> scheduling new task..\n'
|
start_status += '->( scheduling new task..\n'
|
||||||
log.runtime(start_status)
|
log.runtime(start_status)
|
||||||
try:
|
try:
|
||||||
ctx: Context = await actor._service_n.start(
|
ctx: Context = await actor._service_n.start(
|
||||||
|
@ -1218,12 +1264,24 @@ async def process_messages(
|
||||||
# END-OF `async for`:
|
# END-OF `async for`:
|
||||||
# IPC disconnected via `trio.EndOfChannel`, likely
|
# IPC disconnected via `trio.EndOfChannel`, likely
|
||||||
# due to a (graceful) `Channel.aclose()`.
|
# due to a (graceful) `Channel.aclose()`.
|
||||||
|
|
||||||
|
chan_op_repr: str = '<=x] '
|
||||||
|
chan_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op=chan_op_repr,
|
||||||
|
op_suffix='',
|
||||||
|
nest_prefix='',
|
||||||
|
text=chan.pformat(),
|
||||||
|
nest_indent=len(chan_op_repr)-1,
|
||||||
|
rm_from_first_ln='<',
|
||||||
|
)
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'channel for {chan.uid} disconnected, cancelling RPC tasks\n'
|
f'IPC channel disconnected\n'
|
||||||
f'|_{chan}\n'
|
f'{chan_repr}\n'
|
||||||
|
f'\n'
|
||||||
|
f'->c) cancelling RPC tasks.\n'
|
||||||
)
|
)
|
||||||
await actor.cancel_rpc_tasks(
|
await actor.cancel_rpc_tasks(
|
||||||
req_uid=actor.uid,
|
req_aid=actor.aid,
|
||||||
# a "self cancel" in terms of the lifetime of the
|
# a "self cancel" in terms of the lifetime of the
|
||||||
# IPC connection which is presumed to be the
|
# IPC connection which is presumed to be the
|
||||||
# source of any requests for spawned tasks.
|
# source of any requests for spawned tasks.
|
||||||
|
@ -1295,13 +1353,37 @@ async def process_messages(
|
||||||
finally:
|
finally:
|
||||||
# msg debugging for when he machinery is brokey
|
# msg debugging for when he machinery is brokey
|
||||||
if msg is None:
|
if msg is None:
|
||||||
message: str = 'Exiting IPC msg loop without receiving a msg?'
|
message: str = 'Exiting RPC-loop without receiving a msg?'
|
||||||
else:
|
else:
|
||||||
|
task_op_repr: str = ')>'
|
||||||
|
task: trio.Task = trio.lowlevel.current_task()
|
||||||
|
|
||||||
|
# maybe add cancelled opt prefix
|
||||||
|
if task._cancel_status.effectively_cancelled:
|
||||||
|
task_op_repr = 'c' + task_op_repr
|
||||||
|
|
||||||
|
task_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op=task_op_repr,
|
||||||
|
text=f'{task!r}',
|
||||||
|
nest_indent=1,
|
||||||
|
)
|
||||||
|
# chan_op_repr: str = '<=} '
|
||||||
|
# chan_repr: str = _pformat.nest_from_op(
|
||||||
|
# input_op=chan_op_repr,
|
||||||
|
# op_suffix='',
|
||||||
|
# nest_prefix='',
|
||||||
|
# text=chan.pformat(),
|
||||||
|
# nest_indent=len(chan_op_repr)-1,
|
||||||
|
# rm_from_first_ln='<',
|
||||||
|
# )
|
||||||
message: str = (
|
message: str = (
|
||||||
'Exiting IPC msg loop with final msg\n\n'
|
f'Exiting RPC-loop with final msg\n'
|
||||||
f'<= peer: {chan.uid}\n'
|
f'\n'
|
||||||
f' |_{chan}\n\n'
|
# f'{chan_repr}\n'
|
||||||
# f'{pretty_struct.pformat(msg)}'
|
f'{task_repr}\n'
|
||||||
|
f'\n'
|
||||||
|
f'{pretty_struct.pformat(msg)}'
|
||||||
|
f'\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
log.runtime(message)
|
log.runtime(message)
|
||||||
|
|
|
@ -55,6 +55,7 @@ from typing import (
|
||||||
TYPE_CHECKING,
|
TYPE_CHECKING,
|
||||||
)
|
)
|
||||||
import uuid
|
import uuid
|
||||||
|
import textwrap
|
||||||
from types import ModuleType
|
from types import ModuleType
|
||||||
import warnings
|
import warnings
|
||||||
|
|
||||||
|
@ -73,6 +74,9 @@ from tractor.msg import (
|
||||||
pretty_struct,
|
pretty_struct,
|
||||||
types as msgtypes,
|
types as msgtypes,
|
||||||
)
|
)
|
||||||
|
from .trionics import (
|
||||||
|
collapse_eg,
|
||||||
|
)
|
||||||
from .ipc import (
|
from .ipc import (
|
||||||
Channel,
|
Channel,
|
||||||
# IPCServer, # causes cycles atm..
|
# IPCServer, # causes cycles atm..
|
||||||
|
@ -97,7 +101,10 @@ from ._exceptions import (
|
||||||
MsgTypeError,
|
MsgTypeError,
|
||||||
unpack_error,
|
unpack_error,
|
||||||
)
|
)
|
||||||
from .devx import debug
|
from .devx import (
|
||||||
|
debug,
|
||||||
|
pformat as _pformat
|
||||||
|
)
|
||||||
from ._discovery import get_registry
|
from ._discovery import get_registry
|
||||||
from ._portal import Portal
|
from ._portal import Portal
|
||||||
from . import _state
|
from . import _state
|
||||||
|
@ -206,7 +213,7 @@ class Actor:
|
||||||
*,
|
*,
|
||||||
enable_modules: list[str] = [],
|
enable_modules: list[str] = [],
|
||||||
loglevel: str|None = None,
|
loglevel: str|None = None,
|
||||||
registry_addrs: list[UnwrappedAddress]|None = None,
|
registry_addrs: list[Address]|None = None,
|
||||||
spawn_method: str|None = None,
|
spawn_method: str|None = None,
|
||||||
|
|
||||||
# TODO: remove!
|
# TODO: remove!
|
||||||
|
@ -227,7 +234,7 @@ class Actor:
|
||||||
|
|
||||||
# state
|
# state
|
||||||
self._cancel_complete = trio.Event()
|
self._cancel_complete = trio.Event()
|
||||||
self._cancel_called_by_remote: tuple[str, tuple]|None = None
|
self._cancel_called_by: tuple[str, tuple]|None = None
|
||||||
self._cancel_called: bool = False
|
self._cancel_called: bool = False
|
||||||
|
|
||||||
# retreive and store parent `__main__` data which
|
# retreive and store parent `__main__` data which
|
||||||
|
@ -249,11 +256,12 @@ class Actor:
|
||||||
if arbiter_addr is not None:
|
if arbiter_addr is not None:
|
||||||
warnings.warn(
|
warnings.warn(
|
||||||
'`Actor(arbiter_addr=<blah>)` is now deprecated.\n'
|
'`Actor(arbiter_addr=<blah>)` is now deprecated.\n'
|
||||||
'Use `registry_addrs: list[tuple]` instead.',
|
'Use `registry_addrs: list[Address]` instead.',
|
||||||
DeprecationWarning,
|
DeprecationWarning,
|
||||||
stacklevel=2,
|
stacklevel=2,
|
||||||
)
|
)
|
||||||
registry_addrs: list[UnwrappedAddress] = [arbiter_addr]
|
|
||||||
|
registry_addrs: list[Address] = [wrap_address(arbiter_addr)]
|
||||||
|
|
||||||
# marked by the process spawning backend at startup
|
# marked by the process spawning backend at startup
|
||||||
# will be None for the parent most process started manually
|
# will be None for the parent most process started manually
|
||||||
|
@ -292,8 +300,10 @@ class Actor:
|
||||||
# input via the validator.
|
# input via the validator.
|
||||||
self._reg_addrs: list[UnwrappedAddress] = []
|
self._reg_addrs: list[UnwrappedAddress] = []
|
||||||
if registry_addrs:
|
if registry_addrs:
|
||||||
self.reg_addrs: list[UnwrappedAddress] = registry_addrs
|
_state._runtime_vars['_registry_addrs'] = self.reg_addrs = [
|
||||||
_state._runtime_vars['_registry_addrs'] = registry_addrs
|
addr.unwrap()
|
||||||
|
for addr in registry_addrs
|
||||||
|
]
|
||||||
|
|
||||||
@property
|
@property
|
||||||
def aid(self) -> msgtypes.Aid:
|
def aid(self) -> msgtypes.Aid:
|
||||||
|
@ -339,46 +349,125 @@ class Actor:
|
||||||
def pid(self) -> int:
|
def pid(self) -> int:
|
||||||
return self._aid.pid
|
return self._aid.pid
|
||||||
|
|
||||||
def pformat(self) -> str:
|
@property
|
||||||
ds: str = '='
|
def repr_state(self) -> str:
|
||||||
parent_uid: tuple|None = None
|
if self.cancel_complete:
|
||||||
if rent_chan := self._parent_chan:
|
return 'cancelled'
|
||||||
parent_uid = rent_chan.uid
|
|
||||||
|
elif canceller := self.cancel_caller:
|
||||||
|
return f' and cancel-called by {canceller}'
|
||||||
|
|
||||||
|
else:
|
||||||
|
return 'running'
|
||||||
|
|
||||||
|
def pformat(
|
||||||
|
self,
|
||||||
|
ds: str = ': ',
|
||||||
|
indent: int = 0,
|
||||||
|
privates: bool = False,
|
||||||
|
) -> str:
|
||||||
|
|
||||||
|
fmtstr: str = f'|_id: {self.aid.reprol()!r}\n'
|
||||||
|
if privates:
|
||||||
|
aid_nest_prefix: str = '|_aid='
|
||||||
|
aid_field_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op='',
|
||||||
|
text=pretty_struct.pformat(
|
||||||
|
struct=self.aid,
|
||||||
|
field_indent=2,
|
||||||
|
),
|
||||||
|
op_suffix='',
|
||||||
|
nest_prefix=aid_nest_prefix,
|
||||||
|
nest_indent=0,
|
||||||
|
)
|
||||||
|
fmtstr: str = f'{aid_field_repr}'
|
||||||
|
|
||||||
|
if rent_chan := self._parent_chan:
|
||||||
|
fmtstr += (
|
||||||
|
f"|_parent{ds}{rent_chan.aid.reprol()}\n"
|
||||||
|
)
|
||||||
|
|
||||||
peers: list = []
|
|
||||||
server: _server.IPCServer = self.ipc_server
|
server: _server.IPCServer = self.ipc_server
|
||||||
if server:
|
if server:
|
||||||
peers: list[tuple] = list(server._peer_connected)
|
if privates:
|
||||||
|
server_repr: str = self._ipc_server.pformat(
|
||||||
|
privates=privates,
|
||||||
|
)
|
||||||
|
# create field ln as a key-header indented under
|
||||||
|
# and up to the section's key prefix.
|
||||||
|
# ^XXX if we were to indent `repr(Server)` to
|
||||||
|
# '<key>: '
|
||||||
|
# _here_^
|
||||||
|
server_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op='', # nest as sub-obj
|
||||||
|
op_suffix='',
|
||||||
|
text=server_repr,
|
||||||
|
)
|
||||||
|
fmtstr += (
|
||||||
|
f"{server_repr}"
|
||||||
|
)
|
||||||
|
else:
|
||||||
|
fmtstr += (
|
||||||
|
f'|_ipc: {server.repr_state!r}\n'
|
||||||
|
)
|
||||||
|
|
||||||
fmtstr: str = (
|
fmtstr += (
|
||||||
f' |_id: {self.aid!r}\n'
|
f'|_rpc: {len(self._rpc_tasks)} active tasks\n'
|
||||||
# f" aid{ds}{self.aid!r}\n"
|
|
||||||
f" parent{ds}{parent_uid}\n"
|
|
||||||
f'\n'
|
|
||||||
f' |_ipc: {len(peers)!r} connected peers\n'
|
|
||||||
f" peers{ds}{peers!r}\n"
|
|
||||||
f" ipc_server{ds}{self._ipc_server}\n"
|
|
||||||
f'\n'
|
|
||||||
f' |_rpc: {len(self._rpc_tasks)} tasks\n'
|
|
||||||
f" ctxs{ds}{len(self._contexts)}\n"
|
|
||||||
f'\n'
|
|
||||||
f' |_runtime: ._task{ds}{self._task!r}\n'
|
|
||||||
f' _spawn_method{ds}{self._spawn_method}\n'
|
|
||||||
f' _actoruid2nursery{ds}{self._actoruid2nursery}\n'
|
|
||||||
f' _forkserver_info{ds}{self._forkserver_info}\n'
|
|
||||||
f'\n'
|
|
||||||
f' |_state: "TODO: .repr_state()"\n'
|
|
||||||
f' _cancel_complete{ds}{self._cancel_complete}\n'
|
|
||||||
f' _cancel_called_by_remote{ds}{self._cancel_called_by_remote}\n'
|
|
||||||
f' _cancel_called{ds}{self._cancel_called}\n'
|
|
||||||
)
|
)
|
||||||
return (
|
|
||||||
'<Actor(\n'
|
# TODO, actually fix the .repr_state impl/output?
|
||||||
+
|
# append ipc-ctx state summary
|
||||||
fmtstr
|
# ctxs: dict = self._contexts
|
||||||
+
|
# if ctxs:
|
||||||
')>\n'
|
# ctx_states: dict[str, int] = {}
|
||||||
|
# for ctx in self._contexts.values():
|
||||||
|
# ctx_state: str = ctx.repr_state
|
||||||
|
# cnt = ctx_states.setdefault(ctx_state, 0)
|
||||||
|
# ctx_states[ctx_state] = cnt + 1
|
||||||
|
|
||||||
|
# fmtstr += (
|
||||||
|
# f" ctxs{ds}{ctx_states}\n"
|
||||||
|
# )
|
||||||
|
|
||||||
|
# runtime-state
|
||||||
|
task_name: str = '<dne>'
|
||||||
|
if task := self._task:
|
||||||
|
task_name: str = task.name
|
||||||
|
fmtstr += (
|
||||||
|
# TODO, this just like ctx?
|
||||||
|
f'|_state: {self.repr_state!r}\n'
|
||||||
|
f' task: {task_name}\n'
|
||||||
|
f' loglevel: {self.loglevel!r}\n'
|
||||||
|
f' subactors_spawned: {len(self._actoruid2nursery)}\n'
|
||||||
)
|
)
|
||||||
|
if not _state.is_root_process():
|
||||||
|
fmtstr += f' spawn_method: {self._spawn_method!r}\n'
|
||||||
|
|
||||||
|
if privates:
|
||||||
|
fmtstr += (
|
||||||
|
# f' actoruid2nursery{ds}{self._actoruid2nursery}\n'
|
||||||
|
f' cancel_complete{ds}{self._cancel_complete}\n'
|
||||||
|
f' cancel_called_by_remote{ds}{self._cancel_called_by}\n'
|
||||||
|
f' cancel_called{ds}{self._cancel_called}\n'
|
||||||
|
)
|
||||||
|
|
||||||
|
if fmtstr:
|
||||||
|
fmtstr: str = textwrap.indent(
|
||||||
|
text=fmtstr,
|
||||||
|
prefix=' '*(1 + indent),
|
||||||
|
)
|
||||||
|
|
||||||
|
_repr: str = (
|
||||||
|
f'<{type(self).__name__}(\n'
|
||||||
|
f'{fmtstr}'
|
||||||
|
f')>\n'
|
||||||
|
)
|
||||||
|
if indent:
|
||||||
|
_repr: str = textwrap.indent(
|
||||||
|
text=_repr,
|
||||||
|
prefix=' '*indent,
|
||||||
|
)
|
||||||
|
return _repr
|
||||||
|
|
||||||
__repr__ = pformat
|
__repr__ = pformat
|
||||||
|
|
||||||
|
@ -386,7 +475,11 @@ class Actor:
|
||||||
def reg_addrs(self) -> list[UnwrappedAddress]:
|
def reg_addrs(self) -> list[UnwrappedAddress]:
|
||||||
'''
|
'''
|
||||||
List of (socket) addresses for all known (and contactable)
|
List of (socket) addresses for all known (and contactable)
|
||||||
registry actors.
|
registry-service actors in "unwrapped" (i.e. IPC interchange
|
||||||
|
wire-compat) form.
|
||||||
|
|
||||||
|
If you are looking for the "wrapped" address form, use
|
||||||
|
`.registry_addrs` instead.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
return self._reg_addrs
|
return self._reg_addrs
|
||||||
|
@ -405,8 +498,14 @@ class Actor:
|
||||||
|
|
||||||
self._reg_addrs = addrs
|
self._reg_addrs = addrs
|
||||||
|
|
||||||
|
@property
|
||||||
|
def registry_addrs(self) -> list[Address]:
|
||||||
|
return [wrap_address(uw_addr)
|
||||||
|
for uw_addr in self.reg_addrs]
|
||||||
|
|
||||||
def load_modules(
|
def load_modules(
|
||||||
self,
|
self,
|
||||||
|
|
||||||
) -> None:
|
) -> None:
|
||||||
'''
|
'''
|
||||||
Load explicitly enabled python modules from local fs after
|
Load explicitly enabled python modules from local fs after
|
||||||
|
@ -453,6 +552,14 @@ class Actor:
|
||||||
)
|
)
|
||||||
raise
|
raise
|
||||||
|
|
||||||
|
# ?TODO, factor this meth-iface into a new `.rpc` subsys primitive?
|
||||||
|
# - _get_rpc_func(),
|
||||||
|
# - _deliver_ctx_payload(),
|
||||||
|
# - get_context(),
|
||||||
|
# - start_remote_task(),
|
||||||
|
# - cancel_rpc_tasks(),
|
||||||
|
# - _cancel_task(),
|
||||||
|
#
|
||||||
def _get_rpc_func(self, ns, funcname):
|
def _get_rpc_func(self, ns, funcname):
|
||||||
'''
|
'''
|
||||||
Try to lookup and return a target RPC func from the
|
Try to lookup and return a target RPC func from the
|
||||||
|
@ -496,11 +603,11 @@ class Actor:
|
||||||
queue.
|
queue.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
uid: tuple[str, str] = chan.uid
|
aid: msgtypes.Aid = chan.aid
|
||||||
assert uid, f"`chan.uid` can't be {uid}"
|
assert aid, f"`chan.aid` can't be {aid}"
|
||||||
try:
|
try:
|
||||||
ctx: Context = self._contexts[(
|
ctx: Context = self._contexts[(
|
||||||
uid,
|
aid.uid,
|
||||||
cid,
|
cid,
|
||||||
|
|
||||||
# TODO: how to determine this tho?
|
# TODO: how to determine this tho?
|
||||||
|
@ -511,7 +618,7 @@ class Actor:
|
||||||
'Ignoring invalid IPC msg!?\n'
|
'Ignoring invalid IPC msg!?\n'
|
||||||
f'Ctx seems to not/no-longer exist??\n'
|
f'Ctx seems to not/no-longer exist??\n'
|
||||||
f'\n'
|
f'\n'
|
||||||
f'<=? {uid}\n'
|
f'<=? {aid.reprol()!r}\n'
|
||||||
f' |_{pretty_struct.pformat(msg)}\n'
|
f' |_{pretty_struct.pformat(msg)}\n'
|
||||||
)
|
)
|
||||||
match msg:
|
match msg:
|
||||||
|
@ -560,6 +667,7 @@ class Actor:
|
||||||
msging session's lifetime.
|
msging session's lifetime.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
|
# ?TODO, use Aid here as well?
|
||||||
actor_uid = chan.uid
|
actor_uid = chan.uid
|
||||||
assert actor_uid
|
assert actor_uid
|
||||||
try:
|
try:
|
||||||
|
@ -908,6 +1016,22 @@ class Actor:
|
||||||
None, # self cancel all rpc tasks
|
None, # self cancel all rpc tasks
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@property
|
||||||
|
def cancel_complete(self) -> bool:
|
||||||
|
return self._cancel_complete.is_set()
|
||||||
|
|
||||||
|
@property
|
||||||
|
def cancel_called(self) -> bool:
|
||||||
|
'''
|
||||||
|
Was this actor requested to cancel by a remote peer actor.
|
||||||
|
|
||||||
|
'''
|
||||||
|
return self._cancel_called_by is not None
|
||||||
|
|
||||||
|
@property
|
||||||
|
def cancel_caller(self) -> msgtypes.Aid|None:
|
||||||
|
return self._cancel_called_by
|
||||||
|
|
||||||
async def cancel(
|
async def cancel(
|
||||||
self,
|
self,
|
||||||
|
|
||||||
|
@ -932,20 +1056,18 @@ class Actor:
|
||||||
|
|
||||||
'''
|
'''
|
||||||
(
|
(
|
||||||
requesting_uid,
|
requesting_aid, # Aid
|
||||||
requester_type,
|
requester_type, # str
|
||||||
req_chan,
|
req_chan,
|
||||||
log_meth,
|
log_meth,
|
||||||
) = (
|
) = (
|
||||||
req_chan.uid,
|
req_chan.aid,
|
||||||
'peer',
|
'peer',
|
||||||
req_chan,
|
req_chan,
|
||||||
log.cancel,
|
log.cancel,
|
||||||
|
|
||||||
) if req_chan else (
|
) if req_chan else (
|
||||||
|
|
||||||
# a self cancel of ALL rpc tasks
|
# a self cancel of ALL rpc tasks
|
||||||
self.uid,
|
self.aid,
|
||||||
'self',
|
'self',
|
||||||
self,
|
self,
|
||||||
log.runtime,
|
log.runtime,
|
||||||
|
@ -953,14 +1075,14 @@ class Actor:
|
||||||
# TODO: just use the new `Context.repr_rpc: str` (and
|
# TODO: just use the new `Context.repr_rpc: str` (and
|
||||||
# other) repr fields instead of doing this all manual..
|
# other) repr fields instead of doing this all manual..
|
||||||
msg: str = (
|
msg: str = (
|
||||||
f'Actor-runtime cancel request from {requester_type}\n\n'
|
f'Actor-runtime cancel request from {requester_type!r}\n'
|
||||||
f'<=c) {requesting_uid}\n'
|
|
||||||
f' |_{self}\n'
|
|
||||||
f'\n'
|
f'\n'
|
||||||
|
f'<=c)\n'
|
||||||
|
f'{self}'
|
||||||
)
|
)
|
||||||
|
|
||||||
# TODO: what happens here when we self-cancel tho?
|
# TODO: what happens here when we self-cancel tho?
|
||||||
self._cancel_called_by_remote: tuple = requesting_uid
|
self._cancel_called_by: tuple = requesting_aid
|
||||||
self._cancel_called = True
|
self._cancel_called = True
|
||||||
|
|
||||||
# cancel all ongoing rpc tasks
|
# cancel all ongoing rpc tasks
|
||||||
|
@ -988,7 +1110,7 @@ class Actor:
|
||||||
|
|
||||||
# self-cancel **all** ongoing RPC tasks
|
# self-cancel **all** ongoing RPC tasks
|
||||||
await self.cancel_rpc_tasks(
|
await self.cancel_rpc_tasks(
|
||||||
req_uid=requesting_uid,
|
req_aid=requesting_aid,
|
||||||
parent_chan=None,
|
parent_chan=None,
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@ -1005,19 +1127,11 @@ class Actor:
|
||||||
self._cancel_complete.set()
|
self._cancel_complete.set()
|
||||||
return True
|
return True
|
||||||
|
|
||||||
# XXX: hard kill logic if needed?
|
|
||||||
# def _hard_mofo_kill(self):
|
|
||||||
# # If we're the root actor or zombied kill everything
|
|
||||||
# if self._parent_chan is None: # TODO: more robust check
|
|
||||||
# root = trio.lowlevel.current_root_task()
|
|
||||||
# for n in root.child_nurseries:
|
|
||||||
# n.cancel_scope.cancel()
|
|
||||||
|
|
||||||
async def _cancel_task(
|
async def _cancel_task(
|
||||||
self,
|
self,
|
||||||
cid: str,
|
cid: str,
|
||||||
parent_chan: Channel,
|
parent_chan: Channel,
|
||||||
requesting_uid: tuple[str, str]|None,
|
requesting_aid: msgtypes.Aid|None,
|
||||||
|
|
||||||
ipc_msg: dict|None|bool = False,
|
ipc_msg: dict|None|bool = False,
|
||||||
|
|
||||||
|
@ -1055,7 +1169,7 @@ class Actor:
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Cancel request for invalid RPC task.\n'
|
'Cancel request for invalid RPC task.\n'
|
||||||
'The task likely already completed or was never started!\n\n'
|
'The task likely already completed or was never started!\n\n'
|
||||||
f'<= canceller: {requesting_uid}\n'
|
f'<= canceller: {requesting_aid}\n'
|
||||||
f'=> {cid}@{parent_chan.uid}\n'
|
f'=> {cid}@{parent_chan.uid}\n'
|
||||||
f' |_{parent_chan}\n'
|
f' |_{parent_chan}\n'
|
||||||
)
|
)
|
||||||
|
@ -1063,9 +1177,12 @@ class Actor:
|
||||||
|
|
||||||
log.cancel(
|
log.cancel(
|
||||||
'Rxed cancel request for RPC task\n'
|
'Rxed cancel request for RPC task\n'
|
||||||
f'<=c) {requesting_uid}\n'
|
f'{ctx._task!r} <=c) {requesting_aid}\n'
|
||||||
f' |_{ctx._task}\n'
|
f'|_>> {ctx.repr_rpc}\n'
|
||||||
f' >> {ctx.repr_rpc}\n'
|
|
||||||
|
# f'|_{ctx._task}\n'
|
||||||
|
# f' >> {ctx.repr_rpc}\n'
|
||||||
|
|
||||||
# f'=> {ctx._task}\n'
|
# f'=> {ctx._task}\n'
|
||||||
# f' >> Actor._cancel_task() => {ctx._task}\n'
|
# f' >> Actor._cancel_task() => {ctx._task}\n'
|
||||||
# f' |_ {ctx._task}\n\n'
|
# f' |_ {ctx._task}\n\n'
|
||||||
|
@ -1086,9 +1203,9 @@ class Actor:
|
||||||
)
|
)
|
||||||
if (
|
if (
|
||||||
ctx._canceller is None
|
ctx._canceller is None
|
||||||
and requesting_uid
|
and requesting_aid
|
||||||
):
|
):
|
||||||
ctx._canceller: tuple = requesting_uid
|
ctx._canceller: tuple = requesting_aid.uid
|
||||||
|
|
||||||
# TODO: pack the RPC `{'cmd': <blah>}` msg into a ctxc and
|
# TODO: pack the RPC `{'cmd': <blah>}` msg into a ctxc and
|
||||||
# then raise and pack it here?
|
# then raise and pack it here?
|
||||||
|
@ -1114,7 +1231,7 @@ class Actor:
|
||||||
|
|
||||||
# wait for _invoke to mark the task complete
|
# wait for _invoke to mark the task complete
|
||||||
flow_info: str = (
|
flow_info: str = (
|
||||||
f'<= canceller: {requesting_uid}\n'
|
f'<= canceller: {requesting_aid}\n'
|
||||||
f'=> ipc-parent: {parent_chan}\n'
|
f'=> ipc-parent: {parent_chan}\n'
|
||||||
f'|_{ctx}\n'
|
f'|_{ctx}\n'
|
||||||
)
|
)
|
||||||
|
@ -1131,7 +1248,7 @@ class Actor:
|
||||||
|
|
||||||
async def cancel_rpc_tasks(
|
async def cancel_rpc_tasks(
|
||||||
self,
|
self,
|
||||||
req_uid: tuple[str, str],
|
req_aid: msgtypes.Aid,
|
||||||
|
|
||||||
# NOTE: when None is passed we cancel **all** rpc
|
# NOTE: when None is passed we cancel **all** rpc
|
||||||
# tasks running in this actor!
|
# tasks running in this actor!
|
||||||
|
@ -1148,7 +1265,7 @@ class Actor:
|
||||||
if not tasks:
|
if not tasks:
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Actor has no cancellable RPC tasks?\n'
|
'Actor has no cancellable RPC tasks?\n'
|
||||||
f'<= canceller: {req_uid}\n'
|
f'<= canceller: {req_aid.reprol()}\n'
|
||||||
)
|
)
|
||||||
return
|
return
|
||||||
|
|
||||||
|
@ -1188,7 +1305,7 @@ class Actor:
|
||||||
)
|
)
|
||||||
log.cancel(
|
log.cancel(
|
||||||
f'Cancelling {descr} RPC tasks\n\n'
|
f'Cancelling {descr} RPC tasks\n\n'
|
||||||
f'<=c) {req_uid} [canceller]\n'
|
f'<=c) {req_aid} [canceller]\n'
|
||||||
f'{rent_chan_repr}'
|
f'{rent_chan_repr}'
|
||||||
f'c)=> {self.uid} [cancellee]\n'
|
f'c)=> {self.uid} [cancellee]\n'
|
||||||
f' |_{self} [with {len(tasks)} tasks]\n'
|
f' |_{self} [with {len(tasks)} tasks]\n'
|
||||||
|
@ -1216,7 +1333,7 @@ class Actor:
|
||||||
await self._cancel_task(
|
await self._cancel_task(
|
||||||
cid,
|
cid,
|
||||||
task_caller_chan,
|
task_caller_chan,
|
||||||
requesting_uid=req_uid,
|
requesting_aid=req_aid,
|
||||||
)
|
)
|
||||||
|
|
||||||
if tasks:
|
if tasks:
|
||||||
|
@ -1244,25 +1361,13 @@ class Actor:
|
||||||
'''
|
'''
|
||||||
return self.accept_addrs[0]
|
return self.accept_addrs[0]
|
||||||
|
|
||||||
def get_parent(self) -> Portal:
|
# TODO, this should delegate ONLY to the
|
||||||
'''
|
# `._spawn_spec._runtime_vars: dict` / `._state` APIs?
|
||||||
Return a `Portal` to our parent.
|
#
|
||||||
|
# XXX, AH RIGHT that's why..
|
||||||
'''
|
# it's bc we pass this as a CLI flag to the child.py precisely
|
||||||
assert self._parent_chan, "No parent channel for this actor?"
|
# bc we need the bootstrapping pre `async_main()`.. but maybe
|
||||||
return Portal(self._parent_chan)
|
# keep this as an impl deat and not part of the pub iface impl?
|
||||||
|
|
||||||
def get_chans(
|
|
||||||
self,
|
|
||||||
uid: tuple[str, str],
|
|
||||||
|
|
||||||
) -> list[Channel]:
|
|
||||||
'''
|
|
||||||
Return all IPC channels to the actor with provided `uid`.
|
|
||||||
|
|
||||||
'''
|
|
||||||
return self._peers[uid]
|
|
||||||
|
|
||||||
def is_infected_aio(self) -> bool:
|
def is_infected_aio(self) -> bool:
|
||||||
'''
|
'''
|
||||||
If `True`, this actor is running `trio` in guest mode on
|
If `True`, this actor is running `trio` in guest mode on
|
||||||
|
@ -1273,6 +1378,23 @@ class Actor:
|
||||||
'''
|
'''
|
||||||
return self._infected_aio
|
return self._infected_aio
|
||||||
|
|
||||||
|
# ?TODO, is this the right type for this method?
|
||||||
|
def get_parent(self) -> Portal:
|
||||||
|
'''
|
||||||
|
Return a `Portal` to our parent.
|
||||||
|
|
||||||
|
'''
|
||||||
|
assert self._parent_chan, "No parent channel for this actor?"
|
||||||
|
return Portal(self._parent_chan)
|
||||||
|
|
||||||
|
# XXX: hard kill logic if needed?
|
||||||
|
# def _hard_mofo_kill(self):
|
||||||
|
# # If we're the root actor or zombied kill everything
|
||||||
|
# if self._parent_chan is None: # TODO: more robust check
|
||||||
|
# root = trio.lowlevel.current_root_task()
|
||||||
|
# for n in root.child_nurseries:
|
||||||
|
# n.cancel_scope.cancel()
|
||||||
|
|
||||||
|
|
||||||
async def async_main(
|
async def async_main(
|
||||||
actor: Actor,
|
actor: Actor,
|
||||||
|
@ -1316,6 +1438,8 @@ async def async_main(
|
||||||
# establish primary connection with immediate parent
|
# establish primary connection with immediate parent
|
||||||
actor._parent_chan: Channel|None = None
|
actor._parent_chan: Channel|None = None
|
||||||
|
|
||||||
|
# is this a sub-actor?
|
||||||
|
# get runtime info from parent.
|
||||||
if parent_addr is not None:
|
if parent_addr is not None:
|
||||||
(
|
(
|
||||||
actor._parent_chan,
|
actor._parent_chan,
|
||||||
|
@ -1350,18 +1474,18 @@ async def async_main(
|
||||||
# parent is kept alive as a resilient service until
|
# parent is kept alive as a resilient service until
|
||||||
# cancellation steps have (mostly) occurred in
|
# cancellation steps have (mostly) occurred in
|
||||||
# a deterministic way.
|
# a deterministic way.
|
||||||
async with trio.open_nursery(
|
root_tn: trio.Nursery
|
||||||
strict_exception_groups=False,
|
async with (
|
||||||
) as root_nursery:
|
collapse_eg(),
|
||||||
actor._root_n = root_nursery
|
trio.open_nursery() as root_tn,
|
||||||
|
):
|
||||||
|
actor._root_n = root_tn
|
||||||
assert actor._root_n
|
assert actor._root_n
|
||||||
|
|
||||||
ipc_server: _server.IPCServer
|
ipc_server: _server.IPCServer
|
||||||
async with (
|
async with (
|
||||||
trio.open_nursery(
|
collapse_eg(),
|
||||||
strict_exception_groups=False,
|
trio.open_nursery() as service_nursery,
|
||||||
) as service_nursery,
|
|
||||||
|
|
||||||
_server.open_ipc_server(
|
_server.open_ipc_server(
|
||||||
parent_tn=service_nursery,
|
parent_tn=service_nursery,
|
||||||
stream_handler_tn=service_nursery,
|
stream_handler_tn=service_nursery,
|
||||||
|
@ -1412,9 +1536,6 @@ async def async_main(
|
||||||
|
|
||||||
# TODO: why is this not with the root nursery?
|
# TODO: why is this not with the root nursery?
|
||||||
try:
|
try:
|
||||||
log.runtime(
|
|
||||||
'Booting IPC server'
|
|
||||||
)
|
|
||||||
eps: list = await ipc_server.listen_on(
|
eps: list = await ipc_server.listen_on(
|
||||||
accept_addrs=accept_addrs,
|
accept_addrs=accept_addrs,
|
||||||
stream_handler_nursery=service_nursery,
|
stream_handler_nursery=service_nursery,
|
||||||
|
@ -1446,18 +1567,6 @@ async def async_main(
|
||||||
# TODO, just read direct from ipc_server?
|
# TODO, just read direct from ipc_server?
|
||||||
accept_addrs: list[UnwrappedAddress] = actor.accept_addrs
|
accept_addrs: list[UnwrappedAddress] = actor.accept_addrs
|
||||||
|
|
||||||
# NOTE: only set the loopback addr for the
|
|
||||||
# process-tree-global "root" mailbox since
|
|
||||||
# all sub-actors should be able to speak to
|
|
||||||
# their root actor over that channel.
|
|
||||||
if _state._runtime_vars['_is_root']:
|
|
||||||
raddrs: list[Address] = _state._runtime_vars['_root_addrs']
|
|
||||||
for addr in accept_addrs:
|
|
||||||
waddr: Address = wrap_address(addr)
|
|
||||||
raddrs.append(addr)
|
|
||||||
else:
|
|
||||||
_state._runtime_vars['_root_mailbox'] = raddrs[0]
|
|
||||||
|
|
||||||
# Register with the arbiter if we're told its addr
|
# Register with the arbiter if we're told its addr
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Registering `{actor.name}` => {pformat(accept_addrs)}\n'
|
f'Registering `{actor.name}` => {pformat(accept_addrs)}\n'
|
||||||
|
@ -1475,6 +1584,7 @@ async def async_main(
|
||||||
except AssertionError:
|
except AssertionError:
|
||||||
await debug.pause()
|
await debug.pause()
|
||||||
|
|
||||||
|
# !TODO, get rid of the local-portal crap XD
|
||||||
async with get_registry(addr) as reg_portal:
|
async with get_registry(addr) as reg_portal:
|
||||||
for accept_addr in accept_addrs:
|
for accept_addr in accept_addrs:
|
||||||
accept_addr = wrap_address(accept_addr)
|
accept_addr = wrap_address(accept_addr)
|
||||||
|
@ -1499,7 +1609,7 @@ async def async_main(
|
||||||
# start processing parent requests until our channel
|
# start processing parent requests until our channel
|
||||||
# server is 100% up and running.
|
# server is 100% up and running.
|
||||||
if actor._parent_chan:
|
if actor._parent_chan:
|
||||||
await root_nursery.start(
|
await root_tn.start(
|
||||||
partial(
|
partial(
|
||||||
_rpc.process_messages,
|
_rpc.process_messages,
|
||||||
chan=actor._parent_chan,
|
chan=actor._parent_chan,
|
||||||
|
@ -1511,8 +1621,9 @@ async def async_main(
|
||||||
# 'Blocking on service nursery to exit..\n'
|
# 'Blocking on service nursery to exit..\n'
|
||||||
)
|
)
|
||||||
log.runtime(
|
log.runtime(
|
||||||
"Service nursery complete\n"
|
'Service nursery complete\n'
|
||||||
"Waiting on root nursery to complete"
|
'\n'
|
||||||
|
'->} waiting on root nursery to complete..\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# Blocks here as expected until the root nursery is
|
# Blocks here as expected until the root nursery is
|
||||||
|
@ -1567,6 +1678,7 @@ async def async_main(
|
||||||
finally:
|
finally:
|
||||||
teardown_report: str = (
|
teardown_report: str = (
|
||||||
'Main actor-runtime task completed\n'
|
'Main actor-runtime task completed\n'
|
||||||
|
'\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# ?TODO? should this be in `._entry`/`._root` mods instead?
|
# ?TODO? should this be in `._entry`/`._root` mods instead?
|
||||||
|
@ -1608,7 +1720,8 @@ async def async_main(
|
||||||
# Unregister actor from the registry-sys / registrar.
|
# Unregister actor from the registry-sys / registrar.
|
||||||
if (
|
if (
|
||||||
is_registered
|
is_registered
|
||||||
and not actor.is_registrar
|
and
|
||||||
|
not actor.is_registrar
|
||||||
):
|
):
|
||||||
failed: bool = False
|
failed: bool = False
|
||||||
for addr in actor.reg_addrs:
|
for addr in actor.reg_addrs:
|
||||||
|
@ -1643,23 +1756,30 @@ async def async_main(
|
||||||
ipc_server.has_peers(check_chans=True)
|
ipc_server.has_peers(check_chans=True)
|
||||||
):
|
):
|
||||||
teardown_report += (
|
teardown_report += (
|
||||||
f'-> Waiting for remaining peers {ipc_server._peers} to clear..\n'
|
f'-> Waiting for remaining peers to clear..\n'
|
||||||
|
f' {pformat(ipc_server._peers)}'
|
||||||
)
|
)
|
||||||
log.runtime(teardown_report)
|
log.runtime(teardown_report)
|
||||||
await ipc_server.wait_for_no_more_peers(
|
await ipc_server.wait_for_no_more_peers()
|
||||||
shield=True,
|
|
||||||
)
|
|
||||||
|
|
||||||
teardown_report += (
|
teardown_report += (
|
||||||
'-> All peer channels are complete\n'
|
'-]> all peer channels are complete.\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
# op_nested_actor_repr: str = _pformat.nest_from_op(
|
||||||
|
# input_op=')>',
|
||||||
|
# text=actor.pformat(),
|
||||||
|
# nest_prefix='|_',
|
||||||
|
# nest_indent=1, # under >
|
||||||
|
# )
|
||||||
teardown_report += (
|
teardown_report += (
|
||||||
'Actor runtime exiting\n'
|
'-)> actor runtime main task exit.\n'
|
||||||
f'>)\n'
|
# f'{op_nested_actor_repr}'
|
||||||
f'|_{actor}\n'
|
|
||||||
)
|
)
|
||||||
log.info(teardown_report)
|
# if _state._runtime_vars['_is_root']:
|
||||||
|
# log.info(teardown_report)
|
||||||
|
# else:
|
||||||
|
log.runtime(teardown_report)
|
||||||
|
|
||||||
|
|
||||||
# TODO: rename to `Registry` and move to `.discovery._registry`!
|
# TODO: rename to `Registry` and move to `.discovery._registry`!
|
||||||
|
|
|
@ -34,9 +34,9 @@ from typing import (
|
||||||
import trio
|
import trio
|
||||||
from trio import TaskStatus
|
from trio import TaskStatus
|
||||||
|
|
||||||
from .devx.debug import (
|
from .devx import (
|
||||||
maybe_wait_for_debugger,
|
debug,
|
||||||
acquire_debug_lock,
|
pformat as _pformat
|
||||||
)
|
)
|
||||||
from tractor._state import (
|
from tractor._state import (
|
||||||
current_actor,
|
current_actor,
|
||||||
|
@ -51,14 +51,17 @@ from tractor._portal import Portal
|
||||||
from tractor._runtime import Actor
|
from tractor._runtime import Actor
|
||||||
from tractor._entry import _mp_main
|
from tractor._entry import _mp_main
|
||||||
from tractor._exceptions import ActorFailure
|
from tractor._exceptions import ActorFailure
|
||||||
from tractor.msg.types import (
|
from tractor.msg import (
|
||||||
Aid,
|
types as msgtypes,
|
||||||
SpawnSpec,
|
pretty_struct,
|
||||||
)
|
)
|
||||||
|
|
||||||
|
|
||||||
if TYPE_CHECKING:
|
if TYPE_CHECKING:
|
||||||
from ipc import IPCServer
|
from ipc import (
|
||||||
|
_server,
|
||||||
|
Channel,
|
||||||
|
)
|
||||||
from ._supervise import ActorNursery
|
from ._supervise import ActorNursery
|
||||||
ProcessType = TypeVar('ProcessType', mp.Process, trio.Process)
|
ProcessType = TypeVar('ProcessType', mp.Process, trio.Process)
|
||||||
|
|
||||||
|
@ -328,12 +331,13 @@ async def soft_kill(
|
||||||
see `.hard_kill()`).
|
see `.hard_kill()`).
|
||||||
|
|
||||||
'''
|
'''
|
||||||
peer_aid: Aid = portal.channel.aid
|
chan: Channel = portal.channel
|
||||||
|
peer_aid: msgtypes.Aid = chan.aid
|
||||||
try:
|
try:
|
||||||
log.cancel(
|
log.cancel(
|
||||||
f'Soft killing sub-actor via portal request\n'
|
f'Soft killing sub-actor via portal request\n'
|
||||||
f'\n'
|
f'\n'
|
||||||
f'(c=> {peer_aid}\n'
|
f'c)=> {peer_aid.reprol()}@[{chan.maddr}]\n'
|
||||||
f' |_{proc}\n'
|
f' |_{proc}\n'
|
||||||
)
|
)
|
||||||
# wait on sub-proc to signal termination
|
# wait on sub-proc to signal termination
|
||||||
|
@ -341,7 +345,7 @@ async def soft_kill(
|
||||||
|
|
||||||
except trio.Cancelled:
|
except trio.Cancelled:
|
||||||
with trio.CancelScope(shield=True):
|
with trio.CancelScope(shield=True):
|
||||||
await maybe_wait_for_debugger(
|
await debug.maybe_wait_for_debugger(
|
||||||
child_in_debug=_runtime_vars.get(
|
child_in_debug=_runtime_vars.get(
|
||||||
'_debug_mode', False
|
'_debug_mode', False
|
||||||
),
|
),
|
||||||
|
@ -465,7 +469,7 @@ async def trio_proc(
|
||||||
"--uid",
|
"--uid",
|
||||||
# TODO, how to pass this over "wire" encodings like
|
# TODO, how to pass this over "wire" encodings like
|
||||||
# cmdline args?
|
# cmdline args?
|
||||||
# -[ ] maybe we can add an `Aid.min_tuple()` ?
|
# -[ ] maybe we can add an `msgtypes.Aid.min_tuple()` ?
|
||||||
str(subactor.uid),
|
str(subactor.uid),
|
||||||
# Address the child must connect to on startup
|
# Address the child must connect to on startup
|
||||||
"--parent_addr",
|
"--parent_addr",
|
||||||
|
@ -483,13 +487,14 @@ async def trio_proc(
|
||||||
|
|
||||||
cancelled_during_spawn: bool = False
|
cancelled_during_spawn: bool = False
|
||||||
proc: trio.Process|None = None
|
proc: trio.Process|None = None
|
||||||
ipc_server: IPCServer = actor_nursery._actor.ipc_server
|
ipc_server: _server.Server = actor_nursery._actor.ipc_server
|
||||||
try:
|
try:
|
||||||
try:
|
try:
|
||||||
proc: trio.Process = await trio.lowlevel.open_process(spawn_cmd, **proc_kwargs)
|
proc: trio.Process = await trio.lowlevel.open_process(spawn_cmd, **proc_kwargs)
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Started new child\n'
|
f'Started new child subproc\n'
|
||||||
f'|_{proc}\n'
|
f'(>\n'
|
||||||
|
f' |_{proc}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# wait for actor to spawn and connect back to us
|
# wait for actor to spawn and connect back to us
|
||||||
|
@ -507,10 +512,10 @@ async def trio_proc(
|
||||||
with trio.CancelScope(shield=True):
|
with trio.CancelScope(shield=True):
|
||||||
# don't clobber an ongoing pdb
|
# don't clobber an ongoing pdb
|
||||||
if is_root_process():
|
if is_root_process():
|
||||||
await maybe_wait_for_debugger()
|
await debug.maybe_wait_for_debugger()
|
||||||
|
|
||||||
elif proc is not None:
|
elif proc is not None:
|
||||||
async with acquire_debug_lock(subactor.uid):
|
async with debug.acquire_debug_lock(subactor.uid):
|
||||||
# soft wait on the proc to terminate
|
# soft wait on the proc to terminate
|
||||||
with trio.move_on_after(0.5):
|
with trio.move_on_after(0.5):
|
||||||
await proc.wait()
|
await proc.wait()
|
||||||
|
@ -528,14 +533,19 @@ async def trio_proc(
|
||||||
|
|
||||||
# send a "spawning specification" which configures the
|
# send a "spawning specification" which configures the
|
||||||
# initial runtime state of the child.
|
# initial runtime state of the child.
|
||||||
sspec = SpawnSpec(
|
sspec = msgtypes.SpawnSpec(
|
||||||
_parent_main_data=subactor._parent_main_data,
|
_parent_main_data=subactor._parent_main_data,
|
||||||
enable_modules=subactor.enable_modules,
|
enable_modules=subactor.enable_modules,
|
||||||
reg_addrs=subactor.reg_addrs,
|
reg_addrs=subactor.reg_addrs,
|
||||||
bind_addrs=bind_addrs,
|
bind_addrs=bind_addrs,
|
||||||
_runtime_vars=_runtime_vars,
|
_runtime_vars=_runtime_vars,
|
||||||
)
|
)
|
||||||
log.runtime(f'Sending spawn spec: {str(sspec)}')
|
log.runtime(
|
||||||
|
f'Sending spawn spec to child\n'
|
||||||
|
f'{{}}=> {chan.aid.reprol()!r}\n'
|
||||||
|
f'\n'
|
||||||
|
f'{pretty_struct.pformat(sspec)}\n'
|
||||||
|
)
|
||||||
await chan.send(sspec)
|
await chan.send(sspec)
|
||||||
|
|
||||||
# track subactor in current nursery
|
# track subactor in current nursery
|
||||||
|
@ -563,7 +573,7 @@ async def trio_proc(
|
||||||
# condition.
|
# condition.
|
||||||
await soft_kill(
|
await soft_kill(
|
||||||
proc,
|
proc,
|
||||||
trio.Process.wait,
|
trio.Process.wait, # XXX, uses `pidfd_open()` below.
|
||||||
portal
|
portal
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@ -571,8 +581,7 @@ async def trio_proc(
|
||||||
# tandem if not done already
|
# tandem if not done already
|
||||||
log.cancel(
|
log.cancel(
|
||||||
'Cancelling portal result reaper task\n'
|
'Cancelling portal result reaper task\n'
|
||||||
f'>c)\n'
|
f'c)> {subactor.aid.reprol()!r}\n'
|
||||||
f' |_{subactor.uid}\n'
|
|
||||||
)
|
)
|
||||||
nursery.cancel_scope.cancel()
|
nursery.cancel_scope.cancel()
|
||||||
|
|
||||||
|
@ -581,21 +590,24 @@ async def trio_proc(
|
||||||
# allowed! Do this **after** cancellation/teardown to avoid
|
# allowed! Do this **after** cancellation/teardown to avoid
|
||||||
# killing the process too early.
|
# killing the process too early.
|
||||||
if proc:
|
if proc:
|
||||||
|
reap_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op='>x)',
|
||||||
|
text=subactor.pformat(),
|
||||||
|
)
|
||||||
log.cancel(
|
log.cancel(
|
||||||
f'Hard reap sequence starting for subactor\n'
|
f'Hard reap sequence starting for subactor\n'
|
||||||
f'>x)\n'
|
f'{reap_repr}'
|
||||||
f' |_{subactor}@{subactor.uid}\n'
|
|
||||||
)
|
)
|
||||||
|
|
||||||
with trio.CancelScope(shield=True):
|
with trio.CancelScope(shield=True):
|
||||||
# don't clobber an ongoing pdb
|
# don't clobber an ongoing pdb
|
||||||
if cancelled_during_spawn:
|
if cancelled_during_spawn:
|
||||||
# Try again to avoid TTY clobbering.
|
# Try again to avoid TTY clobbering.
|
||||||
async with acquire_debug_lock(subactor.uid):
|
async with debug.acquire_debug_lock(subactor.uid):
|
||||||
with trio.move_on_after(0.5):
|
with trio.move_on_after(0.5):
|
||||||
await proc.wait()
|
await proc.wait()
|
||||||
|
|
||||||
await maybe_wait_for_debugger(
|
await debug.maybe_wait_for_debugger(
|
||||||
child_in_debug=_runtime_vars.get(
|
child_in_debug=_runtime_vars.get(
|
||||||
'_debug_mode', False
|
'_debug_mode', False
|
||||||
),
|
),
|
||||||
|
@ -624,7 +636,7 @@ async def trio_proc(
|
||||||
# acquire the lock and get notified of who has it,
|
# acquire the lock and get notified of who has it,
|
||||||
# check that uid against our known children?
|
# check that uid against our known children?
|
||||||
# this_uid: tuple[str, str] = current_actor().uid
|
# this_uid: tuple[str, str] = current_actor().uid
|
||||||
# await acquire_debug_lock(this_uid)
|
# await debug.acquire_debug_lock(this_uid)
|
||||||
|
|
||||||
if proc.poll() is None:
|
if proc.poll() is None:
|
||||||
log.cancel(f"Attempting to hard kill {proc}")
|
log.cancel(f"Attempting to hard kill {proc}")
|
||||||
|
@ -727,7 +739,7 @@ async def mp_proc(
|
||||||
|
|
||||||
log.runtime(f"Started {proc}")
|
log.runtime(f"Started {proc}")
|
||||||
|
|
||||||
ipc_server: IPCServer = actor_nursery._actor.ipc_server
|
ipc_server: _server.Server = actor_nursery._actor.ipc_server
|
||||||
try:
|
try:
|
||||||
# wait for actor to spawn and connect back to us
|
# wait for actor to spawn and connect back to us
|
||||||
# channel should have handshake completed by the
|
# channel should have handshake completed by the
|
||||||
|
|
|
@ -21,7 +21,6 @@
|
||||||
from contextlib import asynccontextmanager as acm
|
from contextlib import asynccontextmanager as acm
|
||||||
from functools import partial
|
from functools import partial
|
||||||
import inspect
|
import inspect
|
||||||
from pprint import pformat
|
|
||||||
from typing import (
|
from typing import (
|
||||||
TYPE_CHECKING,
|
TYPE_CHECKING,
|
||||||
)
|
)
|
||||||
|
@ -31,7 +30,10 @@ import warnings
|
||||||
import trio
|
import trio
|
||||||
|
|
||||||
|
|
||||||
from .devx.debug import maybe_wait_for_debugger
|
from .devx import (
|
||||||
|
debug,
|
||||||
|
pformat as _pformat,
|
||||||
|
)
|
||||||
from ._addr import (
|
from ._addr import (
|
||||||
UnwrappedAddress,
|
UnwrappedAddress,
|
||||||
mk_uuid,
|
mk_uuid,
|
||||||
|
@ -42,6 +44,7 @@ from ._runtime import Actor
|
||||||
from ._portal import Portal
|
from ._portal import Portal
|
||||||
from .trionics import (
|
from .trionics import (
|
||||||
is_multi_cancelled,
|
is_multi_cancelled,
|
||||||
|
collapse_eg,
|
||||||
)
|
)
|
||||||
from ._exceptions import (
|
from ._exceptions import (
|
||||||
ContextCancelled,
|
ContextCancelled,
|
||||||
|
@ -114,7 +117,6 @@ class ActorNursery:
|
||||||
]
|
]
|
||||||
] = {}
|
] = {}
|
||||||
|
|
||||||
self.cancelled: bool = False
|
|
||||||
self._join_procs = trio.Event()
|
self._join_procs = trio.Event()
|
||||||
self._at_least_one_child_in_debug: bool = False
|
self._at_least_one_child_in_debug: bool = False
|
||||||
self.errors = errors
|
self.errors = errors
|
||||||
|
@ -132,10 +134,53 @@ class ActorNursery:
|
||||||
# TODO: remove the `.run_in_actor()` API and thus this 2ndary
|
# TODO: remove the `.run_in_actor()` API and thus this 2ndary
|
||||||
# nursery when that API get's moved outside this primitive!
|
# nursery when that API get's moved outside this primitive!
|
||||||
self._ria_nursery = ria_nursery
|
self._ria_nursery = ria_nursery
|
||||||
|
|
||||||
|
# TODO, factor this into a .hilevel api!
|
||||||
|
#
|
||||||
# portals spawned with ``run_in_actor()`` are
|
# portals spawned with ``run_in_actor()`` are
|
||||||
# cancelled when their "main" result arrives
|
# cancelled when their "main" result arrives
|
||||||
self._cancel_after_result_on_exit: set = set()
|
self._cancel_after_result_on_exit: set = set()
|
||||||
|
|
||||||
|
# trio.Nursery-like cancel (request) statuses
|
||||||
|
self._cancelled_caught: bool = False
|
||||||
|
self._cancel_called: bool = False
|
||||||
|
|
||||||
|
@property
|
||||||
|
def cancel_called(self) -> bool:
|
||||||
|
'''
|
||||||
|
Records whether cancellation has been requested for this
|
||||||
|
actor-nursery by a call to `.cancel()` either due to,
|
||||||
|
- an explicit call by some actor-local-task,
|
||||||
|
- an implicit call due to an error/cancel emited inside
|
||||||
|
the `tractor.open_nursery()` block.
|
||||||
|
|
||||||
|
'''
|
||||||
|
return self._cancel_called
|
||||||
|
|
||||||
|
@property
|
||||||
|
def cancelled_caught(self) -> bool:
|
||||||
|
'''
|
||||||
|
Set when this nursery was able to cance all spawned subactors
|
||||||
|
gracefully via an (implicit) call to `.cancel()`.
|
||||||
|
|
||||||
|
'''
|
||||||
|
return self._cancelled_caught
|
||||||
|
|
||||||
|
# TODO! remove internal/test-suite usage!
|
||||||
|
@property
|
||||||
|
def cancelled(self) -> bool:
|
||||||
|
warnings.warn(
|
||||||
|
"`ActorNursery.cancelled` is now deprecated, use "
|
||||||
|
" `.cancel_called` instead.",
|
||||||
|
DeprecationWarning,
|
||||||
|
stacklevel=2,
|
||||||
|
)
|
||||||
|
return (
|
||||||
|
self._cancel_called
|
||||||
|
# and
|
||||||
|
# self._cancelled_caught
|
||||||
|
)
|
||||||
|
|
||||||
async def start_actor(
|
async def start_actor(
|
||||||
self,
|
self,
|
||||||
name: str,
|
name: str,
|
||||||
|
@ -199,7 +244,7 @@ class ActorNursery:
|
||||||
loglevel=loglevel,
|
loglevel=loglevel,
|
||||||
|
|
||||||
# verbatim relay this actor's registrar addresses
|
# verbatim relay this actor's registrar addresses
|
||||||
registry_addrs=current_actor().reg_addrs,
|
registry_addrs=current_actor().registry_addrs,
|
||||||
)
|
)
|
||||||
parent_addr: UnwrappedAddress = self._actor.accept_addr
|
parent_addr: UnwrappedAddress = self._actor.accept_addr
|
||||||
assert parent_addr
|
assert parent_addr
|
||||||
|
@ -313,7 +358,7 @@ class ActorNursery:
|
||||||
|
|
||||||
'''
|
'''
|
||||||
__runtimeframe__: int = 1 # noqa
|
__runtimeframe__: int = 1 # noqa
|
||||||
self.cancelled = True
|
self._cancel_called = True
|
||||||
|
|
||||||
# TODO: impl a repr for spawn more compact
|
# TODO: impl a repr for spawn more compact
|
||||||
# then `._children`..
|
# then `._children`..
|
||||||
|
@ -324,9 +369,10 @@ class ActorNursery:
|
||||||
server: IPCServer = self._actor.ipc_server
|
server: IPCServer = self._actor.ipc_server
|
||||||
|
|
||||||
with trio.move_on_after(3) as cs:
|
with trio.move_on_after(3) as cs:
|
||||||
async with trio.open_nursery(
|
async with (
|
||||||
strict_exception_groups=False,
|
collapse_eg(),
|
||||||
) as tn:
|
trio.open_nursery() as tn,
|
||||||
|
):
|
||||||
|
|
||||||
subactor: Actor
|
subactor: Actor
|
||||||
proc: trio.Process
|
proc: trio.Process
|
||||||
|
@ -390,6 +436,8 @@ class ActorNursery:
|
||||||
) in children.values():
|
) in children.values():
|
||||||
log.warning(f"Hard killing process {proc}")
|
log.warning(f"Hard killing process {proc}")
|
||||||
proc.terminate()
|
proc.terminate()
|
||||||
|
else:
|
||||||
|
self._cancelled_caught
|
||||||
|
|
||||||
# mark ourselves as having (tried to have) cancelled all subactors
|
# mark ourselves as having (tried to have) cancelled all subactors
|
||||||
self._join_procs.set()
|
self._join_procs.set()
|
||||||
|
@ -419,10 +467,10 @@ async def _open_and_supervise_one_cancels_all_nursery(
|
||||||
# `ActorNursery.start_actor()`).
|
# `ActorNursery.start_actor()`).
|
||||||
|
|
||||||
# errors from this daemon actor nursery bubble up to caller
|
# errors from this daemon actor nursery bubble up to caller
|
||||||
async with trio.open_nursery(
|
async with (
|
||||||
strict_exception_groups=False,
|
collapse_eg(),
|
||||||
# ^XXX^ TODO? instead unpack any RAE as per "loose" style?
|
trio.open_nursery() as da_nursery,
|
||||||
) as da_nursery:
|
):
|
||||||
try:
|
try:
|
||||||
# This is the inner level "run in actor" nursery. It is
|
# This is the inner level "run in actor" nursery. It is
|
||||||
# awaited first since actors spawned in this way (using
|
# awaited first since actors spawned in this way (using
|
||||||
|
@ -432,11 +480,10 @@ async def _open_and_supervise_one_cancels_all_nursery(
|
||||||
# immediately raised for handling by a supervisor strategy.
|
# immediately raised for handling by a supervisor strategy.
|
||||||
# As such if the strategy propagates any error(s) upwards
|
# As such if the strategy propagates any error(s) upwards
|
||||||
# the above "daemon actor" nursery will be notified.
|
# the above "daemon actor" nursery will be notified.
|
||||||
async with trio.open_nursery(
|
async with (
|
||||||
strict_exception_groups=False,
|
collapse_eg(),
|
||||||
# ^XXX^ TODO? instead unpack any RAE as per "loose" style?
|
trio.open_nursery() as ria_nursery,
|
||||||
) as ria_nursery:
|
):
|
||||||
|
|
||||||
an = ActorNursery(
|
an = ActorNursery(
|
||||||
actor,
|
actor,
|
||||||
ria_nursery,
|
ria_nursery,
|
||||||
|
@ -453,7 +500,7 @@ async def _open_and_supervise_one_cancels_all_nursery(
|
||||||
# the "hard join phase".
|
# the "hard join phase".
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Waiting on subactors to complete:\n'
|
'Waiting on subactors to complete:\n'
|
||||||
f'{pformat(an._children)}\n'
|
f'>}} {len(an._children)}\n'
|
||||||
)
|
)
|
||||||
an._join_procs.set()
|
an._join_procs.set()
|
||||||
|
|
||||||
|
@ -467,7 +514,7 @@ async def _open_and_supervise_one_cancels_all_nursery(
|
||||||
# will make the pdb repl unusable.
|
# will make the pdb repl unusable.
|
||||||
# Instead try to wait for pdb to be released before
|
# Instead try to wait for pdb to be released before
|
||||||
# tearing down.
|
# tearing down.
|
||||||
await maybe_wait_for_debugger(
|
await debug.maybe_wait_for_debugger(
|
||||||
child_in_debug=an._at_least_one_child_in_debug
|
child_in_debug=an._at_least_one_child_in_debug
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@ -543,7 +590,7 @@ async def _open_and_supervise_one_cancels_all_nursery(
|
||||||
|
|
||||||
# XXX: yet another guard before allowing the cancel
|
# XXX: yet another guard before allowing the cancel
|
||||||
# sequence in case a (single) child is in debug.
|
# sequence in case a (single) child is in debug.
|
||||||
await maybe_wait_for_debugger(
|
await debug.maybe_wait_for_debugger(
|
||||||
child_in_debug=an._at_least_one_child_in_debug
|
child_in_debug=an._at_least_one_child_in_debug
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@ -592,9 +639,14 @@ async def _open_and_supervise_one_cancels_all_nursery(
|
||||||
# final exit
|
# final exit
|
||||||
|
|
||||||
|
|
||||||
@acm
|
_shutdown_msg: str = (
|
||||||
|
'Actor-runtime-shutdown'
|
||||||
|
)
|
||||||
|
|
||||||
# @api_frame
|
# @api_frame
|
||||||
|
@acm
|
||||||
async def open_nursery(
|
async def open_nursery(
|
||||||
|
*, # named params only!
|
||||||
hide_tb: bool = True,
|
hide_tb: bool = True,
|
||||||
**kwargs,
|
**kwargs,
|
||||||
# ^TODO, paramspec for `open_root_actor()`
|
# ^TODO, paramspec for `open_root_actor()`
|
||||||
|
@ -679,17 +731,26 @@ async def open_nursery(
|
||||||
):
|
):
|
||||||
__tracebackhide__: bool = False
|
__tracebackhide__: bool = False
|
||||||
|
|
||||||
msg: str = (
|
|
||||||
'Actor-nursery exited\n'
|
op_nested_an_repr: str = _pformat.nest_from_op(
|
||||||
f'|_{an}\n'
|
input_op=')>',
|
||||||
|
text=f'{an}',
|
||||||
|
# nest_prefix='|_',
|
||||||
|
nest_indent=1, # under >
|
||||||
)
|
)
|
||||||
|
an_msg: str = (
|
||||||
|
f'Actor-nursery exited\n'
|
||||||
|
f'{op_nested_an_repr}\n'
|
||||||
|
)
|
||||||
|
# keep noise low during std operation.
|
||||||
|
log.runtime(an_msg)
|
||||||
|
|
||||||
if implicit_runtime:
|
if implicit_runtime:
|
||||||
# shutdown runtime if it was started and report noisly
|
# shutdown runtime if it was started and report noisly
|
||||||
# that we're did so.
|
# that we're did so.
|
||||||
msg += '=> Shutting down actor runtime <=\n'
|
msg: str = (
|
||||||
|
'\n'
|
||||||
|
'\n'
|
||||||
|
f'{_shutdown_msg} )>\n'
|
||||||
|
)
|
||||||
log.info(msg)
|
log.info(msg)
|
||||||
|
|
||||||
else:
|
|
||||||
# keep noise low during std operation.
|
|
||||||
log.runtime(msg)
|
|
||||||
|
|
|
@ -101,11 +101,27 @@ class Channel:
|
||||||
# ^XXX! ONLY set if a remote actor sends an `Error`-msg
|
# ^XXX! ONLY set if a remote actor sends an `Error`-msg
|
||||||
self._closed: bool = False
|
self._closed: bool = False
|
||||||
|
|
||||||
# flag set by ``Portal.cancel_actor()`` indicating remote
|
# flag set by `Portal.cancel_actor()` indicating remote
|
||||||
# (possibly peer) cancellation of the far end actor
|
# (possibly peer) cancellation of the far end actor runtime.
|
||||||
# runtime.
|
|
||||||
self._cancel_called: bool = False
|
self._cancel_called: bool = False
|
||||||
|
|
||||||
|
@property
|
||||||
|
def closed(self) -> bool:
|
||||||
|
'''
|
||||||
|
Was `.aclose()` successfully called?
|
||||||
|
|
||||||
|
'''
|
||||||
|
return self._closed
|
||||||
|
|
||||||
|
@property
|
||||||
|
def cancel_called(self) -> bool:
|
||||||
|
'''
|
||||||
|
Set when `Portal.cancel_actor()` is called on a portal which
|
||||||
|
wraps this IPC channel.
|
||||||
|
|
||||||
|
'''
|
||||||
|
return self._cancel_called
|
||||||
|
|
||||||
@property
|
@property
|
||||||
def uid(self) -> tuple[str, str]:
|
def uid(self) -> tuple[str, str]:
|
||||||
'''
|
'''
|
||||||
|
@ -169,12 +185,26 @@ class Channel:
|
||||||
addr,
|
addr,
|
||||||
**kwargs,
|
**kwargs,
|
||||||
)
|
)
|
||||||
assert transport.raddr == addr
|
# XXX, for UDS *no!* since we recv the peer-pid and build out
|
||||||
|
# a new addr..
|
||||||
|
# assert transport.raddr == addr
|
||||||
chan = Channel(transport=transport)
|
chan = Channel(transport=transport)
|
||||||
|
|
||||||
|
# ?TODO, compact this into adapter level-methods?
|
||||||
|
# -[ ] would avoid extra repr-calcs if level not active?
|
||||||
|
# |_ how would the `calc_if_level` look though? func?
|
||||||
|
if log.at_least_level('runtime'):
|
||||||
|
from tractor.devx import (
|
||||||
|
pformat as _pformat,
|
||||||
|
)
|
||||||
|
chan_repr: str = _pformat.nest_from_op(
|
||||||
|
input_op='[>',
|
||||||
|
text=chan.pformat(),
|
||||||
|
nest_indent=1,
|
||||||
|
)
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Connected channel IPC transport\n'
|
f'Connected channel IPC transport\n'
|
||||||
f'[>\n'
|
f'{chan_repr}'
|
||||||
f' |_{chan}\n'
|
|
||||||
)
|
)
|
||||||
return chan
|
return chan
|
||||||
|
|
||||||
|
@ -196,9 +226,12 @@ class Channel:
|
||||||
self._transport.codec = orig
|
self._transport.codec = orig
|
||||||
|
|
||||||
# TODO: do a .src/.dst: str for maddrs?
|
# TODO: do a .src/.dst: str for maddrs?
|
||||||
def pformat(self) -> str:
|
def pformat(
|
||||||
|
self,
|
||||||
|
privates: bool = False,
|
||||||
|
) -> str:
|
||||||
if not self._transport:
|
if not self._transport:
|
||||||
return '<Channel with inactive transport?>'
|
return '<Channel( with inactive transport? )>'
|
||||||
|
|
||||||
tpt: MsgTransport = self._transport
|
tpt: MsgTransport = self._transport
|
||||||
tpt_name: str = type(tpt).__name__
|
tpt_name: str = type(tpt).__name__
|
||||||
|
@ -206,26 +239,35 @@ class Channel:
|
||||||
'connected' if self.connected()
|
'connected' if self.connected()
|
||||||
else 'closed'
|
else 'closed'
|
||||||
)
|
)
|
||||||
return (
|
repr_str: str = (
|
||||||
f'<Channel(\n'
|
f'<Channel(\n'
|
||||||
f' |_status: {tpt_status!r}\n'
|
f' |_status: {tpt_status!r}\n'
|
||||||
|
) + (
|
||||||
f' _closed={self._closed}\n'
|
f' _closed={self._closed}\n'
|
||||||
f' _cancel_called={self._cancel_called}\n'
|
f' _cancel_called={self._cancel_called}\n'
|
||||||
f'\n'
|
if privates else ''
|
||||||
f' |_peer: {self.aid}\n'
|
) + ( # peer-actor (processs) section
|
||||||
f'\n'
|
f' |_peer: {self.aid.reprol()!r}\n'
|
||||||
|
if self.aid else ' |_peer: <unknown>\n'
|
||||||
|
) + (
|
||||||
f' |_msgstream: {tpt_name}\n'
|
f' |_msgstream: {tpt_name}\n'
|
||||||
f' proto={tpt.laddr.proto_key!r}\n'
|
f' maddr: {tpt.maddr!r}\n'
|
||||||
f' layer={tpt.layer_key!r}\n'
|
f' proto: {tpt.laddr.proto_key!r}\n'
|
||||||
f' laddr={tpt.laddr}\n'
|
f' layer: {tpt.layer_key!r}\n'
|
||||||
f' raddr={tpt.raddr}\n'
|
f' codec: {tpt.codec_key!r}\n'
|
||||||
f' codec={tpt.codec_key!r}\n'
|
f' .laddr={tpt.laddr}\n'
|
||||||
f' stream={tpt.stream}\n'
|
f' .raddr={tpt.raddr}\n'
|
||||||
f' maddr={tpt.maddr!r}\n'
|
) + (
|
||||||
f' drained={tpt.drained}\n'
|
f' ._transport.stream={tpt.stream}\n'
|
||||||
|
f' ._transport.drained={tpt.drained}\n'
|
||||||
|
if privates else ''
|
||||||
|
) + (
|
||||||
f' _send_lock={tpt._send_lock.statistics()}\n'
|
f' _send_lock={tpt._send_lock.statistics()}\n'
|
||||||
f')>\n'
|
if privates else ''
|
||||||
|
) + (
|
||||||
|
')>\n'
|
||||||
)
|
)
|
||||||
|
return repr_str
|
||||||
|
|
||||||
# NOTE: making this return a value that can be passed to
|
# NOTE: making this return a value that can be passed to
|
||||||
# `eval()` is entirely **optional** FYI!
|
# `eval()` is entirely **optional** FYI!
|
||||||
|
@ -247,6 +289,10 @@ class Channel:
|
||||||
def raddr(self) -> Address|None:
|
def raddr(self) -> Address|None:
|
||||||
return self._transport.raddr if self._transport else None
|
return self._transport.raddr if self._transport else None
|
||||||
|
|
||||||
|
@property
|
||||||
|
def maddr(self) -> str:
|
||||||
|
return self._transport.maddr if self._transport else '<no-tpt>'
|
||||||
|
|
||||||
# TODO: something like,
|
# TODO: something like,
|
||||||
# `pdbp.hideframe_on(errors=[MsgTypeError])`
|
# `pdbp.hideframe_on(errors=[MsgTypeError])`
|
||||||
# instead of the `try/except` hack we have rn..
|
# instead of the `try/except` hack we have rn..
|
||||||
|
@ -257,7 +303,7 @@ class Channel:
|
||||||
self,
|
self,
|
||||||
payload: Any,
|
payload: Any,
|
||||||
|
|
||||||
hide_tb: bool = True,
|
hide_tb: bool = False,
|
||||||
|
|
||||||
) -> None:
|
) -> None:
|
||||||
'''
|
'''
|
||||||
|
@ -434,8 +480,8 @@ class Channel:
|
||||||
await self.send(aid)
|
await self.send(aid)
|
||||||
peer_aid: Aid = await self.recv()
|
peer_aid: Aid = await self.recv()
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Received hanshake with peer actor,\n'
|
f'Received hanshake with peer\n'
|
||||||
f'{peer_aid}\n'
|
f'<= {peer_aid.reprol(sin_uuid=False)}\n'
|
||||||
)
|
)
|
||||||
# NOTE, we always are referencing the remote peer!
|
# NOTE, we always are referencing the remote peer!
|
||||||
self.aid = peer_aid
|
self.aid = peer_aid
|
||||||
|
|
|
@ -17,9 +17,16 @@
|
||||||
Utils to tame mp non-SC madeness
|
Utils to tame mp non-SC madeness
|
||||||
|
|
||||||
'''
|
'''
|
||||||
|
|
||||||
|
# !TODO! in 3.13 this can be disabled (the-same/similarly) using
|
||||||
|
# a flag,
|
||||||
|
# - [ ] soo if it works like this, drop this module entirely for
|
||||||
|
# 3.13+ B)
|
||||||
|
# |_https://docs.python.org/3/library/multiprocessing.shared_memory.html
|
||||||
|
#
|
||||||
def disable_mantracker():
|
def disable_mantracker():
|
||||||
'''
|
'''
|
||||||
Disable all ``multiprocessing``` "resource tracking" machinery since
|
Disable all `multiprocessing` "resource tracking" machinery since
|
||||||
it's an absolute multi-threaded mess of non-SC madness.
|
it's an absolute multi-threaded mess of non-SC madness.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
|
|
|
@ -26,7 +26,7 @@ from contextlib import (
|
||||||
from functools import partial
|
from functools import partial
|
||||||
from itertools import chain
|
from itertools import chain
|
||||||
import inspect
|
import inspect
|
||||||
from pprint import pformat
|
import textwrap
|
||||||
from types import (
|
from types import (
|
||||||
ModuleType,
|
ModuleType,
|
||||||
)
|
)
|
||||||
|
@ -43,7 +43,10 @@ from trio import (
|
||||||
SocketListener,
|
SocketListener,
|
||||||
)
|
)
|
||||||
|
|
||||||
# from ..devx import debug
|
from ..devx.pformat import (
|
||||||
|
ppfmt,
|
||||||
|
nest_from_op,
|
||||||
|
)
|
||||||
from .._exceptions import (
|
from .._exceptions import (
|
||||||
TransportClosed,
|
TransportClosed,
|
||||||
)
|
)
|
||||||
|
@ -141,9 +144,8 @@ async def maybe_wait_on_canced_subs(
|
||||||
|
|
||||||
):
|
):
|
||||||
log.cancel(
|
log.cancel(
|
||||||
'Waiting on cancel request to peer..\n'
|
'Waiting on cancel request to peer\n'
|
||||||
f'c)=>\n'
|
f'c)=> {chan.aid.reprol()}@[{chan.maddr}]\n'
|
||||||
f' |_{chan.aid}\n'
|
|
||||||
)
|
)
|
||||||
|
|
||||||
# XXX: this is a soft wait on the channel (and its
|
# XXX: this is a soft wait on the channel (and its
|
||||||
|
@ -179,7 +181,7 @@ async def maybe_wait_on_canced_subs(
|
||||||
log.warning(
|
log.warning(
|
||||||
'Draining msg from disconnected peer\n'
|
'Draining msg from disconnected peer\n'
|
||||||
f'{chan_info}'
|
f'{chan_info}'
|
||||||
f'{pformat(msg)}\n'
|
f'{ppfmt(msg)}\n'
|
||||||
)
|
)
|
||||||
# cid: str|None = msg.get('cid')
|
# cid: str|None = msg.get('cid')
|
||||||
cid: str|None = msg.cid
|
cid: str|None = msg.cid
|
||||||
|
@ -248,7 +250,7 @@ async def maybe_wait_on_canced_subs(
|
||||||
if children := local_nursery._children:
|
if children := local_nursery._children:
|
||||||
# indent from above local-nurse repr
|
# indent from above local-nurse repr
|
||||||
report += (
|
report += (
|
||||||
f' |_{pformat(children)}\n'
|
f' |_{ppfmt(children)}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
log.warning(report)
|
log.warning(report)
|
||||||
|
@ -279,8 +281,9 @@ async def maybe_wait_on_canced_subs(
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Peer IPC broke but subproc is alive?\n\n'
|
f'Peer IPC broke but subproc is alive?\n\n'
|
||||||
|
|
||||||
f'<=x {chan.aid}@{chan.raddr}\n'
|
f'<=x {chan.aid.reprol()}@[{chan.maddr}]\n'
|
||||||
f' |_{proc}\n'
|
f'\n'
|
||||||
|
f'{proc}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
return local_nursery
|
return local_nursery
|
||||||
|
@ -324,9 +327,10 @@ async def handle_stream_from_peer(
|
||||||
|
|
||||||
chan = Channel.from_stream(stream)
|
chan = Channel.from_stream(stream)
|
||||||
con_status: str = (
|
con_status: str = (
|
||||||
'New inbound IPC connection <=\n'
|
f'New inbound IPC transport connection\n'
|
||||||
f'|_{chan}\n'
|
f'<=( {stream!r}\n'
|
||||||
)
|
)
|
||||||
|
con_status_steps: str = ''
|
||||||
|
|
||||||
# initial handshake with peer phase
|
# initial handshake with peer phase
|
||||||
try:
|
try:
|
||||||
|
@ -372,7 +376,7 @@ async def handle_stream_from_peer(
|
||||||
if _pre_chan := server._peers.get(uid):
|
if _pre_chan := server._peers.get(uid):
|
||||||
familiar: str = 'pre-existing-peer'
|
familiar: str = 'pre-existing-peer'
|
||||||
uid_short: str = f'{uid[0]}[{uid[1][-6:]}]'
|
uid_short: str = f'{uid[0]}[{uid[1][-6:]}]'
|
||||||
con_status += (
|
con_status_steps += (
|
||||||
f' -> Handshake with {familiar} `{uid_short}` complete\n'
|
f' -> Handshake with {familiar} `{uid_short}` complete\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@ -397,7 +401,7 @@ async def handle_stream_from_peer(
|
||||||
None,
|
None,
|
||||||
)
|
)
|
||||||
if event:
|
if event:
|
||||||
con_status += (
|
con_status_steps += (
|
||||||
' -> Waking subactor spawn waiters: '
|
' -> Waking subactor spawn waiters: '
|
||||||
f'{event.statistics().tasks_waiting}\n'
|
f'{event.statistics().tasks_waiting}\n'
|
||||||
f' -> Registered IPC chan for child actor {uid}@{chan.raddr}\n'
|
f' -> Registered IPC chan for child actor {uid}@{chan.raddr}\n'
|
||||||
|
@ -408,7 +412,7 @@ async def handle_stream_from_peer(
|
||||||
event.set()
|
event.set()
|
||||||
|
|
||||||
else:
|
else:
|
||||||
con_status += (
|
con_status_steps += (
|
||||||
f' -> Registered IPC chan for peer actor {uid}@{chan.raddr}\n'
|
f' -> Registered IPC chan for peer actor {uid}@{chan.raddr}\n'
|
||||||
) # type: ignore
|
) # type: ignore
|
||||||
|
|
||||||
|
@ -422,8 +426,15 @@ async def handle_stream_from_peer(
|
||||||
# TODO: can we just use list-ref directly?
|
# TODO: can we just use list-ref directly?
|
||||||
chans.append(chan)
|
chans.append(chan)
|
||||||
|
|
||||||
con_status += ' -> Entering RPC msg loop..\n'
|
con_status_steps += ' -> Entering RPC msg loop..\n'
|
||||||
log.runtime(con_status)
|
log.runtime(
|
||||||
|
con_status
|
||||||
|
+
|
||||||
|
textwrap.indent(
|
||||||
|
con_status_steps,
|
||||||
|
prefix=' '*3, # align to first-ln
|
||||||
|
)
|
||||||
|
)
|
||||||
|
|
||||||
# Begin channel management - respond to remote requests and
|
# Begin channel management - respond to remote requests and
|
||||||
# process received reponses.
|
# process received reponses.
|
||||||
|
@ -456,41 +467,67 @@ async def handle_stream_from_peer(
|
||||||
disconnected=disconnected,
|
disconnected=disconnected,
|
||||||
)
|
)
|
||||||
|
|
||||||
# ``Channel`` teardown and closure sequence
|
# `Channel` teardown and closure sequence
|
||||||
# drop ref to channel so it can be gc-ed and disconnected
|
# drop ref to channel so it can be gc-ed and disconnected
|
||||||
con_teardown_status: str = (
|
#
|
||||||
f'IPC channel disconnected:\n'
|
# -[x]TODO mk this be like
|
||||||
f'<=x uid: {chan.aid}\n'
|
# <=x Channel(
|
||||||
f' |_{pformat(chan)}\n\n'
|
# |_field: blah
|
||||||
|
# )>
|
||||||
|
op_repr: str = '<=x '
|
||||||
|
chan_repr: str = nest_from_op(
|
||||||
|
input_op=op_repr,
|
||||||
|
op_suffix='',
|
||||||
|
nest_prefix='',
|
||||||
|
text=chan.pformat(),
|
||||||
|
nest_indent=len(op_repr)-1,
|
||||||
|
rm_from_first_ln='<',
|
||||||
)
|
)
|
||||||
|
|
||||||
|
con_teardown_status: str = (
|
||||||
|
f'IPC channel disconnect\n'
|
||||||
|
f'\n'
|
||||||
|
f'{chan_repr}\n'
|
||||||
|
f'\n'
|
||||||
|
)
|
||||||
|
|
||||||
chans.remove(chan)
|
chans.remove(chan)
|
||||||
|
|
||||||
# TODO: do we need to be this pedantic?
|
# TODO: do we need to be this pedantic?
|
||||||
if not chans:
|
if not chans:
|
||||||
con_teardown_status += (
|
con_teardown_status += (
|
||||||
f'-> No more channels with {chan.aid}'
|
f'-> No more channels with {chan.aid.reprol()!r}\n'
|
||||||
)
|
)
|
||||||
server._peers.pop(uid, None)
|
server._peers.pop(uid, None)
|
||||||
|
|
||||||
peers_str: str = ''
|
if peers := list(server._peers.values()):
|
||||||
for uid, chans in server._peers.items():
|
peer_cnt: int = len(peers)
|
||||||
peers_str += (
|
if (
|
||||||
f'uid: {uid}\n'
|
(first := peers[0][0]) is not chan
|
||||||
)
|
and
|
||||||
for i, chan in enumerate(chans):
|
not disconnected
|
||||||
peers_str += (
|
and
|
||||||
f' |_[{i}] {pformat(chan)}\n'
|
peer_cnt > 1
|
||||||
)
|
):
|
||||||
|
|
||||||
con_teardown_status += (
|
con_teardown_status += (
|
||||||
f'-> Remaining IPC {len(server._peers)} peers: {peers_str}\n'
|
f'-> Remaining IPC {peer_cnt-1!r} peers:\n'
|
||||||
|
)
|
||||||
|
for chans in server._peers.values():
|
||||||
|
first: Channel = chans[0]
|
||||||
|
if not (
|
||||||
|
first is chan
|
||||||
|
and
|
||||||
|
disconnected
|
||||||
|
):
|
||||||
|
con_teardown_status += (
|
||||||
|
f' |_{first.aid.reprol()!r} -> {len(chans)!r} chans\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# No more channels to other actors (at all) registered
|
# No more channels to other actors (at all) registered
|
||||||
# as connected.
|
# as connected.
|
||||||
if not server._peers:
|
if not server._peers:
|
||||||
con_teardown_status += (
|
con_teardown_status += (
|
||||||
'Signalling no more peer channel connections'
|
'-> Signalling no more peer connections!\n'
|
||||||
)
|
)
|
||||||
server._no_more_peers.set()
|
server._no_more_peers.set()
|
||||||
|
|
||||||
|
@ -579,10 +616,10 @@ async def handle_stream_from_peer(
|
||||||
|
|
||||||
class Endpoint(Struct):
|
class Endpoint(Struct):
|
||||||
'''
|
'''
|
||||||
An instance of an IPC "bound" address where the lifetime of the
|
An instance of an IPC "bound" address where the lifetime of an
|
||||||
"ability to accept connections" (from clients) and then handle
|
"ability to accept connections" and handle the subsequent
|
||||||
those inbound sessions or sequences-of-packets is determined by
|
sequence-of-packets (maybe oriented as sessions) is determined by
|
||||||
a (maybe pair of) nurser(y/ies).
|
the underlying nursery scope(s).
|
||||||
|
|
||||||
'''
|
'''
|
||||||
addr: Address
|
addr: Address
|
||||||
|
@ -600,6 +637,24 @@ class Endpoint(Struct):
|
||||||
MsgTransport, # handle to encoded-msg transport stream
|
MsgTransport, # handle to encoded-msg transport stream
|
||||||
] = {}
|
] = {}
|
||||||
|
|
||||||
|
def pformat(
|
||||||
|
self,
|
||||||
|
indent: int = 0,
|
||||||
|
privates: bool = False,
|
||||||
|
) -> str:
|
||||||
|
type_repr: str = type(self).__name__
|
||||||
|
fmtstr: str = (
|
||||||
|
# !TODO, always be ns aware!
|
||||||
|
# f'|_netns: {netns}\n'
|
||||||
|
f' |.addr: {self.addr!r}\n'
|
||||||
|
f' |_peers: {len(self.peer_tpts)}\n'
|
||||||
|
)
|
||||||
|
return (
|
||||||
|
f'<{type_repr}(\n'
|
||||||
|
f'{fmtstr}'
|
||||||
|
f')>'
|
||||||
|
)
|
||||||
|
|
||||||
async def start_listener(self) -> SocketListener:
|
async def start_listener(self) -> SocketListener:
|
||||||
tpt_mod: ModuleType = inspect.getmodule(self.addr)
|
tpt_mod: ModuleType = inspect.getmodule(self.addr)
|
||||||
lstnr: SocketListener = await tpt_mod.start_listener(
|
lstnr: SocketListener = await tpt_mod.start_listener(
|
||||||
|
@ -639,11 +694,13 @@ class Endpoint(Struct):
|
||||||
class Server(Struct):
|
class Server(Struct):
|
||||||
_parent_tn: Nursery
|
_parent_tn: Nursery
|
||||||
_stream_handler_tn: Nursery
|
_stream_handler_tn: Nursery
|
||||||
|
|
||||||
# level-triggered sig for whether "no peers are currently
|
# level-triggered sig for whether "no peers are currently
|
||||||
# connected"; field is **always** set to an instance but
|
# connected"; field is **always** set to an instance but
|
||||||
# initialized with `.is_set() == True`.
|
# initialized with `.is_set() == True`.
|
||||||
_no_more_peers: trio.Event
|
_no_more_peers: trio.Event
|
||||||
|
|
||||||
|
# active eps as allocated by `.listen_on()`
|
||||||
_endpoints: list[Endpoint] = []
|
_endpoints: list[Endpoint] = []
|
||||||
|
|
||||||
# connection tracking & mgmt
|
# connection tracking & mgmt
|
||||||
|
@ -651,12 +708,19 @@ class Server(Struct):
|
||||||
str, # uaid
|
str, # uaid
|
||||||
list[Channel], # IPC conns from peer
|
list[Channel], # IPC conns from peer
|
||||||
] = defaultdict(list)
|
] = defaultdict(list)
|
||||||
|
|
||||||
|
# events-table with entries registered unset while the local
|
||||||
|
# actor is waiting on a new actor to inbound connect, often
|
||||||
|
# a parent waiting on its child just after spawn.
|
||||||
_peer_connected: dict[
|
_peer_connected: dict[
|
||||||
tuple[str, str],
|
tuple[str, str],
|
||||||
trio.Event,
|
trio.Event,
|
||||||
] = {}
|
] = {}
|
||||||
|
|
||||||
# syncs for setup/teardown sequences
|
# syncs for setup/teardown sequences
|
||||||
|
# - null when not yet booted,
|
||||||
|
# - unset when active,
|
||||||
|
# - set when fully shutdown with 0 eps active.
|
||||||
_shutdown: trio.Event|None = None
|
_shutdown: trio.Event|None = None
|
||||||
|
|
||||||
# TODO, maybe just make `._endpoints: list[Endpoint]` and
|
# TODO, maybe just make `._endpoints: list[Endpoint]` and
|
||||||
|
@ -664,7 +728,6 @@ class Server(Struct):
|
||||||
# @property
|
# @property
|
||||||
# def addrs2eps(self) -> dict[Address, Endpoint]:
|
# def addrs2eps(self) -> dict[Address, Endpoint]:
|
||||||
# ...
|
# ...
|
||||||
|
|
||||||
@property
|
@property
|
||||||
def proto_keys(self) -> list[str]:
|
def proto_keys(self) -> list[str]:
|
||||||
return [
|
return [
|
||||||
|
@ -690,7 +753,7 @@ class Server(Struct):
|
||||||
# TODO: obvi a different server type when we eventually
|
# TODO: obvi a different server type when we eventually
|
||||||
# support some others XD
|
# support some others XD
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Cancelling server(s) for\n'
|
f'Cancelling server(s) for tpt-protos\n'
|
||||||
f'{self.proto_keys!r}\n'
|
f'{self.proto_keys!r}\n'
|
||||||
)
|
)
|
||||||
self._parent_tn.cancel_scope.cancel()
|
self._parent_tn.cancel_scope.cancel()
|
||||||
|
@ -717,6 +780,14 @@ class Server(Struct):
|
||||||
f'protos: {tpt_protos!r}\n'
|
f'protos: {tpt_protos!r}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
def len_peers(
|
||||||
|
self,
|
||||||
|
) -> int:
|
||||||
|
return len([
|
||||||
|
chan.connected()
|
||||||
|
for chan in chain(*self._peers.values())
|
||||||
|
])
|
||||||
|
|
||||||
def has_peers(
|
def has_peers(
|
||||||
self,
|
self,
|
||||||
check_chans: bool = False,
|
check_chans: bool = False,
|
||||||
|
@ -730,13 +801,11 @@ class Server(Struct):
|
||||||
has_peers
|
has_peers
|
||||||
and
|
and
|
||||||
check_chans
|
check_chans
|
||||||
|
and
|
||||||
|
(peer_cnt := self.len_peers())
|
||||||
):
|
):
|
||||||
has_peers: bool = (
|
has_peers: bool = (
|
||||||
any(chan.connected()
|
peer_cnt > 0
|
||||||
for chan in chain(
|
|
||||||
*self._peers.values()
|
|
||||||
)
|
|
||||||
)
|
|
||||||
and
|
and
|
||||||
has_peers
|
has_peers
|
||||||
)
|
)
|
||||||
|
@ -745,10 +814,14 @@ class Server(Struct):
|
||||||
|
|
||||||
async def wait_for_no_more_peers(
|
async def wait_for_no_more_peers(
|
||||||
self,
|
self,
|
||||||
shield: bool = False,
|
# XXX, should this even be allowed?
|
||||||
|
# -> i've seen it cause hangs on teardown
|
||||||
|
# in `test_resource_cache.py`
|
||||||
|
# _shield: bool = False,
|
||||||
) -> None:
|
) -> None:
|
||||||
with trio.CancelScope(shield=shield):
|
|
||||||
await self._no_more_peers.wait()
|
await self._no_more_peers.wait()
|
||||||
|
# with trio.CancelScope(shield=_shield):
|
||||||
|
# await self._no_more_peers.wait()
|
||||||
|
|
||||||
async def wait_for_peer(
|
async def wait_for_peer(
|
||||||
self,
|
self,
|
||||||
|
@ -803,30 +876,66 @@ class Server(Struct):
|
||||||
|
|
||||||
return ev.is_set()
|
return ev.is_set()
|
||||||
|
|
||||||
def pformat(self) -> str:
|
@property
|
||||||
|
def repr_state(self) -> str:
|
||||||
|
'''
|
||||||
|
A `str`-status describing the current state of this
|
||||||
|
IPC server in terms of the current operating "phase".
|
||||||
|
|
||||||
|
'''
|
||||||
|
status = 'server is active'
|
||||||
|
if self.has_peers():
|
||||||
|
peer_cnt: int = self.len_peers()
|
||||||
|
status: str = (
|
||||||
|
f'{peer_cnt!r} peer chans'
|
||||||
|
)
|
||||||
|
else:
|
||||||
|
status: str = 'No peer chans'
|
||||||
|
|
||||||
|
if self.is_shutdown():
|
||||||
|
status: str = 'server-shutdown'
|
||||||
|
|
||||||
|
return status
|
||||||
|
|
||||||
|
def pformat(
|
||||||
|
self,
|
||||||
|
privates: bool = False,
|
||||||
|
) -> str:
|
||||||
eps: list[Endpoint] = self._endpoints
|
eps: list[Endpoint] = self._endpoints
|
||||||
|
|
||||||
state_repr: str = (
|
# state_repr: str = (
|
||||||
f'{len(eps)!r} IPC-endpoints active'
|
# f'{len(eps)!r} endpoints active'
|
||||||
)
|
# )
|
||||||
fmtstr = (
|
fmtstr = (
|
||||||
f' |_state: {state_repr}\n'
|
f' |_state: {self.repr_state!r}\n'
|
||||||
f' no_more_peers: {self.has_peers()}\n'
|
|
||||||
)
|
)
|
||||||
|
if privates:
|
||||||
|
fmtstr += f' no_more_peers: {self.has_peers()}\n'
|
||||||
|
|
||||||
if self._shutdown is not None:
|
if self._shutdown is not None:
|
||||||
shutdown_stats: EventStatistics = self._shutdown.statistics()
|
shutdown_stats: EventStatistics = self._shutdown.statistics()
|
||||||
fmtstr += (
|
fmtstr += (
|
||||||
f' task_waiting_on_shutdown: {shutdown_stats}\n'
|
f' task_waiting_on_shutdown: {shutdown_stats}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
if eps := self._endpoints:
|
||||||
|
addrs: list[tuple] = [
|
||||||
|
ep.addr for ep in eps
|
||||||
|
]
|
||||||
|
repr_eps: str = ppfmt(addrs)
|
||||||
|
|
||||||
fmtstr += (
|
fmtstr += (
|
||||||
# TODO, use the `ppfmt()` helper from `modden`!
|
f' |_endpoints: {repr_eps}\n'
|
||||||
f' |_endpoints: {pformat(self._endpoints)}\n'
|
# ^TODO? how to indent closing ']'..
|
||||||
f' |_peers: {len(self._peers)} connected\n'
|
)
|
||||||
|
|
||||||
|
if peers := self._peers:
|
||||||
|
fmtstr += (
|
||||||
|
f' |_peers: {len(peers)} connected\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
return (
|
return (
|
||||||
f'<IPCServer(\n'
|
f'<Server(\n'
|
||||||
f'{fmtstr}'
|
f'{fmtstr}'
|
||||||
f')>\n'
|
f')>\n'
|
||||||
)
|
)
|
||||||
|
@ -885,8 +994,8 @@ class Server(Struct):
|
||||||
)
|
)
|
||||||
|
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Binding to endpoints for,\n'
|
f'Binding endpoints\n'
|
||||||
f'{accept_addrs}\n'
|
f'{ppfmt(accept_addrs)}\n'
|
||||||
)
|
)
|
||||||
eps: list[Endpoint] = await self._parent_tn.start(
|
eps: list[Endpoint] = await self._parent_tn.start(
|
||||||
partial(
|
partial(
|
||||||
|
@ -896,13 +1005,19 @@ class Server(Struct):
|
||||||
listen_addrs=accept_addrs,
|
listen_addrs=accept_addrs,
|
||||||
)
|
)
|
||||||
)
|
)
|
||||||
|
self._endpoints.extend(eps)
|
||||||
|
|
||||||
|
serv_repr: str = nest_from_op(
|
||||||
|
input_op='(>',
|
||||||
|
text=self.pformat(),
|
||||||
|
nest_indent=1,
|
||||||
|
)
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Started IPC endpoints\n'
|
f'Started IPC server\n'
|
||||||
f'{eps}\n'
|
f'{serv_repr}'
|
||||||
)
|
)
|
||||||
|
|
||||||
self._endpoints.extend(eps)
|
# XXX, a little sanity on new ep allocations
|
||||||
# XXX, just a little bit of sanity
|
|
||||||
group_tn: Nursery|None = None
|
group_tn: Nursery|None = None
|
||||||
ep: Endpoint
|
ep: Endpoint
|
||||||
for ep in eps:
|
for ep in eps:
|
||||||
|
@ -956,9 +1071,13 @@ async def _serve_ipc_eps(
|
||||||
stream_handler_tn=stream_handler_tn,
|
stream_handler_tn=stream_handler_tn,
|
||||||
)
|
)
|
||||||
try:
|
try:
|
||||||
|
ep_sclang: str = nest_from_op(
|
||||||
|
input_op='>[',
|
||||||
|
text=f'{ep.pformat()}',
|
||||||
|
)
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Starting new endpoint listener\n'
|
f'Starting new endpoint listener\n'
|
||||||
f'{ep}\n'
|
f'{ep_sclang}\n'
|
||||||
)
|
)
|
||||||
listener: trio.abc.Listener = await ep.start_listener()
|
listener: trio.abc.Listener = await ep.start_listener()
|
||||||
assert listener is ep._listener
|
assert listener is ep._listener
|
||||||
|
@ -996,17 +1115,6 @@ async def _serve_ipc_eps(
|
||||||
handler_nursery=stream_handler_tn
|
handler_nursery=stream_handler_tn
|
||||||
)
|
)
|
||||||
)
|
)
|
||||||
# TODO, wow make this message better! XD
|
|
||||||
log.runtime(
|
|
||||||
'Started server(s)\n'
|
|
||||||
+
|
|
||||||
'\n'.join([f'|_{addr}' for addr in listen_addrs])
|
|
||||||
)
|
|
||||||
|
|
||||||
log.runtime(
|
|
||||||
f'Started IPC endpoints\n'
|
|
||||||
f'{eps}\n'
|
|
||||||
)
|
|
||||||
task_status.started(
|
task_status.started(
|
||||||
eps,
|
eps,
|
||||||
)
|
)
|
||||||
|
@ -1049,8 +1157,7 @@ async def open_ipc_server(
|
||||||
try:
|
try:
|
||||||
yield ipc_server
|
yield ipc_server
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Waiting on server to shutdown or be cancelled..\n'
|
'Server-tn running until terminated\n'
|
||||||
f'{ipc_server}'
|
|
||||||
)
|
)
|
||||||
# TODO? when if ever would we want/need this?
|
# TODO? when if ever would we want/need this?
|
||||||
# with trio.CancelScope(shield=True):
|
# with trio.CancelScope(shield=True):
|
||||||
|
|
|
@ -789,6 +789,11 @@ def open_shm_list(
|
||||||
readonly=readonly,
|
readonly=readonly,
|
||||||
)
|
)
|
||||||
|
|
||||||
|
# TODO, factor into a @actor_fixture acm-API?
|
||||||
|
# -[ ] also `@maybe_actor_fixture()` which inludes
|
||||||
|
# the .current_actor() convenience check?
|
||||||
|
# |_ orr can that just be in the sin-maybe-version?
|
||||||
|
#
|
||||||
# "close" attached shm on actor teardown
|
# "close" attached shm on actor teardown
|
||||||
try:
|
try:
|
||||||
actor = tractor.current_actor()
|
actor = tractor.current_actor()
|
||||||
|
|
|
@ -160,10 +160,9 @@ async def start_listener(
|
||||||
Start a TCP socket listener on the given `TCPAddress`.
|
Start a TCP socket listener on the given `TCPAddress`.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
log.info(
|
log.runtime(
|
||||||
f'Attempting to bind TCP socket\n'
|
f'Trying socket bind\n'
|
||||||
f'>[\n'
|
f'>[ {addr}\n'
|
||||||
f'|_{addr}\n'
|
|
||||||
)
|
)
|
||||||
# ?TODO, maybe we should just change the lower-level call this is
|
# ?TODO, maybe we should just change the lower-level call this is
|
||||||
# using internall per-listener?
|
# using internall per-listener?
|
||||||
|
@ -178,11 +177,10 @@ async def start_listener(
|
||||||
assert len(listeners) == 1
|
assert len(listeners) == 1
|
||||||
listener = listeners[0]
|
listener = listeners[0]
|
||||||
host, port = listener.socket.getsockname()[:2]
|
host, port = listener.socket.getsockname()[:2]
|
||||||
|
bound_addr: TCPAddress = type(addr).from_addr((host, port))
|
||||||
log.info(
|
log.info(
|
||||||
f'Listening on TCP socket\n'
|
f'Listening on TCP socket\n'
|
||||||
f'[>\n'
|
f'[> {bound_addr}\n'
|
||||||
f' |_{addr}\n'
|
|
||||||
)
|
)
|
||||||
return listener
|
return listener
|
||||||
|
|
||||||
|
|
|
@ -18,6 +18,9 @@ Unix Domain Socket implementation of tractor.ipc._transport.MsgTransport protoco
|
||||||
|
|
||||||
'''
|
'''
|
||||||
from __future__ import annotations
|
from __future__ import annotations
|
||||||
|
from contextlib import (
|
||||||
|
contextmanager as cm,
|
||||||
|
)
|
||||||
from pathlib import Path
|
from pathlib import Path
|
||||||
import os
|
import os
|
||||||
from socket import (
|
from socket import (
|
||||||
|
@ -29,6 +32,7 @@ from socket import (
|
||||||
)
|
)
|
||||||
import struct
|
import struct
|
||||||
from typing import (
|
from typing import (
|
||||||
|
Type,
|
||||||
TYPE_CHECKING,
|
TYPE_CHECKING,
|
||||||
ClassVar,
|
ClassVar,
|
||||||
)
|
)
|
||||||
|
@ -99,8 +103,6 @@ class UDSAddress(
|
||||||
self.filedir
|
self.filedir
|
||||||
or
|
or
|
||||||
self.def_bindspace
|
self.def_bindspace
|
||||||
# or
|
|
||||||
# get_rt_dir()
|
|
||||||
)
|
)
|
||||||
|
|
||||||
@property
|
@property
|
||||||
|
@ -205,12 +207,35 @@ class UDSAddress(
|
||||||
f']'
|
f']'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@cm
|
||||||
|
def _reraise_as_connerr(
|
||||||
|
src_excs: tuple[Type[Exception]],
|
||||||
|
addr: UDSAddress,
|
||||||
|
):
|
||||||
|
try:
|
||||||
|
yield
|
||||||
|
except src_excs as src_exc:
|
||||||
|
raise ConnectionError(
|
||||||
|
f'Bad UDS socket-filepath-as-address ??\n'
|
||||||
|
f'{addr}\n'
|
||||||
|
f' |_sockpath: {addr.sockpath}\n'
|
||||||
|
f'\n'
|
||||||
|
f'from src: {src_exc!r}\n'
|
||||||
|
) from src_exc
|
||||||
|
|
||||||
|
|
||||||
async def start_listener(
|
async def start_listener(
|
||||||
addr: UDSAddress,
|
addr: UDSAddress,
|
||||||
**kwargs,
|
**kwargs,
|
||||||
) -> SocketListener:
|
) -> SocketListener:
|
||||||
# sock = addr._sock = socket.socket(
|
'''
|
||||||
|
Start listening for inbound connections via
|
||||||
|
a `trio.SocketListener` (task) which `socket.bind()`s on `addr`.
|
||||||
|
|
||||||
|
Note, if the `UDSAddress.bindspace: Path` directory dne it is
|
||||||
|
implicitly created.
|
||||||
|
|
||||||
|
'''
|
||||||
sock = socket.socket(
|
sock = socket.socket(
|
||||||
socket.AF_UNIX,
|
socket.AF_UNIX,
|
||||||
socket.SOCK_STREAM
|
socket.SOCK_STREAM
|
||||||
|
@ -221,17 +246,25 @@ async def start_listener(
|
||||||
f'|_{addr}\n'
|
f'|_{addr}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
# ?TODO? should we use the `actor.lifetime_stack`
|
||||||
|
# to rm on shutdown?
|
||||||
bindpath: Path = addr.sockpath
|
bindpath: Path = addr.sockpath
|
||||||
try:
|
if not (bs := addr.bindspace).is_dir():
|
||||||
await sock.bind(str(bindpath))
|
log.info(
|
||||||
except (
|
'Creating bindspace dir in file-sys\n'
|
||||||
|
f'>{{\n'
|
||||||
|
f'|_{bs!r}\n'
|
||||||
|
)
|
||||||
|
bs.mkdir()
|
||||||
|
|
||||||
|
with _reraise_as_connerr(
|
||||||
|
src_excs=(
|
||||||
FileNotFoundError,
|
FileNotFoundError,
|
||||||
) as fdne:
|
OSError,
|
||||||
raise ConnectionError(
|
),
|
||||||
f'Bad UDS socket-filepath-as-address ??\n'
|
addr=addr
|
||||||
f'{addr}\n'
|
):
|
||||||
f' |_sockpath: {addr.sockpath}\n'
|
await sock.bind(str(bindpath))
|
||||||
) from fdne
|
|
||||||
|
|
||||||
sock.listen(1)
|
sock.listen(1)
|
||||||
log.info(
|
log.info(
|
||||||
|
@ -356,27 +389,30 @@ class MsgpackUDSStream(MsgpackTransport):
|
||||||
# `.setsockopt()` call tells the OS provide it; the client
|
# `.setsockopt()` call tells the OS provide it; the client
|
||||||
# pid can then be read on server/listen() side via
|
# pid can then be read on server/listen() side via
|
||||||
# `get_peer_info()` above.
|
# `get_peer_info()` above.
|
||||||
try:
|
|
||||||
|
with _reraise_as_connerr(
|
||||||
|
src_excs=(
|
||||||
|
FileNotFoundError,
|
||||||
|
),
|
||||||
|
addr=addr
|
||||||
|
):
|
||||||
stream = await open_unix_socket_w_passcred(
|
stream = await open_unix_socket_w_passcred(
|
||||||
str(sockpath),
|
str(sockpath),
|
||||||
**kwargs
|
**kwargs
|
||||||
)
|
)
|
||||||
except (
|
|
||||||
FileNotFoundError,
|
|
||||||
) as fdne:
|
|
||||||
raise ConnectionError(
|
|
||||||
f'Bad UDS socket-filepath-as-address ??\n'
|
|
||||||
f'{addr}\n'
|
|
||||||
f' |_sockpath: {sockpath}\n'
|
|
||||||
) from fdne
|
|
||||||
|
|
||||||
stream = MsgpackUDSStream(
|
tpt_stream = MsgpackUDSStream(
|
||||||
stream,
|
stream,
|
||||||
prefix_size=prefix_size,
|
prefix_size=prefix_size,
|
||||||
codec=codec
|
codec=codec
|
||||||
)
|
)
|
||||||
stream._raddr = addr
|
# XXX assign from new addrs after peer-PID extract!
|
||||||
return stream
|
(
|
||||||
|
tpt_stream._laddr,
|
||||||
|
tpt_stream._raddr,
|
||||||
|
) = cls.get_stream_addrs(stream)
|
||||||
|
|
||||||
|
return tpt_stream
|
||||||
|
|
||||||
@classmethod
|
@classmethod
|
||||||
def get_stream_addrs(
|
def get_stream_addrs(
|
||||||
|
|
|
@ -81,10 +81,35 @@ BOLD_PALETTE = {
|
||||||
}
|
}
|
||||||
|
|
||||||
|
|
||||||
|
def at_least_level(
|
||||||
|
log: Logger|LoggerAdapter,
|
||||||
|
level: int|str,
|
||||||
|
) -> bool:
|
||||||
|
'''
|
||||||
|
Predicate to test if a given level is active.
|
||||||
|
|
||||||
|
'''
|
||||||
|
if isinstance(level, str):
|
||||||
|
level: int = CUSTOM_LEVELS[level.upper()]
|
||||||
|
|
||||||
|
if log.getEffectiveLevel() <= level:
|
||||||
|
return True
|
||||||
|
return False
|
||||||
|
|
||||||
|
|
||||||
# TODO: this isn't showing the correct '{filename}'
|
# TODO: this isn't showing the correct '{filename}'
|
||||||
# as it did before..
|
# as it did before..
|
||||||
class StackLevelAdapter(LoggerAdapter):
|
class StackLevelAdapter(LoggerAdapter):
|
||||||
|
|
||||||
|
def at_least_level(
|
||||||
|
self,
|
||||||
|
level: str,
|
||||||
|
) -> bool:
|
||||||
|
return at_least_level(
|
||||||
|
log=self,
|
||||||
|
level=level,
|
||||||
|
)
|
||||||
|
|
||||||
def transport(
|
def transport(
|
||||||
self,
|
self,
|
||||||
msg: str,
|
msg: str,
|
||||||
|
@ -401,19 +426,3 @@ def get_loglevel() -> str:
|
||||||
|
|
||||||
# global module logger for tractor itself
|
# global module logger for tractor itself
|
||||||
log: StackLevelAdapter = get_logger('tractor')
|
log: StackLevelAdapter = get_logger('tractor')
|
||||||
|
|
||||||
|
|
||||||
def at_least_level(
|
|
||||||
log: Logger|LoggerAdapter,
|
|
||||||
level: int|str,
|
|
||||||
) -> bool:
|
|
||||||
'''
|
|
||||||
Predicate to test if a given level is active.
|
|
||||||
|
|
||||||
'''
|
|
||||||
if isinstance(level, str):
|
|
||||||
level: int = CUSTOM_LEVELS[level.upper()]
|
|
||||||
|
|
||||||
if log.getEffectiveLevel() <= level:
|
|
||||||
return True
|
|
||||||
return False
|
|
||||||
|
|
|
@ -210,12 +210,14 @@ class PldRx(Struct):
|
||||||
match msg:
|
match msg:
|
||||||
case Return()|Error():
|
case Return()|Error():
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Rxed final outcome msg\n'
|
f'Rxed final-outcome msg\n'
|
||||||
|
f'\n'
|
||||||
f'{msg}\n'
|
f'{msg}\n'
|
||||||
)
|
)
|
||||||
case Stop():
|
case Stop():
|
||||||
log.runtime(
|
log.runtime(
|
||||||
f'Rxed stream stopped msg\n'
|
f'Rxed stream stopped msg\n'
|
||||||
|
f'\n'
|
||||||
f'{msg}\n'
|
f'{msg}\n'
|
||||||
)
|
)
|
||||||
if passthrough_non_pld_msgs:
|
if passthrough_non_pld_msgs:
|
||||||
|
@ -261,8 +263,9 @@ class PldRx(Struct):
|
||||||
if (
|
if (
|
||||||
type(msg) is Return
|
type(msg) is Return
|
||||||
):
|
):
|
||||||
log.info(
|
log.runtime(
|
||||||
f'Rxed final result msg\n'
|
f'Rxed final result msg\n'
|
||||||
|
f'\n'
|
||||||
f'{msg}\n'
|
f'{msg}\n'
|
||||||
)
|
)
|
||||||
return self.decode_pld(
|
return self.decode_pld(
|
||||||
|
@ -304,10 +307,13 @@ class PldRx(Struct):
|
||||||
try:
|
try:
|
||||||
pld: PayloadT = self._pld_dec.decode(pld)
|
pld: PayloadT = self._pld_dec.decode(pld)
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Decoded msg payload\n\n'
|
f'Decoded payload for\n'
|
||||||
|
# f'\n'
|
||||||
f'{msg}\n'
|
f'{msg}\n'
|
||||||
f'where payload decoded as\n'
|
# ^TODO?, ideally just render with `,
|
||||||
f'|_pld={pld!r}\n'
|
# pld={decode}` in the `msg.pformat()`??
|
||||||
|
f'where, '
|
||||||
|
f'{type(msg).__name__}.pld={pld!r}\n'
|
||||||
)
|
)
|
||||||
return pld
|
return pld
|
||||||
except TypeError as typerr:
|
except TypeError as typerr:
|
||||||
|
@ -494,7 +500,8 @@ def limit_plds(
|
||||||
|
|
||||||
finally:
|
finally:
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Reverted to previous payload-decoder\n\n'
|
f'Reverted to previous payload-decoder\n'
|
||||||
|
f'\n'
|
||||||
f'{orig_pldec}\n'
|
f'{orig_pldec}\n'
|
||||||
)
|
)
|
||||||
# sanity on orig settings
|
# sanity on orig settings
|
||||||
|
@ -629,7 +636,8 @@ async def drain_to_final_msg(
|
||||||
(local_cs := rent_n.cancel_scope).cancel_called
|
(local_cs := rent_n.cancel_scope).cancel_called
|
||||||
):
|
):
|
||||||
log.cancel(
|
log.cancel(
|
||||||
'RPC-ctx cancelled by local-parent scope during drain!\n\n'
|
f'RPC-ctx cancelled by local-parent scope during drain!\n'
|
||||||
|
f'\n'
|
||||||
f'c}}>\n'
|
f'c}}>\n'
|
||||||
f' |_{rent_n}\n'
|
f' |_{rent_n}\n'
|
||||||
f' |_.cancel_scope = {local_cs}\n'
|
f' |_.cancel_scope = {local_cs}\n'
|
||||||
|
@ -663,7 +671,8 @@ async def drain_to_final_msg(
|
||||||
# final result arrived!
|
# final result arrived!
|
||||||
case Return():
|
case Return():
|
||||||
log.runtime(
|
log.runtime(
|
||||||
'Context delivered final draining msg:\n'
|
f'Context delivered final draining msg\n'
|
||||||
|
f'\n'
|
||||||
f'{pretty_struct.pformat(msg)}'
|
f'{pretty_struct.pformat(msg)}'
|
||||||
)
|
)
|
||||||
ctx._result: Any = pld
|
ctx._result: Any = pld
|
||||||
|
@ -697,12 +706,14 @@ async def drain_to_final_msg(
|
||||||
):
|
):
|
||||||
log.cancel(
|
log.cancel(
|
||||||
'Cancelling `MsgStream` drain since '
|
'Cancelling `MsgStream` drain since '
|
||||||
f'{reason}\n\n'
|
f'{reason}\n'
|
||||||
|
f'\n'
|
||||||
f'<= {ctx.chan.uid}\n'
|
f'<= {ctx.chan.uid}\n'
|
||||||
f' |_{ctx._nsf}()\n\n'
|
f' |_{ctx._nsf}()\n'
|
||||||
|
f'\n'
|
||||||
f'=> {ctx._task}\n'
|
f'=> {ctx._task}\n'
|
||||||
f' |_{ctx._stream}\n\n'
|
f' |_{ctx._stream}\n'
|
||||||
|
f'\n'
|
||||||
f'{pretty_struct.pformat(msg)}\n'
|
f'{pretty_struct.pformat(msg)}\n'
|
||||||
)
|
)
|
||||||
break
|
break
|
||||||
|
@ -739,7 +750,8 @@ async def drain_to_final_msg(
|
||||||
case Stop():
|
case Stop():
|
||||||
pre_result_drained.append(msg)
|
pre_result_drained.append(msg)
|
||||||
log.runtime( # normal/expected shutdown transaction
|
log.runtime( # normal/expected shutdown transaction
|
||||||
'Remote stream terminated due to "stop" msg:\n\n'
|
f'Remote stream terminated due to "stop" msg\n'
|
||||||
|
f'\n'
|
||||||
f'{pretty_struct.pformat(msg)}\n'
|
f'{pretty_struct.pformat(msg)}\n'
|
||||||
)
|
)
|
||||||
continue
|
continue
|
||||||
|
@ -814,7 +826,8 @@ async def drain_to_final_msg(
|
||||||
|
|
||||||
else:
|
else:
|
||||||
log.cancel(
|
log.cancel(
|
||||||
'Skipping `MsgStream` drain since final outcome is set\n\n'
|
f'Skipping `MsgStream` drain since final outcome is set\n'
|
||||||
|
f'\n'
|
||||||
f'{ctx.outcome}\n'
|
f'{ctx.outcome}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
|
|
@ -154,6 +154,39 @@ class Aid(
|
||||||
# should also include at least `.pid` (equiv to port for tcp)
|
# should also include at least `.pid` (equiv to port for tcp)
|
||||||
# and/or host-part always?
|
# and/or host-part always?
|
||||||
|
|
||||||
|
@property
|
||||||
|
def uid(self) -> tuple[str, str]:
|
||||||
|
'''
|
||||||
|
Legacy actor "unique-id" pair format.
|
||||||
|
|
||||||
|
'''
|
||||||
|
return (
|
||||||
|
self.name,
|
||||||
|
self.uuid,
|
||||||
|
)
|
||||||
|
|
||||||
|
def reprol(
|
||||||
|
self,
|
||||||
|
sin_uuid: bool = True,
|
||||||
|
) -> str:
|
||||||
|
if not sin_uuid:
|
||||||
|
return (
|
||||||
|
f'{self.name}[{self.uuid[:6]}]@{self.pid!r}'
|
||||||
|
)
|
||||||
|
return (
|
||||||
|
f'{self.name}@{self.pid!r}'
|
||||||
|
)
|
||||||
|
|
||||||
|
# mk hashable via `.uuid`
|
||||||
|
def __hash__(self) -> int:
|
||||||
|
return hash(self.uuid)
|
||||||
|
|
||||||
|
def __eq__(self, other: Aid) -> bool:
|
||||||
|
return self.uuid == other.uuid
|
||||||
|
|
||||||
|
# use pretty fmt since often repr-ed for console/log
|
||||||
|
__repr__ = pretty_struct.Struct.__repr__
|
||||||
|
|
||||||
|
|
||||||
class SpawnSpec(
|
class SpawnSpec(
|
||||||
pretty_struct.Struct,
|
pretty_struct.Struct,
|
||||||
|
|
|
@ -130,6 +130,7 @@ class LinkedTaskChannel(
|
||||||
_trio_task: trio.Task
|
_trio_task: trio.Task
|
||||||
_aio_task_complete: trio.Event
|
_aio_task_complete: trio.Event
|
||||||
|
|
||||||
|
_closed_by_aio_task: bool = False
|
||||||
_suppress_graceful_exits: bool = True
|
_suppress_graceful_exits: bool = True
|
||||||
|
|
||||||
_trio_err: BaseException|None = None
|
_trio_err: BaseException|None = None
|
||||||
|
@ -208,10 +209,15 @@ class LinkedTaskChannel(
|
||||||
async def aclose(self) -> None:
|
async def aclose(self) -> None:
|
||||||
await self._from_aio.aclose()
|
await self._from_aio.aclose()
|
||||||
|
|
||||||
def started(
|
# ?TODO? async version of this?
|
||||||
|
def started_nowait(
|
||||||
self,
|
self,
|
||||||
val: Any = None,
|
val: Any = None,
|
||||||
) -> None:
|
) -> None:
|
||||||
|
'''
|
||||||
|
Synchronize aio-sde with its trio-parent.
|
||||||
|
|
||||||
|
'''
|
||||||
self._aio_started_val = val
|
self._aio_started_val = val
|
||||||
return self._to_trio.send_nowait(val)
|
return self._to_trio.send_nowait(val)
|
||||||
|
|
||||||
|
@ -242,6 +248,7 @@ class LinkedTaskChannel(
|
||||||
# cycle on the trio side?
|
# cycle on the trio side?
|
||||||
# await trio.lowlevel.checkpoint()
|
# await trio.lowlevel.checkpoint()
|
||||||
return await self._from_aio.receive()
|
return await self._from_aio.receive()
|
||||||
|
|
||||||
except BaseException as err:
|
except BaseException as err:
|
||||||
async with translate_aio_errors(
|
async with translate_aio_errors(
|
||||||
chan=self,
|
chan=self,
|
||||||
|
@ -319,7 +326,7 @@ def _run_asyncio_task(
|
||||||
qsize: int = 1,
|
qsize: int = 1,
|
||||||
provide_channels: bool = False,
|
provide_channels: bool = False,
|
||||||
suppress_graceful_exits: bool = True,
|
suppress_graceful_exits: bool = True,
|
||||||
hide_tb: bool = False,
|
hide_tb: bool = True,
|
||||||
**kwargs,
|
**kwargs,
|
||||||
|
|
||||||
) -> LinkedTaskChannel:
|
) -> LinkedTaskChannel:
|
||||||
|
@ -347,18 +354,6 @@ def _run_asyncio_task(
|
||||||
# value otherwise it would just return ;P
|
# value otherwise it would just return ;P
|
||||||
assert qsize > 1
|
assert qsize > 1
|
||||||
|
|
||||||
if provide_channels:
|
|
||||||
assert 'to_trio' in args
|
|
||||||
|
|
||||||
# allow target func to accept/stream results manually by name
|
|
||||||
if 'to_trio' in args:
|
|
||||||
kwargs['to_trio'] = to_trio
|
|
||||||
|
|
||||||
if 'from_trio' in args:
|
|
||||||
kwargs['from_trio'] = from_trio
|
|
||||||
|
|
||||||
coro = func(**kwargs)
|
|
||||||
|
|
||||||
trio_task: trio.Task = trio.lowlevel.current_task()
|
trio_task: trio.Task = trio.lowlevel.current_task()
|
||||||
trio_cs = trio.CancelScope()
|
trio_cs = trio.CancelScope()
|
||||||
aio_task_complete = trio.Event()
|
aio_task_complete = trio.Event()
|
||||||
|
@ -373,6 +368,25 @@ def _run_asyncio_task(
|
||||||
_suppress_graceful_exits=suppress_graceful_exits,
|
_suppress_graceful_exits=suppress_graceful_exits,
|
||||||
)
|
)
|
||||||
|
|
||||||
|
# allow target func to accept/stream results manually by name
|
||||||
|
if 'to_trio' in args:
|
||||||
|
kwargs['to_trio'] = to_trio
|
||||||
|
|
||||||
|
if 'from_trio' in args:
|
||||||
|
kwargs['from_trio'] = from_trio
|
||||||
|
|
||||||
|
if 'chan' in args:
|
||||||
|
kwargs['chan'] = chan
|
||||||
|
|
||||||
|
if provide_channels:
|
||||||
|
assert (
|
||||||
|
'to_trio' in args
|
||||||
|
or
|
||||||
|
'chan' in args
|
||||||
|
)
|
||||||
|
|
||||||
|
coro = func(**kwargs)
|
||||||
|
|
||||||
async def wait_on_coro_final_result(
|
async def wait_on_coro_final_result(
|
||||||
to_trio: trio.MemorySendChannel,
|
to_trio: trio.MemorySendChannel,
|
||||||
coro: Awaitable,
|
coro: Awaitable,
|
||||||
|
@ -445,9 +459,15 @@ def _run_asyncio_task(
|
||||||
f'Task exited with final result: {result!r}\n'
|
f'Task exited with final result: {result!r}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
# only close the sender side which will relay
|
# only close the aio (child) side which will relay
|
||||||
# a `trio.EndOfChannel` to the trio (consumer) side.
|
# a `trio.EndOfChannel` to the trio (parent) side.
|
||||||
|
#
|
||||||
|
# XXX NOTE, that trio-side MUST then in such cases
|
||||||
|
# check for a `chan._aio_err` and raise it!!
|
||||||
to_trio.close()
|
to_trio.close()
|
||||||
|
# specially mark the closure as due to the
|
||||||
|
# asyncio.Task terminating!
|
||||||
|
chan._closed_by_aio_task = True
|
||||||
|
|
||||||
aio_task_complete.set()
|
aio_task_complete.set()
|
||||||
log.runtime(
|
log.runtime(
|
||||||
|
@ -645,8 +665,9 @@ def _run_asyncio_task(
|
||||||
not trio_cs.cancel_called
|
not trio_cs.cancel_called
|
||||||
):
|
):
|
||||||
log.cancel(
|
log.cancel(
|
||||||
f'Cancelling `trio` side due to aio-side src exc\n'
|
f'Cancelling trio-side due to aio-side src exc\n'
|
||||||
f'{curr_aio_err}\n'
|
f'\n'
|
||||||
|
f'{curr_aio_err!r}\n'
|
||||||
f'\n'
|
f'\n'
|
||||||
f'(c>\n'
|
f'(c>\n'
|
||||||
f' |_{trio_task}\n'
|
f' |_{trio_task}\n'
|
||||||
|
@ -758,6 +779,7 @@ async def translate_aio_errors(
|
||||||
aio_done_before_trio: bool = aio_task.done()
|
aio_done_before_trio: bool = aio_task.done()
|
||||||
assert aio_task
|
assert aio_task
|
||||||
trio_err: BaseException|None = None
|
trio_err: BaseException|None = None
|
||||||
|
eoc: trio.EndOfChannel|None = None
|
||||||
try:
|
try:
|
||||||
yield # back to one of the cross-loop apis
|
yield # back to one of the cross-loop apis
|
||||||
except trio.Cancelled as taskc:
|
except trio.Cancelled as taskc:
|
||||||
|
@ -789,12 +811,50 @@ async def translate_aio_errors(
|
||||||
# )
|
# )
|
||||||
# raise
|
# raise
|
||||||
|
|
||||||
# XXX always passthrough EoC since this translator is often
|
# XXX EoC is a special SIGNAL from the aio-side here!
|
||||||
# called from `LinkedTaskChannel.receive()` which we want
|
# There are 2 cases to handle:
|
||||||
# passthrough and further we have no special meaning for it in
|
# 1. the "EoC passthrough" case.
|
||||||
# terms of relaying errors or signals from the aio side!
|
# - the aio-task actually closed the channel "gracefully" and
|
||||||
except trio.EndOfChannel as eoc:
|
# the trio-task should unwind any ongoing channel
|
||||||
|
# iteration/receiving,
|
||||||
|
# |_this exc-translator wraps calls to `LinkedTaskChannel.receive()`
|
||||||
|
# in which case we want to relay the actual "end-of-chan" for
|
||||||
|
# iteration purposes.
|
||||||
|
#
|
||||||
|
# 2. relaying the "asyncio.Task termination" case.
|
||||||
|
# - if the aio-task terminates, maybe with an error, AND the
|
||||||
|
# `open_channel_from()` API was used, it will always signal
|
||||||
|
# that termination.
|
||||||
|
# |_`wait_on_coro_final_result()` always calls
|
||||||
|
# `to_trio.close()` when `provide_channels=True` so we need to
|
||||||
|
# always check if there is an aio-side exc which needs to be
|
||||||
|
# relayed to the parent trio side!
|
||||||
|
# |_in this case the special `chan._closed_by_aio_task` is
|
||||||
|
# ALWAYS set.
|
||||||
|
#
|
||||||
|
except trio.EndOfChannel as _eoc:
|
||||||
|
eoc = _eoc
|
||||||
|
if (
|
||||||
|
chan._closed_by_aio_task
|
||||||
|
and
|
||||||
|
aio_err
|
||||||
|
):
|
||||||
|
log.cancel(
|
||||||
|
f'The asyncio-child task terminated due to error\n'
|
||||||
|
f'{aio_err!r}\n'
|
||||||
|
)
|
||||||
|
chan._trio_to_raise = aio_err
|
||||||
trio_err = chan._trio_err = eoc
|
trio_err = chan._trio_err = eoc
|
||||||
|
#
|
||||||
|
# await tractor.pause(shield=True)
|
||||||
|
#
|
||||||
|
# ?TODO?, raise something like a,
|
||||||
|
# chan._trio_to_raise = AsyncioErrored()
|
||||||
|
# BUT, with the tb rewritten to reflect the underlying
|
||||||
|
# call stack?
|
||||||
|
else:
|
||||||
|
trio_err = chan._trio_err = eoc
|
||||||
|
|
||||||
raise eoc
|
raise eoc
|
||||||
|
|
||||||
# NOTE ALSO SEE the matching note in the `cancel_trio()` asyncio
|
# NOTE ALSO SEE the matching note in the `cancel_trio()` asyncio
|
||||||
|
@ -1047,7 +1107,7 @@ async def translate_aio_errors(
|
||||||
#
|
#
|
||||||
if wait_on_aio_task:
|
if wait_on_aio_task:
|
||||||
await chan._aio_task_complete.wait()
|
await chan._aio_task_complete.wait()
|
||||||
log.info(
|
log.debug(
|
||||||
'asyncio-task is done and unblocked trio-side!\n'
|
'asyncio-task is done and unblocked trio-side!\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
@ -1064,11 +1124,17 @@ async def translate_aio_errors(
|
||||||
trio_to_raise: (
|
trio_to_raise: (
|
||||||
AsyncioCancelled|
|
AsyncioCancelled|
|
||||||
AsyncioTaskExited|
|
AsyncioTaskExited|
|
||||||
|
Exception| # relayed from aio-task
|
||||||
None
|
None
|
||||||
) = chan._trio_to_raise
|
) = chan._trio_to_raise
|
||||||
|
|
||||||
|
raise_from: Exception = (
|
||||||
|
trio_err if (aio_err is trio_to_raise)
|
||||||
|
else aio_err
|
||||||
|
)
|
||||||
|
|
||||||
if not suppress_graceful_exits:
|
if not suppress_graceful_exits:
|
||||||
raise trio_to_raise from (aio_err or trio_err)
|
raise trio_to_raise from raise_from
|
||||||
|
|
||||||
if trio_to_raise:
|
if trio_to_raise:
|
||||||
match (
|
match (
|
||||||
|
@ -1101,7 +1167,7 @@ async def translate_aio_errors(
|
||||||
)
|
)
|
||||||
return
|
return
|
||||||
case _:
|
case _:
|
||||||
raise trio_to_raise from (aio_err or trio_err)
|
raise trio_to_raise from raise_from
|
||||||
|
|
||||||
# Check if the asyncio-side is the cause of the trio-side
|
# Check if the asyncio-side is the cause of the trio-side
|
||||||
# error.
|
# error.
|
||||||
|
@ -1167,7 +1233,6 @@ async def run_task(
|
||||||
|
|
||||||
@acm
|
@acm
|
||||||
async def open_channel_from(
|
async def open_channel_from(
|
||||||
|
|
||||||
target: Callable[..., Any],
|
target: Callable[..., Any],
|
||||||
suppress_graceful_exits: bool = True,
|
suppress_graceful_exits: bool = True,
|
||||||
**target_kwargs,
|
**target_kwargs,
|
||||||
|
@ -1201,7 +1266,6 @@ async def open_channel_from(
|
||||||
# deliver stream handle upward
|
# deliver stream handle upward
|
||||||
yield first, chan
|
yield first, chan
|
||||||
except trio.Cancelled as taskc:
|
except trio.Cancelled as taskc:
|
||||||
# await tractor.pause(shield=True) # ya it worx ;)
|
|
||||||
if cs.cancel_called:
|
if cs.cancel_called:
|
||||||
if isinstance(chan._trio_to_raise, AsyncioCancelled):
|
if isinstance(chan._trio_to_raise, AsyncioCancelled):
|
||||||
log.cancel(
|
log.cancel(
|
||||||
|
|
|
@ -31,7 +31,7 @@ from ._broadcast import (
|
||||||
)
|
)
|
||||||
from ._beg import (
|
from ._beg import (
|
||||||
collapse_eg as collapse_eg,
|
collapse_eg as collapse_eg,
|
||||||
maybe_collapse_eg as maybe_collapse_eg,
|
get_collapsed_eg as get_collapsed_eg,
|
||||||
is_multi_cancelled as is_multi_cancelled,
|
is_multi_cancelled as is_multi_cancelled,
|
||||||
)
|
)
|
||||||
from ._taskc import (
|
from ._taskc import (
|
||||||
|
|
|
@ -15,8 +15,9 @@
|
||||||
# along with this program. If not, see <https://www.gnu.org/licenses/>.
|
# along with this program. If not, see <https://www.gnu.org/licenses/>.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
`BaseExceptionGroup` related utils and helpers pertaining to
|
`BaseExceptionGroup` utils and helpers pertaining to
|
||||||
first-class-`trio` from a historical perspective B)
|
first-class-`trio` from a "historical" perspective, like "loose
|
||||||
|
exception group" task-nurseries.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
from contextlib import (
|
from contextlib import (
|
||||||
|
@ -24,27 +25,84 @@ from contextlib import (
|
||||||
)
|
)
|
||||||
from typing import (
|
from typing import (
|
||||||
Literal,
|
Literal,
|
||||||
|
Type,
|
||||||
)
|
)
|
||||||
|
|
||||||
import trio
|
import trio
|
||||||
|
# from trio._core._concat_tb import (
|
||||||
|
# concat_tb,
|
||||||
|
# )
|
||||||
|
|
||||||
|
|
||||||
def maybe_collapse_eg(
|
# XXX NOTE
|
||||||
beg: BaseExceptionGroup,
|
# taken verbatim from `trio._core._run` except,
|
||||||
|
# - remove the NONSTRICT_EXCEPTIONGROUP_NOTE deprecation-note
|
||||||
|
# guard-check; we know we want an explicit collapse.
|
||||||
|
# - mask out tb rewriting in collapse case, i don't think it really
|
||||||
|
# matters?
|
||||||
|
#
|
||||||
|
def collapse_exception_group(
|
||||||
|
excgroup: BaseExceptionGroup[BaseException],
|
||||||
) -> BaseException:
|
) -> BaseException:
|
||||||
|
"""Recursively collapse any single-exception groups into that single contained
|
||||||
|
exception.
|
||||||
|
|
||||||
|
"""
|
||||||
|
exceptions = list(excgroup.exceptions)
|
||||||
|
modified = False
|
||||||
|
for i, exc in enumerate(exceptions):
|
||||||
|
if isinstance(exc, BaseExceptionGroup):
|
||||||
|
new_exc = collapse_exception_group(exc)
|
||||||
|
if new_exc is not exc:
|
||||||
|
modified = True
|
||||||
|
exceptions[i] = new_exc
|
||||||
|
|
||||||
|
if (
|
||||||
|
len(exceptions) == 1
|
||||||
|
and isinstance(excgroup, BaseExceptionGroup)
|
||||||
|
|
||||||
|
# XXX trio's loose-setting condition..
|
||||||
|
# and NONSTRICT_EXCEPTIONGROUP_NOTE in getattr(excgroup, "__notes__", ())
|
||||||
|
):
|
||||||
|
# exceptions[0].__traceback__ = concat_tb(
|
||||||
|
# excgroup.__traceback__,
|
||||||
|
# exceptions[0].__traceback__,
|
||||||
|
# )
|
||||||
|
return exceptions[0]
|
||||||
|
elif modified:
|
||||||
|
return excgroup.derive(exceptions)
|
||||||
|
else:
|
||||||
|
return excgroup
|
||||||
|
|
||||||
|
|
||||||
|
def get_collapsed_eg(
|
||||||
|
beg: BaseExceptionGroup,
|
||||||
|
|
||||||
|
bp: bool = False,
|
||||||
|
) -> BaseException|None:
|
||||||
'''
|
'''
|
||||||
If the input beg can collapse to a single non-eg sub-exception,
|
If the input beg can collapse to a single sub-exception which is
|
||||||
return it instead.
|
itself **not** an eg, return it.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
if len(excs := beg.exceptions) == 1:
|
maybe_exc = collapse_exception_group(beg)
|
||||||
return excs[0]
|
if maybe_exc is beg:
|
||||||
|
return None
|
||||||
|
|
||||||
|
return maybe_exc
|
||||||
|
|
||||||
return beg
|
|
||||||
|
|
||||||
|
|
||||||
@acm
|
@acm
|
||||||
async def collapse_eg():
|
async def collapse_eg(
|
||||||
|
hide_tb: bool = True,
|
||||||
|
|
||||||
|
# XXX, for ex. will always show begs containing single taskc
|
||||||
|
ignore: set[Type[BaseException]] = {
|
||||||
|
# trio.Cancelled,
|
||||||
|
},
|
||||||
|
add_notes: bool = True,
|
||||||
|
):
|
||||||
'''
|
'''
|
||||||
If `BaseExceptionGroup` raised in the body scope is
|
If `BaseExceptionGroup` raised in the body scope is
|
||||||
"collapse-able" (in the same way that
|
"collapse-able" (in the same way that
|
||||||
|
@ -52,15 +110,44 @@ async def collapse_eg():
|
||||||
only raise the lone emedded non-eg in in place.
|
only raise the lone emedded non-eg in in place.
|
||||||
|
|
||||||
'''
|
'''
|
||||||
|
__tracebackhide__: bool = hide_tb
|
||||||
try:
|
try:
|
||||||
yield
|
yield
|
||||||
except* BaseException as beg:
|
except BaseExceptionGroup as _beg:
|
||||||
|
beg = _beg
|
||||||
if (
|
if (
|
||||||
exc := maybe_collapse_eg(beg)
|
(exc := get_collapsed_eg(beg))
|
||||||
) is not beg:
|
and
|
||||||
raise exc
|
type(exc) not in ignore
|
||||||
|
):
|
||||||
|
|
||||||
raise beg
|
# TODO? report number of nested groups it was collapsed
|
||||||
|
# *from*?
|
||||||
|
if add_notes:
|
||||||
|
from_group_note: str = (
|
||||||
|
'( ^^^ this exc was collapsed from a group ^^^ )\n'
|
||||||
|
)
|
||||||
|
if (
|
||||||
|
from_group_note
|
||||||
|
not in
|
||||||
|
getattr(exc, "__notes__", ())
|
||||||
|
):
|
||||||
|
exc.add_note(from_group_note)
|
||||||
|
|
||||||
|
# raise exc
|
||||||
|
# ^^ this will leave the orig beg tb above with the
|
||||||
|
# "during the handling of <beg> the following.."
|
||||||
|
# So, instead do..
|
||||||
|
#
|
||||||
|
if cause := exc.__cause__:
|
||||||
|
raise exc from cause
|
||||||
|
else:
|
||||||
|
# suppress "during handling of <the beg>"
|
||||||
|
# output in tb/console.
|
||||||
|
raise exc from None
|
||||||
|
|
||||||
|
# keep original
|
||||||
|
raise # beg
|
||||||
|
|
||||||
|
|
||||||
def is_multi_cancelled(
|
def is_multi_cancelled(
|
||||||
|
|
|
@ -41,6 +41,9 @@ import trio
|
||||||
from tractor._state import current_actor
|
from tractor._state import current_actor
|
||||||
from tractor.log import get_logger
|
from tractor.log import get_logger
|
||||||
# from ._beg import collapse_eg
|
# from ._beg import collapse_eg
|
||||||
|
# from ._taskc import (
|
||||||
|
# maybe_raise_from_masking_exc,
|
||||||
|
# )
|
||||||
|
|
||||||
|
|
||||||
if TYPE_CHECKING:
|
if TYPE_CHECKING:
|
||||||
|
@ -106,6 +109,9 @@ async def _enter_and_wait(
|
||||||
async def gather_contexts(
|
async def gather_contexts(
|
||||||
mngrs: Sequence[AsyncContextManager[T]],
|
mngrs: Sequence[AsyncContextManager[T]],
|
||||||
|
|
||||||
|
# caller can provide their own scope
|
||||||
|
tn: trio.Nursery|None = None,
|
||||||
|
|
||||||
) -> AsyncGenerator[
|
) -> AsyncGenerator[
|
||||||
tuple[
|
tuple[
|
||||||
T | None,
|
T | None,
|
||||||
|
@ -148,17 +154,22 @@ async def gather_contexts(
|
||||||
'`.trionics.gather_contexts()` input mngrs is empty?\n'
|
'`.trionics.gather_contexts()` input mngrs is empty?\n'
|
||||||
'\n'
|
'\n'
|
||||||
'Did try to use inline generator syntax?\n'
|
'Did try to use inline generator syntax?\n'
|
||||||
'Use a non-lazy iterator or sequence-type intead!\n'
|
'Check that list({mngrs}) works!\n'
|
||||||
|
# 'or sequence-type intead!\n'
|
||||||
|
# 'Use a non-lazy iterator or sequence-type intead!\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
try:
|
||||||
async with (
|
async with (
|
||||||
|
#
|
||||||
|
# ?TODO, does including these (eg-collapsing,
|
||||||
|
# taskc-unmasking) improve tb noise-reduction/legibility?
|
||||||
|
#
|
||||||
# collapse_eg(),
|
# collapse_eg(),
|
||||||
trio.open_nursery(
|
maybe_open_nursery(
|
||||||
strict_exception_groups=False,
|
nursery=tn,
|
||||||
# ^XXX^ TODO? soo roll our own then ??
|
|
||||||
# -> since we kinda want the "if only one `.exception` then
|
|
||||||
# just raise that" interface?
|
|
||||||
) as tn,
|
) as tn,
|
||||||
|
# maybe_raise_from_masking_exc(),
|
||||||
):
|
):
|
||||||
for mngr in mngrs:
|
for mngr in mngrs:
|
||||||
tn.start_soon(
|
tn.start_soon(
|
||||||
|
@ -170,11 +181,12 @@ async def gather_contexts(
|
||||||
seed,
|
seed,
|
||||||
)
|
)
|
||||||
|
|
||||||
# deliver control once all managers have started up
|
# deliver control to caller once all ctx-managers have
|
||||||
|
# started (yielded back to us).
|
||||||
await all_entered.wait()
|
await all_entered.wait()
|
||||||
|
|
||||||
try:
|
|
||||||
yield tuple(unwrapped.values())
|
yield tuple(unwrapped.values())
|
||||||
|
parent_exit.set()
|
||||||
|
|
||||||
finally:
|
finally:
|
||||||
# XXX NOTE: this is ABSOLUTELY REQUIRED to avoid
|
# XXX NOTE: this is ABSOLUTELY REQUIRED to avoid
|
||||||
# the following wacky bug:
|
# the following wacky bug:
|
||||||
|
@ -233,6 +245,9 @@ async def maybe_open_context(
|
||||||
kwargs: dict = {},
|
kwargs: dict = {},
|
||||||
key: Hashable | Callable[..., Hashable] = None,
|
key: Hashable | Callable[..., Hashable] = None,
|
||||||
|
|
||||||
|
# caller can provide their own scope
|
||||||
|
tn: trio.Nursery|None = None,
|
||||||
|
|
||||||
) -> AsyncIterator[tuple[bool, T]]:
|
) -> AsyncIterator[tuple[bool, T]]:
|
||||||
'''
|
'''
|
||||||
Maybe open an async-context-manager (acm) if there is not already
|
Maybe open an async-context-manager (acm) if there is not already
|
||||||
|
@ -265,6 +280,22 @@ async def maybe_open_context(
|
||||||
# have it not be closed until all consumers have exited (which is
|
# have it not be closed until all consumers have exited (which is
|
||||||
# currently difficult to implement any other way besides using our
|
# currently difficult to implement any other way besides using our
|
||||||
# pre-allocated runtime instance..)
|
# pre-allocated runtime instance..)
|
||||||
|
if tn:
|
||||||
|
# TODO, assert tn is eventual parent of this task!
|
||||||
|
task: trio.Task = trio.lowlevel.current_task()
|
||||||
|
task_tn: trio.Nursery = task.parent_nursery
|
||||||
|
if not tn._cancel_status.encloses(
|
||||||
|
task_tn._cancel_status
|
||||||
|
):
|
||||||
|
raise RuntimeError(
|
||||||
|
f'Mis-nesting of task under provided {tn} !?\n'
|
||||||
|
f'Current task is NOT a child(-ish)!!\n'
|
||||||
|
f'\n'
|
||||||
|
f'task: {task}\n'
|
||||||
|
f'task_tn: {task_tn}\n'
|
||||||
|
)
|
||||||
|
service_n = tn
|
||||||
|
else:
|
||||||
service_n: trio.Nursery = current_actor()._service_n
|
service_n: trio.Nursery = current_actor()._service_n
|
||||||
|
|
||||||
# TODO: is there any way to allocate
|
# TODO: is there any way to allocate
|
||||||
|
@ -273,32 +304,70 @@ async def maybe_open_context(
|
||||||
# async with maybe_open_nursery(_Cache.service_n) as service_n:
|
# async with maybe_open_nursery(_Cache.service_n) as service_n:
|
||||||
# _Cache.service_n = service_n
|
# _Cache.service_n = service_n
|
||||||
|
|
||||||
|
cache_miss_ke: KeyError|None = None
|
||||||
|
maybe_taskc: trio.Cancelled|None = None
|
||||||
try:
|
try:
|
||||||
# **critical section** that should prevent other tasks from
|
# **critical section** that should prevent other tasks from
|
||||||
# checking the _Cache until complete otherwise the scheduler
|
# checking the _Cache until complete otherwise the scheduler
|
||||||
# may switch and by accident we create more then one resource.
|
# may switch and by accident we create more then one resource.
|
||||||
yielded = _Cache.values[ctx_key]
|
yielded = _Cache.values[ctx_key]
|
||||||
|
|
||||||
except KeyError:
|
except KeyError as _ke:
|
||||||
log.debug(f'Allocating new {acm_func} for {ctx_key}')
|
# XXX, stay mutexed up to cache-miss yield
|
||||||
|
try:
|
||||||
|
cache_miss_ke = _ke
|
||||||
|
log.debug(
|
||||||
|
f'Allocating new @acm-func entry\n'
|
||||||
|
f'ctx_key={ctx_key}\n'
|
||||||
|
f'acm_func={acm_func}\n'
|
||||||
|
)
|
||||||
mngr = acm_func(**kwargs)
|
mngr = acm_func(**kwargs)
|
||||||
resources = _Cache.resources
|
resources = _Cache.resources
|
||||||
assert not resources.get(ctx_key), f'Resource exists? {ctx_key}'
|
assert not resources.get(ctx_key), f'Resource exists? {ctx_key}'
|
||||||
resources[ctx_key] = (service_n, trio.Event())
|
resources[ctx_key] = (service_n, trio.Event())
|
||||||
|
yielded: Any = await service_n.start(
|
||||||
# sync up to the mngr's yielded value
|
|
||||||
yielded = await service_n.start(
|
|
||||||
_Cache.run_ctx,
|
_Cache.run_ctx,
|
||||||
mngr,
|
mngr,
|
||||||
ctx_key,
|
ctx_key,
|
||||||
)
|
)
|
||||||
_Cache.users += 1
|
_Cache.users += 1
|
||||||
|
finally:
|
||||||
|
# XXX, since this runs from an `except` it's a checkpoint
|
||||||
|
# whih can be `trio.Cancelled`-masked.
|
||||||
|
#
|
||||||
|
# NOTE, in that case the mutex is never released by the
|
||||||
|
# (first and) caching task and **we can't** simply shield
|
||||||
|
# bc that will inf-block on the `await
|
||||||
|
# no_more_users.wait()`.
|
||||||
|
#
|
||||||
|
# SO just always unlock!
|
||||||
lock.release()
|
lock.release()
|
||||||
yield False, yielded
|
|
||||||
|
try:
|
||||||
|
yield (
|
||||||
|
False, # cache_hit = "no"
|
||||||
|
yielded,
|
||||||
|
)
|
||||||
|
except trio.Cancelled as taskc:
|
||||||
|
maybe_taskc = taskc
|
||||||
|
log.cancel(
|
||||||
|
f'Cancelled from cache-miss entry\n'
|
||||||
|
f'\n'
|
||||||
|
f'ctx_key: {ctx_key!r}\n'
|
||||||
|
f'mngr: {mngr!r}\n'
|
||||||
|
)
|
||||||
|
# XXX, always unset ke from cancelled context
|
||||||
|
# since we never consider it a masked exc case!
|
||||||
|
# - bc this can be called directly ty `._rpc._invoke()`?
|
||||||
|
#
|
||||||
|
if maybe_taskc.__context__ is cache_miss_ke:
|
||||||
|
maybe_taskc.__context__ = None
|
||||||
|
|
||||||
|
raise taskc
|
||||||
|
|
||||||
else:
|
else:
|
||||||
_Cache.users += 1
|
_Cache.users += 1
|
||||||
log.runtime(
|
log.debug(
|
||||||
f'Re-using cached resource for user {_Cache.users}\n\n'
|
f'Re-using cached resource for user {_Cache.users}\n\n'
|
||||||
f'{ctx_key!r} -> {type(yielded)}\n'
|
f'{ctx_key!r} -> {type(yielded)}\n'
|
||||||
|
|
||||||
|
@ -308,9 +377,19 @@ async def maybe_open_context(
|
||||||
# f'{ctx_key!r} -> {yielded!r}\n'
|
# f'{ctx_key!r} -> {yielded!r}\n'
|
||||||
)
|
)
|
||||||
lock.release()
|
lock.release()
|
||||||
yield True, yielded
|
yield (
|
||||||
|
True, # cache_hit = "yes"
|
||||||
|
yielded,
|
||||||
|
)
|
||||||
|
|
||||||
finally:
|
finally:
|
||||||
|
if lock.locked():
|
||||||
|
stats: trio.LockStatistics = lock.statistics()
|
||||||
|
log.error(
|
||||||
|
f'Lock left locked by last owner !?\n'
|
||||||
|
f'{stats}\n'
|
||||||
|
)
|
||||||
|
|
||||||
_Cache.users -= 1
|
_Cache.users -= 1
|
||||||
|
|
||||||
if yielded is not None:
|
if yielded is not None:
|
||||||
|
|
|
@ -22,7 +22,10 @@ from __future__ import annotations
|
||||||
from contextlib import (
|
from contextlib import (
|
||||||
asynccontextmanager as acm,
|
asynccontextmanager as acm,
|
||||||
)
|
)
|
||||||
from typing import TYPE_CHECKING
|
from typing import (
|
||||||
|
Type,
|
||||||
|
TYPE_CHECKING,
|
||||||
|
)
|
||||||
|
|
||||||
import trio
|
import trio
|
||||||
from tractor.log import get_logger
|
from tractor.log import get_logger
|
||||||
|
@ -65,7 +68,6 @@ def find_masked_excs(
|
||||||
#
|
#
|
||||||
@acm
|
@acm
|
||||||
async def maybe_raise_from_masking_exc(
|
async def maybe_raise_from_masking_exc(
|
||||||
tn: trio.Nursery|None = None,
|
|
||||||
unmask_from: (
|
unmask_from: (
|
||||||
BaseException|
|
BaseException|
|
||||||
tuple[BaseException]
|
tuple[BaseException]
|
||||||
|
@ -74,15 +76,26 @@ async def maybe_raise_from_masking_exc(
|
||||||
raise_unmasked: bool = True,
|
raise_unmasked: bool = True,
|
||||||
extra_note: str = (
|
extra_note: str = (
|
||||||
'This can occurr when,\n'
|
'This can occurr when,\n'
|
||||||
' - a `trio.Nursery` scope embeds a `finally:`-block '
|
'\n'
|
||||||
'which executes a checkpoint!'
|
' - a `trio.Nursery/CancelScope` embeds a `finally/except:`-block '
|
||||||
|
'which execs an un-shielded checkpoint!'
|
||||||
#
|
#
|
||||||
# ^TODO? other cases?
|
# ^TODO? other cases?
|
||||||
),
|
),
|
||||||
|
|
||||||
always_warn_on: tuple[BaseException] = (
|
always_warn_on: tuple[Type[BaseException]] = (
|
||||||
trio.Cancelled,
|
trio.Cancelled,
|
||||||
),
|
),
|
||||||
|
|
||||||
|
# don't ever unmask or warn on any masking pair,
|
||||||
|
# {<masked-excT-key> -> <masking-excT-value>}
|
||||||
|
never_warn_on: dict[
|
||||||
|
Type[BaseException],
|
||||||
|
Type[BaseException],
|
||||||
|
] = {
|
||||||
|
KeyboardInterrupt: trio.Cancelled,
|
||||||
|
trio.Cancelled: trio.Cancelled,
|
||||||
|
},
|
||||||
# ^XXX, special case(s) where we warn-log bc likely
|
# ^XXX, special case(s) where we warn-log bc likely
|
||||||
# there will be no operational diff since the exc
|
# there will be no operational diff since the exc
|
||||||
# is always expected to be consumed.
|
# is always expected to be consumed.
|
||||||
|
@ -104,81 +117,91 @@ async def maybe_raise_from_masking_exc(
|
||||||
individual sub-excs but maintain the eg-parent's form right?
|
individual sub-excs but maintain the eg-parent's form right?
|
||||||
|
|
||||||
'''
|
'''
|
||||||
|
if not isinstance(unmask_from, tuple):
|
||||||
|
raise ValueError(
|
||||||
|
f'Invalid unmask_from = {unmask_from!r}\n'
|
||||||
|
f'Must be a `tuple[Type[BaseException]]`.\n'
|
||||||
|
)
|
||||||
|
|
||||||
from tractor.devx.debug import (
|
from tractor.devx.debug import (
|
||||||
BoxedMaybeException,
|
BoxedMaybeException,
|
||||||
pause,
|
|
||||||
)
|
)
|
||||||
boxed_maybe_exc = BoxedMaybeException(
|
boxed_maybe_exc = BoxedMaybeException(
|
||||||
raise_on_exit=raise_unmasked,
|
raise_on_exit=raise_unmasked,
|
||||||
)
|
)
|
||||||
matching: list[BaseException]|None = None
|
matching: list[BaseException]|None = None
|
||||||
maybe_eg: ExceptionGroup|None
|
try:
|
||||||
|
|
||||||
if tn:
|
|
||||||
try: # handle egs
|
|
||||||
yield boxed_maybe_exc
|
yield boxed_maybe_exc
|
||||||
return
|
return
|
||||||
except* unmask_from as _maybe_eg:
|
except BaseException as _bexc:
|
||||||
maybe_eg = _maybe_eg
|
bexc = _bexc
|
||||||
|
if isinstance(bexc, BaseExceptionGroup):
|
||||||
matches: ExceptionGroup
|
matches: ExceptionGroup
|
||||||
matches, _ = maybe_eg.split(
|
matches, _ = bexc.split(unmask_from)
|
||||||
|
if matches:
|
||||||
|
matching = matches.exceptions
|
||||||
|
|
||||||
|
elif (
|
||||||
unmask_from
|
unmask_from
|
||||||
)
|
and
|
||||||
if not matches:
|
type(bexc) in unmask_from
|
||||||
raise
|
):
|
||||||
|
matching = [bexc]
|
||||||
matching: list[BaseException] = matches.exceptions
|
|
||||||
else:
|
|
||||||
try: # handle non-egs
|
|
||||||
yield boxed_maybe_exc
|
|
||||||
return
|
|
||||||
except unmask_from as _maybe_exc:
|
|
||||||
maybe_exc = _maybe_exc
|
|
||||||
matching: list[BaseException] = [
|
|
||||||
maybe_exc
|
|
||||||
]
|
|
||||||
|
|
||||||
# XXX, only unmask-ed for debuggin!
|
|
||||||
# TODO, remove eventually..
|
|
||||||
except BaseException as _berr:
|
|
||||||
berr = _berr
|
|
||||||
await pause(shield=True)
|
|
||||||
raise berr
|
|
||||||
|
|
||||||
if matching is None:
|
if matching is None:
|
||||||
raise
|
raise
|
||||||
|
|
||||||
masked: list[tuple[BaseException, BaseException]] = []
|
masked: list[tuple[BaseException, BaseException]] = []
|
||||||
for exc_match in matching:
|
for exc_match in matching:
|
||||||
|
|
||||||
if exc_ctx := find_masked_excs(
|
if exc_ctx := find_masked_excs(
|
||||||
maybe_masker=exc_match,
|
maybe_masker=exc_match,
|
||||||
unmask_from={unmask_from},
|
unmask_from=set(unmask_from),
|
||||||
):
|
):
|
||||||
masked.append((exc_ctx, exc_match))
|
masked.append((
|
||||||
|
exc_ctx,
|
||||||
|
exc_match,
|
||||||
|
))
|
||||||
boxed_maybe_exc.value = exc_match
|
boxed_maybe_exc.value = exc_match
|
||||||
note: str = (
|
note: str = (
|
||||||
f'\n'
|
f'\n'
|
||||||
f'^^WARNING^^ the above {exc_ctx!r} was masked by a {unmask_from!r}\n'
|
f'^^WARNING^^\n'
|
||||||
|
f'the above {type(exc_ctx)!r} was masked by a {type(exc_match)!r}\n'
|
||||||
)
|
)
|
||||||
if extra_note:
|
if extra_note:
|
||||||
note += (
|
note += (
|
||||||
f'\n'
|
f'\n'
|
||||||
f'{extra_note}\n'
|
f'{extra_note}\n'
|
||||||
)
|
)
|
||||||
|
|
||||||
|
do_warn: bool = (
|
||||||
|
never_warn_on.get(
|
||||||
|
type(exc_ctx) # masking type
|
||||||
|
)
|
||||||
|
is not
|
||||||
|
type(exc_match) # masked type
|
||||||
|
)
|
||||||
|
|
||||||
|
if do_warn:
|
||||||
exc_ctx.add_note(note)
|
exc_ctx.add_note(note)
|
||||||
|
|
||||||
if type(exc_match) in always_warn_on:
|
if (
|
||||||
|
do_warn
|
||||||
|
and
|
||||||
|
type(exc_match) in always_warn_on
|
||||||
|
):
|
||||||
log.warning(note)
|
log.warning(note)
|
||||||
|
|
||||||
# await tractor.pause(shield=True)
|
if (
|
||||||
if raise_unmasked:
|
do_warn
|
||||||
|
and
|
||||||
|
raise_unmasked
|
||||||
|
):
|
||||||
if len(masked) < 2:
|
if len(masked) < 2:
|
||||||
raise exc_ctx from exc_match
|
raise exc_ctx from exc_match
|
||||||
else:
|
|
||||||
# ?TODO, see above but, possibly unmasking sub-exc
|
# ??TODO, see above but, possibly unmasking sub-exc
|
||||||
# entries if there are > 1
|
# entries if there are > 1
|
||||||
await pause(shield=True)
|
# else:
|
||||||
|
# await pause(shield=True)
|
||||||
else:
|
else:
|
||||||
raise
|
raise
|
||||||
|
|
Loading…
Reference in New Issue