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 2021/06/28 17:26:42 UTC

[airflow] branch main updated (622b4f4 -> 866a601)

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

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


    from 622b4f4  Refactor usage of unneeded function call (#16653)
     add 866a601  Removes pylint from our toolchain (#16682)

No new revisions were added by this update.

Summary of changes:
 .dockerignore                                      |   2 -
 .github/boring-cyborg.yml                          |   2 +-
 .github/workflows/ci.yml                           |  73 +--
 .pre-commit-config.yaml                            |  51 +-
 .rat-excludes                                      |   3 -
 BREEZE.rst                                         |  31 +-
 CI.rst                                             |   4 +-
 CONTRIBUTING.rst                                   |   2 +-
 CONTRIBUTORS_QUICK_START.rst                       |  14 +-
 PULL_REQUEST_WORKFLOW.rst                          |   6 +-
 STATIC_CODE_CHECKS.rst                             | 117 +---
 airflow/__init__.py                                |  10 +-
 airflow/api/auth/backend/basic_auth.py             |   2 +-
 airflow/api/auth/backend/default.py                |   2 +-
 airflow/api/auth/backend/deny_all.py               |   4 +-
 airflow/api/auth/backend/kerberos_auth.py          |   6 +-
 airflow/api/client/json_client.py                  |   4 +-
 airflow/api/common/experimental/delete_dag.py      |   2 +-
 airflow/api/common/experimental/mark_tasks.py      |   9 +-
 airflow/api/common/experimental/trigger_dag.py     |   2 +-
 .../api_connexion/endpoints/dag_run_endpoint.py    |   4 +-
 airflow/api_connexion/endpoints/health_endpoint.py |   2 +-
 .../endpoints/task_instance_endpoint.py            |   2 +-
 airflow/api_connexion/parameters.py                |   2 +-
 airflow/api_connexion/schemas/common_schema.py     |   4 +-
 airflow/api_connexion/schemas/connection_schema.py |   2 +-
 airflow/api_connexion/schemas/error_schema.py      |   2 +-
 airflow/api_connexion/security.py                  |   2 +-
 airflow/cli/cli_parser.py                          |  13 +-
 airflow/cli/commands/celery_command.py             |   2 +-
 airflow/cli/commands/info_command.py               |   2 +-
 airflow/cli/commands/kubernetes_command.py         |   4 +-
 airflow/cli/commands/plugins_command.py            |   2 +-
 airflow/cli/commands/pool_command.py               |   2 +-
 airflow/cli/commands/role_command.py               |   4 +-
 airflow/cli/commands/standalone_command.py         |   4 +-
 airflow/cli/commands/sync_perm_command.py          |   2 +-
 airflow/cli/commands/task_command.py               |   4 +-
 airflow/cli/commands/user_command.py               |  18 +-
 airflow/cli/commands/variable_command.py           |   4 +-
 airflow/cli/commands/webserver_command.py          |   6 +-
 airflow/cli/simple_table.py                        |   3 +-
 airflow/compat/functools.py                        |   4 +-
 airflow/configuration.py                           |  28 +-
 airflow/contrib/hooks/aws_athena_hook.py           |   1 -
 airflow/contrib/hooks/aws_datasync_hook.py         |   1 -
 airflow/contrib/hooks/aws_dynamodb_hook.py         |   1 -
 airflow/contrib/hooks/aws_firehose_hook.py         |   1 -
 airflow/contrib/hooks/aws_glue_catalog_hook.py     |   1 -
 airflow/contrib/hooks/aws_hook.py                  |   1 -
 airflow/contrib/hooks/aws_lambda_hook.py           |   1 -
 airflow/contrib/hooks/aws_logs_hook.py             |   1 -
 airflow/contrib/hooks/aws_sns_hook.py              |   1 -
 airflow/contrib/hooks/aws_sqs_hook.py              |   1 -
 .../contrib/hooks/azure_container_instance_hook.py |   1 -
 .../contrib/hooks/azure_container_registry_hook.py |   1 -
 .../contrib/hooks/azure_container_volume_hook.py   |   1 -
 airflow/contrib/hooks/azure_cosmos_hook.py         |   1 -
 airflow/contrib/hooks/azure_data_lake_hook.py      |   1 -
 airflow/contrib/hooks/azure_fileshare_hook.py      |   1 -
 airflow/contrib/hooks/bigquery_hook.py             |   1 -
 airflow/contrib/hooks/cassandra_hook.py            |   1 -
 airflow/contrib/hooks/cloudant_hook.py             |   1 -
 airflow/contrib/hooks/databricks_hook.py           |   1 -
 airflow/contrib/hooks/datadog_hook.py              |   1 -
 airflow/contrib/hooks/datastore_hook.py            |   1 -
 airflow/contrib/hooks/dingding_hook.py             |   1 -
 airflow/contrib/hooks/discord_webhook_hook.py      |   1 -
 airflow/contrib/hooks/emr_hook.py                  |   1 -
 airflow/contrib/hooks/fs_hook.py                   |   1 -
 airflow/contrib/hooks/ftp_hook.py                  |   1 -
 airflow/contrib/hooks/gcp_bigtable_hook.py         |   1 -
 airflow/contrib/hooks/gcp_cloud_build_hook.py      |   1 -
 airflow/contrib/hooks/gcp_dlp_hook.py              |   1 -
 airflow/contrib/hooks/gcp_mlengine_hook.py         |   1 -
 airflow/contrib/hooks/gcp_natural_language_hook.py |   1 -
 airflow/contrib/hooks/gcp_pubsub_hook.py           |   1 -
 airflow/contrib/hooks/gcp_tasks_hook.py            |   1 -
 airflow/contrib/hooks/gcp_translate_hook.py        |   1 -
 .../contrib/hooks/gcp_video_intelligence_hook.py   |   1 -
 airflow/contrib/hooks/gcp_vision_hook.py           |   1 -
 airflow/contrib/hooks/gdrive_hook.py               |   1 -
 airflow/contrib/hooks/grpc_hook.py                 |   1 -
 airflow/contrib/hooks/imap_hook.py                 |   1 -
 airflow/contrib/hooks/jenkins_hook.py              |   1 -
 airflow/contrib/hooks/jira_hook.py                 |   1 -
 airflow/contrib/hooks/mongo_hook.py                |   1 -
 airflow/contrib/hooks/openfaas_hook.py             |   1 -
 airflow/contrib/hooks/opsgenie_alert_hook.py       |   1 -
 airflow/contrib/hooks/pagerduty_hook.py            |   1 -
 airflow/contrib/hooks/pinot_hook.py                |   1 -
 airflow/contrib/hooks/qubole_check_hook.py         |   1 -
 airflow/contrib/hooks/qubole_hook.py               |   1 -
 airflow/contrib/hooks/redis_hook.py                |   1 -
 airflow/contrib/hooks/redshift_hook.py             |   1 -
 airflow/contrib/hooks/sagemaker_hook.py            |   1 -
 airflow/contrib/hooks/salesforce_hook.py           |   1 -
 airflow/contrib/hooks/segment_hook.py              |   1 -
 airflow/contrib/hooks/sftp_hook.py                 |   1 -
 airflow/contrib/hooks/slack_webhook_hook.py        |   1 -
 airflow/contrib/hooks/snowflake_hook.py            |   1 -
 airflow/contrib/hooks/spark_jdbc_hook.py           |   1 -
 airflow/contrib/hooks/spark_sql_hook.py            |   1 -
 airflow/contrib/hooks/spark_submit_hook.py         |   1 -
 airflow/contrib/hooks/sqoop_hook.py                |   1 -
 airflow/contrib/hooks/ssh_hook.py                  |   1 -
 airflow/contrib/hooks/vertica_hook.py              |   1 -
 airflow/contrib/hooks/wasb_hook.py                 |   1 -
 airflow/contrib/hooks/winrm_hook.py                |   1 -
 airflow/contrib/operators/adls_list_operator.py    |   1 -
 airflow/contrib/operators/aws_athena_operator.py   |   1 -
 .../contrib/operators/aws_sqs_publish_operator.py  |   1 -
 airflow/contrib/operators/awsbatch_operator.py     |   1 -
 .../azure_container_instances_operator.py          |   1 -
 airflow/contrib/operators/azure_cosmos_operator.py |   1 -
 .../contrib/operators/bigquery_check_operator.py   |   1 -
 airflow/contrib/operators/bigquery_get_data.py     |   1 -
 airflow/contrib/operators/bigquery_operator.py     |   1 -
 airflow/contrib/operators/bigquery_to_bigquery.py  |   1 -
 .../operators/bigquery_to_mysql_operator.py        |   1 -
 airflow/contrib/operators/databricks_operator.py   |   1 -
 airflow/contrib/operators/dingding_operator.py     |   1 -
 .../contrib/operators/discord_webhook_operator.py  |   1 -
 airflow/contrib/operators/docker_swarm_operator.py |   1 -
 airflow/contrib/operators/druid_operator.py        |   1 -
 airflow/contrib/operators/dynamodb_to_s3.py        |   1 -
 airflow/contrib/operators/ecs_operator.py          |   1 -
 .../contrib/operators/emr_add_steps_operator.py    |   1 -
 .../operators/emr_create_job_flow_operator.py      |   1 -
 .../operators/emr_terminate_job_flow_operator.py   |   1 -
 airflow/contrib/operators/file_to_wasb.py          |   1 -
 airflow/contrib/operators/gcp_bigtable_operator.py |   1 -
 .../contrib/operators/gcp_cloud_build_operator.py  |   1 -
 airflow/contrib/operators/gcp_dlp_operator.py      |   1 -
 airflow/contrib/operators/gcp_tasks_operator.py    |   1 -
 .../contrib/operators/gcp_translate_operator.py    |   1 -
 .../operators/gcp_translate_speech_operator.py     |   3 +-
 .../operators/gcp_video_intelligence_operator.py   |   1 -
 airflow/contrib/operators/gcp_vision_operator.py   |   2 +-
 .../operators/gcs_to_gcs_transfer_operator.py      |   2 -
 .../contrib/operators/gcs_to_gdrive_operator.py    |   1 -
 airflow/contrib/operators/grpc_operator.py         |   1 -
 airflow/contrib/operators/hive_to_dynamodb.py      |   1 -
 .../operators/imap_attachment_to_s3_operator.py    |   1 -
 .../operators/jenkins_job_trigger_operator.py      |   1 -
 airflow/contrib/operators/jira_operator.py         |   1 -
 .../contrib/operators/kubernetes_pod_operator.py   |   1 -
 airflow/contrib/operators/mongo_to_s3.py           |   1 -
 .../contrib/operators/opsgenie_alert_operator.py   |   1 -
 .../oracle_to_azure_data_lake_transfer.py          |   1 -
 .../contrib/operators/oracle_to_oracle_transfer.py |   1 -
 airflow/contrib/operators/qubole_check_operator.py |   1 -
 airflow/contrib/operators/qubole_operator.py       |   1 -
 .../contrib/operators/redis_publish_operator.py    |   1 -
 .../contrib/operators/s3_copy_object_operator.py   |   1 -
 .../operators/s3_delete_objects_operator.py        |   1 -
 airflow/contrib/operators/s3_list_operator.py      |   1 -
 airflow/contrib/operators/s3_to_gcs_operator.py    |   1 -
 .../operators/s3_to_gcs_transfer_operator.py       |   1 -
 airflow/contrib/operators/s3_to_sftp_operator.py   |   1 -
 .../contrib/operators/sagemaker_base_operator.py   |   1 -
 .../sagemaker_endpoint_config_operator.py          |   1 -
 .../operators/sagemaker_endpoint_operator.py       |   1 -
 .../contrib/operators/sagemaker_model_operator.py  |   1 -
 .../operators/sagemaker_training_operator.py       |   1 -
 .../operators/sagemaker_transform_operator.py      |   1 -
 .../contrib/operators/sagemaker_tuning_operator.py |   1 -
 .../operators/segment_track_event_operator.py      |   1 -
 airflow/contrib/operators/sftp_operator.py         |   1 -
 airflow/contrib/operators/sftp_to_s3_operator.py   |   1 -
 .../contrib/operators/slack_webhook_operator.py    |   1 -
 airflow/contrib/operators/snowflake_operator.py    |   1 -
 airflow/contrib/operators/sns_publish_operator.py  |   1 -
 airflow/contrib/operators/spark_jdbc_operator.py   |   1 -
 airflow/contrib/operators/spark_sql_operator.py    |   1 -
 airflow/contrib/operators/spark_submit_operator.py |   1 -
 airflow/contrib/operators/sqoop_operator.py        |   1 -
 airflow/contrib/operators/ssh_operator.py          |   1 -
 airflow/contrib/operators/vertica_operator.py      |   1 -
 airflow/contrib/operators/vertica_to_mysql.py      |   1 -
 .../contrib/operators/wasb_delete_blob_operator.py |   1 -
 airflow/contrib/operators/winrm_operator.py        |   1 -
 airflow/contrib/secrets/aws_secrets_manager.py     |   1 -
 airflow/contrib/secrets/aws_systems_manager.py     |   1 -
 airflow/contrib/secrets/azure_key_vault.py         |   1 -
 airflow/contrib/secrets/gcp_secrets_manager.py     |   1 -
 airflow/contrib/secrets/hashicorp_vault.py         |   1 -
 airflow/contrib/sensors/aws_athena_sensor.py       |   1 -
 .../sensors/aws_glue_catalog_partition_sensor.py   |   1 -
 .../contrib/sensors/aws_redshift_cluster_sensor.py |   1 -
 airflow/contrib/sensors/aws_sqs_sensor.py          |   1 -
 airflow/contrib/sensors/azure_cosmos_sensor.py     |   1 -
 airflow/contrib/sensors/bash_sensor.py             |   1 -
 airflow/contrib/sensors/cassandra_record_sensor.py |   1 -
 airflow/contrib/sensors/cassandra_table_sensor.py  |   1 -
 airflow/contrib/sensors/celery_queue_sensor.py     |   1 -
 airflow/contrib/sensors/datadog_sensor.py          |   1 -
 airflow/contrib/sensors/emr_base_sensor.py         |   1 -
 airflow/contrib/sensors/emr_job_flow_sensor.py     |   1 -
 airflow/contrib/sensors/emr_step_sensor.py         |   1 -
 airflow/contrib/sensors/file_sensor.py             |   1 -
 airflow/contrib/sensors/ftp_sensor.py              |   1 -
 airflow/contrib/sensors/hdfs_sensor.py             |   3 -
 airflow/contrib/sensors/imap_attachment_sensor.py  |   1 -
 airflow/contrib/sensors/jira_sensor.py             |   1 -
 airflow/contrib/sensors/mongo_sensor.py            |   1 -
 airflow/contrib/sensors/pubsub_sensor.py           |   1 -
 airflow/contrib/sensors/python_sensor.py           |   1 -
 airflow/contrib/sensors/qubole_sensor.py           |   1 -
 airflow/contrib/sensors/redis_key_sensor.py        |   1 -
 airflow/contrib/sensors/redis_pub_sub_sensor.py    |   1 -
 airflow/contrib/sensors/sagemaker_base_sensor.py   |   1 -
 .../contrib/sensors/sagemaker_endpoint_sensor.py   |   1 -
 .../contrib/sensors/sagemaker_training_sensor.py   |   1 -
 .../contrib/sensors/sagemaker_transform_sensor.py  |   1 -
 airflow/contrib/sensors/sagemaker_tuning_sensor.py |   1 -
 airflow/contrib/sensors/sftp_sensor.py             |   1 -
 airflow/contrib/sensors/wasb_sensor.py             |   1 -
 airflow/contrib/sensors/weekday_sensor.py          |   1 -
 airflow/contrib/task_runner/cgroup_task_runner.py  |   1 -
 airflow/contrib/utils/gcp_field_sanitizer.py       |   1 -
 airflow/contrib/utils/gcp_field_validator.py       |   1 -
 .../log/task_handler_with_custom_formatter.py      |   1 -
 airflow/contrib/utils/mlengine_operator_utils.py   |   1 -
 .../contrib/utils/mlengine_prediction_summary.py   |   1 -
 airflow/contrib/utils/weekday.py                   |   1 -
 airflow/dag_processing/manager.py                  |  14 +-
 airflow/dag_processing/processor.py                |  21 +-
 airflow/decorators/__init__.py                     |   4 +-
 airflow/decorators/base.py                         |   2 +-
 airflow/decorators/python.py                       |   2 +-
 airflow/decorators/python_virtualenv.py            |   2 +-
 airflow/decorators/task_group.py                   |   2 +-
 airflow/example_dags/example_branch_labels.py      |   4 +-
 airflow/example_dags/example_branch_operator.py    |   2 +-
 airflow/example_dags/libs/helper.py                |   3 +-
 airflow/example_dags/tutorial_etl_dag.py           |   1 -
 airflow/example_dags/tutorial_taskflow_api_etl.py  |   1 -
 .../tutorial_taskflow_api_etl_virtualenv.py        |   1 -
 airflow/executors/celery_executor.py               |  26 +-
 airflow/executors/debug_executor.py                |  12 +-
 airflow/executors/kubernetes_executor.py           |  18 +-
 airflow/executors/local_executor.py                |  21 +-
 airflow/hooks/S3_hook.py                           |   3 +-
 airflow/hooks/base_hook.py                         |   1 -
 airflow/hooks/dbapi.py                             |   4 +-
 airflow/hooks/dbapi_hook.py                        |   1 -
 airflow/hooks/docker_hook.py                       |   1 -
 airflow/hooks/druid_hook.py                        |   1 -
 airflow/hooks/hdfs_hook.py                         |   1 -
 airflow/hooks/hive_hooks.py                        |   1 -
 airflow/hooks/http_hook.py                         |   1 -
 airflow/hooks/jdbc_hook.py                         |   1 -
 airflow/hooks/mssql_hook.py                        |   1 -
 airflow/hooks/mysql_hook.py                        |   1 -
 airflow/hooks/oracle_hook.py                       |   1 -
 airflow/hooks/pig_hook.py                          |   1 -
 airflow/hooks/postgres_hook.py                     |   1 -
 airflow/hooks/presto_hook.py                       |   1 -
 airflow/hooks/samba_hook.py                        |   1 -
 airflow/hooks/slack_hook.py                        |   1 -
 airflow/hooks/sqlite_hook.py                       |   1 -
 airflow/hooks/subprocess.py                        |   3 +-
 airflow/hooks/webhdfs_hook.py                      |   1 -
 airflow/hooks/zendesk_hook.py                      |   1 -
 airflow/jobs/__init__.py                           |   6 +-
 airflow/jobs/backfill_job.py                       |  13 +-
 airflow/jobs/base_job.py                           |   2 +-
 airflow/jobs/local_task_job.py                     |  10 +-
 airflow/jobs/scheduler_job.py                      |  25 +-
 airflow/kubernetes/kube_client.py                  |   7 +-
 airflow/kubernetes/kube_config.py                  |   4 +-
 airflow/kubernetes/pod.py                          |   7 +-
 airflow/kubernetes/pod_generator.py                |   9 +-
 airflow/kubernetes/pod_generator_deprecated.py     |   2 +-
 airflow/kubernetes/pod_launcher.py                 |   4 +-
 airflow/kubernetes/pod_runtime_info_env.py         |   2 +-
 airflow/kubernetes/refresh_config.py               |   6 +-
 airflow/kubernetes/volume.py                       |   2 +-
 airflow/kubernetes/volume_mount.py                 |   2 +-
 airflow/lineage/__init__.py                        |   4 +-
 airflow/lineage/backend.py                         |   2 +-
 airflow/lineage/entities.py                        |   5 +-
 airflow/logging_config.py                          |   2 +-
 airflow/migrations/env.py                          |   3 +-
 .../versions/03bc53e68815_add_sm_dag_index.py      |   4 +-
 .../versions/05f30312d566_merge_heads.py           |   4 +-
 .../0a2a5b66e19d_add_task_reschedule_table.py      |  10 +-
 .../0e2a74e0fc9f_add_time_zone_awareness.py        |   4 +-
 ...dfa7_add_dag_id_state_index_on_dag_run_table.py |   4 +-
 .../versions/13eb55f81627_for_compatibility.py     |   4 +-
 .../versions/1507a7289a2f_create_is_encrypted.py   |   4 +-
 ...cfc09e3_add_is_encrypted_column_to_variable_.py |   4 +-
 .../migrations/versions/1b38cef5b76e_add_dagrun.py |   4 +-
 .../versions/211e584da130_add_ti_state_index.py    |   4 +-
 ...30d7c24_add_executor_config_to_task_instance.py |   4 +-
 .../versions/2e541a1dcfed_task_duration.py         |   4 +-
 .../versions/2e82aab8ef20_rename_user_table.py     |   4 +-
 ...338e90f54d61_more_logging_into_task_isntance.py |   4 +-
 ...7a1ff4_add_kubernetes_resource_checkpointing.py |   4 +-
 .../versions/40e67319e3a9_dagrun_config.py         |   4 +-
 .../versions/41f5f12752f8_add_superuser_field.py   |   4 +-
 .../versions/4446e08588_dagrun_start_end.py        |   4 +-
 ...236f1_add_fractional_seconds_to_mysql_tables.py |   8 +-
 .../versions/502898887f84_adding_extra_to_log.py   |   4 +-
 ...0_fix_mssql_exec_date_rendered_task_instance.py |   8 +-
 .../versions/52d714495f0_job_id_indices.py         |   4 +-
 .../561833c1c74b_add_password_column_to_user.py    |   4 +-
 ...73d9401f_add_description_field_to_connection.py |   2 +-
 ...7aae_fix_description_field_in_connection_to_.py |   8 +-
 .../64de9cddf6c9_add_task_fails_journal_table.py   |   4 +-
 .../849da589634d_prefix_dag_permissions.py         |  30 +-
 ...15af_add_rendered_task_instance_fields_table.py |   6 +-
 .../856955da8476_fix_sqlite_foreign_key.py         |   2 +-
 .../8646922c8a04_change_default_pool_slots_to_1.py |   4 +-
 ...0d1215c0_add_kubernetes_scheduler_uniqueness.py |   4 +-
 ...1e647c8_task_reschedule_fk_on_cascade_delete.py |   4 +-
 .../versions/947454bf1dff_add_ti_job_id_index.py   |   4 +-
 .../versions/952da73b5eff_add_dag_code_table.py    |   2 +-
 .../versions/9635ae0956e7_index_faskfail.py        |   4 +-
 ...606e2_add_scheduling_decision_to_dagrun_and_.py |   4 +-
 ...67d16b_add_pool_slots_field_to_task_instance.py |   4 +-
 .../versions/b0125267960b_merge_heads.py           |   4 +-
 ...cfc896_add_a_column_to_track_the_encryption_.py |   4 +-
 ...13e_add_notification_sent_column_to_sla_miss.py |   4 +-
 ...3e6c56_make_xcom_value_column_a_large_binary.py |   4 +-
 .../bf00311e1990_add_index_to_taskinstance.py      |   4 +-
 .../versions/c8ffec048a3b_add_fields_to_dag.py     |   4 +-
 ...623dc7_add_max_tries_column_to_task_instance.py |   8 +-
 .../versions/cf5dc11e79ad_drop_user_and_chart.py   |   4 +-
 .../d2ae31099d61_increase_text_size_for_mysql.py   |   8 +-
 .../d38e04c12aa2_add_serialized_dag_table.py       |  12 +-
 .../versions/dd25f486b8ea_add_idx_log_dag.py       |   4 +-
 .../dd4ecb8fbee3_add_schedule_interval_to_dag.py   |   4 +-
 .../e38be357a868_update_schema_for_smart_sensor.py |  10 +-
 .../versions/e3a246e0dc1_current_schema.py         |   4 +-
 ...ac86c_change_field_in_dagcode_to_mediumtext_.py |   8 +-
 .../f23433877c24_fix_mysql_not_null_constraint.py  |   4 +-
 .../versions/f2ca10b85618_add_dag_stats_table.py   |   4 +-
 airflow/models/__init__.py                         |   2 +-
 airflow/models/baseoperator.py                     |  55 +-
 airflow/models/connection.py                       |  16 +-
 airflow/models/crypto.py                           |   4 +-
 airflow/models/dag.py                              |   2 +-
 airflow/models/dagbag.py                           |  10 +-
 airflow/models/dagrun.py                           |   2 +-
 airflow/models/errors.py                           |   2 +-
 airflow/models/pool.py                             |   2 +-
 airflow/models/serialized_dag.py                   |   7 +-
 airflow/models/skipmixin.py                        |   2 +-
 airflow/models/taskinstance.py                     |  39 +-
 airflow/models/variable.py                         |   6 +-
 airflow/models/xcom_arg.py                         |   2 +-
 airflow/mypy/plugin/decorators.py                  |   8 +-
 airflow/operators/bash_operator.py                 |   1 -
 airflow/operators/branch_operator.py               |   1 -
 airflow/operators/dagrun_operator.py               |   1 -
 airflow/operators/docker_operator.py               |   1 -
 airflow/operators/druid_check_operator.py          |   1 -
 airflow/operators/dummy_operator.py                |   1 -
 airflow/operators/email.py                         |   6 +-
 airflow/operators/email_operator.py                |   1 -
 airflow/operators/gcs_to_s3.py                     |   1 -
 airflow/operators/hive_operator.py                 |   1 -
 airflow/operators/hive_stats_operator.py           |   1 -
 airflow/operators/hive_to_druid.py                 |   1 -
 airflow/operators/hive_to_mysql.py                 |   1 -
 airflow/operators/hive_to_samba_operator.py        |   1 -
 airflow/operators/http_operator.py                 |   1 -
 airflow/operators/jdbc_operator.py                 |   1 -
 airflow/operators/latest_only_operator.py          |   1 -
 airflow/operators/mssql_operator.py                |   1 -
 airflow/operators/mysql_operator.py                |   1 -
 airflow/operators/oracle_operator.py               |   1 -
 airflow/operators/papermill_operator.py            |   1 -
 airflow/operators/pig_operator.py                  |   1 -
 airflow/operators/postgres_operator.py             |   1 -
 airflow/operators/presto_check_operator.py         |   3 +-
 airflow/operators/presto_to_mysql.py               |   1 -
 airflow/operators/python.py                        |   4 +-
 airflow/operators/python_operator.py               |   1 -
 airflow/operators/s3_file_transform_operator.py    |   1 -
 airflow/operators/slack_operator.py                |   1 -
 airflow/operators/sqlite_operator.py               |   1 -
 airflow/operators/subdag_operator.py               |   1 -
 airflow/plugins_manager.py                         |  31 +-
 airflow/providers/airbyte/hooks/airbyte.py         |   2 +-
 .../example_google_api_to_s3_transfer_advanced.py  |   3 +-
 airflow/providers/amazon/aws/hooks/athena.py       |   8 +-
 airflow/providers/amazon/aws/hooks/aws_dynamodb.py |   1 -
 airflow/providers/amazon/aws/hooks/base_aws.py     |   4 +-
 airflow/providers/amazon/aws/hooks/batch_client.py |  12 +-
 airflow/providers/amazon/aws/hooks/glue.py         |   2 +-
 airflow/providers/amazon/aws/hooks/glue_crawler.py |   4 +-
 airflow/providers/amazon/aws/hooks/redshift.py     |   2 +-
 airflow/providers/amazon/aws/hooks/s3.py           |   4 +-
 airflow/providers/amazon/aws/hooks/sagemaker.py    |  10 +-
 airflow/providers/amazon/aws/hooks/ses.py          |   2 +-
 .../amazon/aws/log/cloudwatch_task_handler.py      |   4 +-
 .../providers/amazon/aws/log/s3_task_handler.py    |  10 +-
 airflow/providers/amazon/aws/operators/athena.py   |   4 +-
 airflow/providers/amazon/aws/operators/batch.py    |   6 +-
 airflow/providers/amazon/aws/operators/datasync.py |   1 -
 airflow/providers/amazon/aws/operators/ecs.py      |   7 +-
 airflow/providers/amazon/aws/operators/glue.py     |   2 +-
 .../amazon/aws/operators/s3_file_transform.py      |   2 +-
 .../amazon/aws/operators/sagemaker_base.py         |   4 +-
 .../providers/amazon/aws/sensors/sagemaker_base.py |   2 +-
 .../amazon/aws/transfers/dynamodb_to_s3.py         |   4 +-
 .../providers/amazon/aws/transfers/exasol_to_s3.py |   2 +-
 .../providers/amazon/aws/transfers/gcs_to_s3.py    |   2 +-
 .../amazon/aws/transfers/hive_to_dynamodb.py       |   2 +-
 .../providers/amazon/aws/transfers/mongo_to_s3.py  |   1 -
 .../amazon/aws/transfers/redshift_to_s3.py         |   2 +-
 airflow/providers/apache/beam/hooks/beam.py        |   4 +-
 airflow/providers/apache/beam/operators/beam.py    |  15 +-
 .../providers/apache/cassandra/hooks/cassandra.py  |   2 +-
 .../apache/druid/transfers/hive_to_druid.py        |   2 +-
 airflow/providers/apache/hdfs/hooks/hdfs.py        |   2 +-
 airflow/providers/apache/hdfs/hooks/webhdfs.py     |   2 +-
 airflow/providers/apache/hdfs/sensors/hdfs.py      |   2 +-
 airflow/providers/apache/hive/hooks/hive.py        |  10 +-
 airflow/providers/apache/hive/operators/hive.py    |   1 -
 .../apache/hive/transfers/mssql_to_hive.py         |   3 +-
 .../apache/hive/transfers/mysql_to_hive.py         |   2 +-
 .../providers/apache/hive/transfers/s3_to_hive.py  |   4 +-
 .../providers/apache/kylin/operators/kylin_cube.py |   1 -
 airflow/providers/apache/livy/hooks/livy.py        |   3 -
 airflow/providers/apache/livy/operators/livy.py    |   1 -
 airflow/providers/apache/pinot/hooks/pinot.py      |   4 +-
 airflow/providers/apache/spark/hooks/spark_jdbc.py |   2 -
 .../apache/spark/hooks/spark_jdbc_script.py        |   2 -
 airflow/providers/apache/spark/hooks/spark_sql.py  |   3 +-
 .../providers/apache/spark/hooks/spark_submit.py   |   3 -
 .../providers/apache/spark/operators/spark_jdbc.py |   2 -
 .../providers/apache/spark/operators/spark_sql.py  |   1 -
 .../apache/spark/operators/spark_submit.py         |   2 -
 airflow/providers/apache/sqoop/hooks/sqoop.py      |   3 -
 airflow/providers/apache/sqoop/operators/sqoop.py  |   4 +-
 airflow/providers/asana/hooks/asana.py             |  16 +-
 .../backcompat/backwards_compat_converters.py      |   2 +-
 .../cncf/kubernetes/operators/kubernetes_pod.py    |   4 +-
 .../cncf/kubernetes/utils/pod_launcher.py          |   2 +-
 airflow/providers/databricks/hooks/databricks.py   |   2 +-
 .../providers/databricks/operators/databricks.py   |   2 -
 airflow/providers/datadog/hooks/datadog.py         |   1 -
 .../example_dags/example_docker_copy_data.py       |   2 +-
 airflow/providers/docker/operators/docker.py       |   6 +-
 .../providers/elasticsearch/log/es_task_handler.py |  14 +-
 airflow/providers/ftp/hooks/ftp.py                 |   4 +-
 .../cloud/example_dags/example_automl_tables.py    |  28 +-
 .../cloud/example_dags/example_bigquery_dts.py     |   8 +-
 .../google/cloud/example_dags/example_bigtable.py  |   4 +-
 .../cloud/example_dags/example_cloud_build.py      |   4 +-
 .../google/cloud/example_dags/example_cloud_sql.py |  44 +-
 .../google/cloud/example_dags/example_tasks.py     |   2 +-
 .../google/cloud/example_dags/example_vision.py    |  10 +-
 airflow/providers/google/cloud/hooks/automl.py     |   2 +-
 airflow/providers/google/cloud/hooks/bigquery.py   |  39 +-
 airflow/providers/google/cloud/hooks/bigtable.py   |   1 -
 .../providers/google/cloud/hooks/cloud_build.py    |   9 +-
 airflow/providers/google/cloud/hooks/cloud_sql.py  |  37 +-
 .../cloud/hooks/cloud_storage_transfer_service.py  |  35 +-
 airflow/providers/google/cloud/hooks/compute.py    |  21 +-
 .../providers/google/cloud/hooks/compute_ssh.py    |  28 +-
 .../providers/google/cloud/hooks/datacatalog.py    |   4 +-
 airflow/providers/google/cloud/hooks/dataflow.py   |  19 +-
 airflow/providers/google/cloud/hooks/datafusion.py |  17 +-
 airflow/providers/google/cloud/hooks/dataproc.py   |   6 +-
 airflow/providers/google/cloud/hooks/datastore.py  |  46 +-
 airflow/providers/google/cloud/hooks/dlp.py        |   1 -
 airflow/providers/google/cloud/hooks/functions.py  |  14 +-
 airflow/providers/google/cloud/hooks/gcs.py        |  14 +-
 airflow/providers/google/cloud/hooks/gdm.py        |  12 +-
 .../google/cloud/hooks/kubernetes_engine.py        |   2 +-
 .../providers/google/cloud/hooks/life_sciences.py  |   9 +-
 airflow/providers/google/cloud/hooks/mlengine.py   |  27 +-
 airflow/providers/google/cloud/hooks/pubsub.py     |  19 +-
 .../providers/google/cloud/hooks/secret_manager.py |   2 +-
 airflow/providers/google/cloud/hooks/spanner.py    |   4 +-
 .../providers/google/cloud/hooks/text_to_speech.py |   6 +-
 airflow/providers/google/cloud/hooks/vision.py     |  17 +-
 airflow/providers/google/cloud/hooks/workflows.py  |   4 -
 .../providers/google/cloud/log/gcs_task_handler.py |  11 +-
 .../google/cloud/log/stackdriver_task_handler.py   |   6 +-
 airflow/providers/google/cloud/operators/automl.py |   6 +-
 .../providers/google/cloud/operators/bigquery.py   |   8 +-
 .../providers/google/cloud/operators/bigtable.py   |   2 +-
 .../operators/cloud_storage_transfer_service.py    |   4 +-
 .../google/cloud/operators/datacatalog.py          |   8 +-
 .../providers/google/cloud/operators/dataflow.py   |  36 +-
 .../providers/google/cloud/operators/datafusion.py |   2 +-
 .../providers/google/cloud/operators/dataproc.py   |  13 +-
 .../providers/google/cloud/operators/datastore.py  |   2 +-
 airflow/providers/google/cloud/operators/dlp.py    |   2 +-
 .../providers/google/cloud/operators/mlengine.py   |   6 +-
 airflow/providers/google/cloud/operators/pubsub.py |   5 +-
 .../google/cloud/operators/stackdriver.py          |   2 -
 airflow/providers/google/cloud/operators/tasks.py  |   2 +-
 .../providers/google/cloud/operators/workflows.py  |   4 -
 .../google/cloud/secrets/secret_manager.py         |   2 +-
 airflow/providers/google/cloud/sensors/dataproc.py |   2 +-
 airflow/providers/google/cloud/sensors/gcs.py      |   4 +-
 airflow/providers/google/cloud/sensors/pubsub.py   |   2 +-
 .../cloud/transfers/azure_fileshare_to_gcs.py      |   1 -
 .../google/cloud/transfers/bigquery_to_bigquery.py |   2 +-
 .../google/cloud/transfers/bigquery_to_gcs.py      |   2 +-
 .../google/cloud/transfers/bigquery_to_mssql.py    |   2 +-
 .../google/cloud/transfers/bigquery_to_mysql.py    |   2 +-
 .../google/cloud/transfers/cassandra_to_gcs.py     |   8 +-
 .../google/cloud/transfers/gcs_to_bigquery.py      |   2 -
 .../providers/google/cloud/transfers/gcs_to_gcs.py |   2 +-
 .../google/cloud/transfers/gcs_to_local.py         |   4 +-
 .../google/cloud/transfers/gcs_to_sftp.py          |   1 -
 .../google/cloud/transfers/oracle_to_gcs.py        |   2 +-
 .../providers/google/cloud/transfers/s3_to_gcs.py  |   2 -
 .../providers/google/cloud/transfers/sql_to_gcs.py |   7 +-
 .../google/cloud/utils/credentials_provider.py     |  13 +-
 .../google/cloud/utils/field_sanitizer.py          |   2 +-
 .../google/cloud/utils/mlengine_operator_utils.py  |   4 +-
 .../cloud/utils/mlengine_prediction_summary.py     |   7 +-
 .../google/common/auth_backend/google_openid.py    |   2 +-
 .../providers/google/common/hooks/base_google.py   |  18 +-
 .../providers/google/firebase/hooks/firestore.py   |   8 +-
 .../google/marketing_platform/hooks/analytics.py   |  14 +-
 .../marketing_platform/hooks/campaign_manager.py   |  24 +-
 .../marketing_platform/hooks/display_video.py      |  44 +-
 .../google/marketing_platform/hooks/search_ads.py  |  16 +-
 .../operators/campaign_manager.py                  |   2 +-
 airflow/providers/google/suite/hooks/drive.py      |  12 +-
 airflow/providers/google/suite/hooks/sheets.py     |  18 +-
 airflow/providers/grpc/hooks/grpc.py               |   4 +-
 .../hashicorp/_internal_client/vault_client.py     |   6 +-
 airflow/providers/hashicorp/hooks/vault.py         |   4 +-
 airflow/providers/hashicorp/secrets/vault.py       |   5 +-
 airflow/providers/http/hooks/http.py               |   2 +-
 .../jenkins/operators/jenkins_job_trigger.py       |   4 +-
 airflow/providers/jira/sensors/jira.py             |   4 +-
 .../providers/microsoft/azure/hooks/azure_batch.py |   2 +-
 .../microsoft/azure/hooks/azure_data_factory.py    |   2 +-
 airflow/providers/microsoft/azure/hooks/wasb.py    |   2 +-
 .../microsoft/azure/log/wasb_task_handler.py       |   2 +-
 .../microsoft/azure/operators/azure_batch.py       |   3 +-
 .../azure/operators/azure_container_instances.py   |   7 +-
 .../azure/transfers/oracle_to_azure_data_lake.py   |   1 -
 airflow/providers/microsoft/mssql/hooks/mssql.py   |  16 +-
 airflow/providers/microsoft/winrm/hooks/winrm.py   |   3 +-
 .../providers/microsoft/winrm/operators/winrm.py   |   3 +-
 airflow/providers/mysql/hooks/mysql.py             |  14 +-
 .../providers/mysql/transfers/vertica_to_mysql.py  |   2 +-
 airflow/providers/odbc/hooks/odbc.py               |   1 -
 .../providers/opsgenie/operators/opsgenie_alert.py |   1 -
 airflow/providers/oracle/hooks/oracle.py           |   5 +-
 .../providers/oracle/transfers/oracle_to_oracle.py |   1 -
 airflow/providers/pagerduty/hooks/pagerduty.py     |   1 -
 airflow/providers/postgres/hooks/postgres.py       |   1 -
 airflow/providers/presto/hooks/presto.py           |  10 +-
 airflow/providers/qubole/hooks/qubole.py           |   5 +-
 airflow/providers/qubole/hooks/qubole_check.py     |   2 +-
 airflow/providers/qubole/operators/qubole_check.py |   4 +-
 airflow/providers/qubole/sensors/qubole.py         |   6 +-
 airflow/providers/salesforce/hooks/tableau.py      |   1 -
 .../operators/tableau_refresh_workbook.py          |   1 -
 .../salesforce/sensors/tableau_job_status.py       |   1 -
 .../segment/operators/segment_track_event.py       |   1 -
 airflow/providers/sendgrid/utils/emailer.py        |   2 +-
 .../providers/singularity/operators/singularity.py |   2 +-
 airflow/providers/slack/hooks/slack.py             |   4 +-
 airflow/providers/slack/hooks/slack_webhook.py     |   1 -
 airflow/providers/slack/operators/slack.py         |   4 +-
 airflow/providers/slack/operators/slack_webhook.py |   1 -
 airflow/providers/snowflake/hooks/snowflake.py     |  12 +-
 .../snowflake/transfers/snowflake_to_slack.py      |   2 +-
 airflow/providers/ssh/hooks/ssh.py                 |   6 +-
 airflow/providers/trino/hooks/trino.py             |  10 +-
 airflow/providers/vertica/hooks/vertica.py         |   2 +-
 .../yandex/operators/yandexcloud_dataproc.py       |   7 -
 airflow/providers/zendesk/hooks/zendesk.py         |   1 -
 airflow/providers_manager.py                       |  20 +-
 airflow/secrets/base_secrets.py                    |   2 +-
 airflow/secrets/environment_variables.py           |   1 -
 airflow/secrets/metastore.py                       |   2 -
 airflow/security/kerberos.py                       |   2 +-
 airflow/security/utils.py                          |  10 +-
 airflow/sensors/base.py                            |   2 +-
 airflow/sensors/base_sensor_operator.py            |   1 -
 airflow/sensors/bash.py                            |   2 +-
 airflow/sensors/date_time_sensor.py                |   1 -
 airflow/sensors/external_task.py                   |   4 +-
 airflow/sensors/external_task_sensor.py            |   1 -
 airflow/sensors/hdfs_sensor.py                     |   1 -
 airflow/sensors/hive_partition_sensor.py           |   1 -
 airflow/sensors/http_sensor.py                     |   1 -
 airflow/sensors/metastore_partition_sensor.py      |   1 -
 airflow/sensors/named_hive_partition_sensor.py     |   1 -
 airflow/sensors/s3_key_sensor.py                   |   1 -
 airflow/sensors/s3_prefix_sensor.py                |   1 -
 airflow/sensors/smart_sensor.py                    |  18 +-
 airflow/sensors/sql_sensor.py                      |   1 -
 airflow/sensors/time_delta_sensor.py               |   1 -
 airflow/sensors/web_hdfs_sensor.py                 |   1 -
 airflow/sentry.py                                  |   2 +-
 airflow/serialization/json_schema.py               |   3 +-
 airflow/serialization/serialized_objects.py        |  28 +-
 airflow/settings.py                                |  25 +-
 airflow/stats.py                                   |  12 +-
 airflow/task/task_runner/__init__.py               |   2 +-
 airflow/task/task_runner/base_task_runner.py       |   3 +-
 airflow/task/task_runner/standard_task_runner.py   |   8 +-
 airflow/ti_deps/deps/not_previously_skipped_dep.py |   2 +-
 airflow/ti_deps/deps/task_not_running_dep.py       |   2 +-
 airflow/ti_deps/deps/trigger_rule_dep.py           |   2 +-
 airflow/typing_compat.py                           |   9 +-
 airflow/utils/cli.py                               |  10 +-
 airflow/utils/cli_action_loggers.py                |   6 +-
 airflow/utils/dates.py                             |   3 +-
 airflow/utils/db.py                                |  19 +-
 airflow/utils/decorators.py                        |   2 +-
 airflow/utils/edgemodifier.py                      |   2 +-
 airflow/utils/event_scheduler.py                   |   2 +-
 airflow/utils/file.py                              |   8 +-
 airflow/utils/helpers.py                           |   6 +-
 airflow/utils/json.py                              |   2 +-
 airflow/utils/log/cloudwatch_task_handler.py       |   1 -
 airflow/utils/log/es_task_handler.py               |   1 -
 airflow/utils/log/file_processor_handler.py        |   2 +-
 airflow/utils/log/file_task_handler.py             |  10 +-
 airflow/utils/log/gcs_task_handler.py              |   1 -
 airflow/utils/log/json_formatter.py                |   1 -
 airflow/utils/log/logging_mixin.py                 |   9 +-
 airflow/utils/log/s3_task_handler.py               |   1 -
 airflow/utils/log/secrets_masker.py                |   4 +-
 airflow/utils/log/stackdriver_task_handler.py      |   1 -
 .../log/task_handler_with_custom_formatter.py      |   2 +-
 airflow/utils/log/wasb_task_handler.py             |   1 -
 airflow/utils/orm_event_handlers.py                |   4 +-
 airflow/utils/platform.py                          |   2 +-
 airflow/utils/process_utils.py                     |   4 +-
 airflow/utils/serve_logs.py                        |   4 +-
 airflow/utils/session.py                           |   2 +-
 airflow/utils/sqlalchemy.py                        |   1 -
 airflow/utils/task_group.py                        |   2 +-
 airflow/utils/timeout.py                           |   4 +-
 airflow/utils/types.py                             |   2 +-
 airflow/utils/weekday.py                           |   1 -
 airflow/www/api/experimental/endpoints.py          |   2 +-
 airflow/www/app.py                                 |   4 +-
 airflow/www/auth.py                                |   2 +-
 airflow/www/decorators.py                          |   4 +-
 airflow/www/extensions/init_jinja_globals.py       |   2 +-
 airflow/www/extensions/init_manifest_files.py      |   4 +-
 airflow/www/forms.py                               |   2 +-
 airflow/www/gunicorn_config.py                     |   6 +-
 airflow/www/security.py                            |   8 +-
 airflow/www/utils.py                               |  57 +-
 airflow/www/views.py                               | 198 +++----
 breeze                                             |   8 +-
 breeze-complete                                    |   5 +-
 chart/tests/helm_template_generator.py             |   4 +-
 chart/tests/test_basic_helm_chart.py               |   2 +-
 dev/import_all_classes.py                          |   2 +-
 dev/provider_packages/prepare_provider_packages.py |  14 +-
 dev/retag_docker_images.py                         |   2 +-
 dev/send_email.py                                  |   4 +-
 docs/build_docs.py                                 |  24 +-
 docs/conf.py                                       |   7 +-
 docs/exts/__init__.py                              |   1 -
 docs/exts/airflow_intersphinx.py                   |   4 +-
 docs/exts/docroles.py                              |   8 +-
 docs/exts/docs_build/__init__.py                   |   1 -
 docs/exts/docs_build/dev_index_generator.py        |   2 +-
 docs/exts/docs_build/docs_builder.py               |   8 +-
 docs/exts/docs_build/errors.py                     |   2 +-
 docs/exts/docs_build/fetch_inventories.py          |   8 +-
 docs/exts/docs_build/lint_checks.py                |   4 +-
 docs/exts/docs_build/spelling_checks.py            |   2 +-
 docs/exts/exampleinclude.py                        |  16 +-
 docs/exts/operators_and_hooks_ref.py               |   5 +-
 docs/exts/providers_packages_ref.py                |   2 +-
 docs/exts/removemarktransform.py                   |   5 +-
 docs/exts/substitution_extensions.py               |   2 +-
 docs/publish_docs.py                               |   3 -
 docs/spelling_wordlist.txt                         |   2 -
 kubernetes_tests/test_kubernetes_pod_operator.py   |  18 +-
 .../test_kubernetes_pod_operator_backcompat.py     |   8 +-
 pylintrc                                           | 597 --------------------
 pylintrc-tests                                     | 606 ---------------------
 scripts/ci/docker-compose/local.yml                |   2 -
 scripts/ci/libraries/_all_libs.sh                  |   2 -
 scripts/ci/libraries/_build_images.sh              |   2 +-
 scripts/ci/libraries/_local_mounts.sh              |   2 -
 scripts/ci/libraries/_pylint.sh                    |  37 --
 .../pre_commit_check_extras_have_providers.py      |   2 +-
 .../pre_commit_check_setup_extra_packages_ref.py   |   2 +-
 scripts/ci/pre_commit/pre_commit_insert_extras.py  |   2 +-
 scripts/ci/pre_commit/pre_commit_pylint.sh         |  26 -
 scripts/ci/pre_commit/pre_commit_yaml_to_cfg.py    |   2 +-
 scripts/ci/pylint_todo.txt                         |   5 -
 scripts/ci/static_checks/pylint.sh                 |  56 --
 scripts/ci/static_checks/refresh_pylint_todo.sh    |  33 --
 scripts/in_container/_in_container_utils.sh        |  57 --
 scripts/in_container/refresh_pylint_todo.sh        |  21 -
 scripts/in_container/run_pylint.sh                 |  49 --
 .../in_container/update_quarantined_test_status.py |   4 +-
 scripts/tools/generate-integrations-json.py        |   3 -
 scripts/tools/list-integrations.py                 |   2 +-
 setup.py                                           |  23 +-
 tests/api/auth/backend/test_basic_auth.py          |   2 +-
 tests/api/common/experimental/test_mark_tasks.py   |   2 +-
 tests/api_connexion/endpoints/test_dag_endpoint.py |   4 +-
 .../endpoints/test_dag_run_endpoint.py             |   2 +-
 .../endpoints/test_extra_link_endpoint.py          |   4 +-
 .../endpoints/test_import_error_endpoint.py        |   2 +-
 tests/api_connexion/endpoints/test_log_endpoint.py |   6 +-
 .../api_connexion/endpoints/test_task_endpoint.py  |   2 +-
 .../endpoints/test_task_instance_endpoint.py       |  10 +-
 .../api_connexion/endpoints/test_xcom_endpoint.py  |   2 +-
 tests/api_connexion/schemas/test_error_schema.py   |   2 +-
 tests/api_connexion/test_basic_auth.py             |   2 +-
 tests/build_provider_packages_dependencies.py      |   6 +-
 tests/cli/commands/test_celery_command.py          |   2 +-
 tests/cli/commands/test_info_command.py            |   2 +-
 tests/cli/commands/test_role_command.py            |   2 +-
 tests/cli/commands/test_user_command.py            |   2 +-
 tests/cli/commands/test_webserver_command.py       |  59 +-
 tests/conftest.py                                  |   6 +-
 tests/core/test_core.py                            |   8 +-
 tests/core/test_logging_config.py                  |   7 +-
 tests/core/test_settings.py                        |   8 +-
 tests/dag_processing/test_manager.py               |   2 +-
 tests/dag_processing/test_processor.py             |   2 +-
 tests/dags/subdir1/test_ignore_this.py             |   2 +-
 tests/dags/test_mark_success.py                    |   4 +-
 tests/dags/test_on_failure_callback.py             |   2 +-
 tests/dags/test_subdag.py                          |   2 +-
 tests/decorators/test_python.py                    |  55 +-
 tests/decorators/test_python_virtualenv.py         |  28 +-
 tests/executors/test_celery_executor.py            |  10 +-
 tests/executors/test_kubernetes_executor.py        |  15 +-
 tests/executors/test_local_executor.py             |  10 +-
 tests/hooks/test_subprocess.py                     |   2 +-
 tests/jobs/test_backfill_job.py                    |   1 -
 tests/jobs/test_local_task_job.py                  |  10 +-
 tests/jobs/test_scheduler_job.py                   |  76 +--
 tests/models/test_baseoperator.py                  |  14 +-
 tests/models/test_connection.py                    |   5 +-
 tests/models/test_dag.py                           |  13 +-
 tests/models/test_dagbag.py                        |  10 +-
 tests/models/test_dagparam.py                      |   3 -
 tests/models/test_pool.py                          |  16 +-
 tests/models/test_taskinstance.py                  |  10 +-
 tests/models/test_xcom.py                          |   4 +-
 tests/operators/test_email.py                      |   2 +-
 tests/operators/test_python.py                     |  28 +-
 tests/operators/test_sql.py                        |   1 -
 tests/operators/test_weekday.py                    |   2 +-
 tests/plugins/test_plugins_manager.py              |   8 +-
 tests/providers/amazon/aws/hooks/conftest.py       |   1 -
 tests/providers/amazon/aws/hooks/test_base_aws.py  |   8 +-
 .../amazon/aws/hooks/test_batch_client.py          |   1 -
 .../amazon/aws/hooks/test_batch_waiters.py         |   2 -
 tests/providers/amazon/aws/hooks/test_s3.py        |  18 +-
 .../amazon/aws/log/test_s3_task_handler.py         |  20 +-
 .../providers/amazon/aws/operators/test_athena.py  |   4 -
 tests/providers/amazon/aws/operators/test_batch.py |   1 -
 tests/providers/amazon/aws/operators/test_ecs.py   |  14 +-
 .../amazon/aws/operators/test_glacier_system.py    |   2 +-
 .../aws/operators/test_sagemaker_training.py       |   1 -
 tests/providers/amazon/aws/sensors/test_s3_key.py  |   2 +-
 .../amazon/aws/transfers/test_dynamodb_to_s3.py    |   2 +-
 tests/providers/apache/beam/hooks/test_beam.py     |  12 +-
 .../apache/cassandra/hooks/test_cassandra.py       |   2 +-
 tests/providers/apache/druid/hooks/test_druid.py   |   2 +-
 tests/providers/apache/hive/hooks/test_hive.py     |   2 +-
 .../apache/hive/transfers/test_mssql_to_hive.py    |   8 +-
 tests/providers/apache/livy/hooks/test_livy.py     |  18 +-
 tests/providers/apache/pinot/hooks/test_pinot.py   |   2 +-
 tests/providers/asana/hooks/test_asana.py          |  38 +-
 .../kubernetes/operators/test_kubernetes_pod.py    |   1 -
 tests/providers/docker/hooks/test_docker.py        |   8 +-
 tests/providers/docker/operators/test_docker.py    |   2 +-
 .../elasticsearch/hooks/test_elasticsearch.py      |   2 +-
 .../elasticsearch/log/elasticmock/__init__.py      |   2 +-
 .../log/elasticmock/fake_elasticsearch.py          |   6 +-
 .../elasticsearch/log/test_es_task_handler.py      |   6 +-
 .../_internal_client/test_secret_manager_client.py |   3 +-
 tests/providers/google/cloud/hooks/test_automl.py  |   2 +-
 .../providers/google/cloud/hooks/test_bigquery.py  |   5 +-
 .../google/cloud/hooks/test_cloud_build.py         |  10 +-
 .../google/cloud/hooks/test_cloud_memorystore.py   |  26 +-
 .../providers/google/cloud/hooks/test_cloud_sql.py |  63 +--
 .../hooks/test_cloud_storage_transfer_service.py   |  19 +-
 tests/providers/google/cloud/hooks/test_compute.py |   1 -
 .../google/cloud/hooks/test_datacatalog.py         |  84 +--
 .../providers/google/cloud/hooks/test_dataflow.py  |  34 +-
 .../google/cloud/hooks/test_datafusion.py          |   2 -
 .../providers/google/cloud/hooks/test_dataprep.py  |  18 +-
 .../providers/google/cloud/hooks/test_dataproc.py  |   2 +-
 .../providers/google/cloud/hooks/test_datastore.py |  20 +-
 tests/providers/google/cloud/hooks/test_dlp.py     |  30 +-
 .../providers/google/cloud/hooks/test_functions.py |   8 +-
 tests/providers/google/cloud/hooks/test_gcs.py     |  18 +-
 tests/providers/google/cloud/hooks/test_gdm.py     |   2 +-
 tests/providers/google/cloud/hooks/test_kms.py     |   2 +-
 .../google/cloud/hooks/test_kubernetes_engine.py   |   4 +-
 .../google/cloud/hooks/test_life_sciences.py       |  11 +-
 tests/providers/google/cloud/hooks/test_pubsub.py  |   6 +-
 .../google/cloud/hooks/test_secret_manager.py      |   1 -
 .../google/cloud/hooks/test_stackdriver.py         |  10 +-
 .../providers/google/cloud/hooks/test_workflows.py |   2 +-
 .../google/cloud/operators/test_cloud_sql.py       |   1 -
 .../test_cloud_storage_transfer_service.py         |  30 +-
 .../google/cloud/operators/test_compute.py         |   7 +-
 .../google/cloud/operators/test_dataprep_system.py |   2 +-
 .../google/cloud/operators/test_dataproc.py        |   4 +-
 tests/providers/google/cloud/operators/test_dlp.py |   2 +-
 .../google/cloud/operators/test_dlp_system.py      |   2 +-
 .../google/cloud/operators/test_functions.py       |   2 +-
 .../cloud/operators/test_kubernetes_engine.py      |   7 -
 .../google/cloud/operators/test_spanner.py         |  14 +-
 .../google/cloud/operators/test_speech_to_text.py  |   6 +-
 .../test_azure_fileshare_to_gcs_system.py          |   2 +-
 .../google/cloud/transfers/test_gcs_to_sftp.py     |   1 -
 .../google/cloud/transfers/test_mssql_to_gcs.py    |   2 +-
 .../google/cloud/transfers/test_mysql_to_gcs.py    |   6 +-
 .../google/cloud/transfers/test_oracle_to_gcs.py   |   4 +-
 .../google/cloud/transfers/test_postgres_to_gcs.py |   2 +-
 .../google/cloud/transfers/test_presto_to_gcs.py   |   4 +-
 .../google/cloud/transfers/test_sftp_to_gcs.py     |   1 -
 .../google/cloud/transfers/test_trino_to_gcs.py    |   4 +-
 .../google/cloud/utils/gcp_authenticator.py        |   2 +-
 .../common/auth_backend/test_google_openid.py      |   2 +-
 .../google/common/hooks/test_base_google.py        |   4 +-
 tests/providers/grpc/hooks/test_grpc.py            |   6 +-
 .../_internal_client/test_vault_client.py          |   3 +-
 tests/providers/hashicorp/hooks/test_vault.py      |   1 -
 tests/providers/imap/hooks/test_imap.py            |   2 +-
 tests/providers/jdbc/hooks/test_jdbc.py            |   2 +-
 tests/providers/jira/hooks/test_jira.py            |   2 +-
 tests/providers/jira/sensors/test_jira.py          |   2 +-
 .../azure/hooks/test_azure_data_factory.py         |   1 -
 .../microsoft/azure/operators/test_azure_batch.py  |   2 +-
 tests/providers/mysql/operators/test_mysql.py      |   2 +-
 tests/providers/odbc/hooks/test_odbc.py            |   1 -
 tests/providers/oracle/hooks/test_oracle.py        |   1 -
 tests/providers/postgres/hooks/test_postgres.py    |   2 +-
 tests/providers/qubole/hooks/test_qubole.py        |   1 -
 .../qubole/operators/test_qubole_check.py          |   1 -
 tests/providers/sftp/operators/test_sftp.py        |   6 +-
 tests/providers/snowflake/hooks/test_snowflake.py  |   4 +-
 tests/providers/sqlite/hooks/test_sqlite.py        |   2 +-
 tests/providers/ssh/hooks/test_ssh.py              |   6 +-
 tests/providers/ssh/operators/test_ssh.py          |   8 +-
 tests/providers/tableau/hooks/test_tableau.py      |   2 +-
 tests/security/test_kerberos.py                    |   8 +-
 tests/sensors/test_base.py                         |   2 -
 tests/sensors/test_external_task_sensor.py         |   4 +-
 tests/sensors/test_smart_sensor_operator.py        |   3 -
 tests/serialization/test_dag_serialization.py      |   4 +-
 .../task/task_runner/test_standard_task_runner.py  |   2 +-
 tests/test_utils/asserts.py                        |   2 +-
 tests/test_utils/fake_datetime.py                  |   2 +-
 tests/test_utils/hdfs_utils.py                     |   2 +-
 tests/test_utils/perf/dags/elastic_dag.py          |   1 -
 tests/test_utils/perf/perf_kit/memory.py           |   2 +-
 tests/test_utils/perf/perf_kit/sqlalchemy.py       |  36 +-
 .../perf/scheduler_dag_execution_timing.py         |  10 +-
 tests/test_utils/remote_user_api_auth_backend.py   |   2 +-
 tests/test_utils/reset_warning_registry.py         |   6 +-
 tests/ti_deps/deps/fake_models.py                  |   8 +-
 .../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 +-
 .../ti_deps/deps/test_pool_slots_available_dep.py  |   5 +-
 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/utils/log/test_log_reader.py                 |   2 +-
 tests/utils/test_edgemodifier.py                   |  10 +-
 tests/utils/test_module_loading.py                 |   2 +-
 tests/utils/test_retries.py                        |   4 +-
 tests/utils/test_task_group.py                     |   2 -
 tests/www/api/experimental/test_endpoints.py       |   2 +-
 tests/www/test_security.py                         |   6 +-
 tests/www/views/conftest.py                        |   4 +-
 tests/www/views/test_views_acl.py                  |  22 +-
 tests/www/views/test_views_extra_links.py          |   4 +-
 tests/www/views/test_views_log.py                  |   4 +-
 tests/www/views/test_views_rendered.py             |   2 +-
 tests/www/views/test_views_tasks.py                |   2 +-
 896 files changed, 1909 insertions(+), 4509 deletions(-)
 delete mode 100644 pylintrc
 delete mode 100644 pylintrc-tests
 delete mode 100644 scripts/ci/libraries/_pylint.sh
 delete mode 100755 scripts/ci/pre_commit/pre_commit_pylint.sh
 delete mode 100644 scripts/ci/pylint_todo.txt
 delete mode 100755 scripts/ci/static_checks/pylint.sh
 delete mode 100755 scripts/ci/static_checks/refresh_pylint_todo.sh
 delete mode 100755 scripts/in_container/refresh_pylint_todo.sh
 delete mode 100755 scripts/in_container/run_pylint.sh