You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by "Soeren Laursen (Jira)" <ji...@apache.org> on 2020/02/13 22:31:00 UTC

[jira] [Created] (AIRFLOW-6799) webgui cannot display all tasks

Soeren Laursen created AIRFLOW-6799:
---------------------------------------

             Summary: webgui cannot display all tasks
                 Key: AIRFLOW-6799
                 URL: https://issues.apache.org/jira/browse/AIRFLOW-6799
             Project: Apache Airflow
          Issue Type: Bug
          Components: webserver
    Affects Versions: 1.10.9, 1.10.7
         Environment: linux in a docker container.
            Reporter: Soeren Laursen


The we have "to many" task the graph rendering stops with an 
Edge 'undefined' is not in graph javascript error,

There is no graph in the webgui. Lowering the number of task will enable the the rendering again.

Examplecode:
from airflow import DAG
from airflow.models import DAG
from airflow.operators.dummy_operator import DummyOperator

from datetime import datetime
from datetime import timedelta

DAG_task_concurrency = 30
DAG_max_active_runs = 10

MAIN_DAG_ID = 'BUG_IN_GRAPH_DISPLAY'

default_args = {
    'owner':'prod', 
    'depends_on_past':False, 
    'email':['sln@fcoo.dk'], 
    'email_on_failure':False, 
    'email_on_retry':False, 
    'retries':3, 
    'retry_delay':timedelta(seconds=30),
    'queue':'default'}

BUG_DAG = DAG(MAIN_DAG_ID,
              default_args=default_args,
              catchup=False,
              orientation='LR',
              concurrency=DAG_task_concurrency,
              schedule_interval='@once',
              max_active_runs=DAG_max_active_runs,
              start_date=(datetime(2020, 2, 5))
)

# To many tasks
max_task = 160
# 156 ok

task_range = list(range(0, max_task + 1))

start_task =  DummyOperator(task_id='start_task', dag=BUG_DAG)
after_all_complete =  DummyOperator(task_id='after_all_complete', dag=BUG_DAG)

for task_step in task_range:
    task1 = DummyOperator(task_id='task_{0}'.format(task_step),dag=BUG_DAG)
    start_task >> task1 >> after_all_complete



--
This message was sent by Atlassian Jira
(v8.3.4#803005)