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
Original file line number Diff line number Diff line change
Expand Up @@ -303,7 +303,6 @@ def execute(self, context: Context):
external_task_id=self.external_task_id,
success_states=self.success_states,
failure_states=self.failure_states,
airflow_version=self.airflow_version,
waiter_delay=int(self.poke_interval),
waiter_max_attempts=self.max_retries,
aws_conn_id=self.aws_conn_id,
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@
from __future__ import annotations

from collections.abc import Collection
from typing import TYPE_CHECKING, Literal
from typing import TYPE_CHECKING

from airflow.providers.amazon.aws.hooks.mwaa import MwaaHook
from airflow.providers.amazon.aws.triggers.base import AwsBaseWaiterTrigger
Expand Down Expand Up @@ -121,8 +121,6 @@ class MwaaTaskCompletedTrigger(AwsBaseWaiterTrigger):
``{airflow.utils.state.TaskInstanceState.SUCCESS}`` (templated)
:param failure_states: Collection of task instance states that would make this task marked as failed and raise an
AirflowException, default is ``{airflow.utils.state.TaskInstanceState.FAILED}`` (templated)
:param airflow_version: The Airflow major version the MWAA environment runs.
This parameter is only used if the local web token method is used to call Airflow API. (templated)
:param waiter_delay: The amount of time in seconds to wait between attempts. (default: 60)
:param waiter_max_attempts: The maximum number of attempts to be made. (default: 720)
:param aws_conn_id: The Airflow connection used for AWS credentials.
Expand All @@ -137,7 +135,6 @@ def __init__(
external_task_id: str,
success_states: Collection[str] | None = None,
failure_states: Collection[str] | None = None,
airflow_version: Literal[2, 3] | None = None,
waiter_delay: int = 60,
waiter_max_attempts: int = 720,
**kwargs,
Expand Down Expand Up @@ -168,7 +165,6 @@ def __init__(
"Name": external_env_name,
"Path": f"/dags/{external_dag_id}/dagRuns/{external_dag_run_id}/taskInstances/{external_task_id}",
"Method": "GET",
"airflow_version": airflow_version,
},
failure_message=f"The task {external_task_id} of DAG run {external_dag_run_id} of DAG {external_dag_id} in MWAA environment {external_env_name} failed with state",
status_message="State of DAG run",
Expand Down