You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by "Zachary Lawson (JIRA)" <ji...@apache.org> on 2017/04/27 19:07:04 UTC

[jira] [Created] (AIRFLOW-1156) Using a timedelta object as a Schedule Interval with catchup=False causes the start_date to no longer be honored.

Zachary Lawson created AIRFLOW-1156:
---------------------------------------

             Summary: Using a timedelta object as a Schedule Interval with catchup=False causes the start_date to no longer be honored.
                 Key: AIRFLOW-1156
                 URL: https://issues.apache.org/jira/browse/AIRFLOW-1156
             Project: Apache Airflow
          Issue Type: Bug
    Affects Versions: Airflow 1.8
            Reporter: Zachary Lawson
            Priority: Minor


Currently, in Airflow v1.8, if you set your schedule_interval to a timedelta object and set catchup=False, the start_date is no longer honored and the DAG is scheduled immediately upon unpausing the DAG. It is then schedule on the schedule interval from that point onward. Example below:
{code}
from airflow import DAG
from datetime import datetime, timedelta
import logging
from airflow.operators.python_operator import PythonOperator

default_args = {
    'owner': 'airflow',
    'depends_on_past': False,
    'start_date': datetime(2015, 6, 1),
}

dag = DAG('test', default_args=default_args, schedule_interval=timedelta(seconds=5), catchup=False)

def context_test(ds, **context):
    logging.info('testing')

test_context = PythonOperator(
    task_id='test_context',
    provide_context=True,
    python_callable=context_test,
    dag=dag
)
{code}

If you switch the above over to a CRON expression, the behavior of the scheduling is returned to the expected.



--
This message was sent by Atlassian JIRA
(v6.3.15#6346)