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 2022/10/30 14:56:49 UTC

[GitHub] [airflow] Taragolis commented on pull request #27381: Additional info about Segmentation Violation in LocalTaskJob

Taragolis commented on PR #27381:
URL: https://github.com/apache/airflow/pull/27381#issuecomment-1296278774

   ### Sample DAG
   
   ```python
   import os
   import signal
   import pendulum
   from airflow.decorators import dag, task
   
   
   @dag(
       schedule_interval=None,
       start_date=pendulum.datetime(2022, 1, 1, tz="UTC"),
       catchup=False,
       tags=["signal.SIGSEGV", "Return Code: 11", "Negsignal.SIGSEGV"]
   )
   def example_sigsegv():
       @task
       def sigsegv_signal():
           pid = os.getpid()
           os.kill(pid, signal.SIGSEGV)
   
       sigsegv_signal()
   
   
   dag = example_sigsegv()
   
   ```
   
   ### Task Output Log
   ```text
   [2022-10-30, 14:45:54 UTC] {taskinstance.py:1159} INFO - Dependencies all met for <TaskInstance: example_sigsegv.sigsegv_signal manual__2022-10-30T14:45:52.990793+00:00 [queued]>
   [2022-10-30, 14:45:54 UTC] {taskinstance.py:1159} INFO - Dependencies all met for <TaskInstance: example_sigsegv.sigsegv_signal manual__2022-10-30T14:45:52.990793+00:00 [queued]>
   [2022-10-30, 14:45:54 UTC] {taskinstance.py:1355} INFO - 
   --------------------------------------------------------------------------------
   [2022-10-30, 14:45:54 UTC] {taskinstance.py:1356} INFO - Starting attempt 1 of 1
   [2022-10-30, 14:45:54 UTC] {taskinstance.py:1357} INFO - 
   --------------------------------------------------------------------------------
   [2022-10-30, 14:45:54 UTC] {taskinstance.py:1376} INFO - Executing <Task(_PythonDecoratedOperator): sigsegv_signal> on 2022-10-30 14:45:52.990793+00:00
   [2022-10-30, 14:45:54 UTC] {standard_task_runner.py:55} INFO - Started process 1261 to run task
   [2022-10-30, 14:45:54 UTC] {standard_task_runner.py:82} INFO - Running: ['airflow', 'tasks', 'run', 'example_sigsegv', 'sigsegv_signal', 'manual__2022-10-30T14:45:52.990793+00:00', '--job-id', '49', '--raw', '--subdir', 'DAGS_FOLDER/example_sigsegv.py', '--cfg-path', '/tmp/tmp3z3_7zqd']
   [2022-10-30, 14:45:54 UTC] {standard_task_runner.py:83} INFO - Job 49: Subtask sigsegv_signal
   [2022-10-30, 14:45:54 UTC] {task_command.py:376} INFO - Running <TaskInstance: example_sigsegv.sigsegv_signal manual__2022-10-30T14:45:52.990793+00:00 [running]> on host 2c85bba084bb
   [2022-10-30, 14:45:54 UTC] {taskinstance.py:1585} INFO - Exporting the following env vars:
   AIRFLOW_CTX_DAG_OWNER=airflow
   AIRFLOW_CTX_DAG_ID=example_sigsegv
   AIRFLOW_CTX_TASK_ID=sigsegv_signal
   AIRFLOW_CTX_EXECUTION_DATE=2022-10-30T14:45:52.990793+00:00
   AIRFLOW_CTX_TRY_NUMBER=1
   AIRFLOW_CTX_DAG_RUN_ID=manual__2022-10-30T14:45:52.990793+00:00
   [2022-10-30, 14:45:54 UTC] {local_task_job.py:176} CRITICAL - 
   ******************************************* Received SIGSEGV *******************************************
   SIGSEGV (Segmentation Violation) signal indicates
   an attempt by a program/library to write or read outside its allocated memory.
   
   In Python environment usually this signal refers to libraries which use low level C API.
   Make sure that you use use right libraries/Docker Images
   for your architecture (Intel/ARM) and/or Operational System (Linux/macOS).
   ********************************************************************************************************
   [2022-10-30, 14:45:54 UTC] {local_task_job.py:178} INFO - Task exited with return code Negsignal.SIGSEGV
   [2022-10-30, 14:45:54 UTC] {local_task_job.py:287} 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