async_scope
– Creating scopes for non-sequential concurrencyDocument #: | D2519R0 |
Date: | 2024-06-13 |
Project: | Programming Language C++ |
Audience: |
SG1 Parallelism and Concurrency LEWG Library Evolution |
Reply-to: |
Kirk Shoop <kirk.shoop@gmail.com> Lee Howes <lwh@fb.com> Lucian Radu Teodorescu <lucteo@lucteo.ro> |
A major precept of [P2300R7] is
structured concurrency. The
start_detached
and
ensure_started
algorithms are
motivated by some important scenarios. Not every
async-function
has a
clear chain of work to consume or block on the result. The problem with
these algorithms is that they provide unstructured concurrency. This is
an unnecessary and unwelcome and undesirable property for concurrency.
Using these algorithms leads to problems with lifetimes that are often
‘fixed’ using shared_ptr
for
ad-hoc garbage collection.
This paper describes the
counting_scope
async-object
. A
counting_scope
would be used to
spawn many
async-function
s safely
inside an enclosing
async-function
.
The async-function
s
spawned with a counting_scope
can be running on any execution context. The
counting_scope
async-object
has only
one concern, which is to provide an
async-object
that will
destruct only after all the
async-function
s
spawned by the counting_scope
have completed.
The general concept of an async scope to manage work has been deployed broadly in Meta’s folly [asyncscopefolly] to safely launch awaitables in Folly’s coro library [corofolly] and in Facebook’s libunifex library [asyncscopeunifex] where it is designed to be used with the sender/receiver pattern.
async-object
The definition of an
async-object
, and a
description of how an
async-object
attaches
to an enclosing
async-function
, can be
found in [P2849R0]. An
async-object
is
attached to an enclosing
async-function
in the
same sense that a C++ object is attached to an enclosing C++ function.
The enclosing
async-function
always
contains the construction use and destruction of all contained
async-object
s.
The paper that describes how to build an
async-object
was
written when years of implementation experience with
async_scope
led to the discovery
of a general pattern for all
async-object
s,
including thread-pools, sockets, files, allocators, etc..
Now the counting_scope
is
just the first
async-object
proposed
for standardization. The paper is greatly simplified by moving the
material related to attaching a
counting_scope
to an enclosing
async-function
to the
[P2849R0] paper.
Let us assume the following code:
namespace ex = std::execution;
struct work_context;
struct work_item;
void do_work(work_context&, work_item*);
::vector<work_item*> get_work_items();
std
int main() {
{8};
static_thread_pool my_pool// create a global context for the application
work_context ctx;
::vector<work_item*> items = get_work_items();
stdfor ( auto item: items ) {
// Spawn some work dynamically
::sender auto snd = ex::transfer_just(my_pool.get_scheduler(), item)
ex| ex::then([&](work_item* item){ do_work(ctx, item); });
::start_detached(std::move(snd));
ex}
// `ctx` and `my_pool` is destroyed
}
In this example we are creating parallel work based on the given
input vector. All the work will be spawned on the local
static_thread_pool
object, and
will use a shared work_context
object.
Because the number of work items is dynamic, one is forced to use
start_detached()
from [P2300R7] (or something equivalent) to
dynamically spawn work. [P2300R7] doesn’t
provide any facilities to spawn dynamic work and return a sender (i.e.,
something like when_all
but with
a dynamic number of input senders).
Using start_detached()
here
follows the fire-and-forget style, meaning that we have no
control over, or awareness of, the termination of the
async-function
being
spawned.
At the end of the function, we are destroying the
work_context
and the
static_thread_pool
. But at that
point, we don’t know whether all the spawned
async-function
s have
completed. If there are still
async-function
s that
are not yet complete, this might lead to crashes.
NOTE: As described in [P2849R0], the
work_context
and
static_thread_pool
objects need
to be async-object
s
because they are used by
async-function
s.
[P2300R7] doesn’t give us out-of-the-box facilities to use in solving these types of problems.
This paper proposes the
counting_scope
facility that
would help us avoid the invalid behavior. With
counting_scope
, one might write
safe code this way:
int main() {
auto work = ex::use_resources( // NEW! see P2849R0
[](work_context ctx, static_thread_pool my_pool, counting_scope my_work_scope){
::vector<work_item*> items = get_work_items();
stdfor ( auto item: items ) {
// Spawn some work dynamically
::sender auto snd = ex::transfer_just(my_pool.get_scheduler(), item)
ex| ex::then([&](work_item* item){ do_work(ctx, item); });
::spawn(my_work_scope, std::move(snd)); // MODIFIED!
ex}
},
<work_context_resource>(), // create a global context for the application
make_deferred<static_thread_pool_resource>(8), // create a global thread pool
make_deferred<counting_scope_resource>()); // NEW!
make_deferred::sync_wait(work); // NEW!
this_thread}
The newly introduced
counting_scope_resource
object
allows us to attach the dynamic work we are spawning to the enclosing
use_resources
see [P2849R0]. This structure ensures that
the static_thread_pool
and
work_context
destruct after the
spawned async-function
s complete.
Please see below for more examples.
counting_scope
is step forward
towards Structured ConcurrencyStructured Programming [Dahl72] transformed the software world by making it easier to reason about the code, and build large software from simpler constructs. We want to achieve the same effect on concurrent programming by ensuring that we structure our concurrent code. [P2300R7] makes a big step in that direction, but, by itself, it doesn’t fully realize the principles of Structured Programming. More specifically, it doesn’t always ensure that we can apply the single entry, single exit point principle.
The start_detached
sender
algorithm fails this principle by behaving like a
GOTO
instruction. By calling
start_detached
we essentially
continue in two places: in the same function, and on different thread
that executes the given work. Moreover, the lifetime of the work started
by start_detached
cannot be
bound to the local context. This will prevent local reasoning, which
will make the program harder to understand.
To properly structure our concurrency, we need an abstraction that
ensures that all the
async-function
s being
spawned are attached to an enclosing
async-function
. This is
the goal of counting_scope
.
counting_scope
may increase
consensus for P2300Although [P2300R7] is generally considered a strong improvement on concurrency in C++, various people voted against introducing this into the C++ standard.
This paper is intended to increase consensus for [P2300R7].
Use a counting_scope
in
combination with a
system_context
from [P2079R2] to spawn work from within a
task and join it later:
using namespace std::execution;
int result = 0;
int main() {
auto work = ex::use_resources( // NEW! see P2849R0
[&result](system_context ctx, counting_scope scope){
auto sch = ctx.scheduler();
scheduler
auto val = on(
sender () | then([&result, sch, scope](auto sched) {
sch, justint val = 13;
auto print_sender = just() | then([val]{
::cout << "Hello world! Have an int with value: " << val << "\n";
std});
// spawn the print sender on sched to make sure it
// completes before shutdown
::spawn(scope, on(sch, std::move(print_sender)));
ex
return val;
})
) | then([&result](auto val){result = val});
::spawn(scope, std::move(val));
ex},
<system_execution_resource>(8), // create a global thread pool
make_deferred<counting_scope_resource>()); // NEW!
make_deferred::sync_wait(work); // NEW!
this_thread
::cout << "Result: " << result << "\n";
std}
// The counting scope ensured that all work is safely joined, so result contains 13
In this example we use the
counting_scope
within a class to
start work when the object receives a message and to wait for that work
to complete before closing.
my_window::start()
starts the
sender using storage reserved in
my_window
for this purpose.
using namespace std::execution;
//
class my_window {
//..
// async-construction creates the
// async-object members
system_context ctx;{};
counting_scope scope
auto sch{ctx.scheduler()};
scheduler };
class my_window_resource {
//..
};
auto some_work(int id);
sender
void my_window::onMyMessage(int i) {
::spawn(this->scope, on(this->sch, some_work(i)));
ex}
void my_window::onClickClose() {
this->post(close_message{});
}
In this example we use the
counting_scope
within lexical
scope to construct an algorithm that performs parallel work. This uses
the let_value_with
[letvwthunifex]
algorithm implemented in [libunifex] which simplifies in-place
construction of a non-moveable object in the
let_value_with
algorithms’
operation-state
object.
Here foo
launches 100 tasks that
concurrently run on some scheduler provided to
foo
, through its connected
receiver, and then the tasks are asynchronously joined. In this case the
context the work is run on will be the
system_context
’s scheduler, from
[P2079R2]. This structure emulates how we
might build a parallel algorithm where each
some_work
might be operating on
a fragment of data.
using namespace std::execution;
auto some_work(int work_index);
sender
auto foo(scheduler auto sch) {
sender return ex::use_resources( // NEW! see P2849R0
[sch](counting_scope scope){
return schedule(sch)
| then([]{ std::cout << "Before tasks launch\n"; })
| then(
[sch, scope]{
// Create parallel work
for(int i = 0; i < 100; ++i)
::spawn(scope, on(sch, some_work(i)));
ex// Join the work with the help of the scope
})
;},
<counting_scope_resource>()) // NEW!
make_deferred| then([]{ std::cout << "After tasks complete\n"; })
;}
This example shows how one can write the listener loop in an HTTP
server, with the help of coroutines. The HTTP server will continuously
accept new connection and start work to handle the requests coming on
the new connections. While the listening activity is bound in the scope
of the loop, the lifetime of handling requests may exceed the scope of
the loop. We use counting_scope
to limit the lifetime of the request handling without blocking the
acceptance of new requests.
<size_t> listener(int port, io_context& ctx, static_thread_pool& pool) {
tasksize_t count{0};
// Continue only after all requests are handled
co_await use_resources(// NEW! see P2849R0
[&count, ctx, pool](listening_socket listen_sock, counting_scope work_scope) -> task<> {
while (!ctx.is_stopped()) {
// Accept a new connection
= co_await async_accept(ctx, listen_sock);
connection conn ++;
count
// Create work to handle the connection in the scope of `work_scope`
{std::move(conn), ctx, pool};
conn_data dataauto snd
sender = just()
| let_value([data = std::move(data)]() {
return handle_connection(data);
})
;::spawn(scope, std::move(snd));
work_ex}
co_return ;
},
<listening_socket_resource>(port),
make_deferred<counting_scope_resource>()); // NEW!
make_deferred// At this point, all the request handling is complete
co_return count;
}
The requirements for the async scope are:
async-scope
must
allow an arbitrary sender to be nested within the scope without eagerly
starting the sender
(nest()
).async-scope
must
constrain spawn()
to accept only
senders that complete with
void
.async-scope
must
start the given sender before
spawn()
and
spawn_future()
exit.More on these items can be found below in the sections below.
struct counting_scope {
using self_t = counting_scope; /*exposition-only*/
();
counting_scope~counting_scope();
(const self_t&) = delete;
counting_scope(self_t&&) = delete;
counting_scope& operator=(const self_t&) = delete;
self_t& operator=(self_t&&) = delete;
self_t
void
/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, spawn_t, sender_to<spawn-receiver> auto&& s) noexcept;
decays_to
template <sender_to<spawn-future-receiver> S>
<S>
spawn-future-sender/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, spawn_future_t, S&& s) noexcept;
decays_to
template <sender S>
<S>
nest-sender/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, nest_t, S&& s) noexcept;
decays_to};
The counting_scope
keeps a
counter of how many spawned
async-function
s have
not completed.
spawn()
void
/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, spawn_t, sender_to<spawn-receiver> auto&& s) noexcept; decays_to
Eagerly launches work on the
counting_scope
.
This involves a dynamic allocation of the spawned sender’s
operation-state
. The
operation-state
is
destroyed after the spawned sender completes.
This is similar to
start_detached()
from [P2300R7], but the
counted_scope
keeps track of the
spawned async-function
s.
The given sender must complete with
void
or
stopped
. The given sender is not
allowed to complete with an error; the user must explicitly handle the
errors that might appear as part of the
sender-expression
passed to spawn()
.
As spawn()
starts the given
sender synchronously, it is important that the user provides
non-blocking senders. This matches user expectations that
spawn()
is asynchronous and
avoids surprising blocking behavior at runtime. The reason for
non-blocking start is that spawn must be non-blocking. Using
spawn()
with a sender generated
by
on(sched, blocking-sender)
is a very useful pattern in this context.
NOTE: A query for non-blocking start will allow
spawn()
to be constrained to
require non-blocking start.
Usage example:
...
for (int i=0; i<100; i++)
(s, on(sched, some_work(i))); spawn
spawn_future()
template <sender_to<spawn-future-receiver> S>
<S>
spawn-future-sender/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, spawn_future_t, S&& s) noexcept; decays_to
Eagerly launches work on the
counting_scope
and returns a
spawn-future-sender
that provides access to the result of the spawned sender.
This involves a dynamic allocation of the
spawn-future-sender
state, which includes the given sender
s
’s
operation-state
, and
synchronization to resolve the race between the production of the given
sender s
’s result and the
consumption of the given sender
s
’s result. The
spawn-future-sender
state is destroyed after the given sender
s
completes and all copies of
the spawn-future-sender
have been destructed.
This is similar to
ensure_started()
from [P2300R7], but the
counted_scope
keeps track of the
spawned async-function
s.
Unlike spawn()
, the sender
given to spawn_future()
is not
constrained on a given shape. It may send different types of values, and
it can complete with errors.
It is safe to drop the sender returned from
spawn_future()
without starting
it, because the counting_scope
safely manages the destruction of the
spawn-future-sender
state.
NOTE: there is a race between the completion of the given
sender and the start of the returned sender. The race will be resolved
by the
spawn-future-sender
state.
Cancelling the returned sender, cancels the given sender
s
, but does not cancel any other
spawned sender.
If the given sender s
completes with an error, but the returned sender is dropped, the error
is dropped too.
Usage example:
...
auto snd = s.spawn_future(on(sched, key_work()))
sender | then(continue_fun);
for ( int i=0; i<10; i++)
(s, on(sched, other_work(i)));
spawnreturn when_all(s.on_empty(), std::move(snd));
nest()
template <sender S>
<S>
nest-sender/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, nest_t, S&& s) noexcept; decays_to
Returns a
nest-sender
that, when
started, adds the given sender to the count of senders that the
counting_scope
object will
require to complete before it will destruct.
A call to nest()
does not
start the given sender. A call to
nest()
is not expected to incur
allocations.
The sender returned by a call to
nest()
holds a reference to the
counting_scope
in order to add
the given sender to the count of senders when it is started. Connecting
and starting the sender returned from
nest()
will connect and start
the given sender and add the given sender to the count of senders that
the counting_scope
object will
require to complete before it will destruct.
Similar to spawn_future()
,
nest()
doesn’t constrain the
input sender to any specific shape. Any type of sender is accepted.
Unlike spawn_future()
the
returned sender does not prevent the scope from ending. It is safe to
drop the returned sender without starting it. It is UB to start the
returned sender after the
counting_scope
has been
destroyed.
As nest()
does not
immediately start the given work, it is ok to pass in blocking
senders.
One can say that nest()
is
more fundamental than spawn()
and spawn_future()
as the latter
two can be implemented in terms of
nest()
. In terms of performance,
nest()
does not introduce any
penalty. spawn()
is more
expensive than nest()
as it
needs to allocate memory for the operation.
spawn_future()
is even more
expensive than spawn()
; the
receiver needs to be type-erased and a possible race condition needs to
be resolved. nest()
does not
require allocations, so it can be used in a free-standing
environment.
Cancelling the returned sender, once it is connected and started,
cancels s
but does not cancel
the counting_scope
.
Usage example:
...
auto snd = s.nest(key_work());
sender for ( int i=0; i<10; i++)
(s, on(sched, other_work(i)));
spawnreturn on(sched, std::move(snd));
set_value()
It makes sense for
spawn_future()
and
nest()
to accept senders with
any type of completion signatures. The caller gets back a sender that
can be chained with other senders, and it doesn’t make sense to restrict
the shape of this sender.
The same reasoning doesn’t necessarily follow for
spawn()
as it returns
void
and the result of the
spawned sender is dropped. There are two main alternatives:
The current proposal goes with the second alternative. The main
reason is to make it more difficult and explicit to silently drop
result. The caller can always transform the input sender before passing
it to spawn()
to drop the values
manually.
Chosen:
spawn()
accepts only senders that advertiseset_value()
(without any parameters) in the completion signatures.
spawn()
The current proposal does not accept senders that can complete with
error given to spawn()
. This
will prevent accidental error scenarios that will terminate the
application. The user must deal with all possible errors before passing
the sender to counting_scope
.
I.e., error handling must be explicit.
Another alternative considered was to call
std::terminate()
when the sender
completes with error.
Another alternative is to silently drop the errors when receiving them. This is considered bad practice, as it will often lead to first spotting bugs in production.
Chosen:
spawn()
accepts only senders that do not callset_error()
. Explicit error handling is preferred over stopping the application, and over silently ignoring the error.
spawn()
Similar to the error case, we have the alternative of allowing or
forbidding set_stopped()
as a
completion signal. Because the goal of
counting_scope
is to track the
lifetime of the work started through it, it shouldn’t matter whether
that the work completed with success or by being stopped. As it is
assumed that sending the stop signal is the result of an explicit
choice, it makes sense to allow senders that can terminate with
set_stopped()
.
The alternative would require transforming the sender before passing
it to spawn, something like s.spawn(std::move(snd) | let_stopped([]{ return just(); ))
.
This is considered boilerplate and not helpful, as the stopped scenarios
should be implicit, and not require handling.
Chosen:
spawn()
accepts senders that complete withset_stopped()
.
spawn_future()
and nest()
Similarly to spawn()
, we can
constrain spawn_future()
and
nest()
to accept only a limited
set of senders. But, because we can attach continuations for these
senders, we would be limiting the functionality that can be expressed.
For example, the continuation can handle different types of values and
errors.
Chosen:
spawn_future()
andnest()
accept senders with any completion signatures.
start_detached()
The spawn()
method in this
paper can be used as a replacement for
start_detached
proposed in [P2300R7]. Essentially it does the same
thing, but it can also attach the spawned sender to the enclosing
async-function
.
ensure_started()
The spawn_future()
method in
this paper can be used as a replacement for
ensure_started
proposed in [P2300R7]. Essentially it does the same
thing, but it can also attach the spawned sender to the enclosing
async-function
.
This paper doesn’t support the pipe operator to be used in
conjunction with spawn()
and
spawn_future()
. One might think
that it is useful to write code like the following:
::move(snd1) | spawn(s); // returns void
stdauto snd3 = std::move(snd2) | spawn_future(s) | then(...); sender
In [P2300R7] sender
consumers do not have support for the pipe operator. As
spawn()
works similarly to
start_detached()
from [P2300R7], which is a sender consumer, if
we follow the same rationale, it makes sense not to support the pipe
operator for spawn()
.
On the other hand,
spawn_future()
is not a sender
consumer, thus we might have considered adding pipe operator to it. To
keep consistency with spawn()
,
at this point the paper doesn’t support pipe operator for
spawn_future()
.
If spawn_future()
was an
algorithm and the spawn_future()
method was removed from
counting_scope
, then the pipe
operator would be a natural and obvious fit.
counting_scope
after all nested
and spawned sender complete?stop_callback
is not a
destructor because:
request_stop()
is
asking for early completion.request_stop()
does not end
the lifetime of the operation,
set_value()
,
set_error()
and
set_stopped()
end the lifetime –
those are the destructors for an operation.request_stop()
might result
in completion with
set_stopped()
, but
set_value()
and
set_error()
are equally
valid.request_stop()
should not be
called from a destructor because: If a sync context intends to ask for
early completion of an async operation, then it needs to wait for that
operation to actually complete before continuing
(set_value()
,
set_error()
and
set_stopped()
are the
destructors for the async operation), and sync destructors must not
block.
Principles that discourage blocking in the destructor:
shared_ptr
makes it even more
scary as the destructor will potentially run at a different callstack
and executino resource each time).reinterpret_cast<>
– the
name should be long and scary.join()
is grepable and
explicit, it is not rare, it is not composable (There is a separate
blocking wait for each object. One blocking wait for many different
things to complete would be better)– this is why
async-resource
will
attach to the enclosing
async-function
.Every async-function
will join with non-blocking primitives and
sync_wait()
will be used to
block some composition of those non-blocking primitives. The
async-function
being
stopped would complete before any
async-resource
it is
using completes – without any blocking.
As is often true, naming is a difficult task.
counting_scope
A counting_scope
represents
the root of a set of nested lifetimes.
One mental model for this is a semaphore. It tracks a count of lifetimes and fires an event when the count reaches 0.
Another mental model for this is block syntax.
{}
represents the root of a set
of lifetimes of locals and temporaries and nested blocks.
Another mental model for this is a container. This is the least accurate model. This container is a value that does not contain values. This container contains a set of active senders (an active sender is not a value, it is an operation).
alternatives: async_scope
nest()
This provides a way to build a sender that, when started, adds to the
count of spawned and nested senders that
counting_scope
maintains.
nest()
does not allocate state,
call connect or call start.
nest()
is the basis operation
for counting_scope
.
spawn()
and
spawn_future()
use
nest()
to add to the count that
counting_scope
maintains, and
then they allocate, connect, and start the returned
nest-sender
.
It would be good for the name to indicate that it is a simple
operation (insert, add, embed, extend might communicate allocation,
which nest()
does not do).
alternatives: wrap()
spawn()
This provides a way to start a sender that produces
void
and add to the count that
counting_scope
maintains of
nested and spwned senders. This allocates, connects and starts the given
sender.
It would be good for the name to indicate that it is an expensive operation.
alternatives:
connect_and_start()
spawn_future()
This provides a way to start work and later ask for the result. This will allocate, connect, start and resolve the race (using synchronization primitives) between the completion of the given sender and the start of the returned sender. Since the type of the receiver supplied to the result sender is not known when the given sender starts, the receiver will be type-erased when it is connected.
It would be good for the name to be ugly, to indicate that it is a
more expensive operation than
spawn()
.
alternatives:
spawn_with_result()
namespace std::execution {
namespace { // exposition-only
struct spawn-receiver { // exposition-only
friend void set_value(spawn-receiver) noexcept;
friend void set_stopped(spawn-receiver) noexcept;
};
struct run-sender; // exposition-only
template <typename S>
struct nest-sender; // exposition-only
template <typename S>
struct spawn-future-sender; // exposition-only
}
struct counting_scope {
();
counting_scope~counting_scope();
(const counting_scope&) = delete;
counting_scope(counting_scope&&) = delete;
counting_scope& operator=(const counting_scope&) = delete;
counting_scope& operator=(counting_scope&&) = delete;
counting_scope
void
/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, spawn_t, sender_to<spawn-receiver> auto&& s) noexcept;
decays_to
template <sender_to<spawn-future-receiver> S>
<S>
spawn-future-sender/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, spawn_future_t, S&& s) noexcept;
decays_to
template <sender S>
<S>
nest-sender/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, nest_t, S&& s) noexcept;
decays_to};
struct counting_scope_resource {
using self_t = counting_scope_resource;
();
counting_scope_resource~counting_scope_resource();
(const self_t&) = delete;
counting_scope_resource(self_t&&) = delete;
counting_scope_resource& operator=(const self_t&) = delete;
self_t& operator=(self_t&&) = delete;
self_t
// Option A or Option B from P2849R0
run-sender/*implementation-defined*/ /*customization-point*/(
<self_t> auto&&, run_t) noexcept;
decays_to};
}
counting_scope::counting_scope
counting_scope::counting_scope
constructs the counting_scope
object, in the empty state.counting_scope
object.counting_scope::~counting_scope
counting_scope::~counting_scope
destructs the counting_scope
object, freeing all resources
The destructor will call
terminate()
if there is
outstanding work in the
counting_scope
object (i.e.,
work created by nest()
,
spawn()
and
spawn_future()
did not
complete).
Note: It is always safe to call the destructor after the
sender returned by on_empty()
sent the completion signal, provided that there were no calls to
nest()
,
spawn()
and
spawn_future()
since the
on-empty-sender
was
started.
counting_scope::spawn
counting_scope::spawn
is
used to eagerly start a sender while keeping the execution in the
lifetime of the counting_scope
object.operation-state
object op
will be created by
connecting the given sender to a receiver
recv
of type
spawn-receiver
.op
in its proper storage space,
the exception will be passed to the caller.op
and stop was not requested on
our stop source, then:
start(op)
is called (before
spawn()
returns).op
extends
at least until recv
is called
with a completion notification.recv
supports the
get_stop_token()
query
customization point object; this will return the stop token associated
with counting_scope
object.counting_scope
will not
be empty until recv
is
notified about the completion of the given sender.counting_scope
object to keep
track of how many operations are running at a given time.counting_scope::spawn_future
counting_scope::spawn_future
is used to eagerly start a sender in the context of the
counting_scope
object, and
returning a sender that will be triggered after the completion of the
given sender. The lifetime of the returned sender is not associated with
counting_scope
.
The returned sender has the same completion signatures as the input sender.
Effects:
operation-state
object op
will be created by
connecting the given sender to a receiver
recv
.op
in its proper storage space,
the exception will be passed to the caller.op
and stop was not requested on
our stop source, then:
start(op)
is called (before
spawn_future
returns).op
extends
at least until recv
is called
with a completion notification.rsnd
is the returned
sender, then using it has the following effects:
ext_op
be the
operation-state
object
returned by connecting rsnd
to a
receiver ext_recv
.ext_op
is started, the
completion notifications received by
recv
will be forwarded to
ext_recv
, regardless whether the
completion notification happened before starting
ext_op
or not.rsnd
or not to start
ext_op
.counting_scope
will not
be empty until one of the following is true:
rsnd
is destroyed without
being connectedrsnd
is connected but
ext_op
is destroyed without
being startedrsnd
is connected to a
receiver to return ext_op
,
ext_op
is started, and
recv
is notified about the
completion of the given senderrecv
supports the
get_stop_token()
query
customization point object; this will return a stop token object that
will be stopped when:
counting_scope
object is
stopped (i.e., by using
counting_scope::request_stop()
;rsnd
supports
get_stop_token()
query
customization point object, when stop is requested to the object
get_stop_token(rsnd)
.Note: the receiver
recv
will help the
counting_scope
object to keep
track of how many operations are running at a given time.
Note: the type of completion signal that
op
will use does not influence
the behavior of counting_scope
(i.e., counting_scope
object
behaves the same way if the sender describes a work that ends with
success, error or cancellation).
Note: cancelling the sender returned by this function
will not have an effect about the
counting_scope
object.
counting_scope::nest
counting_scope::nest
is
used to produce a
nest-sender
that, when
started, nests the sender within the lifetime of the
counting_scope
object. The given
sender will be started when the
nest-sender
is
started.
The returned sender has the same completion signatures as the input sender.
Effects:
rsnd
is the returned
nest-sender
, then using
it has the following effects:
op
be the
operation-state
object
returned by connecting the given sender to a receiver
recv
.ext_op
be the
operation-state
object
returned by connecting rsnd
to a
receiver ext_recv
.op
be stored in
ext_op
.ext_op
is started, then
op
is started and the completion
notifications received by recv
will be forwarded to
ext_recv
.op
is
stored in ext_op
, calling
nest()
cannot start the given
sender.rsnd
is connected and
ext_op
started the
counting_scope
will not be empty
until recv
is notified about the
completion of the given sender.recv
supports the
get_stop_token()
query
customization point object; this will return a stop token object that
will be stopped when:
counting_scope
object is
stopped (i.e., by using
counting_scope::request_stop()
;rsnd
supports
get_stop_token()
query
customization point object, when stop is requested to the object
get_stop_token(rsnd)
.Note: the type of completion signal that
op
will use does not influence
the behavior of counting_scope
(i.e., counting_scope
object
behaves the same way if the sender completes with success, error or
cancellation).
Note: cancelling the sender returned by this function
will not cancel the
counting_scope
object.