You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by "Dean (JIRA)" <ji...@apache.org> on 2019/06/21 17:04:02 UTC

[jira] [Updated] (AIRFLOW-4832) Infinite loops during fall DST transition

     [ https://issues.apache.org/jira/browse/AIRFLOW-4832?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Dean updated AIRFLOW-4832:
--------------------------
    Description: 
This seems similar to AIRFLOW-3422, but is still happening in 1.10.3. I'm running  python 3.6.8.

I'm running this dag:

{code:python}
from airflow import DAG
from airflow.operators.python_operator import PythonOperator
from datetime import datetime
import logging
from pendulum import timezone

def msg(**kwargs):
    logging.info(str(kwargs['execution_date']))

default_args = {
    'start_date': datetime(2018, 11, 1, tzinfo=timezone('America/Los_Angeles')),
}

dag = DAG('tz_test_1',
           default_args=default_args,
           catchup=True,
           schedule_interval='0 2 * * *')

t1 = PythonOperator(
    task_id='t1',
    provide_context=True,
    python_callable=msg,
    dag=dag)
{code}

On Nov 4 the clock goes from 1:59:59 AM to 1:00:00 AM. The backfill will run tasks until this one runs:

{noformat}
{tz_test.py:8} INFO - 2018-11-04T09:00:00+00:00
{noformat}

After that, running further tasks doesn't seem to be possible for this dag.

Note that the same dag with {{schedule_interval}} changed to {{'0 0 * * *'}} or {{'0 1 * * *'}} does not have this problem

  was:
This seems similar to AIRFLOW-3422, but is still happening in 1.10.3. I'm running  python 3.6.8.

I'm running this dag:

{code:python}
from airflow import DAG
from airflow.operators.python_operator import PythonOperator
from datetime import datetime
import logging
from pendulum import timezone

def msg(**kwargs):
    logging.info(str(kwargs['execution_date']))

default_args = {
    'start_date': datetime(2018, 11, 1, tzinfo=timezone('America/Los_Angeles')),
}

dag = DAG('tz_test_1',
           default_args=default_args,
           catchup=True,
           schedule_interval='0 2 * * *')

t1 = PythonOperator(
    task_id='t1',
    provide_context=True,
    python_callable=msg,
    dag=dag)
{code}

On Nov 4 the clock goes from 1:59:59 AM to 1:00:00 AM. The backfill will run tasks until this one runs:

{noformat}
{tz_test.py:8} INFO - 2018-11-04T09:00:00+00:00
{noformat}

After that, running further tasks doesn't seem to be possible for this dag.


> Infinite loops during fall DST transition
> -----------------------------------------
>
>                 Key: AIRFLOW-4832
>                 URL: https://issues.apache.org/jira/browse/AIRFLOW-4832
>             Project: Apache Airflow
>          Issue Type: Bug
>          Components: scheduler
>    Affects Versions: 1.10.3
>            Reporter: Dean
>            Priority: Major
>
> This seems similar to AIRFLOW-3422, but is still happening in 1.10.3. I'm running  python 3.6.8.
> I'm running this dag:
> {code:python}
> from airflow import DAG
> from airflow.operators.python_operator import PythonOperator
> from datetime import datetime
> import logging
> from pendulum import timezone
> def msg(**kwargs):
>     logging.info(str(kwargs['execution_date']))
> default_args = {
>     'start_date': datetime(2018, 11, 1, tzinfo=timezone('America/Los_Angeles')),
> }
> dag = DAG('tz_test_1',
>            default_args=default_args,
>            catchup=True,
>            schedule_interval='0 2 * * *')
> t1 = PythonOperator(
>     task_id='t1',
>     provide_context=True,
>     python_callable=msg,
>     dag=dag)
> {code}
> On Nov 4 the clock goes from 1:59:59 AM to 1:00:00 AM. The backfill will run tasks until this one runs:
> {noformat}
> {tz_test.py:8} INFO - 2018-11-04T09:00:00+00:00
> {noformat}
> After that, running further tasks doesn't seem to be possible for this dag.
> Note that the same dag with {{schedule_interval}} changed to {{'0 0 * * *'}} or {{'0 1 * * *'}} does not have this problem



--
This message was sent by Atlassian JIRA
(v7.6.3#76005)