Skip to main content

Deferrable operators

Deferrable operators leverage the Python asyncio library to efficiently run tasks waiting for an external resource to finish. This frees up your workers and allows you to use resources more effectively. In this guide, you'll review deferrable operator concepts and learn how to use deferrable operators in your DAGs.

Other ways to learn

There are multiple resources for learning about this topic. See also:

Assumed knowledge

To get the most out of this guide, you should have an understanding of:

Terms and concepts

Review the following terms and concepts to gain a better understanding of deferrable operator functionality:

  • asyncio: A Python library used as the foundation for multiple asynchronous frameworks. This library is core to deferrable operator functionality, and is used when writing triggers.
  • Triggers: Small, asynchronous sections of Python code. Due to their asynchronous nature, they coexist efficiently in a single process known as the triggerer.
  • Triggerer: An Airflow service similar to a scheduler or a worker that runs an asyncio event loop in your Airflow environment. Running a triggerer is essential for using deferrable operators.
  • Deferred: An Airflow task state indicating that a task has paused its execution, released the worker slot, and submitted a trigger to be picked up by the triggerer process.

The terms deferrable, async, and asynchronous are used interchangeably and have the same meaning.

With traditional operators, a task submits a job to an external system such as a Spark cluster and then polls the job status until it is completed. Although the task isn't doing significant work, it still occupies a worker slot during the polling process. As worker slots are occupied, tasks are queued and start times are delayed. The following image illustrates this process:

Classic Worker

With deferrable operators, worker slots are released when a task is polling for the job status. When the task is deferred, the polling process is offloaded as a trigger to the triggerer, and the worker slot becomes available. The triggerer can run many asynchronous polling tasks concurrently, and this prevents polling tasks from occupying your worker resources. When the terminal status for the job is received, the task resumes, taking a worker slot while it finishes. The following image illustrates this process:

Deferrable Worker

There are numerous benefits to using deferrable operators including:

  • Reduced resource consumption: Depending on the available resources and the workload of your triggers, you can run hundreds to thousands of deferred tasks in a single triggerer process. This can lead to a reduction in the number of workers needed to run tasks during periods of high concurrency. With less workers needed, you are able to scale down the underlying infrastructure of your Airflow environment.
  • Resiliency against restarts: Triggers are stateless by design. This means your deferred tasks are not set to a failure state if a triggerer needs to be restarted due to a deployment or infrastructure issue. When a triggerer is back up and running in your environment, your deferred tasks will resume.
tip

When you can't use a deferrable operator for a longer running sensor task, such as when you can't run a triggerer, Astronomer recommends using a sensor in reschedule mode to reduce unnecessary resource overhead. See the Airflow documentation for details about the differences between deferrable operators and schedulers in reschedule mode.

Use deferrable operators

Deferrable operators should be used whenever you have tasks that occupy a worker slot while polling for a condition in an external system. For example, using deferrable operators for sensor tasks can provide efficiency gains and reduce operational costs.

Start a triggerer

To use deferrable operators, you must have a triggerer running in your Airflow environment. If you are running Airflow on Astro or using the Astro CLI, the triggerer runs automatically if you are on Astro Runtime 4.0 and later. If you are using Astronomer Software 0.26 and later, you can add a triggerer to an Airflow 2.2 and later deployment in the Deployment Settings tab. See Configure a Deployment on Astronomer Software - Triggerer to configure the triggerer.

If you are not using Astro, run airflow triggerer to start a triggerer process in your Airflow environment. Your output should look similar to the following image:

Triggerer Logs

As tasks are raised into a deferred state, triggers are registered in the triggerer. You can set the number of concurrent triggers that can run in a single triggerer process with the default_capacity configuration setting in Airflow. This config can also be set with the AIRFLOW__TRIGGERER__DEFAULT_CAPACITY environment variable. The default value is 1000.

Use deferrable versions of operators

Many Airflow operators, such as the TriggerDagRunOperator and the WasbBlobSensor, can be set to run in deferrable mode using the deferrable parameter. You can check if the operator you want to use has a deferrable parameter in the Astronomer Registry.

To always use the deferrable version of an operator if it's available in Airflow 2.7+, set the Airflow config operators.default_deferrable to True. You can do so by defining the following environment variable in your Airflow environment:

AIRFLOW__OPERATORS__DEFAULT_DEFERRABLE=True

After you set the variable, all operators with a deferrable parameter will run as their deferrable version by default. You can override the config setting at the operator level using the deferrable parameter directly:

trigger_dag_run = TriggerDagRunOperator(
task_id="task_in_downstream_dag",
trigger_dag_id="downstream_dag",
wait_for_completion=True,
poke_interval=20,
deferrable=False, # turns off deferrable mode just for this operator instance
)

You can find a list of operators that support deferrable mode in the Airflow documentation.

Previously, before the deferrable parameter was available in regular operators, deferrable operators were implemented as standalone operators, usually with an -Async suffix. Some of these operators are still available. For example, the DateTimeSensor does not have a deferrable parameter, but has a deferrable version called DateTimeSensorAsync.

info

The Astronomer providers package, which contained many -Async operators, is deprecated. The functionality from most of these operators is integrated into their original operator version in the relevant Airflow provider package.

Example workflow

The following example DAG is scheduled to run every minute between its start_date and its end_date. Every DAG run contains one sensor task that will potentially take up to 20 minutes to complete.

from airflow.decorators import dag
from airflow.sensors.date_time import DateTimeSensor
from pendulum import datetime


@dag(
start_date=datetime(2024, 5, 23, 20, 0),
end_date=datetime(2024, 5, 23, 20, 19),
schedule="* * * * *",
catchup=True,
)
def sync_dag_2():
DateTimeSensor(
task_id="sync_task",
target_time="""{{ macros.datetime.utcnow() + macros.timedelta(minutes=20) }}""",
)


sync_dag_2()

Using DateTimeSensor, one worker slot is taken up by every sensor that runs. By using the deferrable version of this sensor, DateTimeSensorAsync, you can achieve full concurrency while freeing up your workers to complete additional tasks across your Airflow environment.

In the following screenshot, running the DAG produces 16 running task instances, each containing one active DateTimeSensor taking up one worker slot.

Standard sensor Grid View

Because Airflow imposes default limits on the number of active runs of the same DAG or number of active tasks in a DAG across all runs, you'll have to scale up Airflow to concurrently run any other DAGs and tasks as described in the Scaling Airflow to optimize performance guide.

Switching out the DateTimeSensor for DateTimeSensorAsync will create 16 running DAG instances, but the tasks for these DAGs are in a deferred state which does not take up a worker slot. The only difference in the DAG code is using the deferrable operator DateTimeSensorAsync over DateTimeSensor:

from airflow.decorators import dag
from pendulum import datetime
from airflow.sensors.date_time import DateTimeSensorAsync


@dag(
start_date=datetime(2024, 5, 23, 20, 0),
end_date=datetime(2024, 5, 23, 20, 19),
schedule="* * * * *",
catchup=True,
)
def async_dag_2():
DateTimeSensorAsync(
task_id="async_task",
target_time="""{{ macros.datetime.utcnow() + macros.timedelta(minutes=20) }}""",
)


async_dag_2()

In the following screenshot, all tasks are shown in a deferred (violet) state. Tasks in other DAGs can use the available worker slots, making the deferrable operator more cost and time-efficient.

Deferrable sensor Grid View

High availability

Triggers are designed to be highly available. You can implement this by starting multiple triggerer processes. Similar to the HA scheduler, Airflow ensures that they co-exist with correct locking and high availability. See High Availability for more information on this topic.

Create a deferrable operator

If you have an operator that would benefit from being asynchronous, but does not exist in OSS Airflow yet, you can create your own by writing a deferrable operator and trigger class. You can also defer a task several times if needed.

Get a template for a custom deferrable operator and custom trigger class, by clicking the dropdown below:

Click to view the template code
from __future__ import annotations
import asyncio
import time
from asgiref.sync import sync_to_async
from typing import Any, Sequence, AsyncIterator
from airflow.configuration import conf
from airflow.models.baseoperator import BaseOperator
from airflow.triggers.base import BaseTrigger, TriggerEvent
from airflow.utils.context import Context


class MyTrigger(BaseTrigger):
"""
This is an example of a custom trigger that waits for a binary random choice
between 0 and 1 to be 1.
Args:
poll_interval (int): How many seconds to wait between async polls.
my_kwarg_passed_into_the_trigger (str): A kwarg that is passed into the trigger.
Returns:
my_kwarg_passed_out_of_the_trigger (str): A kwarg that is passed out of the trigger.
"""

def __init__(
self,
poll_interval: int = 60,
my_kwarg_passed_into_the_trigger: str = "notset",
my_kwarg_passed_out_of_the_trigger: str = "notset",
# you can add more arguments here
):
super().__init__()
self.poll_interval = poll_interval
self.my_kwarg_passed_into_the_trigger = my_kwarg_passed_into_the_trigger
self.my_kwarg_passed_out_of_the_trigger = my_kwarg_passed_out_of_the_trigger

def serialize(self) -> tuple[str, dict[str, Any]]:
"""
Serialize MyTrigger arguments and classpath.
All arguments must be JSON serializable.
This will be returned by the trigger when it is complete and passed as `event` to the
`execute_complete` method of the deferrable operator.
"""

return (
"include.deferrable_operator_template.MyTrigger", # this is the classpath for the Trigger
{
"my_kwarg_passed_out_of_the_trigger": self.my_kwarg_passed_out_of_the_trigger,
# you can add more kwargs here
},
)

# The run method is an async generator that yields TriggerEvents when the desired condition is met
async def run(self) -> AsyncIterator[TriggerEvent]:
while True:
result = (
await self.my_trigger_function()
) # The my_trigger_function is awaited and where the condition is checked
if result == 1:
self.log.info(f"Result was 1, thats the number! Triggering event.")

self.log.info(
f"Kwarg passed in was: {self.my_kwarg_passed_into_the_trigger}"
)
# This is how you pass data out of the trigger, by setting attributes that get serialized
self.my_kwarg_passed_out_of_the_trigger = "apple"
self.log.info(
f"Kwarg to be passed out is: {self.my_kwarg_passed_out_of_the_trigger}"
)
# Fire the trigger event! This gets a worker to execute the operator's `execute_complete` method
yield TriggerEvent(self.serialize())
return # The return statement prevents the trigger from running again
else:
self.log.info(
f"Result was not the one we are waiting for. Sleeping for {self.poll_interval} seconds."
)
# If the condition is not met, the trigger sleeps for the poll_interval
# this code can run multiple times until the condition is met
await asyncio.sleep(self.poll_interval)

# This is the function that is awaited in the run method
@sync_to_async
def my_trigger_function(self) -> str:
"""
This is where what you are waiting for goes For example a call to an
API to check for the state of a cloud resource.
This code can run multiple times until the condition is met.
"""

import random

randint = random.choice([0, 1])
self.log.info(f"Random number: {randint}")

return randint


class MyOperator(BaseOperator):
"""
Deferrable operator that waits for a binary random choice between 0 and 1 to be 1.
Args:
wait_for_completion (bool): Whether to wait for the trigger to complete.
poke_interval (int): How many seconds to wait between polls,
both in deferrable or sensor mode.
deferrable (bool): Whether to defer the operator. If set to False,
the operator will act as a sensor.
Returns:
str: A kwarg that is passed through the trigger and returned by the operator.
"""

template_fields: Sequence[str] = (
"wait_for_completion",
"poke_interval",
)
ui_color = "#73deff"

def __init__(
self,
*,
# you can add more arguments here
wait_for_completion: bool = False,
poke_interval: int = 60,
deferrable: bool = conf.getboolean(
"operators", "default_deferrable", fallback=False
), # this default is a convention to be able to set the operator to deferrable in the config
# using AIRFLOW__OPERATORS__DEFAULT_DEFERRABLE=True
**kwargs,
) -> None:
super().__init__(**kwargs)

self.wait_for_completion = wait_for_completion
self.poke_interval = poke_interval
self._defer = deferrable

def execute(self, context: Context):

# Add code you want to be executed before the deferred part here (this code only runs once)

# turns operator into sensor/deferred operator
if self.wait_for_completion:
# Starting the deferral process
if self._defer:
self.log.info(
"Operator in deferrable mode. Starting the deferral process."
)
self.defer(
trigger=MyTrigger(
poll_interval=self.poke_interval,
my_kwarg_passed_into_the_trigger="lemon",
# you can pass information into the trigger here
),
method_name="execute_complete",
kwargs={"kwarg_passed_to_execute_complete": "tomato"},
# kwargs get passed through to the execute_complete method
)
else: # regular sensor part
while True:
self.log.info("Operator in sensor mode. Polling.")
time.sleep(self.poke_interval)
import random

# This is where you would check for the condition you are waiting for
# when using the operator as a regular sensor
# This code can run multiple times until the condition is met

randint = random.choice([0, 1])

self.log.info(f"Random number: {randint}")
if randint == 1:
self.log.info("Result was 1, thats the number! Continuing.")
return randint
self.log.info(
"Result was not the one we are waiting for. Sleeping."
)
else:
self.log.info("Not waiting for completion.")

# Add code you want to be executed after the deferred part here (this code only runs once)
# you can have as many deferred parts as you want in an operator

def execute_complete(
self,
context: Context,
event: tuple[str, dict[str, Any]],
kwarg_passed_to_execute_complete: str, # make sure to add the kwargs you want to pass through
):
"""Execute when the trigger is complete. This code only runs once."""

self.log.info("Trigger is complete.")
self.log.info(f"Event: {event}") # printing the serialized event

# you can push additional data to XCom here
context["ti"].xcom_push(
"message_from_the_trigger", event[1]["my_kwarg_passed_out_of_the_trigger"]
)

return kwarg_passed_to_execute_complete # the returned value gets pushed to XCom as `return_value`

Note that when developing a custom trigger, you need to restart your triggerer to pick up any changes you make, since the triggerer caches the trigger classes. Additionally, all information you pass between the triggerer and the worker must be JSON serializable.

See Writing Deferrable Operators for more information.

Was this page helpful?

Sign up for Developer Updates

Get a summary of new Astro features once a month.

You can unsubscribe at any time.
By proceeding you agree to our Privacy Policy, our Website Terms and to receive emails from Astronomer.