Skip to content
Merged
Show file tree
Hide file tree
Changes from all commits
Commits
File filter

Filter by extension

Filter by extension

Conversations
Failed to load comments.
Loading
Jump to
Jump to file
Failed to load files.
Loading
Diff view
Diff view
2 changes: 1 addition & 1 deletion task-sdk/src/airflow/sdk/execution_time/task_runner.py
Original file line number Diff line number Diff line change
Expand Up @@ -765,7 +765,7 @@ def _verify_bundle_access(bundle_instance: BaseDagBundle, log: Logger) -> None:
"""
from getpass import getuser

from airflow.exceptions import AirflowException
from airflow.sdk.exceptions import AirflowException

bundle_path = bundle_instance.path

Expand Down
4 changes: 2 additions & 2 deletions task-sdk/tests/task_sdk/definitions/test_taskgroup.py
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,6 @@
import pendulum
import pytest

from airflow.exceptions import TaskAlreadyInTaskGroup
from airflow.sdk import (
DAG,
XComArg,
Expand All @@ -32,6 +31,7 @@
timezone,
)
from airflow.sdk.definitions.taskgroup import TaskGroup
from airflow.sdk.exceptions import TaskAlreadyInTaskGroup

from tests_common.test_utils.compat import BashOperator, EmptyOperator, PythonOperator

Expand Down Expand Up @@ -426,7 +426,7 @@ def test_dag_edges_task_group_structure():


def test_duplicate_group_id():
from airflow.exceptions import DuplicateTaskIdFound
from airflow.sdk.exceptions import DuplicateTaskIdFound

logical_date = pendulum.parse("20200101")

Expand Down
4 changes: 2 additions & 2 deletions task-sdk/tests/task_sdk/execution_time/test_task_runner.py
Original file line number Diff line number Diff line change
Expand Up @@ -2949,7 +2949,7 @@ def execute(self, context):
)
def test_email_on_failure(self, emails, sent, create_runtime_ti, mock_supervisor_comms):
"""Test email notification on task failure."""
from airflow.exceptions import AirflowFailException
from airflow.sdk.exceptions import AirflowFailException
from airflow.sdk.execution_time.task_runner import finalize, run

class FailingOperator(BaseOperator):
Expand Down Expand Up @@ -2985,7 +2985,7 @@ def execute(self, context):

def test_email_with_custom_templates(self, create_runtime_ti, mock_supervisor_comms, tmp_path):
"""Test email notification respects custom subject and html_content templates."""
from airflow.exceptions import AirflowFailException
from airflow.sdk.exceptions import AirflowFailException

subject_template = tmp_path / "custom_subject.jinja2"
html_template = tmp_path / "custom_html.html"
Expand Down