You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by GitBox <gi...@apache.org> on 2021/07/28 17:40:25 UTC

[GitHub] [airflow] jedcunningham opened a new issue #17291: [QUARANTINE] Quarantine test_retry_still_in_executor

jedcunningham opened a new issue #17291:
URL: https://github.com/apache/airflow/issues/17291


   The `TestSchedulerJob.test_retry_still_in_executor` fails occasionally and should be quarantined.
   
   ```
     ________________ TestSchedulerJob.test_retry_still_in_executor _________________
     
     self = <tests.jobs.test_scheduler_job.TestSchedulerJob object at 0x7f4c9031f128>
     
         def test_retry_still_in_executor(self):
             """
             Checks if the scheduler does not put a task in limbo, when a task is retried
             but is still present in the executor.
             """
             executor = MockExecutor(do_update=False)
             dagbag = DagBag(dag_folder=os.path.join(settings.DAGS_FOLDER, "no_dags.py"), include_examples=False)
             dagbag.dags.clear()
         
             dag = DAG(dag_id='test_retry_still_in_executor', start_date=DEFAULT_DATE, schedule_interval="@once")
             dag_task1 = BashOperator(
                 task_id='test_retry_handling_op', bash_command='exit 1', retries=1, dag=dag, owner='airflow'
             )
         
             dag.clear()
             dag.is_subdag = False
         
             with create_session() as session:
                 orm_dag = DagModel(dag_id=dag.dag_id)
                 orm_dag.is_paused = False
                 session.merge(orm_dag)
         
             dagbag.bag_dag(dag=dag, root_dag=dag)
             dagbag.sync_to_db()
         
             @mock.patch('airflow.dag_processing.processor.DagBag', return_value=dagbag)
             def do_schedule(mock_dagbag):
                 # Use a empty file since the above mock will return the
                 # expected DAGs. Also specify only a single file so that it doesn't
                 # try to schedule the above DAG repeatedly.
                 self.scheduler_job = SchedulerJob(
                     num_runs=1, executor=executor, subdir=os.path.join(settings.DAGS_FOLDER, "no_dags.py")
                 )
                 self.scheduler_job.heartrate = 0
                 self.scheduler_job.run()
         
             do_schedule()
             with create_session() as session:
                 ti = (
                     session.query(TaskInstance)
                     .filter(
                         TaskInstance.dag_id == 'test_retry_still_in_executor',
                         TaskInstance.task_id == 'test_retry_handling_op',
                     )
                     .first()
                 )
     >       ti.task = dag_task1
     E       AttributeError: 'NoneType' object has no attribute 'task'
     
     tests/jobs/test_scheduler_job.py:2514: AttributeError
   ```


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org



[GitHub] [airflow] potiuk closed issue #17291: [QUARANTINE] Quarantine test_retry_still_in_executor

Posted by GitBox <gi...@apache.org>.
potiuk closed issue #17291:
URL: https://github.com/apache/airflow/issues/17291


   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscribe@airflow.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org