You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by jh...@apache.org on 2021/08/17 02:04:36 UTC

[airflow] branch v2-1-test updated: Remove repeated test.

This is an automated email from the ASF dual-hosted git repository.

jhtimmins pushed a commit to branch v2-1-test
in repository https://gitbox.apache.org/repos/asf/airflow.git


The following commit(s) were added to refs/heads/v2-1-test by this push:
     new 3235675  Remove repeated test.
3235675 is described below

commit 3235675c91051715bf1d580665ca0d3f0e762c45
Author: James Timmins <ja...@astronomer.io>
AuthorDate: Mon Aug 16 19:04:13 2021 -0700

    Remove repeated test.
---
 CHANGELOG.txt                     |  2 +-
 tests/jobs/test_local_task_job.py | 28 ----------------------------
 2 files changed, 1 insertion(+), 29 deletions(-)

diff --git a/CHANGELOG.txt b/CHANGELOG.txt
index f0e5eaa..c624996 100644
--- a/CHANGELOG.txt
+++ b/CHANGELOG.txt
@@ -4,7 +4,7 @@ Airflow 2.1.3, 2021-08-23
 Bug Fixes
 """""""""
 
-- Fix task retries when they receive sigkill and have retries and properly handle sigterm (#16301)
+- Fix task retries when they receive ``sigkill`` and have retries and properly handle ``sigterm`` (#16301)
 - Fix redacting secrets in context exceptions. (#17618)
 - Fix race condition with dagrun callbacks (#16741)
 - Add 'queued' to DagRunState (#16854)
diff --git a/tests/jobs/test_local_task_job.py b/tests/jobs/test_local_task_job.py
index c18e6e5..14c74ce 100644
--- a/tests/jobs/test_local_task_job.py
+++ b/tests/jobs/test_local_task_job.py
@@ -864,34 +864,6 @@ class TestLocalTaskJob:
         session.refresh(dr)
         assert dr.state == State.SUCCESS
 
-    def test_task_exit_should_update_state_of_finished_dagruns_with_dag_paused(self, dag_maker):
-        """Test that with DAG paused, DagRun state will update when the tasks finishes the run"""
-        with dag_maker(dag_id='test_dags') as dag:
-            op1 = PythonOperator(task_id='dummy', python_callable=lambda: True)
-
-        session = settings.Session()
-        dagmodel = dag_maker.dag_model
-        dagmodel.next_dagrun_create_after = dag.following_schedule(DEFAULT_DATE)
-        dagmodel.is_paused = True
-        session.merge(dagmodel)
-        session.flush()
-
-        # Write Dag to DB
-        dagbag = DagBag(dag_folder="/dev/null", include_examples=False, read_dags_from_db=False)
-        dagbag.bag_dag(dag, root_dag=dag)
-        dagbag.sync_to_db()
-
-        dr = dag_maker.create_dagrun(run_type=DagRunType.SCHEDULED)
-
-        assert dr.state == State.RUNNING
-        ti = TaskInstance(op1, dr.execution_date)
-        job1 = LocalTaskJob(task_instance=ti, ignore_ti_state=True, executor=SequentialExecutor())
-        job1.task_runner = StandardTaskRunner(job1)
-        job1.run()
-        session.add(dr)
-        session.refresh(dr)
-        assert dr.state == State.SUCCESS
-
 
 @pytest.fixture()
 def clean_db_helper():