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/08/02 07:05:16 UTC

[GitHub] [airflow] cctvzd7 opened a new issue #17370: Task set to be failed by scheduler directly, while all up streams success

cctvzd7 opened a new issue #17370:
URL: https://github.com/apache/airflow/issues/17370


   **Apache Airflow version**: 2.1.1
   
   
   **Kubernetes version (if you are using kubernetes)** (use `kubectl version`): 
   
   **Environment**:
   
   - **Cloud provider or hardware configuration**:
   - **OS** (e.g. from /etc/os-release):
   - **Kernel** (e.g. `uname -a`): Linux e08g09383.cloud.eu13 3.10.0-327.ali2010.rc7.alios7.x86_64 #1 SMP Thu Jun 29 21:45:21 CST 2017 x86_64 x86_64 x86_64 GNU/Linux
   - **Install tools**: docker-compose
   - **Others**:
   I installed the airflow via docker-compose.yaml, and my docker-compose.yaml is as follows:
   `
   # Licensed to the Apache Software Foundation (ASF) under one
   # or more contributor license agreements.  See the NOTICE file
   # distributed with this work for additional information
   # regarding copyright ownership.  The ASF licenses this file
   # to you under the Apache License, Version 2.0 (the
   # "License"); you may not use this file except in compliance
   # with the License.  You may obtain a copy of the License at
   #
   #   http://www.apache.org/licenses/LICENSE-2.0
   #
   # Unless required by applicable law or agreed to in writing,
   # software distributed under the License is distributed on an
   # "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
   # KIND, either express or implied.  See the License for the
   # specific language governing permissions and limitations
   # under the License.
   #
   
   # Basic Airflow cluster configuration for CeleryExecutor with Redis and MySQL.
   #
   # WARNING: This configuration is for local development. Do not use it in a production deployment.
   #
   # This configuration supports basic configuration using environment variables or an .env file
   # The following variables are supported:
   #
   # AIRFLOW_IMAGE_NAME           - Docker image name used to run Airflow.
   #                                Default: apache/airflow:master-python3.8
   # AIRFLOW_UID                  - User ID in Airflow containers
   #                                Default: 50000
   # AIRFLOW_GID                  - Group ID in Airflow containers
   #                                Default: 50000
   #
   # Those configurations are useful mostly in case of standalone testing/running Airflow in test/try-out mode
   #
   # _AIRFLOW_WWW_USER_USERNAME   - Username for the administrator account (if requested).
   #                                Default: airflow
   # _AIRFLOW_WWW_USER_PASSWORD   - Password for the administrator account (if requested).
   #                                Default: airflow
   # _PIP_ADDITIONAL_REQUIREMENTS - Additional PIP requirements to add when starting all containers.
   #                                Default: ''
   #
   # Feel free to modify this file to suit your needs.
   ---
   version: '3'
   x-airflow-common:
     &airflow-common
     image: ${AIRFLOW_IMAGE_NAME}
     environment:
       &airflow-common-env
       AIRFLOW__CORE__EXECUTOR: CeleryExecutor
       AIRFLOW__CORE__SQL_ALCHEMY_CONN: mysql+pymysql://airflow:252***03e@mysql/airflow
       AIRFLOW__CELERY__RESULT_BACKEND: db+mysql://airflow:252***03e@mysql/airflow
       AIRFLOW__CELERY__BROKER_URL: redis://:@redis:6379/0
       AIRFLOW__CORE__FERNET_KEY: ''
       AIRFLOW__CORE__DEFAULT_TIMEZONE: 'Asia/Shanghai'
       AIRFLOW__WEBSERVER__DEFAULT_UI_TIMEZONE: 'Asia/Shanghai'
       AIRFLOW__CORE__DAGS_ARE_PAUSED_AT_CREATION: 'true'
       AIRFLOW__CORE__LOAD_EXAMPLES: 'false'
       AIRFLOW__API__AUTH_BACKEND: 'airflow.api.auth.backend.basic_auth'
       _PIP_ADDITIONAL_REQUIREMENTS: ${_PIP_ADDITIONAL_REQUIREMENTS:-}
       TZ: 'Asia/Shanghai'
   
     volumes:
       - ./dags:/opt/airflow/dags
       - ./logs:/opt/airflow/logs
       - ./plugins:/opt/airflow/plugins
     user: "${AIRFLOW_UID:-50000}:${AIRFLOW_GID:-50000}"
     depends_on:
       redis:
         condition: service_healthy
       mysql:
         condition: service_healthy
   
   services:
     mysql:
       image: reg.docker.alibaba-inc.com/ververica-paas/mysql-server:8.0.25
       command: --default-authentication-plugin=mysql_native_password
       restart: always
       deploy:
         resources:
           limits:
             memory: 4G
             cpus: 1
       ports:
         - 3606:3306
       security_opt:
         - seccomp:unconfined
       volumes:
         - ./mysql-data:/var/lib/mysql
       environment:
         MYSQL_ROOT_PASSWORD: 252***03e
         MYSQL_DATABASE: airflow
         MYSQL_USER: airflow
         MYSQL_PASSWORD: 252***03e
       healthcheck:
         test: mysqladmin ping -h localhost -u $$MYSQL_USER --password=$$MYSQL_PASSWORD
         interval: 5s
         timeout: 5s
         retries: 5
   
     redis:
       image: reg.docker.alibaba-inc.com/ververica-paas/redis:6.2.4-buster
       ports:
         - 6379:6379
       volumes:
         - ./redis-data:/data
       healthcheck:
         test: [ "CMD", "redis-cli", "ping" ]
         interval: 5s
         timeout: 30s
         retries: 50
       restart: always
       deploy:
         resources:
           limits:
             memory: 4G
             cpus: 1
   
     airflow-webserver:
       <<: *airflow-common
       command: webserver
       ports:
         - 9999:8080
       healthcheck:
         test: [ "CMD", "curl", "--fail", "http://localhost:8080/health" ]
         interval: 10s
         timeout: 10s
         retries: 5
       restart: always
       deploy:
         resources:
           limits:
             memory: 8G
             cpus: 2
   
     airflow-scheduler:
       <<: *airflow-common
       command: scheduler
       healthcheck:
         test: [ "CMD-SHELL", 'airflow jobs check --job-type SchedulerJob --hostname "$${HOSTNAME}"' ]
         interval: 10s
         timeout: 10s
         retries: 5
       restart: always
       deploy:
         resources:
           limits:
             memory: 4G
             cpus: 1
   
     airflow-worker:
       <<: *airflow-common
       command: celery worker
       healthcheck:
         test:
           - "CMD-SHELL"
           - 'celery --app airflow.executors.celery_executor.app inspect ping -d "celery@$${HOSTNAME}"'
         interval: 10s
         timeout: 10s
         retries: 5
       restart: always
       deploy:
         resources:
           limits:
             memory: 8G
             cpus: 2
   
     airflow-init:
       <<: *airflow-common
       command: version
       environment:
         <<: *airflow-common-env
         _AIRFLOW_DB_UPGRADE: 'true'
         _AIRFLOW_WWW_USER_CREATE: 'true'
         _AIRFLOW_WWW_USER_USERNAME: ${_AIRFLOW_WWW_USER_USERNAME}
         _AIRFLOW_WWW_USER_PASSWORD: ${_AIRFLOW_WWW_USER_PASSWORD}
       deploy:
         resources:
           limits:
             memory: 2G
             cpus: 1
   
     flower:
       <<: *airflow-common
       command: celery flower
       ports:
         - 5555:5555
       healthcheck:
         test: [ "CMD", "curl", "--fail", "http://localhost:5555/" ]
         interval: 10s
         timeout: 10s
         retries: 5
       restart: always
       deploy:
         resources:
           limits:
             memory: 4G
             cpus: 1
   networks:
     default:
       external:
         name: airflow_default
   
   `
   
   **What happened**:
   
   A task was set to be failed directly by scheduler, while all up streams were success.
   The task has not be run, no log info either.
   
   **What you expected to happen**:
   
   The task should be running
   
   **How to reproduce it**:
   It happens by chance, I can not reproduce it.
   
   **Anything else we need to know**:
   A log from scheduler:
   [2021-08-01 21:46:14,003] {scheduler_job.py:600} INFO - Executed failure callback for <TaskInstance: blink_create_cluster.create_master_ecs_task 2021-08-01 13:46:09.195000+00:00 [failed]> in state failed
   
   


-- 
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] cctvzd7 commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
cctvzd7 commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-890802962


   > Could you post some context around the log? That log line simply says the task has failed, which we already know from your description. Something might have happened before that to trigger the failure state.
   There was only one log line about this issue in scheduler log file.
   ![image](https://user-images.githubusercontent.com/7961421/127823563-8306479b-0657-4637-9b79-9424d7c3b9f2.png)
   


-- 
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] cctvzd7 commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
cctvzd7 commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-893113306


   @jedcunningham @uranusjr 
   Any ideas about this issue?


-- 
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] ephraimbuddy commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
ephraimbuddy commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-890838205


   @cctvzd7 can you add a dag that can be used to reproduce this?


-- 
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] shubhamg931 commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
shubhamg931 commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-931619081


   This is a duplicate of https://github.com/apache/airflow/issues/18401 right?


-- 
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] ephraimbuddy commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
ephraimbuddy commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-893236021


   > May be related with: #16625
   
   If so, then it's resolved in https://github.com/apache/airflow/pull/16301 which will be released in 2.1.3


-- 
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] uranusjr commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
uranusjr commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-890804205


   That’s unfortunate. Maybe someone would be able to spot some pattern.


-- 
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] cctvzd7 edited a comment on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
cctvzd7 edited a comment on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-891506572


   @jedcunningham @uranusjr 
   I enable debug log level in scheduler, and the logs are as follows:
   
   ```
   [2021-08-03 11:41:46,088] {scheduler_job.py:643} INFO - DAG(s) dict_keys(['blink_deploy_zprofile']) retrieved from /opt/airflow/dags/dag/blink_deploy_zprofile.py
   [2021-08-03 11:41:46,088] {scheduler_job.py:560} DEBUG - Processing Callback Request: {'full_filepath': '/opt/airflow/dags/dag/blink_deploy_zprofile.py', 'msg': 'Executor reports task instance <TaskInstance: blink_deploy_zprofile.add_security_group_rule_task 2021-08-03 03:41:43.527000+00:00 [queued]> finished (failed) although the task says its queued. (Info: None) Was the task killed externally?', 'simple_task_instance': <airflow.models.taskinstance.SimpleTaskInstance object at 0x7fa1ca377ba8>, 'is_failure_callback': True}
   [2021-08-03 11:41:46,164] {scheduler_job.py:600} INFO - Executed failure callback for <TaskInstance: blink_deploy_zprofile.add_security_group_rule_task 2021-08-03 03:41:43.527000+00:00 [failed]> in state failed
   ```
   
   ![image](https://user-images.githubusercontent.com/7961421/127956827-34804fde-4e96-4eb8-a010-f4eeceba1798.png)
   


-- 
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] cctvzd7 edited a comment on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
cctvzd7 edited a comment on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-890802962


   There was only one log line about this issue in scheduler log file.
   ![image](https://user-images.githubusercontent.com/7961421/127823563-8306479b-0657-4637-9b79-9424d7c3b9f2.png)
   


-- 
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] cctvzd7 commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
cctvzd7 commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-891662894


   May be related with: #16625 


-- 
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] ephraimbuddy commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
ephraimbuddy commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-895885489


   > > > May be related with: #16625
   > > 
   > > 
   > > If so, then it's resolved in #16301 which will be released in 2.1.3
   > 
   > @ephraimbuddy I don't think that #16301 solves #16625, the code in that PR is only ran when the container has been started. But the issue in #16625 happens when a pod has never started but did fail. I added some more info on the issue #16625 maybe this sheds a bit more light on what might be going on.
   
   Oh, I see, we even had an issue with task being stuck in queued because a POD had an error starting or something else happened, and the executor report that the task has failed while the scheduler still sees it as queued. We made this change https://github.com/apache/airflow/pull/15929 which has not been released to resolve the task getting stuck. 
   I will take a closer look and see if we can make this work properly


-- 
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] cctvzd7 commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
cctvzd7 commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-891506572


   @jedcunningham @uranusjr 
   I enable debug log level in scheduler, and the logs are as follows:
   
   [2021-08-03 11:41:46,088] {scheduler_job.py:643} INFO - DAG(s) dict_keys(['blink_deploy_zprofile']) retrieved from /opt/airflow/dags/dag/blink_deploy_zprofile.py
   [2021-08-03 11:41:46,088] {scheduler_job.py:560} DEBUG - Processing Callback Request: {'full_filepath': '/opt/airflow/dags/dag/blink_deploy_zprofile.py', 'msg': 'Executor reports task instance <TaskInstance: blink_deploy_zprofile.add_security_group_rule_task 2021-08-03 03:41:43.527000+00:00 [queued]> finished (failed) although the task says its queued. (Info: None) Was the task killed externally?', 'simple_task_instance': <airflow.models.taskinstance.SimpleTaskInstance object at 0x7fa1ca377ba8>, 'is_failure_callback': True}
   [2021-08-03 11:41:46,164] {scheduler_job.py:600} INFO - Executed failure callback for <TaskInstance: blink_deploy_zprofile.add_security_group_rule_task 2021-08-03 03:41:43.527000+00:00 [failed]> in state failed


-- 
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] boring-cyborg[bot] commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
boring-cyborg[bot] commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-890776863


   Thanks for opening your first issue here! Be sure to follow the issue template!
   


-- 
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] ephraimbuddy commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
ephraimbuddy commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-893236021


   > May be related with: #16625
   
   If so, then it's resolved in https://github.com/apache/airflow/pull/16301 which will be released in 2.1.3


-- 
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] uranusjr commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
uranusjr commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-890796585


   Could you post some context around the log? That log line simply says the task has failed, which we already know from your description. Something might have happened before that to trigger the failure state.


-- 
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] jedcunningham commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
jedcunningham commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-891431935


   Is there anything in the normal scheduler log (the above is the parsing log)?


-- 
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] stijndehaes commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
stijndehaes commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-895995979


   > > > > May be related with: #16625
   > > > 
   > > > 
   > > > If so, then it's resolved in #16301 which will be released in 2.1.3
   > > 
   > > 
   > > @ephraimbuddy I don't think that #16301 solves #16625, the code in that PR is only ran when the container has been started. But the issue in #16625 happens when a pod has never started but did fail. I added some more info on the issue #16625 maybe this sheds a bit more light on what might be going on.
   > 
   > Oh, I see, we even had an issue with task being stuck in queued because a POD had an error starting or something else happened, and the executor report that the task has failed while the scheduler still sees it as queued. We made this change #15929 which has not been released to resolve the task getting stuck.
   > I will take a closer look and see if we can make this work properly
   
   Ah I thought this code was already active in our environment but it isn't 😅 If you could look into making this more robust that would be great. If I can provide more info or help please let me know


-- 
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] stijndehaes commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
stijndehaes commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-895877622


   > > May be related with: #16625
   > 
   > If so, then it's resolved in #16301 which will be released in 2.1.3
   
   @ephraimbuddy I don't think that #16301 solves #16625, the code in that PR is only ran when the container has been started. But the issue in #16625 happens when a pod has never started but did fail. I added some more info on the issue #16625 maybe this sheds a bit more light on what might be going on.


-- 
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] cctvzd7 commented on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
cctvzd7 commented on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-893113306


   @jedcunningham @uranusjr 
   Any ideas about this issue?


-- 
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] cctvzd7 edited a comment on issue #17370: Task set to be failed by scheduler directly, while all up streams success

Posted by GitBox <gi...@apache.org>.
cctvzd7 edited a comment on issue #17370:
URL: https://github.com/apache/airflow/issues/17370#issuecomment-891506572


   @jedcunningham @uranusjr 
   I enable debug log level in scheduler, and the logs are as follows:
   
   [2021-08-03 11:41:46,088] {scheduler_job.py:643} INFO - DAG(s) dict_keys(['blink_deploy_zprofile']) retrieved from /opt/airflow/dags/dag/blink_deploy_zprofile.py
   [2021-08-03 11:41:46,088] {scheduler_job.py:560} DEBUG - Processing Callback Request: {'full_filepath': '/opt/airflow/dags/dag/blink_deploy_zprofile.py', 'msg': 'Executor reports task instance <TaskInstance: blink_deploy_zprofile.add_security_group_rule_task 2021-08-03 03:41:43.527000+00:00 [queued]> finished (failed) although the task says its queued. (Info: None) Was the task killed externally?', 'simple_task_instance': <airflow.models.taskinstance.SimpleTaskInstance object at 0x7fa1ca377ba8>, 'is_failure_callback': True}
   [2021-08-03 11:41:46,164] {scheduler_job.py:600} INFO - Executed failure callback for <TaskInstance: blink_deploy_zprofile.add_security_group_rule_task 2021-08-03 03:41:43.527000+00:00 [failed]> in state failed
   
   ![image](https://user-images.githubusercontent.com/7961421/127956827-34804fde-4e96-4eb8-a010-f4eeceba1798.png)
   


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