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/01 12:29:29 UTC

[GitHub] [airflow] nathadfield commented on issue #19346: Sensors no longer respecting `retries` with timeouts.

nathadfield commented on issue #19346:
URL: https://github.com/apache/airflow/issues/19346#issuecomment-956193222


   Task log:
   
   ```
   --------------------------------------------------------------------------------
   [2021-11-01, 12:28:55 UTC] {taskinstance.py:1240} INFO - Starting attempt 1 of 3
   [2021-11-01, 12:28:55 UTC] {taskinstance.py:1241} INFO - 
   --------------------------------------------------------------------------------
   [2021-11-01, 12:28:55 UTC] {taskinstance.py:1260} INFO - Executing <Task(ExternalTaskSensor): sensor> on 2021-10-31 00:00:00+00:00
   [2021-11-01, 12:28:55 UTC] {standard_task_runner.py:52} INFO - Started process 611 to run task
   [2021-11-01, 12:28:55 UTC] {standard_task_runner.py:76} INFO - Running: ['***', 'tasks', 'run', 'child_dag', 'sensor', 'scheduled__2021-10-31T00:00:00+00:00', '--job-id', '33', '--raw', '--subdir', 'DAGS_FOLDER/child_dag.py', '--cfg-path', '/tmp/tmpbc8xmbmm', '--error-file', '/tmp/tmp36p794w3']
   [2021-11-01, 12:28:55 UTC] {standard_task_runner.py:77} INFO - Job 33: Subtask sensor
   [2021-11-01, 12:28:55 UTC] {logging_mixin.py:109} INFO - Running <TaskInstance: child_dag.sensor scheduled__2021-10-31T00:00:00+00:00 [running]> on host 986a9620cf97
   [2021-11-01, 12:28:55 UTC] {taskinstance.py:1427} INFO - Exporting the following env vars:
   AIRFLOW_CTX_DAG_OWNER=***
   AIRFLOW_CTX_DAG_ID=child_dag
   AIRFLOW_CTX_TASK_ID=sensor
   AIRFLOW_CTX_EXECUTION_DATE=2021-10-31T00:00:00+00:00
   AIRFLOW_CTX_DAG_RUN_ID=scheduled__2021-10-31T00:00:00+00:00
   [2021-11-01, 12:28:55 UTC] {logging_mixin.py:109} WARNING - /opt/***/***/models/taskinstance.py:1939 DeprecationWarning: Accessing 'execution_date' from the template is deprecated and will be removed in a future version. Please use 'logical_date' or 'data_interval_start' instead.
   [2021-11-01, 12:28:55 UTC] {external_task.py:173} INFO - Poking for tasks ['dummy'] in dag parent_dag on 2021-10-31T00:00:00+00:00 ... 
   [2021-11-01, 12:28:55 UTC] {taskinstance.py:1701} ERROR - Task failed with exception
   Traceback (most recent call last):
     File "/opt/airflow/airflow/models/taskinstance.py", line 1330, in _run_raw_task
       self._execute_task_with_callbacks(context)
     File "/opt/airflow/airflow/models/taskinstance.py", line 1456, in _execute_task_with_callbacks
       result = self._execute_task(context, self.task)
     File "/opt/airflow/airflow/models/taskinstance.py", line 1512, in _execute_task
       result = execute_callable(context=context)
     File "/opt/airflow/airflow/sensors/base.py", line 234, in execute
       raise AirflowSensorTimeout(f"Snap. Time is OUT. DAG id: {log_dag_id}")
   airflow.exceptions.AirflowSensorTimeout: Snap. Time is OUT. DAG id: child_dag
   [2021-11-01, 12:28:55 UTC] {taskinstance.py:1278} INFO - Immediate failure requested. Marking task as FAILED. dag_id=child_dag, task_id=sensor, execution_date=20211031T000000, start_date=20211101T122855, end_date=20211101T122855
   [2021-11-01, 12:28:55 UTC] {standard_task_runner.py:91} ERROR - Failed to execute job 33 for task sensor
   Traceback (most recent call last):
     File "/opt/airflow/airflow/task/task_runner/standard_task_runner.py", line 85, in _start_by_fork
       args.func(args, dag=self.dag)
     File "/opt/airflow/airflow/cli/cli_parser.py", line 48, in command
       return func(*args, **kwargs)
     File "/opt/airflow/airflow/utils/cli.py", line 92, in wrapper
       return f(*args, **kwargs)
     File "/opt/airflow/airflow/cli/commands/task_command.py", line 293, in task_run
       _run_task_by_selected_method(args, dag, ti)
     File "/opt/airflow/airflow/cli/commands/task_command.py", line 107, in _run_task_by_selected_method
       _run_raw_task(args, ti)
     File "/opt/airflow/airflow/cli/commands/task_command.py", line 184, in _run_raw_task
       error_file=args.error_file,
     File "/opt/airflow/airflow/utils/session.py", line 70, in wrapper
       return func(*args, session=session, **kwargs)
     File "/opt/airflow/airflow/models/taskinstance.py", line 1330, in _run_raw_task
       self._execute_task_with_callbacks(context)
     File "/opt/airflow/airflow/models/taskinstance.py", line 1456, in _execute_task_with_callbacks
       result = self._execute_task(context, self.task)
     File "/opt/airflow/airflow/models/taskinstance.py", line 1512, in _execute_task
       result = execute_callable(context=context)
     File "/opt/airflow/airflow/sensors/base.py", line 234, in execute
       raise AirflowSensorTimeout(f"Snap. Time is OUT. DAG id: {log_dag_id}")
   airflow.exceptions.AirflowSensorTimeout: Snap. Time is OUT. DAG id: child_dag
   [2021-11-01, 12:28:55 UTC] {local_task_job.py:154} INFO - Task exited with return code 1
   [2021-11-01, 12:28:55 UTC] {local_task_job.py:264} INFO - 0 downstream tasks scheduled from follow-on schedule check
   ```


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