You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by "audubon (JIRA)" <ji...@apache.org> on 2016/06/09 23:32:21 UTC

[jira] [Created] (AIRFLOW-229) new DAG runs 5 times when manually started from website

audubon created AIRFLOW-229:
-------------------------------

             Summary: new DAG runs 5 times when manually started from website
                 Key: AIRFLOW-229
                 URL: https://issues.apache.org/jira/browse/AIRFLOW-229
             Project: Apache Airflow
          Issue Type: Bug
    Affects Versions: Airflow 1.6.2
         Environment: celery, rabbitmq, mysql
            Reporter: audubon
            Priority: Minor


version 1.6.2
using celery, rabbitmq, mysql

example:

from airflow import DAG
from airflow.operators import BashOperator
from datetime import datetime, timedelta
import json
import sys

one_day_ahead = datetime.combine(datetime.today() + timedelta(1), datetime.min.time())
one_day_ahead = one_day_ahead.replace(hour=3, minute=31)

default_args = {
    'owner': 'airflow',
    'depends_on_past': False,
    'start_date': one_day_ahead,
    'email': ['me@email.com'],
    'email_on_failure': True,
    'email_on_retry': False,
    'retries': 1,
    'retry_delay': timedelta(minutes=5),
}

dag = DAG('alpha', default_args=default_args , schedule_interval='15 6 * * *' )

task = BashOperator(
        task_id='alphaV2',
        bash_command='sleep 10',
        dag=dag)



--
This message was sent by Atlassian JIRA
(v6.3.4#6332)