Customizing Dag Scheduling with Timetables¶
For our example, let’s say a company wants to run a job after each weekday to
process data collected during the work day. The first intuitive answer to this
would be schedule="0 0 * * 1-5" (midnight on Monday to Friday), but
this means data collected on Friday will not be processed right after Friday
ends, but on the next Monday, and that run’s interval would be from midnight
Friday to midnight Monday. Further, the above schedule string cannot skip
processing on holidays. What we want is:
- Schedule a run for each Monday, Tuesday, Wednesday, Thursday, and Friday. The run’s data interval would cover from midnight of each day, to midnight of the next day (e.g. 2021-01-01 00:00:00 to 2021-01-02 00:00:00). 
- Each run would be created right after the data interval ends. The run covering Monday happens on midnight Tuesday and so on. The run covering Friday happens on midnight Saturday. No runs happen on midnights Sunday and Monday. 
- Do not schedule a run on defined holidays. 
For simplicity, we will only deal with UTC datetimes in this example.
Note
All datetime values returned by a custom timetable MUST be “aware”, i.e.
contains timezone information. Furthermore, they must use pendulum’s
datetime and timezone types.
Timetable Registration¶
A timetable must be a subclass of Timetable,
and be registered as a part of a plugin.
The following is a skeleton for us to implement a new timetable:
from airflow.plugins_manager import AirflowPlugin
from airflow.timetables.base import Timetable
class AfterWorkdayTimetable(Timetable):
    pass
class WorkdayTimetablePlugin(AirflowPlugin):
    name = "workday_timetable_plugin"
    timetables = [AfterWorkdayTimetable]
Next, we’ll start putting code into AfterWorkdayTimetable. After the
implementation is finished, we should be able to use the timetable in our Dag
file:
import pendulum
from airflow.sdk import DAG
from airflow.example_dags.plugins.workday import AfterWorkdayTimetable
with DAG(
    dag_id="example_after_workday_timetable_dag",
    start_date=pendulum.datetime(2021, 3, 10, tz="UTC"),
    schedule=AfterWorkdayTimetable(),
    tags=["example", "timetable"],
):
    ...
Define Scheduling Logic¶
When Airflow’s scheduler encounters a Dag, it calls one of the two methods to know when to schedule the Dag’s next run.
- next_dagrun_info: The scheduler uses this to learn the timetable’s regular schedule, i.e. the “one for every workday, run at the end of it” part in our example.
- infer_manual_data_interval: When a Dag run is manually triggered (from the web UI, for example), the scheduler uses this method to learn about how to reverse-infer the out-of-schedule run’s data interval.
We’ll start with infer_manual_data_interval since it’s the easier of the two:
def infer_manual_data_interval(self, run_after: DateTime) -> DataInterval:
    start = DateTime.combine((run_after - timedelta(days=1)).date(), Time.min).replace(tzinfo=UTC)
    # Skip backwards over weekends and holidays to find last run
    start = self.get_next_workday(start, incr=-1)
    return DataInterval(start=start, end=(start + timedelta(days=1)))
The method accepts one argument run_after, a pendulum.DateTime object
that indicates when the Dag is externally triggered. Since our timetable creates
a data interval for each complete work day, the data interval inferred here
should usually start at the midnight one day prior to run_after, but if
run_after falls on a Sunday or Monday (i.e. the prior day is Saturday or
Sunday), it should be pushed further back to the previous Friday. Once we know
the start of the interval, the end is simply one full day after it. We then
create a DataInterval object to describe this
interval.
Next is the implementation of next_dagrun_info:
def next_dagrun_info(
    self,
    *,
    last_automated_data_interval: DataInterval | None,
    restriction: TimeRestriction,
) -> DagRunInfo | None:
    if last_automated_data_interval is not None:  # There was a previous run on the regular schedule.
        last_start = last_automated_data_interval.start
        next_start = DateTime.combine((last_start + timedelta(days=1)).date(), Time.min)
    # Otherwise this is the first ever run on the regular schedule...
    elif (earliest := restriction.earliest) is None:
        return None  # No start_date. Don't schedule.
    elif not restriction.catchup:
        # If the DAG has catchup=False, today is the earliest to consider.
        next_start = max(earliest, DateTime.combine(Date.today(), Time.min, tzinfo=UTC))
    elif earliest.time() != Time.min:
        # If earliest does not fall on midnight, skip to the next day.
        next_start = DateTime.combine(earliest.date() + timedelta(days=1), Time.min)
    else:
        next_start = earliest
    # Skip weekends and holidays
    next_start = self.get_next_workday(next_start.replace(tzinfo=UTC))
    if restriction.latest is not None and next_start > restriction.latest:
        return None  # Over the DAG's scheduled end; don't schedule.
    return DagRunInfo.interval(start=next_start, end=(next_start + timedelta(days=1)))
This method accepts two arguments. last_automated_data_interval is a
DataInterval instance indicating the data
interval of this Dag’s previous non-manually-triggered run, or None if this
is the first time ever the Dag is being scheduled. restriction encapsulates
how the Dag and its tasks specify the schedule, and contains three attributes:
- earliest: The earliest time the Dag may be scheduled. This is a- pendulum.DateTimecalculated from all the- start_datearguments from the Dag and its tasks, or- Noneif there are no- start_datearguments found at all.
- latest: Similar to- earliest, this is the latest time the Dag may be scheduled, calculated from- end_datearguments.
- catchup: A boolean reflecting the Dag’s- catchupargument. Defaults to- False.
Note
Both earliest and latest apply to the Dag run’s logical date
(the start of the data interval), not when the run will be scheduled
(usually after the end of the data interval).
If there was a run scheduled previously, we should now schedule for the next
non-holiday weekday by looping through subsequent days to find one that is not
a Saturday, Sunday, or US holiday. If there was not a previous scheduled run,
however, we pick the next non-holiday workday’s midnight after
restriction.earliest.
restriction.catchup also needs to be considered—if it’s False, we
can’t schedule before the current time, even if start_date values are in the
past. Finally, if our calculated data interval is later than
restriction.latest, we must respect it and not schedule a run by returning
None.
If we decide to schedule a run, we need to describe it with a
DagRunInfo. This type has two arguments and
attributes:
- data_interval: A- DataIntervalinstance describing the next run’s data interval.
- run_after: A- pendulum.DateTimeinstance that tells the scheduler when the Dag run can be scheduled.
A DagRunInfo can be created like this:
info = DagRunInfo(
    data_interval=DataInterval(start=start, end=end),
    run_after=run_after,
)
Since we typically want to schedule a run as soon as the data interval ends,
end and run_after above are generally the same. DagRunInfo therefore
provides a shortcut for this:
info = DagRunInfo.interval(start=start, end=end)
assert info.data_interval.end == info.run_after  # Always True.
For reference, here’s our plugin and Dag files in their entirety:
from pendulum import UTC, Date, DateTime, Time
from airflow.plugins_manager import AirflowPlugin
from airflow.timetables.base import DagRunInfo, DataInterval, Timetable
if TYPE_CHECKING:
    from airflow.timetables.base import TimeRestriction
log = logging.getLogger(__name__)
try:
    from pandas.tseries.holiday import USFederalHolidayCalendar
    holiday_calendar = USFederalHolidayCalendar()
except ImportError:
    log.warning("Could not import pandas. Holidays will not be considered.")
    holiday_calendar = None  # type: ignore[assignment]
class AfterWorkdayTimetable(Timetable):
    def get_next_workday(self, d: DateTime, incr=1) -> DateTime:
        next_start = d
        while True:
            if next_start.weekday() not in (5, 6):  # not on weekend
                if holiday_calendar is None:
                    holidays = set()
                else:
                    holidays = holiday_calendar.holidays(start=next_start, end=next_start).to_pydatetime()
                if next_start not in holidays:
                    break
            next_start = next_start.add(days=incr)
        return next_start
    def infer_manual_data_interval(self, run_after: DateTime) -> DataInterval:
        start = DateTime.combine((run_after - timedelta(days=1)).date(), Time.min).replace(tzinfo=UTC)
        # Skip backwards over weekends and holidays to find last run
        start = self.get_next_workday(start, incr=-1)
        return DataInterval(start=start, end=(start + timedelta(days=1)))
    def next_dagrun_info(
        self,
        *,
        last_automated_data_interval: DataInterval | None,
        restriction: TimeRestriction,
    ) -> DagRunInfo | None:
        if last_automated_data_interval is not None:  # There was a previous run on the regular schedule.
            last_start = last_automated_data_interval.start
            next_start = DateTime.combine((last_start + timedelta(days=1)).date(), Time.min)
        # Otherwise this is the first ever run on the regular schedule...
        elif (earliest := restriction.earliest) is None:
            return None  # No start_date. Don't schedule.
        elif not restriction.catchup:
            # If the DAG has catchup=False, today is the earliest to consider.
            next_start = max(earliest, DateTime.combine(Date.today(), Time.min, tzinfo=UTC))
        elif earliest.time() != Time.min:
            # If earliest does not fall on midnight, skip to the next day.
            next_start = DateTime.combine(earliest.date() + timedelta(days=1), Time.min)
        else:
            next_start = earliest
        # Skip weekends and holidays
        next_start = self.get_next_workday(next_start.replace(tzinfo=UTC))
        if restriction.latest is not None and next_start > restriction.latest:
            return None  # Over the DAG's scheduled end; don't schedule.
        return DagRunInfo.interval(start=next_start, end=(next_start + timedelta(days=1)))
class WorkdayTimetablePlugin(AirflowPlugin):
    name = "workday_timetable_plugin"
    timetables = [AfterWorkdayTimetable]
import pendulum
from airflow.sdk import DAG
from airflow.example_dags.plugins.workday import AfterWorkdayTimetable
from airflow.providers.standard.operators.empty import EmptyOperator
with DAG(
    dag_id="example_workday_timetable",
    start_date=pendulum.datetime(2021, 1, 1, tz="UTC"),
    schedule=AfterWorkdayTimetable(),
    tags=["example", "timetable"],
):
    EmptyOperator(task_id="run_this")
Parameterized Timetables¶
Sometimes we need to pass some run-time arguments to the timetable. Continuing
with our AfterWorkdayTimetable example, maybe we have Dags running on
different timezones, and we want to schedule some Dags at 8am the next day,
instead of on midnight. Instead of creating a separate timetable for each
purpose, we’d want to do something like:
class SometimeAfterWorkdayTimetable(Timetable):
    def __init__(self, schedule_at: Time) -> None:
        self._schedule_at = schedule_at
    def next_dagrun_info(self, last_automated_dagrun, restriction):
        ...
        end = start + timedelta(days=1)
        return DagRunInfo(
            data_interval=DataInterval(start=start, end=end),
            run_after=DateTime.combine(end.date(), self._schedule_at).replace(tzinfo=UTC),
        )
However, since the timetable is a part of the Dag, we need to tell Airflow how
to serialize it with the context we provide in __init__. This is done by
implementing two additional methods on our timetable class:
class SometimeAfterWorkdayTimetable(Timetable):
    ...
    def serialize(self) -> dict[str, Any]:
        return {"schedule_at": self._schedule_at.isoformat()}
    @classmethod
    def deserialize(cls, value: dict[str, Any]) -> Timetable:
        return cls(Time.fromisoformat(value["schedule_at"]))
When the Dag is being serialized, serialize is called to obtain a
JSON-serializable value. That value is passed to deserialize when the
serialized Dag is accessed by the scheduler to reconstruct the timetable.
Timetable Display in UI¶
By default, a custom timetable is displayed by their class name in the UI (e.g.
the Schedule column in the “dags” table). It is possible to customize this
by overriding the summary property. This is especially useful for
parameterized timetables to include arguments provided in __init__. For
our SometimeAfterWorkdayTimetable class, for example, we could have:
@property
def summary(self) -> str:
    return f"after each workday, at {self._schedule_at}"
So for a Dag declared like this:
with DAG(
    schedule=SometimeAfterWorkdayTimetable(Time(8)),  # 8am.
    ...,
):
    ...
The Schedule column would say after each workday, at 08:00:00.
See also
- Module airflow.timetables.base
- The public interface is heavily documented to explain what should be implemented by subclasses. 
Timetable Description Display in UI¶
You can also provide a description for your Timetable Implementation
by overriding the description property.
This is especially useful for providing comprehensive description for your implementation in UI.
For our SometimeAfterWorkdayTimetable class, for example, we could have:
description = "Schedule: after each workday"
You can also wrap this inside __init__, if you want to derive description.
def __init__(self) -> None:
    self.description = "Schedule: after each workday, at f{self._schedule_at}"
This is specially useful when you want to provide comprehensive description which is different from summary property.
So for a Dag declared like this:
with DAG(
    schedule=SometimeAfterWorkdayTimetable(Time(8)),  # 8am.
    ...,
):
    ...
The i icon  would show,  Schedule: after each workday, at 08:00:00.
See also
- Module airflow.timetables.interval
- check - CronDataIntervalTimetabledescription implementation which provides comprehensive cron description in UI.
Changing generated run_id¶
Added in version 2.4.
Since Airflow 2.4, Timetables are also responsible for generating the run_id for DagRuns.
For example to have the Run ID show a “human friendly” date of when the run started (that is, the end of the data interval, rather then the start which is the date currently used) you could add a method like this to a custom timetable:
def generate_run_id(
    self,
    *,
    run_type: DagRunType,
    logical_date: DateTime,
    data_interval: DataInterval | None,
    **extra,
) -> str:
    if run_type == DagRunType.SCHEDULED and data_interval:
        return data_interval.end.format("YYYY-MM-DD dddd")
    return super().generate_run_id(
        run_type=run_type, logical_date=logical_date, data_interval=data_interval, **extra
    )
Remember that the RunID is limited to 250 characters, and must be unique within a Dag.