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/11/30 10:33:44 UTC

[GitHub] [airflow] ephraimbuddy commented on a change in pull request #19860: Restore stability and unquarantine all test_scheduler_job tests

ephraimbuddy commented on a change in pull request #19860:
URL: https://github.com/apache/airflow/pull/19860#discussion_r759142516



##########
File path: tests/jobs/test_scheduler_job.py
##########
@@ -1858,26 +1844,20 @@ def _create_dagruns():
         # As tasks require 2 slots, only 3 can fit into 6 available
         assert len(task_instances_list) == 3
 
-    @pytest.mark.quarantined
     def test_scheduler_keeps_scheduling_pool_full(self, dag_maker):
         """
         Test task instances in a pool that isn't full keep getting scheduled even when a pool is full.
         """
-        with dag_maker(
-            dag_id='test_scheduler_keeps_scheduling_pool_full_d1',
-            start_date=DEFAULT_DATE,
-        ):
+
+        with dag_maker(dag_id='test_scheduler_keeps_scheduling_pool_full_d1', start_date=DEFAULT_DATE):

Review comment:
       Maybe we should use the session fixture here and have everything use the same session. Not a problem though.
   ```python
   def test_scheduler_keeps_scheduling_pool_full(self, session, dag_maker):
           """
           Test task instances in a pool that isn't full keep getting scheduled even when a pool is full.
           """
           with dag_maker(
               dag_id='test_scheduler_keeps_scheduling_pool_full_d1',
               start_date=DEFAULT_DATE,
               session = session
           ):
               BashOperator(
                   task_id='test_scheduler_keeps_scheduling_pool_full_t1',
                   pool='test_scheduler_keeps_scheduling_pool_full_p1',
                   bash_command='echo hi',
               )
           dag_d1 = dag_maker.dag
   
           with dag_maker(
               dag_id='test_scheduler_keeps_scheduling_pool_full_d2',
               start_date=DEFAULT_DATE,
               session=session
           ):
               BashOperator(
                   task_id='test_scheduler_keeps_scheduling_pool_full_t2',
                   pool='test_scheduler_keeps_scheduling_pool_full_p2',
                   bash_command='echo hi',
               )
           dag_d2 = dag_maker.dag
           pool_p1 = Pool(pool='test_scheduler_keeps_scheduling_pool_full_p1', slots=1)
           pool_p2 = Pool(pool='test_scheduler_keeps_scheduling_pool_full_p2', slots=10)
           session.add(pool_p1)
           session.add(pool_p2)
           session.flush()
   
           scheduler = SchedulerJob(executor=self.null_exec)
           scheduler.processor_agent = mock.MagicMock()
   ```




-- 
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