You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by po...@apache.org on 2022/09/14 10:11:12 UTC

[airflow] branch v2-4-test updated (b437d0b3e8 -> c3f4951c0c)

This is an automated email from the ASF dual-hosted git repository.

potiuk pushed a change to branch v2-4-test
in repository https://gitbox.apache.org/repos/asf/airflow.git


    from b437d0b3e8 Fix Dataset bugs in grid view (#26356)
     add 14b025a98b Apply PEP-563 (Postponed Evaluation of Annotations) to core airflow (#26290)
     add c3f4951c0c Flag to deserialize value on custom XCom backend (#26343)

No new revisions were added by this update.

Summary of changes:
 .pre-commit-config.yaml                            |   8 +-
 Dockerfile.ci                                      |   7 +-
 airflow/__init__.py                                |   5 +-
 airflow/__main__.py                                |   3 +-
 airflow/api/__init__.py                            |   2 +
 airflow/api/auth/backend/basic_auth.py             |   8 +-
 airflow/api/auth/backend/default.py                |   6 +-
 airflow/api/auth/backend/deny_all.py               |   6 +-
 airflow/api/auth/backend/kerberos_auth.py          |   5 +-
 airflow/api/auth/backend/session.py                |   6 +-
 airflow/api/client/__init__.py                     |   2 +
 airflow/api/client/api_client.py                   |   2 +
 airflow/api/client/json_client.py                  |   1 +
 airflow/api/client/local_client.py                 |   1 +
 airflow/api/common/delete_dag.py                   |   2 +
 airflow/api/common/experimental/__init__.py        |   5 +-
 airflow/api/common/experimental/delete_dag.py      |   2 +
 airflow/api/common/experimental/get_code.py        |   2 +
 .../api/common/experimental/get_dag_run_state.py   |   5 +-
 airflow/api/common/experimental/get_dag_runs.py    |   6 +-
 airflow/api/common/experimental/get_lineage.py     |   8 +-
 airflow/api/common/experimental/get_task.py        |   2 +
 .../api/common/experimental/get_task_instance.py   |   3 +-
 airflow/api/common/experimental/mark_tasks.py      |   3 +
 airflow/api/common/experimental/pool.py            |   2 +
 airflow/api/common/experimental/trigger_dag.py     |   1 +
 airflow/api/common/mark_tasks.py                   |  55 ++--
 airflow/api/common/trigger_dag.py                  |  19 +-
 airflow/api_connexion/endpoints/config_endpoint.py |   1 +
 .../api_connexion/endpoints/connection_endpoint.py |   1 +
 airflow/api_connexion/endpoints/dag_endpoint.py    |   7 +-
 .../api_connexion/endpoints/dag_run_endpoint.py    |  45 +--
 .../api_connexion/endpoints/dag_source_endpoint.py |   1 +
 .../endpoints/dag_warning_endpoint.py              |   9 +-
 .../api_connexion/endpoints/dataset_endpoint.py    |  15 +-
 .../api_connexion/endpoints/event_log_endpoint.py  |   5 +-
 .../api_connexion/endpoints/extra_link_endpoint.py |   1 +
 airflow/api_connexion/endpoints/health_endpoint.py |   1 +
 .../endpoints/import_error_endpoint.py             |   5 +-
 airflow/api_connexion/endpoints/log_endpoint.py    |   6 +-
 airflow/api_connexion/endpoints/plugin_endpoint.py |   2 +
 airflow/api_connexion/endpoints/pool_endpoint.py   |   4 +-
 .../api_connexion/endpoints/provider_endpoint.py   |   1 +
 airflow/api_connexion/endpoints/request_dict.py    |   1 +
 .../endpoints/role_and_permission_endpoint.py      |   8 +-
 airflow/api_connexion/endpoints/task_endpoint.py   |   2 +
 .../endpoints/task_instance_endpoint.py            |  68 ++---
 airflow/api_connexion/endpoints/user_endpoint.py   |   7 +-
 .../api_connexion/endpoints/variable_endpoint.py   |   7 +-
 .../api_connexion/endpoints/version_endpoint.py    |   5 +-
 airflow/api_connexion/endpoints/xcom_endpoint.py   |  32 +-
 airflow/api_connexion/exceptions.py                |  28 +-
 airflow/api_connexion/openapi/v1.yaml              |  17 ++
 airflow/api_connexion/parameters.py                |  10 +-
 airflow/api_connexion/schemas/common_schema.py     |   1 +
 airflow/api_connexion/schemas/config_schema.py     |   7 +-
 airflow/api_connexion/schemas/connection_schema.py |   6 +-
 airflow/api_connexion/schemas/dag_run_schema.py    |   6 +-
 airflow/api_connexion/schemas/dag_schema.py        |   5 +-
 airflow/api_connexion/schemas/dag_source_schema.py |   1 +
 .../api_connexion/schemas/dag_warning_schema.py    |   6 +-
 airflow/api_connexion/schemas/dataset_schema.py    |   7 +-
 airflow/api_connexion/schemas/enum_schemas.py      |   1 +
 airflow/api_connexion/schemas/error_schema.py      |   6 +-
 airflow/api_connexion/schemas/event_log_schema.py  |   5 +-
 airflow/api_connexion/schemas/health_schema.py     |   1 +
 airflow/api_connexion/schemas/log_schema.py        |   6 +-
 airflow/api_connexion/schemas/plugin_schema.py     |   5 +-
 airflow/api_connexion/schemas/pool_schema.py       |   5 +-
 airflow/api_connexion/schemas/provider_schema.py   |   5 +-
 .../schemas/role_and_permission_schema.py          |   7 +-
 airflow/api_connexion/schemas/sla_miss_schema.py   |   1 +
 .../api_connexion/schemas/task_instance_schema.py  |   7 +-
 airflow/api_connexion/schemas/task_schema.py       |   5 +-
 airflow/api_connexion/schemas/user_schema.py       |   6 +-
 airflow/api_connexion/schemas/variable_schema.py   |   1 +
 airflow/api_connexion/schemas/version_schema.py    |   1 +
 airflow/api_connexion/schemas/xcom_schema.py       |   6 +-
 airflow/api_connexion/security.py                  |   5 +-
 airflow/api_connexion/types.py                     |   1 +
 airflow/callbacks/base_callback_sink.py            |   2 +-
 airflow/callbacks/callback_requests.py             |  25 +-
 airflow/callbacks/database_callback_sink.py        |   2 +-
 airflow/callbacks/pipe_callback_sink.py            |   3 +-
 airflow/cli/cli_parser.py                          |  19 +-
 airflow/cli/commands/celery_command.py             |   4 +-
 airflow/cli/commands/cheat_sheet_command.py        |  14 +-
 airflow/cli/commands/config_command.py             |   2 +
 airflow/cli/commands/connection_command.py         |   8 +-
 airflow/cli/commands/dag_command.py                |   6 +-
 airflow/cli/commands/dag_processor_command.py      |   3 +-
 airflow/cli/commands/db_command.py                 |   2 +
 airflow/cli/commands/info_command.py               |   9 +-
 airflow/cli/commands/jobs_command.py               |   5 +-
 airflow/cli/commands/kerberos_command.py           |   3 +-
 airflow/cli/commands/kubernetes_command.py         |   2 +
 airflow/cli/commands/legacy_commands.py            |   1 +
 airflow/cli/commands/plugins_command.py            |   8 +-
 airflow/cli/commands/pool_command.py               |   2 +
 airflow/cli/commands/provider_command.py           |   2 +
 airflow/cli/commands/role_command.py               |   3 +-
 airflow/cli/commands/rotate_fernet_key_command.py  |   2 +
 airflow/cli/commands/scheduler_command.py          |   8 +-
 airflow/cli/commands/standalone_command.py         |   4 +-
 airflow/cli/commands/sync_perm_command.py          |   2 +
 airflow/cli/commands/task_command.py               |  22 +-
 airflow/cli/commands/triggerer_command.py          |   3 +-
 airflow/cli/commands/user_command.py               |   6 +-
 airflow/cli/commands/variable_command.py           |   2 +
 airflow/cli/commands/version_command.py            |   2 +
 airflow/cli/commands/webserver_command.py          |   9 +-
 airflow/cli/simple_table.py                        |  20 +-
 airflow/compat/functools.py                        |   2 +
 airflow/compat/sqlalchemy.py                       |   1 +
 airflow/config_templates/airflow_local_settings.py |  25 +-
 airflow/config_templates/default_airflow.cfg       |   1 -
 airflow/config_templates/default_celery.py         |   2 +
 .../config_templates/default_webserver_config.py   |   2 +
 airflow/configuration.py                           | 103 ++++---
 airflow/contrib/hooks/__init__.py                  |   3 +-
 airflow/contrib/operators/__init__.py              |   3 +-
 airflow/contrib/secrets/__init__.py                |   2 +
 airflow/contrib/sensors/__init__.py                |   1 +
 airflow/contrib/task_runner/__init__.py            |   2 +
 airflow/contrib/utils/__init__.py                  |   1 +
 airflow/contrib/utils/log/__init__.py              |   1 +
 airflow/dag_processing/manager.py                  |  38 +--
 airflow/dag_processing/processor.py                |  57 ++--
 airflow/datasets/__init__.py                       |   6 +-
 airflow/datasets/manager.py                        |   6 +-
 airflow/decorators/__init__.py                     |   1 +
 airflow/decorators/base.py                         |  47 ++-
 airflow/decorators/branch_python.py                |   5 +-
 airflow/decorators/external_python.py              |   9 +-
 airflow/decorators/python.py                       |   7 +-
 airflow/decorators/python_virtualenv.py            |   7 +-
 airflow/decorators/short_circuit.py                |   7 +-
 airflow/decorators/task_group.py                   |  24 +-
 airflow/example_dags/example_bash_operator.py      |   2 +-
 .../example_branch_datetime_operator.py            |   3 +-
 .../example_branch_day_of_week_operator.py         |   3 +-
 airflow/example_dags/example_branch_labels.py      |   3 +-
 airflow/example_dags/example_branch_operator.py    |   2 +-
 .../example_branch_operator_decorator.py           |   2 -
 .../example_branch_python_dop_operator_3.py        |   3 +-
 airflow/example_dags/example_complex.py            |   3 +-
 airflow/example_dags/example_dag_decorator.py      |   6 +-
 airflow/example_dags/example_datasets.py           |   2 +
 .../example_external_task_marker_dag.py            |   2 +-
 .../example_dags/example_kubernetes_executor.py    |   2 +
 airflow/example_dags/example_latest_only.py        |   2 +-
 .../example_latest_only_with_trigger.py            |   1 +
 .../example_local_kubernetes_executor.py           |   2 +
 airflow/example_dags/example_nested_branch_dag.py  |   3 +-
 .../example_passing_params_via_test_command.py     |   2 +-
 airflow/example_dags/example_python_operator.py    |   3 +-
 .../example_short_circuit_decorator.py             |   3 +-
 .../example_dags/example_short_circuit_operator.py |   3 +-
 airflow/example_dags/example_skip_dag.py           |   2 +-
 airflow/example_dags/example_sla_dag.py            |   4 +-
 airflow/example_dags/example_subdag_operator.py    |   2 +-
 airflow/example_dags/example_task_group.py         |   3 +-
 .../example_dags/example_task_group_decorator.py   |   2 +-
 .../example_time_delta_sensor_async.py             |   2 +-
 .../example_dags/example_trigger_controller_dag.py |   3 +-
 airflow/example_dags/example_trigger_target_dag.py |   3 +-
 airflow/example_dags/example_xcom.py               |   3 +-
 airflow/example_dags/example_xcomargs.py           |   3 +-
 airflow/example_dags/libs/helper.py                |   1 +
 airflow/example_dags/plugins/workday.py            |   7 +-
 airflow/example_dags/subdags/subdag.py             |   2 +-
 airflow/example_dags/tutorial.py                   |   3 +-
 airflow/example_dags/tutorial_dag.py               |   4 +-
 airflow/example_dags/tutorial_taskflow_api.py      |   2 +-
 .../tutorial_taskflow_api_virtualenv.py            |   2 +-
 airflow/exceptions.py                              |  19 +-
 airflow/executors/base_executor.py                 |  40 +--
 airflow/executors/celery_executor.py               |  30 +-
 airflow/executors/celery_kubernetes_executor.py    |  30 +-
 airflow/executors/dask_executor.py                 |  12 +-
 airflow/executors/debug_executor.py                |  13 +-
 airflow/executors/executor_constants.py            |   1 +
 airflow/executors/executor_loader.py               |  16 +-
 airflow/executors/kubernetes_executor.py           |  49 ++--
 airflow/executors/local_executor.py                |  44 +--
 airflow/executors/local_kubernetes_executor.py     |  30 +-
 airflow/executors/sequential_executor.py           |   8 +-
 airflow/hooks/__init__.py                          |   4 +-
 airflow/hooks/base.py                              |  18 +-
 airflow/hooks/dbapi.py                             |   2 +
 airflow/hooks/filesystem.py                        |   2 +-
 airflow/hooks/subprocess.py                        |  11 +-
 airflow/jobs/__init__.py                           |   1 -
 airflow/jobs/backfill_job.py                       |  28 +-
 airflow/jobs/base_job.py                           |   5 +-
 airflow/jobs/local_task_job.py                     |  11 +-
 airflow/jobs/scheduler_job.py                      |  59 ++--
 airflow/jobs/triggerer_job.py                      |  17 +-
 airflow/kubernetes/k8s_model.py                    |   5 +-
 airflow/kubernetes/kube_client.py                  |   7 +-
 airflow/kubernetes/kube_config.py                  |   1 +
 airflow/kubernetes/kubernetes_helper_functions.py  |   4 +-
 airflow/kubernetes/pod.py                          |   4 +-
 airflow/kubernetes/pod_generator.py                |  31 +-
 airflow/kubernetes/pod_generator_deprecated.py     |  55 ++--
 airflow/kubernetes/pod_launcher.py                 |   2 +
 airflow/kubernetes/pod_launcher_deprecated.py      |  13 +-
 airflow/kubernetes/pod_runtime_info_env.py         |   2 +
 airflow/kubernetes/secret.py                       |   5 +-
 airflow/kubernetes/volume.py                       |   2 +
 airflow/kubernetes/volume_mount.py                 |   2 +
 airflow/lineage/__init__.py                        |  10 +-
 airflow/lineage/backend.py                         |  12 +-
 airflow/lineage/entities.py                        |  29 +-
 airflow/listeners/__init__.py                      |   2 +
 airflow/listeners/events.py                        |   2 +
 airflow/listeners/listener.py                      |   4 +-
 airflow/listeners/spec.py                          |  10 +-
 airflow/logging_config.py                          |   3 +-
 airflow/macros/__init__.py                         |   6 +-
 airflow/macros/hive.py                             |   1 +
 airflow/migrations/db_types.py                     |   3 +-
 airflow/migrations/env.py                          |   1 +
 airflow/migrations/utils.py                        |   1 +
 .../versions/0001_1_5_0_current_schema.py          |   2 +-
 .../versions/0002_1_5_0_create_is_encrypted.py     |   3 +-
 .../versions/0003_1_5_0_for_compatibility.py       |   2 +-
 .../0004_1_5_0_more_logging_into_task_isntance.py  |   3 +-
 .../versions/0005_1_5_2_job_id_indices.py          |   3 +-
 .../versions/0006_1_6_0_adding_extra_to_log.py     |   3 +-
 .../migrations/versions/0007_1_6_0_add_dagrun.py   |   2 +-
 .../versions/0008_1_6_0_task_duration.py           |   2 +-
 .../versions/0009_1_6_0_dagrun_config.py           |   1 -
 .../0010_1_6_2_add_password_column_to_user.py      |   3 +-
 .../versions/0011_1_6_2_dagrun_start_end.py        |   2 +-
 ...7_0_add_notification_sent_column_to_sla_miss.py |   3 +-
 ..._1_7_0_add_a_column_to_track_the_encryption_.py |   2 +-
 ...4_1_7_0_add_is_encrypted_column_to_variable_.py |   3 +-
 .../versions/0015_1_7_1_rename_user_table.py       |   3 +-
 .../versions/0016_1_7_1_add_ti_state_index.py      |   3 +-
 .../0017_1_7_1_add_task_fails_journal_table.py     |   3 +-
 .../versions/0018_1_7_1_add_dag_stats_table.py     |   3 +-
 ...1_7_1_add_fractional_seconds_to_mysql_tables.py |   2 +-
 .../versions/0020_1_7_1_xcom_dag_task_indices.py   |   2 +-
 .../0021_1_7_1_add_pid_field_to_taskinstance.py    |   2 +-
 ..._7_1_add_dag_id_state_index_on_dag_run_table.py |   3 +-
 ..._1_8_2_add_max_tries_column_to_task_instance.py |   2 +-
 ..._1_8_2_make_xcom_value_column_a_large_binary.py |   3 +-
 .../versions/0025_1_8_2_add_ti_job_id_index.py     |   3 +-
 .../0026_1_8_2_increase_text_size_for_mysql.py     |   3 +-
 .../0027_1_10_0_add_time_zone_awareness.py         |   2 +-
 ...1_10_0_add_kubernetes_resource_checkpointing.py |   4 +-
 ..._1_10_0_add_executor_config_to_task_instance.py |   3 +-
 ...0_1_10_0_add_kubernetes_scheduler_uniqueness.py |   4 +-
 .../migrations/versions/0031_1_10_0_merge_heads.py |   2 +-
 .../0032_1_10_0_fix_mysql_not_null_constraint.py   |   3 +-
 .../versions/0033_1_10_0_fix_sqlite_foreign_key.py |   2 +-
 .../versions/0034_1_10_0_index_taskfail.py         |   3 +-
 .../versions/0035_1_10_2_add_idx_log_dag.py        |   2 +
 .../0036_1_10_2_add_index_to_taskinstance.py       |   2 +-
 .../0037_1_10_2_add_task_reschedule_table.py       |   3 +-
 .../versions/0038_1_10_2_add_sm_dag_index.py       |   2 +-
 .../versions/0039_1_10_2_add_superuser_field.py    |   2 +-
 .../versions/0040_1_10_3_add_fields_to_dag.py      |   2 +-
 .../0041_1_10_3_add_schedule_interval_to_dag.py    |   2 +-
 ..._1_10_3_task_reschedule_fk_on_cascade_delete.py |   2 +-
 ...3_1_10_4_make_taskinstance_pool_not_nullable.py |   2 +-
 .../0044_1_10_7_add_serialized_dag_table.py        |   3 +-
 .../versions/0045_1_10_7_add_root_dag_id_to_dag.py |   2 +-
 ...0_5_change_datetime_to_datetime2_6_on_mssql_.py |   2 +-
 .../0047_1_10_4_increase_queue_name_size_limit.py  |   2 +-
 .../versions/0048_1_10_3_remove_dag_stat_table.py  |   2 +-
 .../migrations/versions/0049_1_10_7_merge_heads.py |   2 +-
 ...10_7_increase_length_for_connection_password.py |   2 +-
 .../versions/0051_1_10_8_add_dagtags_table.py      |   2 +-
 ..._10_10_add_pool_slots_field_to_task_instance.py |   2 +-
 ...0_10_add_rendered_task_instance_fields_table.py |   2 +-
 .../versions/0054_1_10_10_add_dag_code_table.py    |   2 +-
 ..._11_add_precision_to_execution_date_in_mysql.py |   2 +-
 ...10_12_add_dag_hash_column_to_serialized_dag_.py |   2 +-
 .../versions/0057_1_10_13_add_fab_tables.py        |   2 +-
 ...1_10_13_increase_length_of_fab_ab_view_menu_.py |   2 +-
 .../versions/0059_2_0_0_drop_user_and_chart.py     |   3 +-
 .../0060_2_0_0_remove_id_column_from_xcom.py       |   2 +-
 .../0061_2_0_0_increase_length_of_pool_name.py     |   2 +-
 .../versions/0062_2_0_0_add_dagrun_run_type.py     |   2 +-
 .../0063_2_0_0_set_conn_type_as_non_nullable.py    |   2 +-
 .../0064_2_0_0_add_unique_constraint_to_conn_id.py |   2 +-
 .../0065_2_0_0_update_schema_for_smart_sensor.py   |   3 +-
 .../0066_2_0_0_add_queued_by_job_id_to_ti.py       |   2 +-
 .../0067_2_0_0_add_external_executor_id_to_ti.py   |   2 +-
 .../0068_2_0_0_drop_kuberesourceversion_and_.py    |   2 +-
 ...2_0_0_add_scheduling_decision_to_dagrun_and_.py |   2 +-
 ...0_fix_mssql_exec_date_rendered_task_instance.py |   3 +-
 .../0071_2_0_0_add_job_id_to_dagrun_table.py       |   2 +-
 ...072_2_0_0_add_k8s_yaml_to_rendered_templates.py |   2 +-
 .../versions/0073_2_0_0_prefix_dag_permissions.py  |   2 +-
 .../0074_2_0_0_resource_based_permissions.py       |   3 +-
 ...75_2_0_0_add_description_field_to_connection.py |   2 +-
 ..._0_0_fix_description_field_in_connection_to_.py |   2 +-
 ...2_0_0_change_field_in_dagcode_to_mediumtext_.py |   3 +-
 ..._2_0_1_remove_can_read_permission_on_config_.py |   3 +-
 ...0_2_increase_size_of_connection_extra_field_.py |   2 +-
 .../0080_2_0_2_change_default_pool_slots_to_1.py   |   2 +-
 .../0081_2_0_2_rename_last_scheduler_run_column.py |   2 +-
 ..._1_0_increase_pool_name_size_in_taskinstance.py |   2 +-
 ...0083_2_1_0_add_description_field_to_variable.py |   2 +-
 ..._1_0_resource_based_permissions_for_default_.py |   3 +-
 ...5_2_1_3_add_queued_at_column_to_dagrun_table.py |   2 +-
 ..._1_4_add_max_active_runs_column_to_dagmodel_.py |   2 +-
 ..._2_1_4_add_index_on_state_dag_id_for_queued_.py |   2 +-
 .../0088_2_2_0_improve_mssql_compatibility.py      |   2 +-
 ...89_2_2_0_make_xcom_pkey_columns_non_nullable.py |   3 +-
 ..._2_0_rename_concurrency_column_in_dag_table_.py |   2 +-
 .../0091_2_2_0_add_trigger_table_and_task_info.py  |   2 +-
 ...ta_interval_start_end_to_dagmodel_and_dagrun.py |   2 +-
 .../0093_2_2_0_taskinstance_keyed_to_dagrun.py     |   2 +-
 ...2_3_add_has_import_errors_column_to_dagmodel.py |   2 +-
 .../versions/0095_2_2_4_add_session_table_to_db.py |   2 +-
 .../0096_2_2_4_adding_index_for_dag_id_in_job.py   |   2 +-
 ..._2_3_0_increase_length_of_email_and_username.py |   2 +-
 ...098_2_3_0_added_timetable_description_column.py |   2 +-
 ...9_2_3_0_add_task_log_filename_template_model.py |   2 +-
 ...2_3_0_add_taskmap_and_map_id_on_taskinstance.py |   2 +-
 ..._2_3_0_add_data_compressed_to_serialized_dag.py |   2 +-
 .../0102_2_3_0_switch_xcom_table_to_use_run_id.py  |   3 +-
 .../0103_2_3_0_add_callback_request_table.py       |   2 +-
 ...3_0_migrate_rtif_to_use_run_id_and_map_index.py |   2 +-
 .../0105_2_3_0_add_map_index_to_taskfail.py        |   6 +-
 ...on_for_fab_tables_to_add_missing_constraints.py |   3 +-
 .../versions/0107_2_3_0_add_map_index_to_log.py    |   3 +-
 .../versions/0108_2_3_0_default_dag_view_grid.py   |   2 +-
 .../0109_2_3_1_add_index_for_event_in_log.py       |   2 +-
 ...0110_2_3_2_add_cascade_to_dag_tag_foreignkey.py |   2 +-
 .../0111_2_3_3_add_indexes_for_cascade_deletes.py  |   2 +-
 .../versions/0112_2_4_0_add_dagwarning_model.py    |   2 +-
 .../0113_2_4_0_compare_types_between_orm_and_db.py |   2 +-
 .../versions/0114_2_4_0_add_dataset_model.py       |   3 +-
 .../versions/0115_2_4_0_remove_smart_sensors.py    |   2 +-
 .../0116_2_4_0_add_dag_owner_attributes_table.py   |   2 +-
 ..._2_4_0_add_processor_subdir_to_dagmodel_and_.py |   2 +-
 airflow/models/__init__.py                         |   1 +
 airflow/models/abstractoperator.py                 |  81 +++--
 airflow/models/base.py                             |   1 +
 airflow/models/baseoperator.py                     | 243 ++++++++-------
 airflow/models/connection.py                       |  36 +--
 airflow/models/crypto.py                           |   2 +
 airflow/models/dag.py                              | 326 ++++++++++-----------
 airflow/models/dagbag.py                           |  23 +-
 airflow/models/dagcode.py                          |   8 +-
 airflow/models/dagparam.py                         |   2 +-
 airflow/models/dagpickle.py                        |   1 +
 airflow/models/dagrun.py                           | 152 +++++-----
 airflow/models/dagwarning.py                       |   2 +
 airflow/models/db_callback_request.py              |   1 +
 airflow/models/errors.py                           |   1 +
 airflow/models/expandinput.py                      |   1 -
 airflow/models/log.py                              |   1 +
 airflow/models/mappedoperator.py                   | 140 ++++-----
 airflow/models/operator.py                         |   1 +
 airflow/models/param.py                            |  22 +-
 airflow/models/pool.py                             |  11 +-
 airflow/models/renderedtifields.py                 |   7 +-
 airflow/models/serialized_dag.py                   |  28 +-
 airflow/models/skipmixin.py                        |  23 +-
 airflow/models/slamiss.py                          |   1 +
 airflow/models/taskfail.py                         |   1 +
 airflow/models/taskinstance.py                     | 199 ++++++-------
 airflow/models/tasklog.py                          |   1 +
 airflow/models/taskmap.py                          |   8 +-
 airflow/models/taskmixin.py                        |  69 ++---
 airflow/models/taskreschedule.py                   |   3 +-
 airflow/models/trigger.py                          |  10 +-
 airflow/models/variable.py                         |   7 +-
 airflow/models/xcom.py                             | 111 +++----
 airflow/models/xcom_arg.py                         | 107 +++----
 airflow/mypy/plugin/decorators.py                  |   6 +-
 airflow/mypy/plugin/outputs.py                     |   1 -
 airflow/operators/__init__.py                      |   3 +-
 airflow/operators/bash.py                          |   8 +-
 airflow/operators/branch.py                        |   5 +-
 airflow/operators/datetime.py                      |  17 +-
 airflow/operators/email.py                         |  16 +-
 airflow/operators/empty.py                         |   1 +
 airflow/operators/generic_transfer.py              |   8 +-
 airflow/operators/latest_only.py                   |  10 +-
 airflow/operators/python.py                        |  58 ++--
 airflow/operators/smooth.py                        |   2 +
 airflow/operators/subdag.py                        |  10 +-
 airflow/operators/trigger_dagrun.py                |  15 +-
 airflow/operators/weekday.py                       |  12 +-
 airflow/plugins_manager.py                         |  70 ++---
 .../google/config_templates/default_config.cfg     |   1 -
 airflow/providers_manager.py                       |  90 +++---
 airflow/secrets/__init__.py                        |   2 +
 airflow/secrets/base_secrets.py                    |  18 +-
 airflow/secrets/environment_variables.py           |   8 +-
 airflow/secrets/local_filesystem.py                |  40 +--
 airflow/secrets/metastore.py                       |   8 +-
 airflow/security/kerberos.py                       |  13 +-
 airflow/security/permissions.py                    |   1 +
 airflow/security/utils.py                          |   4 +-
 airflow/sensors/__init__.py                        |   3 +-
 airflow/sensors/base.py                            |  11 +-
 airflow/sensors/bash.py                            |   1 +
 airflow/sensors/date_time.py                       |   5 +-
 airflow/sensors/external_task.py                   |  23 +-
 airflow/sensors/filesystem.py                      |   2 +-
 airflow/sensors/python.py                          |  10 +-
 airflow/sensors/time_delta.py                      |   1 +
 airflow/sensors/time_sensor.py                     |   2 +
 airflow/sensors/weekday.py                         |   6 +-
 airflow/sentry.py                                  |   3 +-
 airflow/serialization/__init__.py                  |   1 -
 airflow/serialization/enums.py                     |   2 +-
 airflow/serialization/helpers.py                   |   7 +-
 airflow/serialization/json_schema.py               |   4 +-
 airflow/serialization/serialized_objects.py        |  96 +++---
 airflow/settings.py                                |  16 +-
 airflow/stats.py                                   |  13 +-
 airflow/task/task_runner/__init__.py               |   2 +-
 airflow/task/task_runner/base_task_runner.py       |   5 +-
 airflow/task/task_runner/cgroup_task_runner.py     |   5 +-
 airflow/task/task_runner/standard_task_runner.py   |   5 +-
 airflow/templates.py                               |   1 -
 airflow/ti_deps/dep_context.py                     |   7 +-
 airflow/ti_deps/dependencies_deps.py               |   1 +
 airflow/ti_deps/dependencies_states.py             |   1 +
 airflow/ti_deps/deps/base_ti_dep.py                |   1 +
 airflow/ti_deps/deps/dag_ti_slots_available_dep.py |   1 +
 airflow/ti_deps/deps/dag_unpaused_dep.py           |   1 +
 airflow/ti_deps/deps/dagrun_backfill_dep.py        |   2 +-
 airflow/ti_deps/deps/dagrun_exists_dep.py          |   1 +
 .../ti_deps/deps/exec_date_after_start_date_dep.py |   1 +
 airflow/ti_deps/deps/mapped_task_expanded.py       |   2 +
 airflow/ti_deps/deps/not_in_retry_period_dep.py    |   1 +
 airflow/ti_deps/deps/not_previously_skipped_dep.py |   2 +
 airflow/ti_deps/deps/pool_slots_available_dep.py   |   2 +-
 airflow/ti_deps/deps/prev_dagrun_dep.py            |   2 +
 airflow/ti_deps/deps/ready_to_reschedule.py        |   1 +
 airflow/ti_deps/deps/runnable_exec_date_dep.py     |   1 +
 airflow/ti_deps/deps/task_concurrency_dep.py       |   1 +
 airflow/ti_deps/deps/task_not_running_dep.py       |   1 +
 airflow/ti_deps/deps/trigger_rule_dep.py           |   7 +-
 airflow/ti_deps/deps/valid_state_dep.py            |   1 +
 airflow/timetables/_cron.py                        |   1 -
 airflow/timetables/base.py                         |  27 +-
 airflow/timetables/events.py                       |  10 +-
 airflow/timetables/interval.py                     |  21 +-
 airflow/timetables/simple.py                       |  31 +-
 airflow/timetables/trigger.py                      |   1 -
 airflow/triggers/base.py                           |   5 +-
 airflow/triggers/temporal.py                       |   5 +-
 airflow/triggers/testing.py                        |   7 +-
 airflow/typing_compat.py                           |   2 +-
 airflow/utils/airflow_flask_app.py                 |   5 +-
 airflow/utils/cli.py                               |  13 +-
 airflow/utils/cli_action_loggers.py                |   2 +-
 airflow/utils/code_utils.py                        |   5 +-
 airflow/utils/compression.py                       |   1 +
 airflow/utils/configuration.py                     |   1 +
 airflow/utils/context.py                           |  31 +-
 airflow/utils/dag_cycle_tester.py                  |  10 +-
 airflow/utils/dag_edges.py                         |   7 +-
 airflow/utils/dag_parsing_context.py               |  10 +-
 airflow/utils/dates.py                             |  14 +-
 airflow/utils/db.py                                |  28 +-
 airflow/utils/db_cleanup.py                        |  24 +-
 airflow/utils/decorators.py                        |   2 +-
 airflow/utils/deprecation_tools.py                 |   6 +-
 airflow/utils/docs.py                              |   5 +-
 airflow/utils/dot_renderer.py                      |  16 +-
 airflow/utils/edgemodifier.py                      |  18 +-
 airflow/utils/email.py                             |  47 +--
 airflow/utils/entry_points.py                      |   1 -
 airflow/utils/event_scheduler.py                   |   1 +
 airflow/utils/file.py                              |  42 +--
 airflow/utils/helpers.py                           |  43 +--
 airflow/utils/json.py                              |   1 +
 airflow/utils/jwt_signer.py                        |   8 +-
 airflow/utils/log/__init__.py                      |   2 +
 airflow/utils/log/colored_log.py                   |   6 +-
 airflow/utils/log/file_processor_handler.py        |   1 +
 airflow/utils/log/file_task_handler.py             |  12 +-
 airflow/utils/log/json_formatter.py                |   2 +-
 airflow/utils/log/log_reader.py                    |  11 +-
 airflow/utils/log/logging_mixin.py                 |   6 +-
 airflow/utils/log/non_caching_file_handler.py      |   1 +
 airflow/utils/log/secrets_masker.py                |  20 +-
 .../log/task_handler_with_custom_formatter.py      |   7 +-
 airflow/utils/log/timezone_aware.py                |   2 +
 airflow/utils/mixins.py                            |   1 +
 airflow/utils/module_loading.py                    |   1 +
 airflow/utils/net.py                               |   3 +-
 airflow/utils/operator_helpers.py                  |   9 +-
 airflow/utils/operator_resources.py                |   4 +-
 airflow/utils/orm_event_handlers.py                |   1 +
 airflow/utils/platform.py                          |   3 +-
 airflow/utils/process_utils.py                     |  19 +-
 airflow/utils/python_virtualenv.py                 |  20 +-
 airflow/utils/retries.py                           |   5 +-
 airflow/utils/scheduler_health.py                  |   1 +
 airflow/utils/serve_logs.py                        |   3 +-
 airflow/utils/session.py                           |   2 +
 airflow/utils/sqlalchemy.py                        |  14 +-
 airflow/utils/state.py                             |  19 +-
 airflow/utils/strings.py                           |   4 +-
 airflow/utils/task_group.py                        |  58 ++--
 airflow/utils/timeout.py                           |   7 +-
 airflow/utils/timezone.py                          |  25 +-
 airflow/utils/trigger_rule.py                      |   5 +-
 airflow/utils/types.py                             |  10 +-
 airflow/utils/weekday.py                           |  10 +-
 airflow/utils/weight_rule.py                       |   5 +-
 airflow/utils/yaml.py                              |   7 +-
 airflow/version.py                                 |   2 +-
 airflow/www/api/__init__.py                        |   1 -
 airflow/www/api/experimental/__init__.py           |   1 -
 airflow/www/api/experimental/endpoints.py          |   2 +
 airflow/www/app.py                                 |   6 +-
 airflow/www/auth.py                                |   5 +-
 airflow/www/blueprints.py                          |   3 +-
 airflow/www/decorators.py                          |   1 +
 airflow/www/extensions/init_appbuilder.py          |  14 +-
 airflow/www/extensions/init_appbuilder_links.py    |   1 +
 airflow/www/extensions/init_dagbag.py              |   1 +
 airflow/www/extensions/init_jinja_globals.py       |   1 +
 airflow/www/extensions/init_manifest_files.py      |   1 +
 airflow/www/extensions/init_robots.py              |   2 +
 airflow/www/extensions/init_security.py            |   2 +
 airflow/www/extensions/init_session.py             |   1 +
 airflow/www/extensions/init_views.py               |   1 +
 airflow/www/extensions/init_wsgi_middlewares.py    |   1 +
 airflow/www/fab_security/manager.py                |  54 ++--
 airflow/www/fab_security/sqla/manager.py           |  16 +-
 airflow/www/fab_security/sqla/models.py            |   5 +-
 airflow/www/fab_security/views.py                  |   2 +-
 airflow/www/forms.py                               |   1 +
 airflow/www/gunicorn_config.py                     |   1 +
 airflow/www/security.py                            |  22 +-
 airflow/www/session.py                             |   1 +
 airflow/www/static/js/types/api-generated.ts       |  16 +-
 airflow/www/utils.py                               |  14 +-
 airflow/www/validators.py                          |   1 +
 airflow/www/views.py                               |  79 ++---
 airflow/www/widgets.py                             |   2 +
 dev/assign_cherry_picked_prs_with_milestone.py     |  23 +-
 dev/breeze/README.md                               |   2 +-
 dev/breeze/setup.py                                |   2 +
 dev/breeze/src/airflow_breeze/__init__.py          |   2 +
 dev/breeze/src/airflow_breeze/branch_defaults.py   |   1 +
 dev/breeze/src/airflow_breeze/breeze.py            |   5 +-
 .../src/airflow_breeze/commands/ci_commands.py     |  20 +-
 .../airflow_breeze/commands/ci_commands_config.py  |   6 +-
 .../airflow_breeze/commands/ci_image_commands.py   |  23 +-
 .../commands/ci_image_commands_config.py           |   6 +-
 .../airflow_breeze/commands/developer_commands.py  |  39 +--
 .../commands/developer_commands_config.py          |   6 +-
 .../airflow_breeze/commands/kubernetes_commands.py |  77 ++---
 .../commands/kubernetes_commands_config.py         |  10 +-
 .../src/airflow_breeze/commands/main_command.py    |   5 +-
 .../commands/production_image_commands.py          |  21 +-
 .../commands/production_image_commands_config.py   |   6 +-
 .../commands/release_management_commands.py        |  30 +-
 .../commands/release_management_commands_config.py |   6 +-
 .../src/airflow_breeze/commands/setup_commands.py  |  20 +-
 .../commands/setup_commands_config.py              |   6 +-
 .../airflow_breeze/commands/testing_commands.py    |  23 +-
 .../commands/testing_commands_config.py            |   6 +-
 .../src/airflow_breeze/configure_rich_click.py     |   2 +
 dev/breeze/src/airflow_breeze/global_constants.py  |   4 +-
 .../src/airflow_breeze/params/build_ci_params.py   |   9 +-
 .../src/airflow_breeze/params/build_prod_params.py |  10 +-
 .../airflow_breeze/params/common_build_params.py   |  18 +-
 .../src/airflow_breeze/params/doc_build_params.py  |   6 +-
 .../src/airflow_breeze/params/shell_params.py      |  12 +-
 dev/breeze/src/airflow_breeze/utils/cache.py       |  11 +-
 dev/breeze/src/airflow_breeze/utils/ci_group.py    |   6 +-
 dev/breeze/src/airflow_breeze/utils/click_utils.py |   1 +
 .../src/airflow_breeze/utils/common_options.py     |   1 +
 dev/breeze/src/airflow_breeze/utils/confirm.py     |  11 +-
 dev/breeze/src/airflow_breeze/utils/console.py     |   8 +-
 .../src/airflow_breeze/utils/custom_param_types.py |   5 +-
 .../airflow_breeze/utils/docker_command_utils.py   |  33 +--
 .../utils/find_newer_dependencies.py               |  10 +-
 .../src/airflow_breeze/utils/github_actions.py     |   1 +
 .../src/airflow_breeze/utils/host_info_utils.py    |   7 +-
 dev/breeze/src/airflow_breeze/utils/image.py       |  29 +-
 .../src/airflow_breeze/utils/kubernetes_utils.py   |  33 ++-
 .../utils/mark_image_as_refreshed.py               |   1 +
 .../src/airflow_breeze/utils/md5_build_check.py    |   5 +-
 dev/breeze/src/airflow_breeze/utils/parallel.py    |  58 ++--
 dev/breeze/src/airflow_breeze/utils/path_utils.py  |   7 +-
 dev/breeze/src/airflow_breeze/utils/platforms.py   |   1 +
 .../src/airflow_breeze/utils/python_versions.py    |   4 +-
 dev/breeze/src/airflow_breeze/utils/recording.py   |   7 +-
 dev/breeze/src/airflow_breeze/utils/registry.py    |   7 +-
 dev/breeze/src/airflow_breeze/utils/reinstall.py   |   1 +
 dev/breeze/src/airflow_breeze/utils/run_tests.py   |  13 +-
 dev/breeze/src/airflow_breeze/utils/run_utils.py   |  22 +-
 .../src/airflow_breeze/utils/selective_checks.py   |   1 -
 dev/breeze/src/airflow_breeze/utils/visuals.py     |   1 +
 dev/breeze/tests/conftest.py                       |   2 +
 dev/breeze/tests/test_cache.py                     |   1 +
 dev/breeze/tests/test_commands.py                  |   2 +
 dev/breeze/tests/test_docker_command_utils.py      |   1 +
 dev/breeze/tests/test_find_airflow_directory.py    |   1 +
 dev/breeze/tests/test_global_constants.py          |   1 +
 dev/breeze/tests/test_host_info_utils.py           |   1 +
 dev/breeze/tests/test_pr_info.py                   |   1 +
 dev/breeze/tests/test_run_utils.py                 |   1 +
 dev/breeze/tests/test_selective_checks.py          |  31 +-
 dev/chart/build_changelog_annotations.py           |  16 +-
 dev/check_files.py                                 |  10 +-
 dev/deprecations/generate_deprecated_dicts.py      |   9 +-
 dev/example_dags/update_example_dags_paths.py      |   5 +-
 dev/prepare_bulk_issues.py                         |  14 +-
 dev/prepare_release_issue.py                       |  33 ++-
 dev/provider_packages/prepare_provider_packages.py | 102 +++----
 dev/provider_packages/remove_old_releases.py       |   7 +-
 dev/retag_docker_images.py                         |   6 +-
 dev/send_email.py                                  |  10 +-
 ...calculate_statistics_provider_testing_issues.py |  20 +-
 dev/stats/get_important_pr_candidates.py           |   8 +-
 dev/system_tests/update_issue_status.py            |  19 +-
 dev/validate_version_added_fields_in_config.py     |  20 +-
 docker_tests/command_utils.py                      |   4 +-
 docker_tests/constants.py                          |   1 +
 docker_tests/docker_tests_utils.py                 |   1 +
 docker_tests/test_ci_image.py                      |   1 +
 docker_tests/test_docker_compose_quick_start.py    |   4 +-
 .../test_examples_of_prod_image_building.py        |   1 +
 docker_tests/test_prod_image.py                    |   1 +
 docs/apache-airflow/img/airflow_erd.sha256         |   2 +-
 docs/build_docs.py                                 |  40 +--
 docs/conf.py                                       |  20 +-
 .../extending/embedding-dags/test_dag.py           |   4 +-
 docs/exts/airflow_intersphinx.py                   |   7 +-
 docs/exts/docroles.py                              |   3 +-
 docs/exts/docs_build/code_utils.py                 |   2 +
 docs/exts/docs_build/dev_index_generator.py        |   1 +
 docs/exts/docs_build/docs_builder.py               |   7 +-
 docs/exts/docs_build/errors.py                     |  12 +-
 docs/exts/docs_build/fetch_inventories.py          |   9 +-
 docs/exts/docs_build/github_action_utils.py        |   1 +
 docs/exts/docs_build/helm_chart_utils.py           |   1 +
 docs/exts/docs_build/lint_checks.py                |  33 +--
 docs/exts/docs_build/package_filter.py             |   4 +-
 docs/exts/docs_build/spelling_checks.py            |  17 +-
 docs/exts/docs_build/third_party_inventories.py    |   1 +
 docs/exts/exampleinclude.py                        |   2 +-
 docs/exts/extra_files_with_substitutions.py        |   1 +
 docs/exts/operators_and_hooks_ref.py               |  27 +-
 docs/exts/provider_init_hack.py                    |   1 +
 docs/exts/provider_yaml_utils.py                   |   7 +-
 docs/exts/providers_packages_ref.py                |   1 +
 docs/exts/redirects.py                             |   2 +
 docs/exts/removemarktransform.py                   |   3 +-
 docs/exts/sphinx_script_update.py                  |   5 +-
 docs/exts/substitution_extensions.py               |   7 +-
 docs/publish_docs.py                               |   2 +-
 docs/rtd-deprecation/conf.py                       |   1 +
 kubernetes_tests/test_base.py                      |   1 +
 kubernetes_tests/test_kubernetes_executor.py       |   1 +
 kubernetes_tests/test_kubernetes_pod_operator.py   |   5 +-
 .../test_kubernetes_pod_operator_backcompat.py     |   1 +
 kubernetes_tests/test_other_executors.py           |   1 +
 metastore_browser/hive_metastore.py                |   2 +-
 scripts/ci/pre_commit/common_precommit_utils.py    |   7 +-
 .../pre_commit_base_operator_partial_arguments.py  |   1 -
 scripts/ci/pre_commit/pre_commit_boring_cyborg.py  |   1 +
 .../ci/pre_commit/pre_commit_breeze_cmd_line.py    |   2 +
 .../pre_commit_build_providers_dependencies.py     |  32 +-
 .../pre_commit/pre_commit_changelog_duplicates.py  |   1 +
 scripts/ci/pre_commit/pre_commit_chart_schema.py   |   1 +
 .../pre_commit_check_2_2_compatibility.py          |   5 +-
 .../pre_commit/pre_commit_check_init_in_tests.py   |   5 +-
 .../ci/pre_commit/pre_commit_check_lazy_logging.py |   1 -
 scripts/ci/pre_commit/pre_commit_check_license.py  |   2 +
 .../pre_commit_check_order_dockerfile_extras.py    |  11 +-
 .../ci/pre_commit/pre_commit_check_order_setup.py  |   5 +-
 .../pre_commit_check_pre_commit_hooks.py           |  12 +-
 .../pre_commit_check_provider_yaml_files.py        |  37 +--
 .../pre_commit/pre_commit_check_providers_init.py  |   2 +
 ...it_check_providers_subpackages_all_have_init.py |   4 +-
 .../pre_commit_check_setup_extra_packages_ref.py   |  14 +-
 .../ci/pre_commit/pre_commit_check_system_tests.py |   5 +-
 ...re_commit_check_system_tests_hidden_in_index.py |   2 +
 .../pre_commit_checkout_no_credentials.py          |   2 +
 .../ci/pre_commit/pre_commit_compile_www_assets.py |   2 +
 .../pre_commit_compile_www_assets_dev.py           |   2 +
 ...it_decorator_operator_implements_custom_name.py |   1 -
 .../pre_commit/pre_commit_docstring_param_type.py  |   2 +
 scripts/ci/pre_commit/pre_commit_flake8.py         |   2 +
 scripts/ci/pre_commit/pre_commit_helm_lint.py      |   2 +
 .../pre_commit_inline_scripts_in_docker.py         |   7 +-
 scripts/ci/pre_commit/pre_commit_insert_extras.py  |   2 +
 scripts/ci/pre_commit/pre_commit_json_schema.py    |   8 +-
 .../ci/pre_commit/pre_commit_lint_dockerfile.py    |   2 +
 .../ci/pre_commit/pre_commit_local_yml_mounts.py   |   2 +
 .../pre_commit/pre_commit_migration_reference.py   |   2 +
 scripts/ci/pre_commit/pre_commit_mypy.py           |   2 +
 scripts/ci/pre_commit/pre_commit_newsfragments.py  |   1 +
 .../pre_commit_replace_bad_characters.py           |   5 +-
 scripts/ci/pre_commit/pre_commit_setup_cfg_file.py |   2 +
 .../ci/pre_commit/pre_commit_sort_in_the_wild.py   |   2 +
 .../pre_commit_sort_spelling_wordlist.py           |   2 +
 .../ci/pre_commit/pre_commit_supported_versions.py |   2 +
 .../pre_commit_sync_dag_init_decorator.py          |   1 -
 .../pre_commit_update_breeze_config_hash.py        |   2 +
 .../ci/pre_commit/pre_commit_update_er_diagram.py  |   2 +
 .../pre_commit_update_example_dags_paths.py        |   7 +-
 .../ci/pre_commit/pre_commit_update_versions.py    |   2 +
 .../pre_commit_vendor_k8s_json_schema.py           |   1 +
 .../ci/pre_commit/pre_commit_version_heads_map.py  |   1 +
 scripts/ci/pre_commit/pre_commit_www_lint.py       |   2 +
 scripts/ci/pre_commit/pre_commit_yaml_to_cfg.py    |   2 +-
 scripts/ci/testing/summarize_junit_failures.py     |   1 +
 scripts/docker/entrypoint_ci.sh                    |   7 +-
 scripts/in_container/check_junitxml_result.py      |   1 +
 scripts/in_container/run_migration_reference.py    |  10 +-
 scripts/in_container/run_prepare_er_diagram.py     |   2 +
 scripts/in_container/run_resource_check.py         |   4 +-
 .../in_container/update_quarantined_test_status.py |  25 +-
 scripts/in_container/verify_providers.py           |  92 +++---
 scripts/tools/check_if_limited_dependencies.py     |   2 +
 scripts/tools/generate-integrations-json.py        |   2 +
 scripts/tools/initialize_virtualenv.py             |   1 +
 scripts/tools/list-integrations.py                 |   2 +
 setup.py                                           |  48 +--
 tests/always/test_connection.py                    |   2 +
 tests/always/test_example_dags.py                  |   1 +
 tests/always/test_project_structure.py             |  19 +-
 tests/always/test_secrets.py                       |   3 +-
 tests/always/test_secrets_backends.py              |   3 +-
 tests/always/test_secrets_local_filesystem.py      |   1 +
 tests/api/auth/backend/test_basic_auth.py          |   1 +
 tests/api/auth/backend/test_kerberos_auth.py       |   1 +
 tests/api/auth/test_client.py                      |   1 +
 tests/api/client/test_local_client.py              |   1 +
 tests/api/common/experimental/test_pool.py         |   1 +
 tests/api/common/test_delete_dag.py                |   1 +
 tests/api/common/test_mark_tasks.py                |   1 +
 tests/api/common/test_trigger_dag.py               |   1 +
 tests/api/conftest.py                              |   1 +
 tests/api_connexion/conftest.py                    |   1 +
 .../endpoints/test_config_endpoint.py              |   1 +
 .../endpoints/test_connection_endpoint.py          |   1 +
 tests/api_connexion/endpoints/test_dag_endpoint.py |   2 +
 .../endpoints/test_dag_run_endpoint.py             |   2 +
 .../endpoints/test_dag_source_endpoint.py          |   5 +-
 .../endpoints/test_dag_warning_endpoint.py         |   2 +
 .../endpoints/test_dataset_endpoint.py             |   1 +
 .../endpoints/test_event_log_endpoint.py           |   1 +
 .../endpoints/test_extra_link_endpoint.py          |   1 +
 .../endpoints/test_health_endpoint.py              |   2 +
 .../endpoints/test_import_error_endpoint.py        |   2 +
 tests/api_connexion/endpoints/test_log_endpoint.py |   2 +
 .../test_mapped_task_instance_endpoint.py          |   2 +
 .../endpoints/test_plugin_endpoint.py              |   2 +-
 .../api_connexion/endpoints/test_pool_endpoint.py  |   1 +
 .../endpoints/test_provider_endpoint.py            |   1 +
 .../endpoints/test_role_and_permission_endpoint.py |   1 +
 .../api_connexion/endpoints/test_task_endpoint.py  |   2 +
 .../endpoints/test_task_instance_endpoint.py       |   2 +
 .../api_connexion/endpoints/test_user_endpoint.py  |   2 +
 .../endpoints/test_variable_endpoint.py            |   2 +
 .../endpoints/test_version_endpoint.py             |   2 +
 .../api_connexion/endpoints/test_xcom_endpoint.py  |  55 +++-
 tests/api_connexion/schemas/test_common_schema.py  |   1 +
 tests/api_connexion/schemas/test_config_schema.py  |   1 +
 .../schemas/test_connection_schema.py              |   2 +
 tests/api_connexion/schemas/test_dag_run_schema.py |   2 +
 tests/api_connexion/schemas/test_dag_schema.py     |   1 +
 tests/api_connexion/schemas/test_dataset_schema.py |   1 +
 tests/api_connexion/schemas/test_error_schema.py   |   2 +
 .../api_connexion/schemas/test_event_log_schema.py |   1 +
 tests/api_connexion/schemas/test_health_schema.py  |   2 +
 tests/api_connexion/schemas/test_plugin_schema.py  |   1 +
 tests/api_connexion/schemas/test_pool_schemas.py   |   1 +
 .../schemas/test_role_and_permission_schema.py     |   1 +
 .../schemas/test_task_instance_schema.py           |   1 +
 tests/api_connexion/schemas/test_task_schema.py    |   1 +
 tests/api_connexion/schemas/test_user_schema.py    |   1 +
 tests/api_connexion/schemas/test_version_schema.py |   1 +
 tests/api_connexion/schemas/test_xcom_schema.py    |   2 +
 tests/api_connexion/test_auth.py                   |   1 +
 tests/api_connexion/test_cors.py                   |   1 +
 tests/api_connexion/test_error_handling.py         |   3 +
 tests/api_connexion/test_parameters.py             |   1 +
 tests/api_connexion/test_security.py               |   1 +
 tests/callbacks/test_callback_requests.py          |   1 +
 tests/cli/commands/__init__.py                     |   1 -
 tests/cli/commands/test_celery_command.py          |   2 +
 tests/cli/commands/test_cheat_sheet_command.py     |   4 +-
 tests/cli/commands/test_config_command.py          |   2 +
 tests/cli/commands/test_connection_command.py      |   1 +
 tests/cli/commands/test_dag_command.py             |   2 +
 tests/cli/commands/test_dag_processor_command.py   |   2 +
 tests/cli/commands/test_db_command.py              |   1 +
 tests/cli/commands/test_info_command.py            |   1 +
 tests/cli/commands/test_jobs_command.py            |   2 +
 tests/cli/commands/test_kerberos_command.py        |   1 +
 tests/cli/commands/test_kubernetes_command.py      |   1 +
 tests/cli/commands/test_legacy_commands.py         |   2 +
 tests/cli/commands/test_plugins_command.py         |   1 +
 tests/cli/commands/test_pool_command.py            |   3 +-
 tests/cli/commands/test_role_command.py            |   3 +-
 .../cli/commands/test_rotate_fernet_key_command.py |   1 +
 tests/cli/commands/test_scheduler_command.py       |   2 +
 tests/cli/commands/test_sync_perm_command.py       |   3 +-
 tests/cli/commands/test_task_command.py            |   1 +
 tests/cli/commands/test_triggerer_command.py       |   2 +
 tests/cli/commands/test_user_command.py            |   1 +
 tests/cli/commands/test_variable_command.py        |   3 +-
 tests/cli/commands/test_version_command.py         |   1 +
 tests/cli/commands/test_webserver_command.py       |   1 +
 tests/cli/conftest.py                              |   3 +-
 tests/cli/test_cli_parser.py                       |   1 +
 tests/cluster_policies/__init__.py                 |   6 +-
 tests/conftest.py                                  |   2 +
 tests/core/test_config_templates.py                |   2 +
 tests/core/test_configuration.py                   |   2 +
 tests/core/test_core.py                            |   2 +
 tests/core/test_example_dags_system.py             |   2 +
 tests/core/test_impersonation_tests.py             |   1 +
 tests/core/test_logging_config.py                  |   2 +
 tests/core/test_providers_manager.py               |   5 +-
 tests/core/test_sentry.py                          |   1 +
 tests/core/test_settings.py                        |   3 +-
 tests/core/test_sqlalchemy_config.py               |   1 +
 tests/core/test_stats.py                           |   2 +
 tests/core/test_templates.py                       |   1 +
 tests/dag_processing/test_manager.py               |   1 +
 tests/dag_processing/test_processor.py             |   3 +-
 tests/dags/no_dags.py                              |   2 +-
 tests/dags/subdir1/test_ignore_this.py             |   1 +
 tests/dags/subdir2/subdir3/test_nested_dag.py      |   1 +
 tests/dags/subdir2/test_dont_ignore_this.py        |   2 +
 tests/dags/test_clear_subdag.py                    |   5 +-
 tests/dags/test_cli_triggered_dags.py              |   2 +-
 tests/dags/test_dag_with_no_tags.py                |   1 +
 tests/dags/test_dagrun_fast_follow.py              |   1 +
 tests/dags/test_datasets.py                        |   1 +
 tests/dags/test_default_impersonation.py           |   1 +
 tests/dags/test_default_views.py                   |   1 +
 tests/dags/test_double_trigger.py                  |   2 +
 tests/dags/test_example_bash_operator.py           |   2 +
 tests/dags/test_heartbeat_failed_fast.py           |   2 +
 tests/dags/test_impersonation.py                   |   1 +
 tests/dags/test_impersonation_subdag.py            |   2 +
 tests/dags/test_invalid_cron.py                    |   1 +
 tests/dags/test_invalid_param.py                   |   1 +
 tests/dags/test_issue_1225.py                      |   4 +-
 tests/dags/test_latest_runs.py                     |   2 +-
 tests/dags/test_logging_in_dag.py                  |   2 +
 tests/dags/test_mapped_classic.py                  |   1 +
 tests/dags/test_mapped_taskflow.py                 |   1 +
 tests/dags/test_mark_state.py                      |   2 +
 tests/dags/test_miscellaneous.py                   |   2 +-
 tests/dags/test_missing_owner.py                   |   1 +
 tests/dags/test_multiple_dags.py                   |   2 +
 tests/dags/test_no_impersonation.py                |   1 +
 tests/dags/test_on_failure_callback.py             |   1 +
 tests/dags/test_on_kill.py                         |   2 +
 tests/dags/test_only_empty_tasks.py                |   2 +
 tests/dags/test_parsing_context.py                 |   2 +
 tests/dags/test_prev_dagrun_dep.py                 |   1 +
 tests/dags/test_retry_handling_job.py              |   1 +
 tests/dags/test_scheduler_dags.py                  |   1 +
 tests/dags/test_sensor.py                          |   1 +
 tests/dags/test_subdag.py                          |   3 +-
 tests/dags/test_task_view_type_check.py            |   4 +-
 tests/dags/test_with_non_default_owner.py          |   1 +
 tests/dags_corrupted/test_impersonation_custom.py  |   1 +
 tests/dags_corrupted/test_nonstring_owner.py       |   1 +
 tests/dags_with_system_exit/a_system_exit.py       |   8 +-
 .../dags_with_system_exit/b_test_scheduler_dags.py |   1 +
 tests/dags_with_system_exit/c_system_exit.py       |   8 +-
 tests/datasets/test_manager.py                     |   1 +
 tests/decorators/test_branch_python.py             |   2 +-
 tests/decorators/test_external_python.py           |   2 +
 tests/decorators/test_mapped.py                    |   1 +
 tests/decorators/test_python_virtualenv.py         |   2 +
 tests/decorators/test_short_circuit.py             |   2 +
 tests/decorators/test_task_group.py                |   2 +
 tests/executors/test_base_executor.py              |   2 +
 tests/executors/test_celery_executor.py            |   2 +
 tests/executors/test_celery_kubernetes_executor.py |   2 +
 tests/executors/test_dask_executor.py              |   2 +
 tests/executors/test_debug_executor.py             |   1 +
 tests/executors/test_executor_loader.py            |   1 +
 tests/executors/test_kubernetes_executor.py        |   3 +-
 tests/executors/test_local_executor.py             |   2 +
 tests/executors/test_local_kubernetes_executor.py  |   2 +
 tests/executors/test_sequential_executor.py        |   1 +
 tests/hooks/test_subprocess.py                     |   1 +
 tests/jobs/__init__.py                             |   1 -
 tests/jobs/test_backfill_job.py                    |   2 +-
 tests/jobs/test_base_job.py                        |   2 +-
 tests/jobs/test_local_task_job.py                  |   6 +-
 tests/jobs/test_scheduler_job.py                   |   8 +-
 tests/jobs/test_triggerer_job.py                   |   1 +
 tests/kubernetes/models/test_secret.py             |   2 +
 tests/kubernetes/test_client.py                    |   1 +
 tests/kubernetes/test_pod_generator.py             |   2 +
 tests/lineage/test_lineage.py                      |   2 +
 tests/listeners/empty_listener.py                  |   1 +
 tests/listeners/full_listener.py                   |   1 +
 tests/listeners/partial_listener.py                |   1 +
 tests/listeners/test_listeners.py                  |   2 +
 tests/listeners/throwing_listener.py               |   1 +
 tests/macros/__init__.py                           |   1 -
 tests/macros/test_hive.py                          |   1 +
 tests/macros/test_macros.py                        |   3 +-
 tests/models/__init__.py                           |   1 +
 tests/models/test_base.py                          |   1 +
 tests/models/test_baseoperator.py                  |   2 +
 tests/models/test_cleartasks.py                    |   1 +
 tests/models/test_dag.py                           |  10 +-
 tests/models/test_dagbag.py                        |   2 +
 tests/models/test_dagcode.py                       |   2 +
 tests/models/test_dagrun.py                        |   7 +-
 tests/models/test_dataset.py                       |   1 +
 tests/models/test_mappedoperator.py                |   2 +
 tests/models/test_param.py                         |   1 +
 tests/models/test_pool.py                          |   1 +
 tests/models/test_renderedtifields.py              |   2 +-
 tests/models/test_serialized_dag.py                |   2 +-
 tests/models/test_skipmixin.py                     |   1 +
 tests/models/test_taskinstance.py                  |  15 +-
 tests/models/test_timestamp.py                     |   1 +
 tests/models/test_trigger.py                       |   1 +
 tests/models/test_variable.py                      |   1 +
 tests/models/test_xcom.py                          |   2 +
 tests/models/test_xcom_arg.py                      |   2 +
 tests/models/test_xcom_arg_map.py                  |   3 +-
 tests/operators/test_bash.py                       |   1 +
 tests/operators/test_branch_operator.py            |   1 +
 tests/operators/test_datetime.py                   |   1 +
 tests/operators/test_email.py                      |   1 +
 tests/operators/test_generic_transfer.py           |   1 +
 tests/operators/test_latest_only_operator.py       |   1 +
 tests/operators/test_python.py                     |   5 +-
 tests/operators/test_subdag_operator.py            |   1 +
 tests/operators/test_trigger_dagrun.py             |   1 +
 tests/operators/test_weekday.py                    |   2 +
 tests/plugins/test_plugin.py                       |   1 +
 tests/plugins/test_plugin_ignore.py                |   2 +-
 tests/plugins/test_plugins_manager.py              |   2 +
 tests/security/test_kerberos.py                    |   2 +
 tests/sensors/test_base.py                         |   2 +
 tests/sensors/test_bash.py                         |   2 +-
 tests/sensors/test_date_time.py                    |   1 +
 tests/sensors/test_external_task_sensor.py         |   2 +
 tests/sensors/test_filesystem.py                   |   2 +-
 tests/sensors/test_python.py                       |   2 +-
 tests/sensors/test_time_delta.py                   |   2 +
 tests/sensors/test_time_sensor.py                  |   1 +
 tests/sensors/test_timeout_sensor.py               |   2 +
 tests/sensors/test_weekday_sensor.py               |   2 +-
 tests/serialization/test_dag_serialization.py      |   5 +-
 tests/system/conftest.py                           |   1 +
 tests/system/utils/__init__.py                     |   2 +
 tests/system/utils/watcher.py                      |   2 +
 tests/task/task_runner/test_base_task_runner.py    |   2 +
 tests/task/task_runner/test_cgroup_task_runner.py  |   2 +
 .../task/task_runner/test_standard_task_runner.py  |   2 +
 tests/task/task_runner/test_task_runner.py         |   1 +
 tests/test_utils/__init__.py                       |   2 +
 tests/test_utils/amazon_system_helpers.py          |   6 +-
 tests/test_utils/api_connexion_utils.py            |   2 +
 tests/test_utils/asserts.py                        |   5 +-
 tests/test_utils/azure_system_helpers.py           |   1 +
 tests/test_utils/config.py                         |   1 +
 tests/test_utils/db.py                             |   2 +
 tests/test_utils/decorators.py                     |   1 +
 tests/test_utils/fake_datetime.py                  |   1 +
 tests/test_utils/gcp_system_helpers.py             |  14 +-
 tests/test_utils/get_all_tests.py                  |   2 +
 tests/test_utils/hdfs_utils.py                     |   1 +
 tests/test_utils/logging_command_executor.py       |   2 +
 tests/test_utils/mapping.py                        |   3 +-
 tests/test_utils/mock_executor.py                  |   1 +
 tests/test_utils/mock_operators.py                 |   2 +
 tests/test_utils/mock_plugins.py                   |   1 +
 tests/test_utils/mock_security_manager.py          |   1 +
 tests/test_utils/perf/dags/elastic_dag.py          |   1 +
 tests/test_utils/perf/dags/perf_dag_1.py           |   2 +
 tests/test_utils/perf/dags/perf_dag_2.py           |   2 +
 tests/test_utils/perf/dags/sql_perf_dag.py         |   1 +
 tests/test_utils/perf/perf_kit/memory.py           |   2 +
 tests/test_utils/perf/perf_kit/python.py           |   2 +
 tests/test_utils/perf/perf_kit/repeat_and_time.py  |   2 +
 tests/test_utils/perf/perf_kit/sqlalchemy.py       |   2 +
 .../perf/scheduler_dag_execution_timing.py         |   2 +
 tests/test_utils/perf/scheduler_ops_metrics.py     |   1 +
 tests/test_utils/perf/sql_queries.py               |   9 +-
 tests/test_utils/remote_user_api_auth_backend.py   |   6 +-
 tests/test_utils/reset_warning_registry.py         |   1 +
 tests/test_utils/salesforce_system_helpers.py      |   1 +
 tests/test_utils/sftp_system_helpers.py            |   1 +
 tests/test_utils/system_tests_class.py             |   5 +-
 tests/test_utils/terraform.py                      |   1 +
 tests/test_utils/timetables.py                     |   1 +
 tests/test_utils/www.py                            |   2 +
 tests/ti_deps/deps/fake_models.py                  |   1 +
 .../deps/test_dag_ti_slots_available_dep.py        |   2 +-
 tests/ti_deps/deps/test_dag_unpaused_dep.py        |   2 +-
 tests/ti_deps/deps/test_dagrun_exists_dep.py       |   2 +-
 tests/ti_deps/deps/test_dagrun_id_dep.py           |   2 +-
 tests/ti_deps/deps/test_not_in_retry_period_dep.py |   2 +-
 .../deps/test_not_previously_skipped_dep.py        |   1 +
 .../ti_deps/deps/test_pool_slots_available_dep.py  |   2 +-
 tests/ti_deps/deps/test_prev_dagrun_dep.py         |   2 +-
 tests/ti_deps/deps/test_ready_to_reschedule_dep.py |   2 +-
 tests/ti_deps/deps/test_runnable_exec_date_dep.py  |   2 +-
 tests/ti_deps/deps/test_task_concurrency.py        |   2 +-
 tests/ti_deps/deps/test_task_not_running_dep.py    |   2 +-
 tests/ti_deps/deps/test_trigger_rule_dep.py        |   2 +
 tests/ti_deps/deps/test_valid_state_dep.py         |   2 +-
 tests/timetables/test_events_timetable.py          |   2 +
 tests/timetables/test_interval_timetable.py        |   9 +-
 tests/timetables/test_trigger_timetable.py         |   1 -
 tests/timetables/test_workday_timetable.py         |   2 +
 tests/triggers/test_temporal.py                    |   1 +
 tests/utils/log/test_file_processor_handler.py     |   1 +
 tests/utils/log/test_json_formatter.py             |   3 +-
 tests/utils/log/test_log_reader.py                 |   1 +
 tests/utils/log/test_secrets_masker.py             |   2 +
 tests/utils/test_cli_util.py                       |   3 +-
 tests/utils/test_compression.py                    |   1 +
 tests/utils/test_config.py                         |   8 +-
 tests/utils/test_dag_cycle.py                      |   1 +
 tests/utils/test_dates.py                          |   1 +
 tests/utils/test_db.py                             |   1 +
 tests/utils/test_db_cleanup.py                     |   2 +
 tests/utils/test_docs.py                           |   1 +
 tests/utils/test_dot_renderer.py                   |   2 +
 tests/utils/test_edgemodifier.py                   |   1 +
 tests/utils/test_email.py                          |   2 +
 tests/utils/test_entry_points.py                   |   3 +-
 tests/utils/test_event_scheduler.py                |   1 +
 tests/utils/test_file.py                           |   1 +
 tests/utils/test_helpers.py                        |   2 +
 tests/utils/test_json.py                           |   1 +
 tests/utils/test_log_handlers.py                   |   1 +
 tests/utils/test_logging_mixin.py                  |   1 +
 tests/utils/test_module_loading.py                 |   1 +
 tests/utils/test_net.py                            |   2 +
 tests/utils/test_operator_helpers.py               |   1 +
 tests/utils/test_operator_resources.py             |   1 +
 ...test_preexisting_python_virtualenv_decorator.py |   3 +-
 tests/utils/test_process_utils.py                  |   2 +-
 tests/utils/test_python_virtualenv.py              |   3 +-
 tests/utils/test_retries.py                        |   1 +
 tests/utils/test_serve_logs.py                     |  24 +-
 tests/utils/test_session.py                        |   3 +-
 tests/utils/test_sqlalchemy.py                     |   3 +-
 tests/utils/test_state.py                          |   1 +
 tests/utils/test_task_group.py                     |   1 +
 .../test_task_handler_with_custom_formatter.py     |   2 +
 tests/utils/test_timezone.py                       |   1 +
 tests/utils/test_trigger_rule.py                   |   1 +
 tests/utils/test_types.py                          |   1 +
 tests/utils/test_weekday.py                        |   2 +
 tests/utils/test_weight_rule.py                    |   1 +
 tests/www/api/experimental/conftest.py             |   2 +
 .../www/api/experimental/test_dag_runs_endpoint.py |   2 +
 tests/www/api/experimental/test_endpoints.py       |   2 +
 tests/www/test_app.py                              |   2 +
 tests/www/test_init_views.py                       |   1 +
 tests/www/test_security.py                         |   2 +
 tests/www/test_utils.py                            |   1 +
 tests/www/test_validators.py                       |   1 +
 tests/www/views/conftest.py                        |   8 +-
 tests/www/views/test_session.py                    |   1 +
 tests/www/views/test_views.py                      |   2 +
 tests/www/views/test_views_acl.py                  |   2 +
 tests/www/views/test_views_base.py                 |   2 +
 tests/www/views/test_views_blocked.py              |   2 +
 tests/www/views/test_views_configuration.py        |   1 +
 tests/www/views/test_views_connection.py           |   2 +
 tests/www/views/test_views_custom_user_views.py    |   1 +
 tests/www/views/test_views_dagrun.py               |   2 +
 tests/www/views/test_views_decorators.py           |   5 +-
 tests/www/views/test_views_extra_links.py          |   2 +
 tests/www/views/test_views_graph_gantt.py          |   2 +
 tests/www/views/test_views_grid.py                 |   5 +-
 tests/www/views/test_views_home.py                 |   1 +
 tests/www/views/test_views_log.py                  |   2 +
 tests/www/views/test_views_mount.py                |   2 +
 tests/www/views/test_views_pool.py                 |   2 +
 tests/www/views/test_views_rendered.py             |   2 +
 tests/www/views/test_views_robots.py               |   2 +
 tests/www/views/test_views_task_norun.py           |   2 +
 tests/www/views/test_views_tasks.py                |   2 +
 tests/www/views/test_views_trigger_dag.py          |   2 +
 tests/www/views/test_views_variable.py             |   2 +
 1099 files changed, 4541 insertions(+), 3476 deletions(-)