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

[airflow] branch main updated (a16aa73068 -> 01a819a42d)

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

dstandish pushed a change to branch main
in repository https://gitbox.apache.org/repos/asf/airflow.git


    from a16aa73068 Expand tasks in mapped group at parse time (#27158)
     add 01a819a42d Enable python string normalization everywhere (#27588)

No new revisions were added by this update.

Summary of changes:
 .pre-commit-config.yaml                            |   21 +-
 STATIC_CODE_CHECKS.rst                             |    4 +-
 airflow/__init__.py                                |   18 +-
 airflow/__main__.py                                |    8 +-
 airflow/api/__init__.py                            |    2 +-
 airflow/api/auth/backend/kerberos_auth.py          |   14 +-
 airflow/api/client/__init__.py                     |    8 +-
 airflow/api/client/json_client.py                  |   50 +-
 airflow/api/common/delete_dag.py                   |    6 +-
 airflow/api/common/experimental/__init__.py        |    4 +-
 .../api/common/experimental/get_dag_run_state.py   |    2 +-
 airflow/api/common/experimental/get_dag_runs.py    |   14 +-
 .../api/common/experimental/get_task_instance.py   |    2 +-
 airflow/api/common/mark_tasks.py                   |   14 +-
 airflow/api/common/trigger_dag.py                  |    2 +-
 airflow/api_connexion/endpoints/config_endpoint.py |   18 +-
 .../api_connexion/endpoints/connection_endpoint.py |   16 +-
 airflow/api_connexion/endpoints/dag_endpoint.py    |   20 +-
 .../api_connexion/endpoints/dag_run_endpoint.py    |   22 +-
 .../api_connexion/endpoints/dag_source_endpoint.py |   10 +-
 .../endpoints/dag_warning_endpoint.py              |    2 +-
 .../api_connexion/endpoints/dataset_endpoint.py    |    8 +-
 .../api_connexion/endpoints/event_log_endpoint.py  |    2 +-
 .../endpoints/import_error_endpoint.py             |    6 +-
 airflow/api_connexion/endpoints/log_endpoint.py    |   12 +-
 airflow/api_connexion/endpoints/pool_endpoint.py   |    2 +-
 .../endpoints/role_and_permission_endpoint.py      |    8 +-
 airflow/api_connexion/endpoints/task_endpoint.py   |    2 +-
 .../endpoints/task_instance_endpoint.py            |   52 +-
 airflow/api_connexion/endpoints/user_endpoint.py   |    6 +-
 .../api_connexion/endpoints/variable_endpoint.py   |    2 +-
 airflow/api_connexion/endpoints/xcom_endpoint.py   |    6 +-
 airflow/api_connexion/exceptions.py                |    2 +-
 airflow/api_connexion/parameters.py                |    6 +-
 airflow/api_connexion/schemas/connection_schema.py |    4 +-
 airflow/api_connexion/schemas/dag_run_schema.py    |    4 +-
 airflow/api_connexion/schemas/dag_schema.py        |   10 +-
 airflow/api_connexion/schemas/dataset_schema.py    |    4 +-
 airflow/api_connexion/schemas/event_log_schema.py  |    4 +-
 .../schemas/role_and_permission_schema.py          |    2 +-
 airflow/api_connexion/schemas/task_schema.py       |    2 +-
 airflow/api_connexion/schemas/user_schema.py       |    2 +-
 airflow/api_connexion/security.py                  |    2 +-
 airflow/cli/cli_parser.py                          |  798 ++++----
 airflow/cli/commands/celery_command.py             |   36 +-
 airflow/cli/commands/config_command.py             |    4 +-
 airflow/cli/commands/connection_command.py         |   90 +-
 airflow/cli/commands/dag_command.py                |   26 +-
 airflow/cli/commands/dag_processor_command.py      |   12 +-
 airflow/cli/commands/db_command.py                 |   26 +-
 airflow/cli/commands/info_command.py               |    6 +-
 airflow/cli/commands/kerberos_command.py           |    2 +-
 airflow/cli/commands/kubernetes_command.py         |   30 +-
 airflow/cli/commands/pool_command.py               |    2 +-
 airflow/cli/commands/provider_command.py           |    8 +-
 airflow/cli/commands/role_command.py               |    6 +-
 airflow/cli/commands/scheduler_command.py          |    4 +-
 airflow/cli/commands/standalone_command.py         |    2 +-
 airflow/cli/commands/sync_perm_command.py          |    4 +-
 airflow/cli/commands/task_command.py               |   20 +-
 airflow/cli/commands/triggerer_command.py          |    2 +-
 airflow/cli/commands/user_command.py               |   58 +-
 airflow/cli/commands/variable_command.py           |    4 +-
 airflow/cli/commands/webserver_command.py          |   92 +-
 airflow/config_templates/airflow_local_settings.py |  340 ++--
 airflow/config_templates/default_celery.py         |   76 +-
 airflow/configuration.py                           |  482 ++---
 airflow/dag_processing/manager.py                  |   64 +-
 airflow/dag_processing/processor.py                |   28 +-
 airflow/datasets/__init__.py                       |   10 +-
 airflow/datasets/manager.py                        |   12 +-
 airflow/decorators/base.py                         |   26 +-
 airflow/decorators/branch_python.py                |    4 +-
 airflow/decorators/external_python.py              |    6 +-
 airflow/decorators/python.py                       |    6 +-
 airflow/decorators/python_virtualenv.py            |    6 +-
 airflow/decorators/sensor.py                       |    8 +-
 airflow/decorators/short_circuit.py                |    6 +-
 airflow/example_dags/example_bash_operator.py      |   18 +-
 .../example_branch_datetime_operator.py            |   30 +-
 .../example_branch_day_of_week_operator.py         |    8 +-
 airflow/example_dags/example_branch_operator.py    |   14 +-
 .../example_branch_operator_decorator.py           |   12 +-
 .../example_branch_python_dop_operator_3.py        |   14 +-
 airflow/example_dags/example_complex.py            |    2 +-
 airflow/example_dags/example_dag_decorator.py      |   14 +-
 airflow/example_dags/example_datasets.py           |   56 +-
 .../example_external_task_marker_dag.py            |   14 +-
 .../example_dags/example_kubernetes_executor.py    |   24 +-
 airflow/example_dags/example_latest_only.py        |    8 +-
 .../example_latest_only_with_trigger.py            |   14 +-
 .../example_local_kubernetes_executor.py           |   16 +-
 .../example_passing_params_via_test_command.py     |    6 +-
 airflow/example_dags/example_python_operator.py    |   22 +-
 airflow/example_dags/example_sensor_decorator.py   |    2 +-
 airflow/example_dags/example_sensors.py            |   34 +-
 .../example_short_circuit_decorator.py             |    6 +-
 .../example_dags/example_short_circuit_operator.py |   12 +-
 airflow/example_dags/example_skip_dag.py           |   16 +-
 airflow/example_dags/example_sla_dag.py            |    2 +-
 airflow/example_dags/example_subdag_operator.py    |   18 +-
 airflow/example_dags/example_task_group.py         |    6 +-
 .../example_dags/example_task_group_decorator.py   |   10 +-
 .../example_dags/example_trigger_controller_dag.py |    2 +-
 airflow/example_dags/example_trigger_target_dag.py |    4 +-
 airflow/example_dags/example_xcom.py               |   18 +-
 airflow/example_dags/example_xcomargs.py           |    6 +-
 airflow/example_dags/subdags/subdag.py             |    4 +-
 airflow/example_dags/tutorial.py                   |   28 +-
 airflow/example_dags/tutorial_dag.py               |   28 +-
 airflow/example_dags/tutorial_taskflow_api.py      |    2 +-
 .../tutorial_taskflow_api_virtualenv.py            |    4 +-
 airflow/executors/base_executor.py                 |   10 +-
 airflow/executors/celery_executor.py               |   40 +-
 airflow/executors/celery_kubernetes_executor.py    |    2 +-
 airflow/executors/dask_executor.py                 |   14 +-
 airflow/executors/executor_loader.py               |   18 +-
 airflow/executors/kubernetes_executor.py           |  160 +-
 airflow/executors/local_kubernetes_executor.py     |    2 +-
 airflow/hooks/__init__.py                          |   94 +-
 airflow/hooks/filesystem.py                        |    4 +-
 airflow/hooks/subprocess.py                        |   26 +-
 airflow/jobs/backfill_job.py                       |   38 +-
 airflow/jobs/base_job.py                           |   28 +-
 airflow/jobs/local_task_job.py                     |   10 +-
 airflow/jobs/scheduler_job.py                      |   90 +-
 airflow/jobs/triggerer_job.py                      |   16 +-
 airflow/kubernetes/kube_client.py                  |   18 +-
 airflow/kubernetes/kube_config.py                  |   50 +-
 airflow/kubernetes/kubernetes_helper_functions.py  |   16 +-
 airflow/kubernetes/pod_generator.py                |   78 +-
 airflow/kubernetes/pod_generator_deprecated.py     |   40 +-
 airflow/kubernetes/pod_launcher_deprecated.py      |   58 +-
 airflow/kubernetes/secret.py                       |   16 +-
 airflow/lineage/__init__.py                        |   18 +-
 airflow/listeners/events.py                        |    6 +-
 airflow/logging_config.py                          |   32 +-
 airflow/macros/hive.py                             |   16 +-
 airflow/migrations/db_types.py                     |    2 +-
 airflow/migrations/env.py                          |    4 +-
 airflow/migrations/utils.py                        |    2 +-
 .../versions/0001_1_5_0_current_schema.py          |  328 ++--
 .../versions/0002_1_5_0_create_is_encrypted.py     |   18 +-
 .../versions/0003_1_5_0_for_compatibility.py       |    6 +-
 .../0004_1_5_0_more_logging_into_task_isntance.py  |   14 +-
 .../versions/0005_1_5_2_job_id_indices.py          |   10 +-
 .../versions/0006_1_6_0_adding_extra_to_log.py     |   10 +-
 .../migrations/versions/0007_1_6_0_add_dagrun.py   |   28 +-
 .../versions/0008_1_6_0_task_duration.py           |    8 +-
 .../versions/0009_1_6_0_dagrun_config.py           |   10 +-
 .../0010_1_6_2_add_password_column_to_user.py      |   10 +-
 .../versions/0011_1_6_2_dagrun_start_end.py        |   14 +-
 ...7_0_add_notification_sent_column_to_sla_miss.py |   10 +-
 ..._1_7_0_add_a_column_to_track_the_encryption_.py |   10 +-
 ...4_1_7_0_add_is_encrypted_column_to_variable_.py |   10 +-
 .../versions/0015_1_7_1_rename_user_table.py       |   10 +-
 .../versions/0016_1_7_1_add_ti_state_index.py      |   10 +-
 .../0017_1_7_1_add_task_fails_journal_table.py     |   26 +-
 .../versions/0018_1_7_1_add_dag_stats_table.py     |   20 +-
 ...1_7_1_add_fractional_seconds_to_mysql_tables.py |  104 +-
 .../versions/0020_1_7_1_xcom_dag_task_indices.py   |   10 +-
 .../0021_1_7_1_add_pid_field_to_taskinstance.py    |   10 +-
 ..._7_1_add_dag_id_state_index_on_dag_run_table.py |   10 +-
 ..._1_8_2_add_max_tries_column_to_task_instance.py |   14 +-
 ..._1_8_2_make_xcom_value_column_a_large_binary.py |   10 +-
 .../versions/0025_1_8_2_add_ti_job_id_index.py     |   10 +-
 .../0026_1_8_2_increase_text_size_for_mysql.py     |   10 +-
 .../0027_1_10_0_add_time_zone_awareness.py         |    2 +-
 ...1_10_0_add_kubernetes_resource_checkpointing.py |    6 +-
 ..._1_10_0_add_executor_config_to_task_instance.py |    6 +-
 ...0_1_10_0_add_kubernetes_scheduler_uniqueness.py |    6 +-
 .../migrations/versions/0031_1_10_0_merge_heads.py |    6 +-
 .../0032_1_10_0_fix_mysql_not_null_constraint.py   |   22 +-
 .../versions/0033_1_10_0_fix_sqlite_foreign_key.py |   46 +-
 .../versions/0034_1_10_0_index_taskfail.py         |   10 +-
 .../versions/0035_1_10_2_add_idx_log_dag.py        |   10 +-
 .../0036_1_10_2_add_index_to_taskinstance.py       |   10 +-
 .../0037_1_10_2_add_task_reschedule_table.py       |   40 +-
 .../versions/0038_1_10_2_add_sm_dag_index.py       |   10 +-
 .../versions/0039_1_10_2_add_superuser_field.py    |   10 +-
 .../versions/0040_1_10_3_add_fields_to_dag.py      |   14 +-
 .../0041_1_10_3_add_schedule_interval_to_dag.py    |   10 +-
 ..._1_10_3_task_reschedule_fk_on_cascade_delete.py |   32 +-
 ...3_1_10_4_make_taskinstance_pool_not_nullable.py |   26 +-
 .../0044_1_10_7_add_serialized_dag_table.py        |   24 +-
 .../versions/0045_1_10_7_add_root_dag_id_to_dag.py |   14 +-
 ...0_5_change_datetime_to_datetime2_6_on_mssql_.py |  214 +--
 .../0047_1_10_4_increase_queue_name_size_limit.py  |   14 +-
 .../versions/0048_1_10_3_remove_dag_stat_table.py  |   18 +-
 .../migrations/versions/0049_1_10_7_merge_heads.py |    6 +-
 ...10_7_increase_length_for_connection_password.py |   14 +-
 .../versions/0051_1_10_8_add_dagtags_table.py      |   20 +-
 ..._10_10_add_pool_slots_field_to_task_instance.py |   10 +-
 ...0_10_add_rendered_task_instance_fields_table.py |   18 +-
 .../versions/0054_1_10_10_add_dag_code_table.py    |   28 +-
 ..._11_add_precision_to_execution_date_in_mysql.py |   10 +-
 ...10_12_add_dag_hash_column_to_serialized_dag_.py |   12 +-
 .../versions/0057_1_10_13_add_fab_tables.py        |  150 +-
 ...1_10_13_increase_length_of_fab_ab_view_menu_.py |   12 +-
 .../versions/0059_2_0_0_drop_user_and_chart.py     |   78 +-
 .../0060_2_0_0_remove_id_column_from_xcom.py       |   38 +-
 .../0061_2_0_0_increase_length_of_pool_name.py     |   14 +-
 .../versions/0062_2_0_0_add_dagrun_run_type.py     |    4 +-
 .../0063_2_0_0_set_conn_type_as_non_nullable.py    |    2 +-
 .../0064_2_0_0_add_unique_constraint_to_conn_id.py |   10 +-
 .../0065_2_0_0_update_schema_for_smart_sensor.py   |   56 +-
 .../0066_2_0_0_add_queued_by_job_id_to_ti.py       |   14 +-
 .../0067_2_0_0_add_external_executor_id_to_ti.py   |   14 +-
 .../0068_2_0_0_drop_kuberesourceversion_and_.py    |    6 +-
 ...2_0_0_add_scheduling_decision_to_dagrun_and_.py |   56 +-
 ...0_fix_mssql_exec_date_rendered_task_instance.py |   28 +-
 .../0071_2_0_0_add_job_id_to_dagrun_table.py       |   10 +-
 ...072_2_0_0_add_k8s_yaml_to_rendered_templates.py |   10 +-
 .../versions/0073_2_0_0_prefix_dag_permissions.py  |   38 +-
 .../0074_2_0_0_resource_based_permissions.py       |   10 +-
 ...75_2_0_0_add_description_field_to_connection.py |   16 +-
 ..._0_0_fix_description_field_in_connection_to_.py |   20 +-
 ...2_0_0_change_field_in_dagcode_to_mediumtext_.py |    8 +-
 ..._2_0_1_remove_can_read_permission_on_config_.py |   10 +-
 ...0_2_increase_size_of_connection_extra_field_.py |   14 +-
 .../0080_2_0_2_change_default_pool_slots_to_1.py   |   14 +-
 .../0081_2_0_2_rename_last_scheduler_run_column.py |   22 +-
 ..._1_0_increase_pool_name_size_in_taskinstance.py |   24 +-
 ...0083_2_1_0_add_description_field_to_variable.py |   14 +-
 ..._1_0_resource_based_permissions_for_default_.py |   10 +-
 ...5_2_1_3_add_queued_at_column_to_dagrun_table.py |   12 +-
 ..._1_4_add_max_active_runs_column_to_dagmodel_.py |   24 +-
 ..._2_1_4_add_index_on_state_dag_id_for_queued_.py |   14 +-
 .../0088_2_2_0_improve_mssql_compatibility.py      |   76 +-
 ...89_2_2_0_make_xcom_pkey_columns_non_nullable.py |   18 +-
 ..._2_0_rename_concurrency_column_in_dag_table_.py |   18 +-
 .../0091_2_2_0_add_trigger_table_and_task_info.py  |   48 +-
 ...ta_interval_start_end_to_dagmodel_and_dagrun.py |    2 +-
 .../0093_2_2_0_taskinstance_keyed_to_dagrun.py     |  316 ++--
 ...2_3_add_has_import_errors_column_to_dagmodel.py |   12 +-
 .../versions/0095_2_2_4_add_session_table_to_db.py |   20 +-
 .../0096_2_2_4_adding_index_for_dag_id_in_job.py   |   10 +-
 ..._2_3_0_increase_length_of_email_and_username.py |   66 +-
 ...098_2_3_0_added_timetable_description_column.py |   20 +-
 ...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 |   18 +-
 .../0102_2_3_0_switch_xcom_table_to_use_run_id.py  |   10 +-
 .../0103_2_3_0_add_callback_request_table.py       |   22 +-
 ...3_0_migrate_rtif_to_use_run_id_and_map_index.py |  100 +-
 .../0105_2_3_0_add_map_index_to_taskfail.py        |   86 +-
 ...on_for_fab_tables_to_add_missing_constraints.py |  118 +-
 .../versions/0107_2_3_0_add_map_index_to_log.py    |    2 +-
 .../versions/0108_2_3_0_default_dag_view_grid.py   |   18 +-
 .../0109_2_3_1_add_index_for_event_in_log.py       |   10 +-
 ...0110_2_3_2_add_cascade_to_dag_tag_foreignkey.py |   50 +-
 .../0111_2_3_3_add_indexes_for_cascade_deletes.py  |   46 +-
 .../versions/0112_2_4_0_add_dagwarning_model.py    |   26 +-
 .../0113_2_4_0_compare_types_between_orm_and_db.py |  172 +-
 .../versions/0114_2_4_0_add_dataset_model.py       |  148 +-
 .../versions/0115_2_4_0_remove_smart_sensors.py    |   56 +-
 .../0116_2_4_0_add_dag_owner_attributes_table.py   |   20 +-
 ..._2_4_0_add_processor_subdir_to_dagmodel_and_.py |   42 +-
 .../versions/0118_2_4_2_add_missing_autoinc_fab.py |   30 +-
 ...e_insensitive_unique_constraint_for_username.py |   46 +-
 .../0120_2_5_0_add_updated_at_to_dagrun_and_ti.py  |   22 +-
 airflow/models/__init__.py                         |   60 +-
 airflow/models/abstractoperator.py                 |   22 +-
 airflow/models/base.py                             |   10 +-
 airflow/models/baseoperator.py                     |  148 +-
 airflow/models/connection.py                       |   84 +-
 airflow/models/crypto.py                           |    4 +-
 airflow/models/dag.py                              |  222 +--
 airflow/models/dagbag.py                           |   28 +-
 airflow/models/dagcode.py                          |   10 +-
 airflow/models/dagpickle.py                        |    2 +-
 airflow/models/dagrun.py                           |   78 +-
 airflow/models/dagwarning.py                       |   12 +-
 airflow/models/dataset.py                          |   54 +-
 airflow/models/db_callback_request.py              |    2 +-
 airflow/models/log.py                              |   22 +-
 airflow/models/mappedoperator.py                   |    6 +-
 airflow/models/param.py                            |   20 +-
 airflow/models/pool.py                             |   14 +-
 airflow/models/renderedtifields.py                 |   10 +-
 airflow/models/serialized_dag.py                   |   12 +-
 airflow/models/slamiss.py                          |    2 +-
 airflow/models/taskfail.py                         |    6 +-
 airflow/models/taskinstance.py                     |  294 +--
 airflow/models/taskmixin.py                        |    8 +-
 airflow/models/taskreschedule.py                   |   12 +-
 airflow/models/variable.py                         |   28 +-
 airflow/models/xcom.py                             |   14 +-
 airflow/operators/bash.py                          |   20 +-
 airflow/operators/branch.py                        |    2 +-
 airflow/operators/email.py                         |   10 +-
 airflow/operators/empty.py                         |    2 +-
 airflow/operators/generic_transfer.py              |   14 +-
 airflow/operators/latest_only.py                   |   16 +-
 airflow/operators/python.py                        |  128 +-
 airflow/operators/smooth.py                        |    2 +-
 airflow/operators/subdag.py                        |   40 +-
 airflow/operators/trigger_dagrun.py                |    6 +-
 airflow/plugins_manager.py                         |   38 +-
 airflow/providers_manager.py                       |   52 +-
 airflow/secrets/__init__.py                        |    2 +-
 airflow/secrets/base_secrets.py                    |    2 +-
 airflow/security/kerberos.py                       |   32 +-
 airflow/security/utils.py                          |   10 +-
 airflow/sensors/base.py                            |   24 +-
 airflow/sensors/bash.py                            |   12 +-
 airflow/sensors/external_task.py                   |   60 +-
 airflow/sensors/filesystem.py                      |   12 +-
 airflow/sensors/python.py                          |    2 +-
 airflow/sensors/time_delta.py                      |    6 +-
 airflow/sensors/time_sensor.py                     |    2 +-
 airflow/sensors/weekday.py                         |    4 +-
 airflow/sentry.py                                  |    8 +-
 airflow/serialization/enums.py                     |   34 +-
 airflow/serialization/json_schema.py               |    2 +-
 airflow/serialization/serialized_objects.py        |   88 +-
 airflow/settings.py                                |  136 +-
 airflow/stats.py                                   |   40 +-
 airflow/task/task_runner/__init__.py               |    2 +-
 airflow/task/task_runner/base_task_runner.py       |   22 +-
 airflow/task/task_runner/cgroup_task_runner.py     |    4 +-
 airflow/task/task_runner/standard_task_runner.py   |    6 +-
 airflow/templates.py                               |   18 +-
 airflow/ti_deps/deps/base_ti_dep.py                |    6 +-
 airflow/ti_deps/deps/task_not_running_dep.py       |    2 +-
 airflow/ti_deps/deps/valid_state_dep.py            |    2 +-
 airflow/timetables/simple.py                       |    4 +-
 airflow/utils/cli.py                               |   44 +-
 airflow/utils/cli_action_loggers.py                |   22 +-
 airflow/utils/code_utils.py                        |    4 +-
 airflow/utils/compression.py                       |   10 +-
 airflow/utils/configuration.py                     |    2 +-
 airflow/utils/dates.py                             |   28 +-
 airflow/utils/db.py                                |  184 +-
 airflow/utils/db_cleanup.py                        |   60 +-
 airflow/utils/decorators.py                        |    4 +-
 airflow/utils/deprecation_tools.py                 |    2 +-
 airflow/utils/docs.py                              |    8 +-
 airflow/utils/email.py                             |   50 +-
 airflow/utils/file.py                              |   16 +-
 airflow/utils/helpers.py                           |   34 +-
 airflow/utils/json.py                              |    6 +-
 airflow/utils/log/colored_log.py                   |    6 +-
 airflow/utils/log/file_processor_handler.py        |    4 +-
 airflow/utils/log/file_task_handler.py             |   42 +-
 airflow/utils/log/json_formatter.py                |    4 +-
 airflow/utils/log/log_reader.py                    |   20 +-
 airflow/utils/log/logging_mixin.py                 |   12 +-
 airflow/utils/log/secrets_masker.py                |   42 +-
 .../log/task_handler_with_custom_formatter.py      |    2 +-
 airflow/utils/log/timezone_aware.py                |    6 +-
 airflow/utils/mixins.py                            |    4 +-
 airflow/utils/module_loading.py                    |    2 +-
 airflow/utils/net.py                               |    6 +-
 airflow/utils/operator_helpers.py                  |   72 +-
 airflow/utils/operator_resources.py                |   42 +-
 airflow/utils/orm_event_handlers.py                |   16 +-
 airflow/utils/platform.py                          |    4 +-
 airflow/utils/process_utils.py                     |    4 +-
 airflow/utils/python_virtualenv.py                 |   14 +-
 airflow/utils/retries.py                           |    2 +-
 airflow/utils/scheduler_health.py                  |    4 +-
 airflow/utils/serve_logs.py                        |   16 +-
 airflow/utils/sqlalchemy.py                        |   72 +-
 airflow/utils/state.py                             |   36 +-
 airflow/utils/strings.py                           |    2 +-
 airflow/utils/task_group.py                        |   68 +-
 airflow/utils/timeout.py                           |    8 +-
 airflow/utils/timezone.py                          |   14 +-
 airflow/utils/trigger_rule.py                      |   24 +-
 airflow/utils/weight_rule.py                       |    6 +-
 airflow/version.py                                 |    4 +-
 airflow/www/api/experimental/endpoints.py          |  114 +-
 airflow/www/app.py                                 |   34 +-
 airflow/www/auth.py                                |    6 +-
 airflow/www/blueprints.py                          |    6 +-
 airflow/www/decorators.py                          |   26 +-
 airflow/www/extensions/init_appbuilder.py          |   14 +-
 airflow/www/extensions/init_appbuilder_links.py    |    8 +-
 airflow/www/extensions/init_dagbag.py              |    2 +-
 airflow/www/extensions/init_jinja_globals.py       |   44 +-
 airflow/www/extensions/init_manifest_files.py      |    4 +-
 airflow/www/extensions/init_robots.py              |    2 +-
 airflow/www/extensions/init_security.py            |    6 +-
 airflow/www/extensions/init_session.py             |   12 +-
 airflow/www/extensions/init_views.py               |   36 +-
 airflow/www/extensions/init_wsgi_middlewares.py    |   10 +-
 airflow/www/fab_security/manager.py                |    2 +-
 airflow/www/fab_security/sqla/models.py            |    4 +-
 airflow/www/fab_security/views.py                  |  126 +-
 airflow/www/forms.py                               |   62 +-
 airflow/www/security.py                            |   50 +-
 airflow/www/session.py                             |    4 +-
 airflow/www/utils.py                               |  162 +-
 airflow/www/validators.py                          |    6 +-
 airflow/www/views.py                               | 1926 ++++++++++----------
 airflow/www/widgets.py                             |   12 +-
 docs/apache-airflow/img/airflow_erd.sha256         |    2 +-
 398 files changed, 6822 insertions(+), 6841 deletions(-)