Corrotinas e Tarefas¶
Esta seção descreve APIs assíncronas de alto nível para trabalhar com corrotinas e tarefas.
Corrotinas¶
Source code: Lib/asyncio/coroutines.py
Corrotinas declaradas com a sintaxe async/await é a forma preferida de escrever aplicações assíncronas. Por exemplo, o seguinte trecho de código imprime “hello”, espera 1 segundo, e então imprime “world”:
>>> import asyncio
>>> async def main():
... print('hello')
... await asyncio.sleep(1)
... print('world')
>>> asyncio.run(main())
hello
world
Perceba que simplesmente chamar uma corrotina não irá agendá-la para ser executada:
>>> main()
<coroutine object main at 0x1053bb7c8>
To actually run a coroutine, asyncio provides the following mechanisms:
A função
asyncio.run()
para executar a função “main()” do ponto de entrada no nível mais alto (veja o exemplo acima.)Aguardando uma corrotina. O seguinte trecho de código exibirá “hello” após esperar por 1 segundo e, em seguida, exibirá “world” após esperar por outros 2 segundos:
import asyncio import time async def say_after(delay, what): await asyncio.sleep(delay) print(what) async def main(): print(f"started at {time.strftime('%X')}") await say_after(1, 'hello') await say_after(2, 'world') print(f"finished at {time.strftime('%X')}") asyncio.run(main())
Resultado esperado:
started at 17:13:52 hello world finished at 17:13:55
A função
asyncio.create_task()
para executar corrotinas concorrentemente comoTasks
asyncio.Vamos modificar o exemplo acima e executar duas corrotinas
say_after
concorrentemente:async def main(): task1 = asyncio.create_task( say_after(1, 'hello')) task2 = asyncio.create_task( say_after(2, 'world')) print(f"started at {time.strftime('%X')}") # Wait until both tasks are completed (should take # around 2 seconds.) await task1 await task2 print(f"finished at {time.strftime('%X')}")
Perceba que a saída esperada agora mostra que o trecho de código é executado 1 segundo mais rápido do que antes:
started at 17:14:32 hello world finished at 17:14:34
The
asyncio.TaskGroup
class provides a more modern alternative tocreate_task()
. Using this API, the last example becomes:async def main(): async with asyncio.TaskGroup() as tg: task1 = tg.create_task( say_after(1, 'hello')) task2 = tg.create_task( say_after(2, 'world')) print(f"started at {time.strftime('%X')}") # The await is implicit when the context manager exits. print(f"finished at {time.strftime('%X')}")
The timing and output should be the same as for the previous version.
Adicionado na versão 3.11:
asyncio.TaskGroup
.
Aguardáveis¶
Dizemos que um objeto é um objeto aguardável se ele pode ser usado em uma expressão await
. Muitas APIs asyncio são projetadas para aceitar aguardáveis.
Existem três tipos principais de objetos aguardáveis: corrotinas, Tarefas, e Futuros.
Corrotinas
Corrotinas Python são aguardáveis e portanto podem ser aguardadas a partir de outras corrotinas:
import asyncio
async def nested():
return 42
async def main():
# Nothing happens if we just call "nested()".
# A coroutine object is created but not awaited,
# so it *won't run at all*.
nested() # will raise a "RuntimeWarning".
# Let's do it differently now and await it:
print(await nested()) # will print "42".
asyncio.run(main())
Importante
Nesta documentação, o termo “corrotina” pode ser usado para dois conceitos intimamente relacionados:
uma função de corrotina: uma função
async def
;um objeto de corrotina: um objeto retornado ao chamar uma função de corrotina.
Tarefas
Tarefas são usadas para agendar corrotinas concorrentemente.
Quando uma corrotina é envolta em uma tarefa com funções como asyncio.create_task()
, a corrotina é automaticamente agendada para executar em breve:
import asyncio
async def nested():
return 42
async def main():
# Schedule nested() to run soon concurrently
# with "main()".
task = asyncio.create_task(nested())
# "task" can now be used to cancel "nested()", or
# can simply be awaited to wait until it is complete:
await task
asyncio.run(main())
Futuros
Um Future
é um objeto aguardável especial de baixo nível que representa um resultado eventual de uma operação assíncrona.
Quando um objeto Future é aguardado isso significa que a corrotina irá esperar até que o Future seja resolvido em algum outro local.
Objetos Future em asyncio são necessários para permitir que código baseado em função de retorno seja utilizado com async/await.
Normalmente não existe necessidade em criar objetos Future no nível de código da aplicação.
Objetos Future, algumas vezes expostos por bibliotecas e algumas APIs asyncio, podem ser aguardados:
async def main():
await function_that_returns_a_future_object()
# this is also valid:
await asyncio.gather(
function_that_returns_a_future_object(),
some_python_coroutine()
)
Um bom exemplo de uma função de baixo nível que retorna um objeto Future é loop.run_in_executor()
.
Criando Tarefas¶
Source code: Lib/asyncio/tasks.py
- asyncio.create_task(coro, *, name=None, context=None)¶
Envolva a corrotina coro em uma
Task
e agende sua execução. Retorne o objeto Task.Se name não for
None
, ele é setado como o nome da tarefa usandoTask.set_name()
.An optional keyword-only context argument allows specifying a custom
contextvars.Context
for the coro to run in. The current context copy is created when no context is provided.A tarefa é executada no laço e retornada por
get_running_loop()
,RuntimeError
é levantado se não existir nenhum loop na thread atual.Nota
asyncio.TaskGroup.create_task()
is a new alternative leveraging structural concurrency; it allows for waiting for a group of related tasks with strong safety guarantees.Importante
Mantenha uma referência para o resultado dessa função, evitando assim que uma tarefa desapareça durante a execução. O laço de eventos mantém apenas referências fracas para as tarefas. Uma tarefa que não é referenciada por nada mais pode ser removida pelo coletor de lixo a qualquer momento, antes mesmo da função ser finalizada. Para tarefas de segundo plano “atire-e-esqueça”, junte-as em uma coleção:
background_tasks = set() for i in range(10): task = asyncio.create_task(some_coro(param=i)) # Add task to the set. This creates a strong reference. background_tasks.add(task) # To prevent keeping references to finished tasks forever, # make each task remove its own reference from the set after # completion: task.add_done_callback(background_tasks.discard)
Adicionado na versão 3.7.
Alterado na versão 3.8: Adicionado o parâmetro name.
Alterado na versão 3.11: Adicionado o parâmetro context.
Task Cancellation¶
Tasks can easily and safely be cancelled.
When a task is cancelled, asyncio.CancelledError
will be raised
in the task at the next opportunity.
It is recommended that coroutines use try/finally
blocks to robustly
perform clean-up logic. In case asyncio.CancelledError
is explicitly caught, it should generally be propagated when
clean-up is complete. asyncio.CancelledError
directly subclasses
BaseException
so most code will not need to be aware of it.
The asyncio components that enable structured concurrency, like
asyncio.TaskGroup
and asyncio.timeout()
,
are implemented using cancellation internally and might misbehave if
a coroutine swallows asyncio.CancelledError
. Similarly, user code
should not generally call uncancel
.
However, in cases when suppressing asyncio.CancelledError
is
truly desired, it is necessary to also call uncancel()
to completely
remove the cancellation state.
Task Groups¶
Task groups combine a task creation API with a convenient and reliable way to wait for all tasks in the group to finish.
- class asyncio.TaskGroup¶
An asynchronous context manager holding a group of tasks. Tasks can be added to the group using
create_task()
. All tasks are awaited when the context manager exits.Adicionado na versão 3.11.
- create_task(coro, *, name=None, context=None)¶
Create a task in this task group. The signature matches that of
asyncio.create_task()
. If the task group is inactive (e.g. not yet entered, already finished, or in the process of shutting down), we will close the givencoro
.Alterado na versão 3.13: Close the given coroutine if the task group is not active.
Exemplo:
async def main():
async with asyncio.TaskGroup() as tg:
task1 = tg.create_task(some_coro(...))
task2 = tg.create_task(another_coro(...))
print(f"Both tasks have completed now: {task1.result()}, {task2.result()}")
The async with
statement will wait for all tasks in the group to finish.
While waiting, new tasks may still be added to the group
(for example, by passing tg
into one of the coroutines
and calling tg.create_task()
in that coroutine).
Once the last task has finished and the async with
block is exited,
no new tasks may be added to the group.
The first time any of the tasks belonging to the group fails
with an exception other than asyncio.CancelledError
,
the remaining tasks in the group are cancelled.
No further tasks can then be added to the group.
At this point, if the body of the async with
statement is still active
(i.e., __aexit__()
hasn’t been called yet),
the task directly containing the async with
statement is also cancelled.
The resulting asyncio.CancelledError
will interrupt an await
,
but it will not bubble out of the containing async with
statement.
Once all tasks have finished, if any tasks have failed
with an exception other than asyncio.CancelledError
,
those exceptions are combined in an
ExceptionGroup
or BaseExceptionGroup
(as appropriate; see their documentation)
which is then raised.
Two base exceptions are treated specially:
If any task fails with KeyboardInterrupt
or SystemExit
,
the task group still cancels the remaining tasks and waits for them,
but then the initial KeyboardInterrupt
or SystemExit
is re-raised instead of ExceptionGroup
or BaseExceptionGroup
.
If the body of the async with
statement exits with an exception
(so __aexit__()
is called with an exception set),
this is treated the same as if one of the tasks failed:
the remaining tasks are cancelled and then waited for,
and non-cancellation exceptions are grouped into an
exception group and raised.
The exception passed into __aexit__()
,
unless it is asyncio.CancelledError
,
is also included in the exception group.
The same special case is made for
KeyboardInterrupt
and SystemExit
as in the previous paragraph.
Task groups are careful not to mix up the internal cancellation used to
“wake up” their __aexit__()
with cancellation requests
for the task in which they are running made by other parties.
In particular, when one task group is syntactically nested in another,
and both experience an exception in one of their child tasks simultaneously,
the inner task group will process its exceptions, and then the outer task group
will receive another cancellation and process its own exceptions.
In the case where a task group is cancelled externally and also must
raise an ExceptionGroup
, it will call the parent task’s
cancel()
method. This ensures that a
asyncio.CancelledError
will be raised at the next
await
, so the cancellation is not lost.
Task groups preserve the cancellation count
reported by asyncio.Task.cancelling()
.
Alterado na versão 3.13: Improved handling of simultaneous internal and external cancellations and correct preservation of cancellation counts.
Terminating a Task Group¶
While terminating a task group is not natively supported by the standard library, termination can be achieved by adding an exception-raising task to the task group and ignoring the raised exception:
import asyncio
from asyncio import TaskGroup
class TerminateTaskGroup(Exception):
"""Exception raised to terminate a task group."""
async def force_terminate_task_group():
"""Used to force termination of a task group."""
raise TerminateTaskGroup()
async def job(task_id, sleep_time):
print(f'Task {task_id}: start')
await asyncio.sleep(sleep_time)
print(f'Task {task_id}: done')
async def main():
try:
async with TaskGroup() as group:
# spawn some tasks
group.create_task(job(1, 0.5))
group.create_task(job(2, 1.5))
# sleep for 1 second
await asyncio.sleep(1)
# add an exception-raising task to force the group to terminate
group.create_task(force_terminate_task_group())
except* TerminateTaskGroup:
pass
asyncio.run(main())
Expected output:
Task 1: start
Task 2: start
Task 1: done
Dormindo¶
- coroutine asyncio.sleep(delay, result=None)¶
Bloqueia por delay segundos.
Se result é fornecido, é retornado para o autor da chamada quando a corrotina termina.
sleep()
sempre suspende a tarefa atual, permitindo que outras tarefas sejam executadas.Configurando o delay para 0 fornece um caminho otimizado para permitir que outras tarefas executem. Isto pode ser usado por funções de longa execução para evitar que bloqueiem o laço de eventos por toda a duração da chamada da função.
Exemplo de uma corrotina exibindo a data atual a cada segundo durante 5 segundos:
import asyncio import datetime async def display_date(): loop = asyncio.get_running_loop() end_time = loop.time() + 5.0 while True: print(datetime.datetime.now()) if (loop.time() + 1.0) >= end_time: break await asyncio.sleep(1) asyncio.run(display_date())
Alterado na versão 3.10: Removido o parâmetro loop.
Alterado na versão 3.13: Raises
ValueError
if delay isnan
.
Executando tarefas concorrentemente¶
- awaitable asyncio.gather(*aws, return_exceptions=False)¶
Executa objetos aguardáveis na sequência aws de forma concorrente.
Se qualquer aguardável em aws é uma corrotina, ele é automaticamente agendado como uma Tarefa.
Se todos os aguardáveis forem concluídos com sucesso, o resultado é uma lista agregada de valores retornados. A ordem dos valores resultantes corresponde a ordem dos aguardáveis em aws.
Se return_exceptions for
False
(valor padrão), a primeira exceção levantada é imediatamente propagada para a tarefa que espera emgather()
. Outros aguardáveis na sequência aws não serão cancelados e irão continuar a executar.Se return_exceptions for
True
, exceções são tratadas da mesma forma que resultados com sucesso, e agregadas na lista de resultados.Se
gather()
for cancelado, todos os aguardáveis que foram submetidos (que não foram concluídos ainda) também são cancelados.Se qualquer Tarefa ou Futuro da sequência aws for cancelado, ele é tratado como se tivesse levantado
CancelledError
– a chamada paragather()
não é cancelada neste caso. Isso existe para prevenir que o cancelamento de uma Tarefa/Futuro submetida ocasione outras Tarefas/Futuros a serem cancelados.Nota
A new alternative to create and run tasks concurrently and wait for their completion is
asyncio.TaskGroup
. TaskGroup provides stronger safety guarantees than gather for scheduling a nesting of subtasks: if a task (or a subtask, a task scheduled by a task) raises an exception, TaskGroup will, while gather will not, cancel the remaining scheduled tasks).Exemplo:
import asyncio async def factorial(name, number): f = 1 for i in range(2, number + 1): print(f"Task {name}: Compute factorial({number}), currently i={i}...") await asyncio.sleep(1) f *= i print(f"Task {name}: factorial({number}) = {f}") return f async def main(): # Schedule three calls *concurrently*: L = await asyncio.gather( factorial("A", 2), factorial("B", 3), factorial("C", 4), ) print(L) asyncio.run(main()) # Expected output: # # Task A: Compute factorial(2), currently i=2... # Task B: Compute factorial(3), currently i=2... # Task C: Compute factorial(4), currently i=2... # Task A: factorial(2) = 2 # Task B: Compute factorial(3), currently i=3... # Task C: Compute factorial(4), currently i=3... # Task B: factorial(3) = 6 # Task C: Compute factorial(4), currently i=4... # Task C: factorial(4) = 24 # [2, 6, 24]
Nota
If return_exceptions is false, cancelling gather() after it has been marked done won’t cancel any submitted awaitables. For instance, gather can be marked done after propagating an exception to the caller, therefore, calling
gather.cancel()
after catching an exception (raised by one of the awaitables) from gather won’t cancel any other awaitables.Alterado na versão 3.7: Se gather por si mesmo for cancelado, o cancelamento é propagado independente de return_exceptions.
Alterado na versão 3.10: Removido o parâmetro loop.
Obsoleto desde a versão 3.10: Aviso de descontinuidade é emitido se nenhum argumento posicional for fornecido, ou nem todos os argumentos posicionais são objetos similar a Futuro, e não existe nenhum laço de eventos em execução.
Eager Task Factory¶
- asyncio.eager_task_factory(loop, coro, *, name=None, context=None)¶
A task factory for eager task execution.
When using this factory (via
loop.set_task_factory(asyncio.eager_task_factory)
), coroutines begin execution synchronously duringTask
construction. Tasks are only scheduled on the event loop if they block. This can be a performance improvement as the overhead of loop scheduling is avoided for coroutines that complete synchronously.A common example where this is beneficial is coroutines which employ caching or memoization to avoid actual I/O when possible.
Nota
Immediate execution of the coroutine is a semantic change. If the coroutine returns or raises, the task is never scheduled to the event loop. If the coroutine execution blocks, the task is scheduled to the event loop. This change may introduce behavior changes to existing applications. For example, the application’s task execution order is likely to change.
Adicionado na versão 3.12.
- asyncio.create_eager_task_factory(custom_task_constructor)¶
Create an eager task factory, similar to
eager_task_factory()
, using the provided custom_task_constructor when creating a new task instead of the defaultTask
.custom_task_constructor must be a callable with the signature matching the signature of
Task.__init__
. The callable must return aasyncio.Task
-compatible object.This function returns a callable intended to be used as a task factory of an event loop via
loop.set_task_factory(factory)
).Adicionado na versão 3.12.
Protegendo contra cancelamento¶
- awaitable asyncio.shield(aw)¶
Protege um objeto aguardável de ser
cancelado
.Se aw é uma corrotina, ela é automaticamente agendada como uma Tarefa.
A instrução:
task = asyncio.create_task(something()) res = await shield(task)
é equivalente a:
res = await something()
exceto que se a corrotina contendo-a for cancelada, a Tarefa executando em
something()
não é cancelada. Do ponto de vista desomething()
, o cancelamento não aconteceu. Apesar do autor da chamada ainda estar cancelado, então a expressão “await” ainda levanta umCancelledError
.Se
something()
é cancelada por outros meios (isto é, dentro ou a partir de si mesma) isso também iria cancelarshield()
.Se for desejado ignorar completamente os cancelamentos (não recomendado) a função
shield()
deve ser combinada com uma cláusula try/except, conforme abaixo:task = asyncio.create_task(something()) try: res = await shield(task) except CancelledError: res = None
Importante
Mantenha uma referência para as tarefas passadas para essa função função, evitando assim que uma tarefa desapareça durante a execução. O laço de eventos mantém apenas referências fracas para as tarefas. Uma tarefa que não é referenciada por nada mais pode ser removida pelo coletor de lixo a qualquer momento, antes mesmo da função ser finalizada.
Alterado na versão 3.10: Removido o parâmetro loop.
Obsoleto desde a versão 3.10: Aviso de descontinuidade é emitido se aw não é um objeto similar a Futuro, e não existe nenhum laço de eventos em execução.
Tempo limite¶
- asyncio.timeout(delay)¶
Return an asynchronous context manager that can be used to limit the amount of time spent waiting on something.
delay can either be
None
, or a float/int number of seconds to wait. If delay isNone
, no time limit will be applied; this can be useful if the delay is unknown when the context manager is created.In either case, the context manager can be rescheduled after creation using
Timeout.reschedule()
.Exemplo:
async def main(): async with asyncio.timeout(10): await long_running_task()
If
long_running_task
takes more than 10 seconds to complete, the context manager will cancel the current task and handle the resultingasyncio.CancelledError
internally, transforming it into aTimeoutError
which can be caught and handled.Nota
The
asyncio.timeout()
context manager is what transforms theasyncio.CancelledError
into aTimeoutError
, which means theTimeoutError
can only be caught outside of the context manager.Example of catching
TimeoutError
:async def main(): try: async with asyncio.timeout(10): await long_running_task() except TimeoutError: print("The long operation timed out, but we've handled it.") print("This statement will run regardless.")
The context manager produced by
asyncio.timeout()
can be rescheduled to a different deadline and inspected.- class asyncio.Timeout(when)¶
An asynchronous context manager for cancelling overdue coroutines.
when
should be an absolute time at which the context should time out, as measured by the event loop’s clock:If
when
isNone
, the timeout will never trigger.If
when < loop.time()
, the timeout will trigger on the next iteration of the event loop.
Exemplo:
async def main(): try: # We do not know the timeout when starting, so we pass ``None``. async with asyncio.timeout(None) as cm: # We know the timeout now, so we reschedule it. new_deadline = get_running_loop().time() + 10 cm.reschedule(new_deadline) await long_running_task() except TimeoutError: pass if cm.expired(): print("Looks like we haven't finished on time.")
Timeout context managers can be safely nested.
Adicionado na versão 3.11.
- asyncio.timeout_at(when)¶
Similar to
asyncio.timeout()
, except when is the absolute time to stop waiting, orNone
.Exemplo:
async def main(): loop = get_running_loop() deadline = loop.time() + 20 try: async with asyncio.timeout_at(deadline): await long_running_task() except TimeoutError: print("The long operation timed out, but we've handled it.") print("This statement will run regardless.")
Adicionado na versão 3.11.
- coroutine asyncio.wait_for(aw, timeout)¶
Espera o aguardável aw concluir sem ultrapassar o tempo limite “timeout”.
Se aw é uma corrotina, ela é automaticamente agendada como uma Tarefa.
timeout pode ser
None
, ou um ponto flutuante, ou um número inteiro de segundos para aguardar. Se timeout éNone
, aguarda até o future encerrar.If a timeout occurs, it cancels the task and raises
TimeoutError
.Para evitar o
cancelamento
da tarefa, envolva-a comshield()
.A função irá aguardar até o future ser realmente cancelado, então o tempo total de espera pode exceder o tempo limite timeout. Se uma exceção ocorrer durante o cancelamento, ela será propagada.
Se ele for cancelado, o future aw também é cancelado.
Exemplo:
async def eternity(): # Sleep for one hour await asyncio.sleep(3600) print('yay!') async def main(): # Wait for at most 1 second try: await asyncio.wait_for(eternity(), timeout=1.0) except TimeoutError: print('timeout!') asyncio.run(main()) # Expected output: # # timeout!
Alterado na versão 3.7: When aw is cancelled due to a timeout,
wait_for
waits for aw to be cancelled. Previously, it raisedTimeoutError
immediately.Alterado na versão 3.10: Removido o parâmetro loop.
Alterado na versão 3.11: Raises
TimeoutError
instead ofasyncio.TimeoutError
.
Primitivas de Espera¶
- coroutine asyncio.wait(aws, *, timeout=None, return_when=ALL_COMPLETED)¶
Run
Future
andTask
instances in the aws iterable concurrently and block until the condition specified by return_when.O iterável aws não deve ser vazio.
Retorna dois conjuntos de Tarefas/Futuros:
(done, pending)
.Uso:
done, pending = await asyncio.wait(aws)
timeout (um ponto flutuante ou inteiro), se especificado, pode ser usado para controlar o número máximo de segundos para aguardar antes de retornar.
Note that this function does not raise
TimeoutError
. Futures or Tasks that aren’t done when the timeout occurs are simply returned in the second set.return_when indica quando esta função deve retornar. Ele deve ser uma das seguintes constantes:
Constante
Descrição
- asyncio.FIRST_COMPLETED¶
A função irá retornar quando qualquer futuro terminar ou for cancelado.
- asyncio.FIRST_EXCEPTION¶
The function will return when any future finishes by raising an exception. If no future raises an exception then it is equivalent to
ALL_COMPLETED
.- asyncio.ALL_COMPLETED¶
A função irá retornar quando todos os futuros encerrarem ou forem cancelados.
Diferente de
wait_for()
,wait()
não cancela os futuros quando um tempo limite é atingido.Alterado na versão 3.10: Removido o parâmetro loop.
Alterado na versão 3.11: Passing coroutine objects to
wait()
directly is forbidden.Alterado na versão 3.12: Added support for generators yielding tasks.
- asyncio.as_completed(aws, *, timeout=None)¶
Run awaitable objects in the aws iterable concurrently. The returned object can be iterated to obtain the results of the awaitables as they finish.
The object returned by
as_completed()
can be iterated as an asynchronous iterator or a plain iterator. When asynchronous iteration is used, the originally-supplied awaitables are yielded if they are tasks or futures. This makes it easy to correlate previously-scheduled tasks with their results. Example:ipv4_connect = create_task(open_connection("127.0.0.1", 80)) ipv6_connect = create_task(open_connection("::1", 80)) tasks = [ipv4_connect, ipv6_connect] async for earliest_connect in as_completed(tasks): # earliest_connect is done. The result can be obtained by # awaiting it or calling earliest_connect.result() reader, writer = await earliest_connect if earliest_connect is ipv6_connect: print("IPv6 connection established.") else: print("IPv4 connection established.")
During asynchronous iteration, implicitly-created tasks will be yielded for supplied awaitables that aren’t tasks or futures.
When used as a plain iterator, each iteration yields a new coroutine that returns the result or raises the exception of the next completed awaitable. This pattern is compatible with Python versions older than 3.13:
ipv4_connect = create_task(open_connection("127.0.0.1", 80)) ipv6_connect = create_task(open_connection("::1", 80)) tasks = [ipv4_connect, ipv6_connect] for next_connect in as_completed(tasks): # next_connect is not one of the original task objects. It must be # awaited to obtain the result value or raise the exception of the # awaitable that finishes next. reader, writer = await next_connect
A
TimeoutError
is raised if the timeout occurs before all awaitables are done. This is raised by theasync for
loop during asynchronous iteration or by the coroutines yielded during plain iteration.Alterado na versão 3.10: Removido o parâmetro loop.
Obsoleto desde a versão 3.10: Aviso de descontinuidade é emitido se nem todos os objetos aguardáveis no iterável aws forem objetos similar a Futuro, e não existe nenhum laço de eventos em execução.
Alterado na versão 3.12: Added support for generators yielding tasks.
Alterado na versão 3.13: The result can now be used as either an asynchronous iterator or as a plain iterator (previously it was only a plain iterator).
Executando em Threads¶
- coroutine asyncio.to_thread(func, /, *args, **kwargs)¶
Executa a função func assincronamente em uma thread separada.
Quaisquer *args e **kwargs fornecidos para esta função são diretamente passados para func. Além disso, o
contextvars.Context
atual é propagado, permitindo que variáveis de contexto da thread do laço de eventos sejam acessadas na thread separada.Retorna uma corrotina que pode ser aguardada para obter o resultado eventual de func.
This coroutine function is primarily intended to be used for executing IO-bound functions/methods that would otherwise block the event loop if they were run in the main thread. For example:
def blocking_io(): print(f"start blocking_io at {time.strftime('%X')}") # Note that time.sleep() can be replaced with any blocking # IO-bound operation, such as file operations. time.sleep(1) print(f"blocking_io complete at {time.strftime('%X')}") async def main(): print(f"started main at {time.strftime('%X')}") await asyncio.gather( asyncio.to_thread(blocking_io), asyncio.sleep(1)) print(f"finished main at {time.strftime('%X')}") asyncio.run(main()) # Expected output: # # started main at 19:50:53 # start blocking_io at 19:50:53 # blocking_io complete at 19:50:54 # finished main at 19:50:54
Chamar diretamente
blocking_io()
em qualquer corrotina iria bloquear o laço de eventos durante a sua duração, resultando em 1 segundo adicional no tempo de execução. Ao invés disso, ao utilizarasyncio.to_thread()
, nós podemos executá-la em uma thread separada sem bloquear o laço de eventos.Nota
Devido à GIL,
asyncio.to_thread()
pode tipicamente ser usado apenas para fazer funções vinculadas a IO não-bloqueantes. Entretanto, para módulos de extensão que liberam o GIL ou implementações alternativas do Python que não tem um,asyncio.to_thread()
também pode ser usado para funções vinculadas à CPU.Adicionado na versão 3.9.
Agendando a partir de outras Threads¶
- asyncio.run_coroutine_threadsafe(coro, loop)¶
Envia uma corrotina para o laço de eventos fornecido. Seguro para thread.
Retorna um
concurrent.futures.Future
para aguardar pelo resultado de outra thread do sistema operacional.Esta função destina-se a ser chamada partir de uma thread diferente do sistema operacional, da qual o laço de eventos está executando. Exemplo:
# Create a coroutine coro = asyncio.sleep(1, result=3) # Submit the coroutine to a given loop future = asyncio.run_coroutine_threadsafe(coro, loop) # Wait for the result with an optional timeout argument assert future.result(timeout) == 3
Se uma exceção for levantada na corrotina, o Futuro retornado será notificado. Isso também pode ser usado para cancelar a tarefa no laço de eventos:
try: result = future.result(timeout) except TimeoutError: print('The coroutine took too long, cancelling the task...') future.cancel() except Exception as exc: print(f'The coroutine raised an exception: {exc!r}') else: print(f'The coroutine returned: {result!r}')
Veja a seção concorrência e multithreading da documentação.
Ao contrário de outras funções asyncio, esta função requer que o argumento loop seja passado explicitamente.
Adicionado na versão 3.5.1.
Introspecção¶
- asyncio.current_task(loop=None)¶
Retorna a instância
Task
atualmente em execução, ouNone
se nenhuma tarefa estiver executando.Se loop for
None
, entãoget_running_loop()
é usado para obter o laço atual.Adicionado na versão 3.7.
- asyncio.all_tasks(loop=None)¶
Retorna um conjunto de objetos
Task
ainda não concluídos a serem executados pelo laço.Se loop for
None
, entãoget_running_loop()
é usado para obter o laço atual.Adicionado na versão 3.7.
- asyncio.iscoroutine(obj)¶
Return
True
if obj is a coroutine object.Adicionado na versão 3.4.
Objeto Task¶
- class asyncio.Task(coro, *, loop=None, name=None, context=None, eager_start=False)¶
Um objeto
similar a Futuro
que executa uma corrotina Python. Não é seguro para thread.Tarefas são usadas para executar corrotinas em laços de eventos. Se uma corrotina espera por um Futuro, a Tarefa suspende a execução da corrotina e aguarda a conclusão do Futuro. Quando o Futuro é concluído, a execução da corrotina contida é retomada.
Laço de eventos usam agendamento cooperativo: um ciclo de evento executa uma Tarefa de cada vez. Enquanto uma Tarefa aguarda a conclusão de um Futuro, o laço de eventos executa outras Tarefas, funções de retorno, ou executa operações de IO.
Use a função de alto nível
asyncio.create_task()
para criar Tarefas, ou as funções de baixo nívelloop.create_task()
ouensure_future()
. Instanciação manual de Tarefas é desencorajado.Para cancelar uma Tarefa em execução, use o método
cancel()
. Chamar ele fará com que a Tarefa levante uma exceçãoCancelledError
dentro da corrotina contida. Se a corrotina estiver esperando por um objeto Future durante o cancelamento, o objeto Future será cancelado.cancelled()
pode ser usado para verificar se a Tarefa foi cancelada. O método retornaTrue
se a corrotina envolta não suprimiu a exceçãoCancelledError
e foi na verdade cancelada.asyncio.Task
herda deFuture
todas as suas APIs excetoFuture.set_result()
eFuture.set_exception()
.An optional keyword-only context argument allows specifying a custom
contextvars.Context
for the coro to run in. If no context is provided, the Task copies the current context and later runs its coroutine in the copied context.An optional keyword-only eager_start argument allows eagerly starting the execution of the
asyncio.Task
at task creation time. If set toTrue
and the event loop is running, the task will start executing the coroutine immediately, until the first time the coroutine blocks. If the coroutine returns or raises without blocking, the task will be finished eagerly and will skip scheduling to the event loop.Alterado na versão 3.7: Adicionado suporte para o módulo
contextvars
.Alterado na versão 3.8: Adicionado o parâmetro name.
Obsoleto desde a versão 3.10: Aviso de descontinuidade é emitido se loop não é especificado, e não existe nenhum laço de eventos em execução.
Alterado na versão 3.11: Adicionado o parâmetro context.
Alterado na versão 3.12: Added the eager_start parameter.
- done()¶
Retorna
True
se a Tarefa estiver concluída.Uma Tarefa está concluída quando a corrotina contida retornou um valor, ou levantou uma exceção, ou a Tarefa foi cancelada.
- result()¶
Retorna o resultado da Tarefa.
Se a Tarefa estiver concluída, o resultado da corrotina contida é retornado (ou se a corrotina levantou uma exceção, essa exceção é re-levantada.)
Se a Tarefa foi cancelada, este método levanta uma exceção
CancelledError
.If the Task’s result isn’t yet available, this method raises an
InvalidStateError
exception.
- exception()¶
Retorna a exceção de uma Tarefa.
Se a corrotina contida levantou uma exceção, essa exceção é retornada. Se a corrotina contida retornou normalmente, este método retorna
None
.Se a Tarefa foi cancelada, este método levanta uma exceção
CancelledError
.Se a Tarefa não estiver concluída ainda, este método levanta uma exceção
InvalidStateError
.
- add_done_callback(callback, *, context=None)¶
Adiciona uma função de retorno para ser executada quando a Tarefa estiver concluída.
Este método deve ser usado apenas em código de baixo nível baseado em funções de retorno.
Veja a documentação para
Future.add_done_callback()
para mais detalhes.
- remove_done_callback(callback)¶
Remove callback da lista de funções de retorno.
Este método deve ser usado apenas em código de baixo nível baseado em funções de retorno.
Veja a documentação do método
Future.remove_done_callback()
para mais detalhes.
- get_stack(*, limit=None)¶
Retorna a lista de frames da pilha para esta Tarefa.
Se a corrotina contida não estiver concluída, isto retorna a pilha onde ela foi suspensa. Se a corrotina foi concluída com sucesso ou foi cancelada, isto retorna uma lista vazia. Se a corrotina foi terminada por uma exceção, isto retorna a lista de frames do traceback (situação da pilha de execução).
Os quadros são sempre ordenados dos mais antigos para os mais recentes.
Apenas um frame da pilha é retornado para uma corrotina suspensa.
O argumento opcional limit define o o número de frames máximo para retornar; por padrão todos os frames disponíveis são retornados. O ordenamento da lista retornada é diferente dependendo se uma pilha ou um traceback (situação da pilha de execução) é retornado: os frames mais recentes de uma pilha são retornados, mas os frames mais antigos de um traceback são retornados. (Isso combina com o comportamento do módulo traceback.)
- print_stack(*, limit=None, file=None)¶
Exibe a pilha ou situação da pilha de execução para esta Tarefa.
Isto produz uma saída similar a do módulo traceback para frames recuperados por
get_stack()
.O argumento limit é passado para
get_stack()
diretamente.The file argument is an I/O stream to which the output is written; by default output is written to
sys.stdout
.
- get_coro()¶
Retorna o objeto corrotina contido pela
Task
.Nota
This will return
None
for Tasks which have already completed eagerly. See the Eager Task Factory.Adicionado na versão 3.8.
Alterado na versão 3.12: Newly added eager task execution means result may be
None
.
- get_context()¶
Return the
contextvars.Context
object associated with the task.Adicionado na versão 3.12.
- get_name()¶
Retorna o nome da Tarefa.
Se nenhum nome foi explicitamente designado para a Tarefa, a implementação padrão asyncio da classe Task gera um nome padrão durante a instanciação.
Adicionado na versão 3.8.
- set_name(value)¶
Define o nome da Tarefa.
O argumento value pode ser qualquer objeto, o qual é então convertido para uma string.
Na implementação padrão da Tarefa, o nome será visível na
repr()
de saída de um objeto task.Adicionado na versão 3.8.
- cancel(msg=None)¶
Solicita o cancelamento da Tarefa.
Isto prepara para uma exceção
CancelledError
ser lançada na corrotina contida no próximo ciclo do laço de eventos.The coroutine then has a chance to clean up or even deny the request by suppressing the exception with a
try
… …except CancelledError
…finally
block. Therefore, unlikeFuture.cancel()
,Task.cancel()
does not guarantee that the Task will be cancelled, although suppressing cancellation completely is not common and is actively discouraged. Should the coroutine nevertheless decide to suppress the cancellation, it needs to callTask.uncancel()
in addition to catching the exception.Alterado na versão 3.9: Adicionado o parâmetro msg.
Alterado na versão 3.11: The
msg
parameter is propagated from cancelled task to its awaiter.O seguinte exemplo ilustra como corrotinas podem interceptar o cancelamento de requisições:
async def cancel_me(): print('cancel_me(): before sleep') try: # Wait for 1 hour await asyncio.sleep(3600) except asyncio.CancelledError: print('cancel_me(): cancel sleep') raise finally: print('cancel_me(): after sleep') async def main(): # Create a "cancel_me" Task task = asyncio.create_task(cancel_me()) # Wait for 1 second await asyncio.sleep(1) task.cancel() try: await task except asyncio.CancelledError: print("main(): cancel_me is cancelled now") asyncio.run(main()) # Expected output: # # cancel_me(): before sleep # cancel_me(): cancel sleep # cancel_me(): after sleep # main(): cancel_me is cancelled now
- cancelled()¶
Retorna
True
se a Tarefa for cancelada.A Tarefa é cancelada quando o cancelamento foi requisitado com
cancel()
e a corrotina contida propagou a exceçãoCancelledError
gerada nela.
- uncancel()¶
Decrement the count of cancellation requests to this Task.
Returns the remaining number of cancellation requests.
Note that once execution of a cancelled task completed, further calls to
uncancel()
are ineffective.Adicionado na versão 3.11.
This method is used by asyncio’s internals and isn’t expected to be used by end-user code. In particular, if a Task gets successfully uncancelled, this allows for elements of structured concurrency like Task Groups and
asyncio.timeout()
to continue running, isolating cancellation to the respective structured block. For example:async def make_request_with_timeout(): try: async with asyncio.timeout(1): # Structured block affected by the timeout: await make_request() await make_another_request() except TimeoutError: log("There was a timeout") # Outer code not affected by the timeout: await unrelated_code()
While the block with
make_request()
andmake_another_request()
might get cancelled due to the timeout,unrelated_code()
should continue running even in case of the timeout. This is implemented withuncancel()
.TaskGroup
context managers useuncancel()
in a similar fashion.If end-user code is, for some reason, suppressing cancellation by catching
CancelledError
, it needs to call this method to remove the cancellation state.When this method decrements the cancellation count to zero, the method checks if a previous
cancel()
call had arranged forCancelledError
to be thrown into the task. If it hasn’t been thrown yet, that arrangement will be rescinded (by resetting the internal_must_cancel
flag).
Alterado na versão 3.13: Changed to rescind pending cancellation requests upon reaching zero.
- cancelling()¶
Return the number of pending cancellation requests to this Task, i.e., the number of calls to
cancel()
less the number ofuncancel()
calls.Note that if this number is greater than zero but the Task is still executing,
cancelled()
will still returnFalse
. This is because this number can be lowered by callinguncancel()
, which can lead to the task not being cancelled after all if the cancellation requests go down to zero.This method is used by asyncio’s internals and isn’t expected to be used by end-user code. See
uncancel()
for more details.Adicionado na versão 3.11.