./codecov.yml .bash_completion .coveragerc .dockerignore .editorconfig .flake8 .gitattributes .github/CODEOWNERS .github/SECURITY.rst .github/actions/checks-action .github/actions/codecov-action .github/actions/configure-aws-credentials .github/actions/get-workflow-origin .github/actions/github-push-action .github/actions/label-when-approved-action .gitmodules .mailmap .rat-excludes BREEZE.rst CI.rst COMMITTERS.rst CONTRIBUTING.rst CONTRIBUTORS_QUICK_START.rst Dockerfile Dockerfile.ci IMAGES.rst INSTALL ISSUE_TRIAGE_PROCESS.rst LICENSE LOCAL_VIRTUALENV.rst MANIFEST.in NOTICE PULL_REQUEST_WORKFLOW.rst STATIC_CODE_CHECKS.rst TESTING.rst airflow/__init__.py airflow/__main__.py airflow/_vendor/__init__.py airflow/_vendor/connexion/__init__.py airflow/_vendor/connexion/__main__.py airflow/_vendor/connexion/apis/__init__.py airflow/_vendor/connexion/apis/abstract.py airflow/_vendor/connexion/apis/aiohttp_api.py airflow/_vendor/connexion/apis/flask_api.py airflow/_vendor/connexion/apis/flask_utils.py airflow/_vendor/connexion/apps/__init__.py airflow/_vendor/connexion/apps/abstract.py airflow/_vendor/connexion/apps/aiohttp_app.py airflow/_vendor/connexion/apps/flask_app.py airflow/_vendor/connexion/cli.py airflow/_vendor/connexion/decorators/__init__.py airflow/_vendor/connexion/decorators/coroutine_wrappers.py airflow/_vendor/connexion/decorators/decorator.py airflow/_vendor/connexion/decorators/metrics.py airflow/_vendor/connexion/decorators/parameter.py airflow/_vendor/connexion/decorators/produces.py airflow/_vendor/connexion/decorators/response.py airflow/_vendor/connexion/decorators/security.py airflow/_vendor/connexion/decorators/uri_parsing.py airflow/_vendor/connexion/decorators/validation.py airflow/_vendor/connexion/exceptions.py airflow/_vendor/connexion/handlers.py airflow/_vendor/connexion/http_facts.py airflow/_vendor/connexion/json_schema.py airflow/_vendor/connexion/jsonifier.py airflow/_vendor/connexion/lifecycle.py airflow/_vendor/connexion/mock.py airflow/_vendor/connexion/operations/__init__.py airflow/_vendor/connexion/operations/abstract.py airflow/_vendor/connexion/operations/compat.py airflow/_vendor/connexion/operations/openapi.py airflow/_vendor/connexion/operations/secure.py airflow/_vendor/connexion/operations/swagger2.py airflow/_vendor/connexion/options.py airflow/_vendor/connexion/problem.py airflow/_vendor/connexion/resolver.py airflow/_vendor/connexion/setup.cfg airflow/_vendor/connexion/setup.py airflow/_vendor/connexion/spec.py airflow/_vendor/connexion/utils.py airflow/alembic.ini airflow/api/__init__.py airflow/api/auth/__init__.py airflow/api/auth/backend/__init__.py airflow/api/auth/backend/basic_auth.py airflow/api/auth/backend/default.py airflow/api/auth/backend/deny_all.py airflow/api/auth/backend/kerberos_auth.py airflow/api/client/__init__.py airflow/api/client/api_client.py airflow/api/client/json_client.py airflow/api/client/local_client.py airflow/api/common/__init__.py airflow/api/common/experimental/__init__.py airflow/api/common/experimental/delete_dag.py airflow/api/common/experimental/get_code.py airflow/api/common/experimental/get_dag_run_state.py airflow/api/common/experimental/get_dag_runs.py airflow/api/common/experimental/get_lineage.py airflow/api/common/experimental/get_task.py airflow/api/common/experimental/get_task_instance.py airflow/api/common/experimental/mark_tasks.py airflow/api/common/experimental/pool.py airflow/api/common/experimental/trigger_dag.py airflow/api_connexion/__init__.py airflow/api_connexion/endpoints/__init__.py airflow/api_connexion/endpoints/config_endpoint.py airflow/api_connexion/endpoints/connection_endpoint.py airflow/api_connexion/endpoints/dag_endpoint.py airflow/api_connexion/endpoints/dag_run_endpoint.py airflow/api_connexion/endpoints/dag_source_endpoint.py airflow/api_connexion/endpoints/event_log_endpoint.py airflow/api_connexion/endpoints/extra_link_endpoint.py airflow/api_connexion/endpoints/health_endpoint.py airflow/api_connexion/endpoints/import_error_endpoint.py airflow/api_connexion/endpoints/log_endpoint.py airflow/api_connexion/endpoints/plugin_endpoint.py airflow/api_connexion/endpoints/pool_endpoint.py airflow/api_connexion/endpoints/provider_endpoint.py airflow/api_connexion/endpoints/role_and_permission_endpoint.py airflow/api_connexion/endpoints/task_endpoint.py airflow/api_connexion/endpoints/task_instance_endpoint.py airflow/api_connexion/endpoints/user_endpoint.py airflow/api_connexion/endpoints/variable_endpoint.py airflow/api_connexion/endpoints/version_endpoint.py airflow/api_connexion/endpoints/xcom_endpoint.py airflow/api_connexion/exceptions.py airflow/api_connexion/parameters.py airflow/api_connexion/schemas/__init__.py airflow/api_connexion/schemas/common_schema.py airflow/api_connexion/schemas/config_schema.py airflow/api_connexion/schemas/connection_schema.py airflow/api_connexion/schemas/dag_run_schema.py airflow/api_connexion/schemas/dag_schema.py airflow/api_connexion/schemas/dag_source_schema.py airflow/api_connexion/schemas/enum_schemas.py airflow/api_connexion/schemas/error_schema.py airflow/api_connexion/schemas/event_log_schema.py airflow/api_connexion/schemas/health_schema.py airflow/api_connexion/schemas/log_schema.py airflow/api_connexion/schemas/plugin_schema.py airflow/api_connexion/schemas/pool_schema.py airflow/api_connexion/schemas/provider_schema.py airflow/api_connexion/schemas/role_and_permission_schema.py airflow/api_connexion/schemas/sla_miss_schema.py airflow/api_connexion/schemas/task_instance_schema.py airflow/api_connexion/schemas/task_schema.py airflow/api_connexion/schemas/user_schema.py airflow/api_connexion/schemas/variable_schema.py airflow/api_connexion/schemas/version_schema.py airflow/api_connexion/schemas/xcom_schema.py airflow/api_connexion/security.py airflow/cli/__init__.py airflow/cli/cli_parser.py airflow/cli/commands/__init__.py airflow/cli/commands/celery_command.py airflow/cli/commands/cheat_sheet_command.py airflow/cli/commands/config_command.py airflow/cli/commands/connection_command.py airflow/cli/commands/dag_command.py airflow/cli/commands/db_command.py airflow/cli/commands/info_command.py airflow/cli/commands/jobs_command.py airflow/cli/commands/kerberos_command.py airflow/cli/commands/kubernetes_command.py airflow/cli/commands/legacy_commands.py airflow/cli/commands/plugins_command.py airflow/cli/commands/pool_command.py airflow/cli/commands/provider_command.py airflow/cli/commands/role_command.py airflow/cli/commands/rotate_fernet_key_command.py airflow/cli/commands/scheduler_command.py airflow/cli/commands/standalone_command.py airflow/cli/commands/sync_perm_command.py airflow/cli/commands/task_command.py airflow/cli/commands/user_command.py airflow/cli/commands/variable_command.py airflow/cli/commands/version_command.py airflow/cli/commands/webserver_command.py airflow/cli/simple_table.py airflow/compat/__init__.py airflow/compat/functools.py airflow/config_templates/__init__.py airflow/config_templates/airflow_local_settings.py airflow/config_templates/config.yml.schema.json airflow/config_templates/default_airflow.cfg airflow/config_templates/default_celery.py airflow/config_templates/default_test.cfg airflow/config_templates/default_webserver_config.py airflow/configuration.py airflow/contrib/__init__.py airflow/contrib/hooks/__init__.py airflow/contrib/hooks/aws_athena_hook.py airflow/contrib/hooks/aws_datasync_hook.py airflow/contrib/hooks/aws_dynamodb_hook.py airflow/contrib/hooks/aws_firehose_hook.py airflow/contrib/hooks/aws_glue_catalog_hook.py airflow/contrib/hooks/aws_hook.py airflow/contrib/hooks/aws_lambda_hook.py airflow/contrib/hooks/aws_logs_hook.py airflow/contrib/hooks/aws_sns_hook.py airflow/contrib/hooks/aws_sqs_hook.py airflow/contrib/hooks/azure_container_instance_hook.py airflow/contrib/hooks/azure_container_registry_hook.py airflow/contrib/hooks/azure_container_volume_hook.py airflow/contrib/hooks/azure_cosmos_hook.py airflow/contrib/hooks/azure_data_lake_hook.py airflow/contrib/hooks/azure_fileshare_hook.py airflow/contrib/hooks/bigquery_hook.py airflow/contrib/hooks/cassandra_hook.py airflow/contrib/hooks/cloudant_hook.py airflow/contrib/hooks/databricks_hook.py airflow/contrib/hooks/datadog_hook.py airflow/contrib/hooks/datastore_hook.py airflow/contrib/hooks/dingding_hook.py airflow/contrib/hooks/discord_webhook_hook.py airflow/contrib/hooks/emr_hook.py airflow/contrib/hooks/fs_hook.py airflow/contrib/hooks/ftp_hook.py airflow/contrib/hooks/gcp_api_base_hook.py airflow/contrib/hooks/gcp_bigtable_hook.py airflow/contrib/hooks/gcp_cloud_build_hook.py airflow/contrib/hooks/gcp_compute_hook.py airflow/contrib/hooks/gcp_container_hook.py airflow/contrib/hooks/gcp_dataflow_hook.py airflow/contrib/hooks/gcp_dataproc_hook.py airflow/contrib/hooks/gcp_dlp_hook.py airflow/contrib/hooks/gcp_function_hook.py airflow/contrib/hooks/gcp_kms_hook.py airflow/contrib/hooks/gcp_mlengine_hook.py airflow/contrib/hooks/gcp_natural_language_hook.py airflow/contrib/hooks/gcp_pubsub_hook.py airflow/contrib/hooks/gcp_spanner_hook.py airflow/contrib/hooks/gcp_speech_to_text_hook.py airflow/contrib/hooks/gcp_sql_hook.py airflow/contrib/hooks/gcp_tasks_hook.py airflow/contrib/hooks/gcp_text_to_speech_hook.py airflow/contrib/hooks/gcp_transfer_hook.py airflow/contrib/hooks/gcp_translate_hook.py airflow/contrib/hooks/gcp_video_intelligence_hook.py airflow/contrib/hooks/gcp_vision_hook.py airflow/contrib/hooks/gcs_hook.py airflow/contrib/hooks/gdrive_hook.py airflow/contrib/hooks/grpc_hook.py airflow/contrib/hooks/imap_hook.py airflow/contrib/hooks/jenkins_hook.py airflow/contrib/hooks/jira_hook.py airflow/contrib/hooks/mongo_hook.py airflow/contrib/hooks/openfaas_hook.py airflow/contrib/hooks/opsgenie_alert_hook.py airflow/contrib/hooks/pagerduty_hook.py airflow/contrib/hooks/pinot_hook.py airflow/contrib/hooks/qubole_check_hook.py airflow/contrib/hooks/qubole_hook.py airflow/contrib/hooks/redis_hook.py airflow/contrib/hooks/redshift_hook.py airflow/contrib/hooks/sagemaker_hook.py airflow/contrib/hooks/salesforce_hook.py airflow/contrib/hooks/segment_hook.py airflow/contrib/hooks/sftp_hook.py airflow/contrib/hooks/slack_webhook_hook.py airflow/contrib/hooks/snowflake_hook.py airflow/contrib/hooks/spark_jdbc_hook.py airflow/contrib/hooks/spark_sql_hook.py airflow/contrib/hooks/spark_submit_hook.py airflow/contrib/hooks/sqoop_hook.py airflow/contrib/hooks/ssh_hook.py airflow/contrib/hooks/vertica_hook.py airflow/contrib/hooks/wasb_hook.py airflow/contrib/hooks/winrm_hook.py airflow/contrib/operators/__init__.py airflow/contrib/operators/adls_list_operator.py airflow/contrib/operators/adls_to_gcs.py airflow/contrib/operators/aws_athena_operator.py airflow/contrib/operators/aws_sqs_publish_operator.py airflow/contrib/operators/awsbatch_operator.py airflow/contrib/operators/azure_container_instances_operator.py airflow/contrib/operators/azure_cosmos_operator.py airflow/contrib/operators/bigquery_check_operator.py airflow/contrib/operators/bigquery_get_data.py airflow/contrib/operators/bigquery_operator.py airflow/contrib/operators/bigquery_table_delete_operator.py airflow/contrib/operators/bigquery_to_bigquery.py airflow/contrib/operators/bigquery_to_gcs.py airflow/contrib/operators/bigquery_to_mysql_operator.py airflow/contrib/operators/cassandra_to_gcs.py airflow/contrib/operators/databricks_operator.py airflow/contrib/operators/dataflow_operator.py airflow/contrib/operators/dataproc_operator.py airflow/contrib/operators/datastore_export_operator.py airflow/contrib/operators/datastore_import_operator.py airflow/contrib/operators/dingding_operator.py airflow/contrib/operators/discord_webhook_operator.py airflow/contrib/operators/docker_swarm_operator.py airflow/contrib/operators/druid_operator.py airflow/contrib/operators/dynamodb_to_s3.py airflow/contrib/operators/ecs_operator.py airflow/contrib/operators/emr_add_steps_operator.py airflow/contrib/operators/emr_create_job_flow_operator.py airflow/contrib/operators/emr_terminate_job_flow_operator.py airflow/contrib/operators/file_to_gcs.py airflow/contrib/operators/file_to_wasb.py airflow/contrib/operators/gcp_bigtable_operator.py airflow/contrib/operators/gcp_cloud_build_operator.py airflow/contrib/operators/gcp_compute_operator.py airflow/contrib/operators/gcp_container_operator.py airflow/contrib/operators/gcp_dlp_operator.py airflow/contrib/operators/gcp_function_operator.py airflow/contrib/operators/gcp_natural_language_operator.py airflow/contrib/operators/gcp_spanner_operator.py airflow/contrib/operators/gcp_speech_to_text_operator.py airflow/contrib/operators/gcp_sql_operator.py airflow/contrib/operators/gcp_tasks_operator.py airflow/contrib/operators/gcp_text_to_speech_operator.py airflow/contrib/operators/gcp_transfer_operator.py airflow/contrib/operators/gcp_translate_operator.py airflow/contrib/operators/gcp_translate_speech_operator.py airflow/contrib/operators/gcp_video_intelligence_operator.py airflow/contrib/operators/gcp_vision_operator.py airflow/contrib/operators/gcs_acl_operator.py airflow/contrib/operators/gcs_delete_operator.py airflow/contrib/operators/gcs_download_operator.py airflow/contrib/operators/gcs_list_operator.py airflow/contrib/operators/gcs_operator.py airflow/contrib/operators/gcs_to_bq.py airflow/contrib/operators/gcs_to_gcs.py airflow/contrib/operators/gcs_to_gcs_transfer_operator.py airflow/contrib/operators/gcs_to_gdrive_operator.py airflow/contrib/operators/gcs_to_s3.py airflow/contrib/operators/grpc_operator.py airflow/contrib/operators/hive_to_dynamodb.py airflow/contrib/operators/imap_attachment_to_s3_operator.py airflow/contrib/operators/jenkins_job_trigger_operator.py airflow/contrib/operators/jira_operator.py airflow/contrib/operators/kubernetes_pod_operator.py airflow/contrib/operators/mlengine_operator.py airflow/contrib/operators/mongo_to_s3.py airflow/contrib/operators/mssql_to_gcs.py airflow/contrib/operators/mysql_to_gcs.py airflow/contrib/operators/opsgenie_alert_operator.py airflow/contrib/operators/oracle_to_azure_data_lake_transfer.py airflow/contrib/operators/oracle_to_oracle_transfer.py airflow/contrib/operators/postgres_to_gcs_operator.py airflow/contrib/operators/pubsub_operator.py airflow/contrib/operators/qubole_check_operator.py airflow/contrib/operators/qubole_operator.py airflow/contrib/operators/redis_publish_operator.py airflow/contrib/operators/s3_copy_object_operator.py airflow/contrib/operators/s3_delete_objects_operator.py airflow/contrib/operators/s3_list_operator.py airflow/contrib/operators/s3_to_gcs_operator.py airflow/contrib/operators/s3_to_gcs_transfer_operator.py airflow/contrib/operators/s3_to_sftp_operator.py airflow/contrib/operators/sagemaker_base_operator.py airflow/contrib/operators/sagemaker_endpoint_config_operator.py airflow/contrib/operators/sagemaker_endpoint_operator.py airflow/contrib/operators/sagemaker_model_operator.py airflow/contrib/operators/sagemaker_training_operator.py airflow/contrib/operators/sagemaker_transform_operator.py airflow/contrib/operators/sagemaker_tuning_operator.py airflow/contrib/operators/segment_track_event_operator.py airflow/contrib/operators/sftp_operator.py airflow/contrib/operators/sftp_to_s3_operator.py airflow/contrib/operators/slack_webhook_operator.py airflow/contrib/operators/snowflake_operator.py airflow/contrib/operators/sns_publish_operator.py airflow/contrib/operators/spark_jdbc_operator.py airflow/contrib/operators/spark_sql_operator.py airflow/contrib/operators/spark_submit_operator.py airflow/contrib/operators/sql_to_gcs.py airflow/contrib/operators/sqoop_operator.py airflow/contrib/operators/ssh_operator.py airflow/contrib/operators/vertica_operator.py airflow/contrib/operators/vertica_to_hive.py airflow/contrib/operators/vertica_to_mysql.py airflow/contrib/operators/wasb_delete_blob_operator.py airflow/contrib/operators/winrm_operator.py airflow/contrib/secrets/__init__.py airflow/contrib/secrets/aws_secrets_manager.py airflow/contrib/secrets/aws_systems_manager.py airflow/contrib/secrets/azure_key_vault.py airflow/contrib/secrets/gcp_secrets_manager.py airflow/contrib/secrets/hashicorp_vault.py airflow/contrib/sensors/__init__.py airflow/contrib/sensors/aws_athena_sensor.py airflow/contrib/sensors/aws_glue_catalog_partition_sensor.py airflow/contrib/sensors/aws_redshift_cluster_sensor.py airflow/contrib/sensors/aws_sqs_sensor.py airflow/contrib/sensors/azure_cosmos_sensor.py airflow/contrib/sensors/bash_sensor.py airflow/contrib/sensors/bigquery_sensor.py airflow/contrib/sensors/cassandra_record_sensor.py airflow/contrib/sensors/cassandra_table_sensor.py airflow/contrib/sensors/celery_queue_sensor.py airflow/contrib/sensors/datadog_sensor.py airflow/contrib/sensors/emr_base_sensor.py airflow/contrib/sensors/emr_job_flow_sensor.py airflow/contrib/sensors/emr_step_sensor.py airflow/contrib/sensors/file_sensor.py airflow/contrib/sensors/ftp_sensor.py airflow/contrib/sensors/gcp_transfer_sensor.py airflow/contrib/sensors/gcs_sensor.py airflow/contrib/sensors/hdfs_sensor.py airflow/contrib/sensors/imap_attachment_sensor.py airflow/contrib/sensors/jira_sensor.py airflow/contrib/sensors/mongo_sensor.py airflow/contrib/sensors/pubsub_sensor.py airflow/contrib/sensors/python_sensor.py airflow/contrib/sensors/qubole_sensor.py airflow/contrib/sensors/redis_key_sensor.py airflow/contrib/sensors/redis_pub_sub_sensor.py airflow/contrib/sensors/sagemaker_base_sensor.py airflow/contrib/sensors/sagemaker_endpoint_sensor.py airflow/contrib/sensors/sagemaker_training_sensor.py airflow/contrib/sensors/sagemaker_transform_sensor.py airflow/contrib/sensors/sagemaker_tuning_sensor.py airflow/contrib/sensors/sftp_sensor.py airflow/contrib/sensors/wasb_sensor.py airflow/contrib/sensors/weekday_sensor.py airflow/contrib/task_runner/__init__.py airflow/contrib/task_runner/cgroup_task_runner.py airflow/contrib/utils/__init__.py airflow/contrib/utils/gcp_field_sanitizer.py airflow/contrib/utils/gcp_field_validator.py airflow/contrib/utils/log/__init__.py airflow/contrib/utils/log/task_handler_with_custom_formatter.py airflow/contrib/utils/mlengine_operator_utils.py airflow/contrib/utils/mlengine_prediction_summary.py airflow/contrib/utils/sendgrid.py airflow/contrib/utils/weekday.py airflow/customized_form_field_behaviours.schema.json airflow/decorators/__init__.py airflow/decorators/base.py airflow/decorators/python.py airflow/decorators/python_virtualenv.py airflow/decorators/task_group.py airflow/deprecated_schemas/provider-2.0.0.yaml.schema.json airflow/example_dags/__init__.py airflow/example_dags/example_bash_operator.py airflow/example_dags/example_branch_datetime_operator.py airflow/example_dags/example_branch_day_of_week_operator.py airflow/example_dags/example_branch_labels.py airflow/example_dags/example_branch_operator.py airflow/example_dags/example_branch_python_dop_operator_3.py airflow/example_dags/example_complex.py airflow/example_dags/example_dag_decorator.py airflow/example_dags/example_external_task_marker_dag.py airflow/example_dags/example_kubernetes_executor.py airflow/example_dags/example_kubernetes_executor_config.py airflow/example_dags/example_latest_only.py airflow/example_dags/example_latest_only_with_trigger.py airflow/example_dags/example_nested_branch_dag.py airflow/example_dags/example_passing_params_via_test_command.py airflow/example_dags/example_python_operator.py airflow/example_dags/example_short_circuit_operator.py airflow/example_dags/example_skip_dag.py airflow/example_dags/example_subdag_operator.py airflow/example_dags/example_task_group.py airflow/example_dags/example_task_group_decorator.py airflow/example_dags/example_trigger_controller_dag.py airflow/example_dags/example_trigger_target_dag.py airflow/example_dags/example_xcom.py airflow/example_dags/example_xcomargs.py airflow/example_dags/libs/__init__.py airflow/example_dags/libs/helper.py airflow/example_dags/subdags/__init__.py airflow/example_dags/subdags/subdag.py airflow/example_dags/test_utils.py airflow/example_dags/tutorial.py airflow/example_dags/tutorial_etl_dag.py airflow/example_dags/tutorial_taskflow_api_etl.py airflow/example_dags/tutorial_taskflow_api_etl_virtualenv.py airflow/exceptions.py airflow/executors/__init__.py airflow/executors/base_executor.py airflow/executors/celery_executor.py airflow/executors/celery_kubernetes_executor.py airflow/executors/dask_executor.py airflow/executors/debug_executor.py airflow/executors/executor_constants.py airflow/executors/executor_loader.py airflow/executors/kubernetes_executor.py airflow/executors/local_executor.py airflow/executors/sequential_executor.py airflow/hooks/S3_hook.py airflow/hooks/__init__.py airflow/hooks/base.py airflow/hooks/base_hook.py airflow/hooks/dbapi.py airflow/hooks/dbapi_hook.py airflow/hooks/docker_hook.py airflow/hooks/druid_hook.py airflow/hooks/filesystem.py airflow/hooks/hdfs_hook.py airflow/hooks/hive_hooks.py airflow/hooks/http_hook.py airflow/hooks/jdbc_hook.py airflow/hooks/mssql_hook.py airflow/hooks/mysql_hook.py airflow/hooks/oracle_hook.py airflow/hooks/pig_hook.py airflow/hooks/postgres_hook.py airflow/hooks/presto_hook.py airflow/hooks/samba_hook.py airflow/hooks/slack_hook.py airflow/hooks/sqlite_hook.py airflow/hooks/subprocess.py airflow/hooks/webhdfs_hook.py airflow/hooks/zendesk_hook.py airflow/jobs/__init__.py airflow/jobs/backfill_job.py airflow/jobs/base_job.py airflow/jobs/local_task_job.py airflow/jobs/scheduler_job.py airflow/kubernetes/__init__.py airflow/kubernetes/k8s_model.py airflow/kubernetes/kube_client.py airflow/kubernetes/kube_config.py airflow/kubernetes/kubernetes_helper_functions.py airflow/kubernetes/pod.py airflow/kubernetes/pod_generator.py airflow/kubernetes/pod_generator_deprecated.py airflow/kubernetes/pod_launcher.py airflow/kubernetes/pod_launcher_deprecated.py airflow/kubernetes/pod_runtime_info_env.py airflow/kubernetes/refresh_config.py airflow/kubernetes/secret.py airflow/kubernetes/volume.py airflow/kubernetes/volume_mount.py airflow/lineage/__init__.py airflow/lineage/backend.py airflow/lineage/entities.py airflow/logging_config.py airflow/macros/__init__.py airflow/macros/hive.py airflow/migrations/__init__.py airflow/migrations/env.py airflow/migrations/script.py.mako airflow/migrations/versions/004c1210f153_increase_queue_name_size_limit.py airflow/migrations/versions/03afc6b6f902_increase_length_of_fab_ab_view_menu_.py airflow/migrations/versions/03bc53e68815_add_sm_dag_index.py airflow/migrations/versions/05f30312d566_merge_heads.py airflow/migrations/versions/0a2a5b66e19d_add_task_reschedule_table.py airflow/migrations/versions/0e2a74e0fc9f_add_time_zone_awareness.py airflow/migrations/versions/127d2bf2dfa7_add_dag_id_state_index_on_dag_run_table.py airflow/migrations/versions/13eb55f81627_for_compatibility.py airflow/migrations/versions/1507a7289a2f_create_is_encrypted.py airflow/migrations/versions/1968acfc09e3_add_is_encrypted_column_to_variable_.py airflow/migrations/versions/1b38cef5b76e_add_dagrun.py airflow/migrations/versions/211e584da130_add_ti_state_index.py airflow/migrations/versions/27c6a30d7c24_add_executor_config_to_task_instance.py airflow/migrations/versions/2c6edca13270_resource_based_permissions.py airflow/migrations/versions/2e42bb497a22_rename_last_scheduler_run_column.py airflow/migrations/versions/2e541a1dcfed_task_duration.py airflow/migrations/versions/2e82aab8ef20_rename_user_table.py airflow/migrations/versions/338e90f54d61_more_logging_into_task_isntance.py airflow/migrations/versions/33ae817a1ff4_add_kubernetes_resource_checkpointing.py airflow/migrations/versions/364159666cbd_add_job_id_to_dagrun_table.py airflow/migrations/versions/3c20cacc0044_add_dagrun_run_type.py airflow/migrations/versions/40e67319e3a9_dagrun_config.py airflow/migrations/versions/41f5f12752f8_add_superuser_field.py airflow/migrations/versions/4446e08588_dagrun_start_end.py airflow/migrations/versions/449b4072c2da_increase_size_of_connection_extra_field_.py airflow/migrations/versions/45ba3f1493b9_add_k8s_yaml_to_rendered_templates.py airflow/migrations/versions/4addfa1236f1_add_fractional_seconds_to_mysql_tables.py airflow/migrations/versions/502898887f84_adding_extra_to_log.py airflow/migrations/versions/52d53670a240_fix_mssql_exec_date_rendered_task_instance.py airflow/migrations/versions/52d714495f0_job_id_indices.py airflow/migrations/versions/561833c1c74b_add_password_column_to_user.py airflow/migrations/versions/5e7d17757c7a_add_pid_field_to_taskinstance.py airflow/migrations/versions/61ec73d9401f_add_description_field_to_connection.py airflow/migrations/versions/64a7d6477aae_fix_description_field_in_connection_to_.py airflow/migrations/versions/64de9cddf6c9_add_task_fails_journal_table.py airflow/migrations/versions/6e96a59344a4_make_taskinstance_pool_not_nullable.py airflow/migrations/versions/74effc47d867_change_datetime_to_datetime2_6_on_mssql_.py airflow/migrations/versions/7939bcff74ba_add_dagtags_table.py airflow/migrations/versions/82b7c48c147f_remove_can_read_permission_on_config_.py airflow/migrations/versions/83f031fd9f1c_improve_mssql_compatibility.py airflow/migrations/versions/849da589634d_prefix_dag_permissions.py airflow/migrations/versions/8504051e801b_xcom_dag_task_indices.py airflow/migrations/versions/852ae6c715af_add_rendered_task_instance_fields_table.py airflow/migrations/versions/856955da8476_fix_sqlite_foreign_key.py airflow/migrations/versions/8646922c8a04_change_default_pool_slots_to_1.py airflow/migrations/versions/86770d1215c0_add_kubernetes_scheduler_uniqueness.py airflow/migrations/versions/8d48763f6d53_add_unique_constraint_to_conn_id.py airflow/migrations/versions/8f966b9c467a_set_conn_type_as_non_nullable.py airflow/migrations/versions/90d1635d7b86_increase_pool_name_size_in_taskinstance.py airflow/migrations/versions/92c57b58940d_add_fab_tables.py airflow/migrations/versions/939bb1e647c8_task_reschedule_fk_on_cascade_delete.py airflow/migrations/versions/947454bf1dff_add_ti_job_id_index.py airflow/migrations/versions/952da73b5eff_add_dag_code_table.py airflow/migrations/versions/9635ae0956e7_index_faskfail.py airflow/migrations/versions/98271e7606e2_add_scheduling_decision_to_dagrun_and_.py airflow/migrations/versions/__init__.py airflow/migrations/versions/a13f7613ad25_resource_based_permissions_for_default_.py airflow/migrations/versions/a4c2fd67d16b_add_pool_slots_field_to_task_instance.py airflow/migrations/versions/a56c9515abdc_remove_dag_stat_table.py airflow/migrations/versions/a66efa278eea_add_precision_to_execution_date_in_mysql.py airflow/migrations/versions/b0125267960b_merge_heads.py airflow/migrations/versions/b247b1e3d1ed_add_queued_by_job_id_to_ti.py airflow/migrations/versions/b25a55525161_increase_length_of_pool_name.py airflow/migrations/versions/b3b105409875_add_root_dag_id_to_dag.py airflow/migrations/versions/bba5a7cfc896_add_a_column_to_track_the_encryption_.py airflow/migrations/versions/bbc73705a13e_add_notification_sent_column_to_sla_miss.py airflow/migrations/versions/bbf4a7ad0465_remove_id_column_from_xcom.py airflow/migrations/versions/bdaa763e6c56_make_xcom_value_column_a_large_binary.py airflow/migrations/versions/bef4f3d11e8b_drop_kuberesourceversion_and_.py airflow/migrations/versions/bf00311e1990_add_index_to_taskinstance.py airflow/migrations/versions/c8ffec048a3b_add_fields_to_dag.py airflow/migrations/versions/cc1e65623dc7_add_max_tries_column_to_task_instance.py airflow/migrations/versions/cf5dc11e79ad_drop_user_and_chart.py airflow/migrations/versions/d2ae31099d61_increase_text_size_for_mysql.py airflow/migrations/versions/d38e04c12aa2_add_serialized_dag_table.py airflow/migrations/versions/da3f683c3a5a_add_dag_hash_column_to_serialized_dag_.py airflow/migrations/versions/dd25f486b8ea_add_idx_log_dag.py airflow/migrations/versions/dd4ecb8fbee3_add_schedule_interval_to_dag.py airflow/migrations/versions/e165e7455d70_add_description_field_to_variable.py airflow/migrations/versions/e1a11ece99cc_add_external_executor_id_to_ti.py airflow/migrations/versions/e38be357a868_update_schema_for_smart_sensor.py airflow/migrations/versions/e3a246e0dc1_current_schema.py airflow/migrations/versions/e9304a3141f0_make_xcom_pkey_columns_non_nullable.py airflow/migrations/versions/e959f08ac86c_change_field_in_dagcode_to_mediumtext_.py airflow/migrations/versions/f23433877c24_fix_mysql_not_null_constraint.py airflow/migrations/versions/f2ca10b85618_add_dag_stats_table.py airflow/migrations/versions/fe461863935f_increase_length_for_connection_password.py airflow/models/__init__.py airflow/models/base.py airflow/models/baseoperator.py airflow/models/connection.py airflow/models/crypto.py airflow/models/dag.py airflow/models/dagbag.py airflow/models/dagcode.py airflow/models/dagparam.py airflow/models/dagpickle.py airflow/models/dagrun.py airflow/models/errors.py airflow/models/log.py airflow/models/pool.py airflow/models/renderedtifields.py airflow/models/sensorinstance.py airflow/models/serialized_dag.py airflow/models/skipmixin.py airflow/models/slamiss.py airflow/models/taskfail.py airflow/models/taskinstance.py airflow/models/taskmixin.py airflow/models/taskreschedule.py airflow/models/variable.py airflow/models/xcom.py airflow/models/xcom_arg.py airflow/mypy/__init__.py airflow/mypy/plugin/__init__.py airflow/mypy/plugin/decorators.py airflow/operators/__init__.py airflow/operators/bash.py airflow/operators/bash_operator.py airflow/operators/branch.py airflow/operators/branch_operator.py airflow/operators/check_operator.py airflow/operators/dagrun_operator.py airflow/operators/datetime.py airflow/operators/docker_operator.py airflow/operators/druid_check_operator.py airflow/operators/dummy.py airflow/operators/dummy_operator.py airflow/operators/email.py airflow/operators/email_operator.py airflow/operators/gcs_to_s3.py airflow/operators/generic_transfer.py airflow/operators/google_api_to_s3_transfer.py airflow/operators/hive_operator.py airflow/operators/hive_stats_operator.py airflow/operators/hive_to_druid.py airflow/operators/hive_to_mysql.py airflow/operators/hive_to_samba_operator.py airflow/operators/http_operator.py airflow/operators/jdbc_operator.py airflow/operators/latest_only.py airflow/operators/latest_only_operator.py airflow/operators/mssql_operator.py airflow/operators/mssql_to_hive.py airflow/operators/mysql_operator.py airflow/operators/mysql_to_hive.py airflow/operators/oracle_operator.py airflow/operators/papermill_operator.py airflow/operators/pig_operator.py airflow/operators/postgres_operator.py airflow/operators/presto_check_operator.py airflow/operators/presto_to_mysql.py airflow/operators/python.py airflow/operators/python_operator.py airflow/operators/redshift_to_s3_operator.py airflow/operators/s3_file_transform_operator.py airflow/operators/s3_to_hive_operator.py airflow/operators/s3_to_redshift_operator.py airflow/operators/slack_operator.py airflow/operators/sql.py airflow/operators/sql_branch_operator.py airflow/operators/sqlite_operator.py airflow/operators/subdag.py airflow/operators/subdag_operator.py airflow/operators/trigger_dagrun.py airflow/operators/weekday.py airflow/plugins_manager.py airflow/provider.yaml.schema.json airflow/provider_info.schema.json airflow/providers/airbyte/CHANGELOG.rst airflow/providers/airbyte/__init__.py airflow/providers/airbyte/example_dags/__init__.py airflow/providers/airbyte/example_dags/example_airbyte_trigger_job.py airflow/providers/airbyte/hooks/__init__.py airflow/providers/airbyte/hooks/airbyte.py airflow/providers/airbyte/operators/__init__.py airflow/providers/airbyte/operators/airbyte.py airflow/providers/airbyte/sensors/__init__.py airflow/providers/airbyte/sensors/airbyte.py airflow/providers/amazon/CHANGELOG.rst airflow/providers/amazon/__init__.py airflow/providers/amazon/aws/__init__.py airflow/providers/amazon/aws/example_dags/__init__.py airflow/providers/amazon/aws/example_dags/example_datasync_1.py airflow/providers/amazon/aws/example_dags/example_datasync_2.py airflow/providers/amazon/aws/example_dags/example_ecs_fargate.py airflow/providers/amazon/aws/example_dags/example_emr_job_flow_automatic_steps.py airflow/providers/amazon/aws/example_dags/example_emr_job_flow_manual_steps.py airflow/providers/amazon/aws/example_dags/example_glacier_to_gcs.py airflow/providers/amazon/aws/example_dags/example_google_api_to_s3_transfer_advanced.py airflow/providers/amazon/aws/example_dags/example_google_api_to_s3_transfer_basic.py airflow/providers/amazon/aws/example_dags/example_imap_attachment_to_s3.py airflow/providers/amazon/aws/example_dags/example_s3_bucket.py airflow/providers/amazon/aws/example_dags/example_s3_bucket_tagging.py airflow/providers/amazon/aws/example_dags/example_s3_to_redshift.py airflow/providers/amazon/aws/exceptions.py airflow/providers/amazon/aws/hooks/__init__.py airflow/providers/amazon/aws/hooks/athena.py airflow/providers/amazon/aws/hooks/aws_dynamodb.py airflow/providers/amazon/aws/hooks/base_aws.py airflow/providers/amazon/aws/hooks/batch_client.py airflow/providers/amazon/aws/hooks/batch_waiters.json airflow/providers/amazon/aws/hooks/batch_waiters.py airflow/providers/amazon/aws/hooks/cloud_formation.py airflow/providers/amazon/aws/hooks/datasync.py airflow/providers/amazon/aws/hooks/dynamodb.py airflow/providers/amazon/aws/hooks/ec2.py airflow/providers/amazon/aws/hooks/elasticache_replication_group.py airflow/providers/amazon/aws/hooks/emr.py airflow/providers/amazon/aws/hooks/glacier.py airflow/providers/amazon/aws/hooks/glue.py airflow/providers/amazon/aws/hooks/glue_catalog.py airflow/providers/amazon/aws/hooks/glue_crawler.py airflow/providers/amazon/aws/hooks/kinesis.py airflow/providers/amazon/aws/hooks/lambda_function.py airflow/providers/amazon/aws/hooks/logs.py airflow/providers/amazon/aws/hooks/redshift.py airflow/providers/amazon/aws/hooks/s3.py airflow/providers/amazon/aws/hooks/sagemaker.py airflow/providers/amazon/aws/hooks/secrets_manager.py airflow/providers/amazon/aws/hooks/ses.py airflow/providers/amazon/aws/hooks/sns.py airflow/providers/amazon/aws/hooks/sqs.py airflow/providers/amazon/aws/hooks/step_function.py airflow/providers/amazon/aws/log/__init__.py airflow/providers/amazon/aws/log/cloudwatch_task_handler.py airflow/providers/amazon/aws/log/s3_task_handler.py airflow/providers/amazon/aws/operators/__init__.py airflow/providers/amazon/aws/operators/athena.py airflow/providers/amazon/aws/operators/batch.py airflow/providers/amazon/aws/operators/cloud_formation.py airflow/providers/amazon/aws/operators/datasync.py airflow/providers/amazon/aws/operators/ec2_start_instance.py airflow/providers/amazon/aws/operators/ec2_stop_instance.py airflow/providers/amazon/aws/operators/ecs.py airflow/providers/amazon/aws/operators/emr_add_steps.py airflow/providers/amazon/aws/operators/emr_create_job_flow.py airflow/providers/amazon/aws/operators/emr_modify_cluster.py airflow/providers/amazon/aws/operators/emr_terminate_job_flow.py airflow/providers/amazon/aws/operators/glacier.py airflow/providers/amazon/aws/operators/glue.py airflow/providers/amazon/aws/operators/glue_crawler.py airflow/providers/amazon/aws/operators/s3_bucket.py airflow/providers/amazon/aws/operators/s3_bucket_tagging.py airflow/providers/amazon/aws/operators/s3_copy_object.py airflow/providers/amazon/aws/operators/s3_delete_objects.py airflow/providers/amazon/aws/operators/s3_file_transform.py airflow/providers/amazon/aws/operators/s3_list.py airflow/providers/amazon/aws/operators/sagemaker_base.py airflow/providers/amazon/aws/operators/sagemaker_endpoint.py airflow/providers/amazon/aws/operators/sagemaker_endpoint_config.py airflow/providers/amazon/aws/operators/sagemaker_model.py airflow/providers/amazon/aws/operators/sagemaker_processing.py airflow/providers/amazon/aws/operators/sagemaker_training.py airflow/providers/amazon/aws/operators/sagemaker_transform.py airflow/providers/amazon/aws/operators/sagemaker_tuning.py airflow/providers/amazon/aws/operators/sns.py airflow/providers/amazon/aws/operators/sqs.py airflow/providers/amazon/aws/operators/step_function_get_execution_output.py airflow/providers/amazon/aws/operators/step_function_start_execution.py airflow/providers/amazon/aws/secrets/__init__.py airflow/providers/amazon/aws/secrets/secrets_manager.py airflow/providers/amazon/aws/secrets/systems_manager.py airflow/providers/amazon/aws/sensors/__init__.py airflow/providers/amazon/aws/sensors/athena.py airflow/providers/amazon/aws/sensors/cloud_formation.py airflow/providers/amazon/aws/sensors/ec2_instance_state.py airflow/providers/amazon/aws/sensors/emr_base.py airflow/providers/amazon/aws/sensors/emr_job_flow.py airflow/providers/amazon/aws/sensors/emr_step.py airflow/providers/amazon/aws/sensors/glacier.py airflow/providers/amazon/aws/sensors/glue.py airflow/providers/amazon/aws/sensors/glue_catalog_partition.py airflow/providers/amazon/aws/sensors/glue_crawler.py airflow/providers/amazon/aws/sensors/redshift.py airflow/providers/amazon/aws/sensors/s3_key.py airflow/providers/amazon/aws/sensors/s3_keys_unchanged.py airflow/providers/amazon/aws/sensors/s3_prefix.py airflow/providers/amazon/aws/sensors/sagemaker_base.py airflow/providers/amazon/aws/sensors/sagemaker_endpoint.py airflow/providers/amazon/aws/sensors/sagemaker_training.py airflow/providers/amazon/aws/sensors/sagemaker_transform.py airflow/providers/amazon/aws/sensors/sagemaker_tuning.py airflow/providers/amazon/aws/sensors/sqs.py airflow/providers/amazon/aws/sensors/step_function_execution.py airflow/providers/amazon/aws/transfers/__init__.py airflow/providers/amazon/aws/transfers/dynamodb_to_s3.py airflow/providers/amazon/aws/transfers/exasol_to_s3.py airflow/providers/amazon/aws/transfers/ftp_to_s3.py airflow/providers/amazon/aws/transfers/gcs_to_s3.py airflow/providers/amazon/aws/transfers/glacier_to_gcs.py airflow/providers/amazon/aws/transfers/google_api_to_s3.py airflow/providers/amazon/aws/transfers/hive_to_dynamodb.py airflow/providers/amazon/aws/transfers/imap_attachment_to_s3.py airflow/providers/amazon/aws/transfers/mongo_to_s3.py airflow/providers/amazon/aws/transfers/mysql_to_s3.py airflow/providers/amazon/aws/transfers/redshift_to_s3.py airflow/providers/amazon/aws/transfers/s3_to_ftp.py airflow/providers/amazon/aws/transfers/s3_to_redshift.py airflow/providers/amazon/aws/transfers/s3_to_sftp.py airflow/providers/amazon/aws/transfers/sftp_to_s3.py airflow/providers/amazon/aws/utils/__init__.py airflow/providers/amazon/aws/utils/emailer.py airflow/providers/amazon/aws/utils/redshift.py airflow/providers/apache/__init__.py airflow/providers/apache/beam/CHANGELOG.rst airflow/providers/apache/beam/__init__.py airflow/providers/apache/beam/example_dags/__init__.py airflow/providers/apache/beam/example_dags/example_beam.py airflow/providers/apache/beam/hooks/__init__.py airflow/providers/apache/beam/hooks/beam.py airflow/providers/apache/beam/operators/__init__.py airflow/providers/apache/beam/operators/beam.py airflow/providers/apache/cassandra/CHANGELOG.rst airflow/providers/apache/cassandra/__init__.py airflow/providers/apache/cassandra/example_dags/__init__.py airflow/providers/apache/cassandra/example_dags/example_cassandra_dag.py airflow/providers/apache/cassandra/hooks/__init__.py airflow/providers/apache/cassandra/hooks/cassandra.py airflow/providers/apache/cassandra/sensors/__init__.py airflow/providers/apache/cassandra/sensors/record.py airflow/providers/apache/cassandra/sensors/table.py airflow/providers/apache/druid/CHANGELOG.rst airflow/providers/apache/druid/__init__.py airflow/providers/apache/druid/hooks/__init__.py airflow/providers/apache/druid/hooks/druid.py airflow/providers/apache/druid/operators/__init__.py airflow/providers/apache/druid/operators/druid.py airflow/providers/apache/druid/operators/druid_check.py airflow/providers/apache/druid/transfers/__init__.py airflow/providers/apache/druid/transfers/hive_to_druid.py airflow/providers/apache/hdfs/CHANGELOG.rst airflow/providers/apache/hdfs/__init__.py airflow/providers/apache/hdfs/hooks/__init__.py airflow/providers/apache/hdfs/hooks/hdfs.py airflow/providers/apache/hdfs/hooks/webhdfs.py airflow/providers/apache/hdfs/sensors/__init__.py airflow/providers/apache/hdfs/sensors/hdfs.py airflow/providers/apache/hdfs/sensors/web_hdfs.py airflow/providers/apache/hive/CHANGELOG.rst airflow/providers/apache/hive/__init__.py airflow/providers/apache/hive/example_dags/__init__.py airflow/providers/apache/hive/example_dags/example_twitter_dag.py airflow/providers/apache/hive/hooks/__init__.py airflow/providers/apache/hive/hooks/hive.py airflow/providers/apache/hive/operators/__init__.py airflow/providers/apache/hive/operators/hive.py airflow/providers/apache/hive/operators/hive_stats.py airflow/providers/apache/hive/sensors/__init__.py airflow/providers/apache/hive/sensors/hive_partition.py airflow/providers/apache/hive/sensors/metastore_partition.py airflow/providers/apache/hive/sensors/named_hive_partition.py airflow/providers/apache/hive/transfers/__init__.py airflow/providers/apache/hive/transfers/hive_to_mysql.py airflow/providers/apache/hive/transfers/hive_to_samba.py airflow/providers/apache/hive/transfers/mssql_to_hive.py airflow/providers/apache/hive/transfers/mysql_to_hive.py airflow/providers/apache/hive/transfers/s3_to_hive.py airflow/providers/apache/hive/transfers/vertica_to_hive.py airflow/providers/apache/kylin/CHANGELOG.rst airflow/providers/apache/kylin/__init__.py airflow/providers/apache/kylin/example_dags/__init__.py airflow/providers/apache/kylin/example_dags/example_kylin_dag.py airflow/providers/apache/kylin/hooks/__init__.py airflow/providers/apache/kylin/hooks/kylin.py airflow/providers/apache/kylin/operators/__init__.py airflow/providers/apache/kylin/operators/kylin_cube.py airflow/providers/apache/livy/CHANGELOG.rst airflow/providers/apache/livy/__init__.py airflow/providers/apache/livy/example_dags/__init__.py airflow/providers/apache/livy/example_dags/example_livy.py airflow/providers/apache/livy/hooks/__init__.py airflow/providers/apache/livy/hooks/livy.py airflow/providers/apache/livy/operators/__init__.py airflow/providers/apache/livy/operators/livy.py airflow/providers/apache/livy/sensors/__init__.py airflow/providers/apache/livy/sensors/livy.py airflow/providers/apache/pig/CHANGELOG.rst airflow/providers/apache/pig/__init__.py airflow/providers/apache/pig/example_dags/__init__.py airflow/providers/apache/pig/example_dags/example_pig.py airflow/providers/apache/pig/hooks/__init__.py airflow/providers/apache/pig/hooks/pig.py airflow/providers/apache/pig/operators/__init__.py airflow/providers/apache/pig/operators/pig.py airflow/providers/apache/pinot/CHANGELOG.rst airflow/providers/apache/pinot/__init__.py airflow/providers/apache/pinot/hooks/__init__.py airflow/providers/apache/pinot/hooks/pinot.py airflow/providers/apache/spark/CHANGELOG.rst airflow/providers/apache/spark/__init__.py airflow/providers/apache/spark/example_dags/__init__.py airflow/providers/apache/spark/example_dags/example_spark_dag.py airflow/providers/apache/spark/hooks/__init__.py airflow/providers/apache/spark/hooks/spark_jdbc.py airflow/providers/apache/spark/hooks/spark_jdbc_script.py airflow/providers/apache/spark/hooks/spark_sql.py airflow/providers/apache/spark/hooks/spark_submit.py airflow/providers/apache/spark/operators/__init__.py airflow/providers/apache/spark/operators/spark_jdbc.py airflow/providers/apache/spark/operators/spark_sql.py airflow/providers/apache/spark/operators/spark_submit.py airflow/providers/apache/sqoop/CHANGELOG.rst airflow/providers/apache/sqoop/__init__.py airflow/providers/apache/sqoop/hooks/__init__.py airflow/providers/apache/sqoop/hooks/sqoop.py airflow/providers/apache/sqoop/operators/__init__.py airflow/providers/apache/sqoop/operators/sqoop.py airflow/providers/asana/CHANGELOG.rst airflow/providers/asana/__init__.py airflow/providers/asana/example_dags/__init__.py airflow/providers/asana/example_dags/example_asana.py airflow/providers/asana/hooks/__init__.py airflow/providers/asana/hooks/asana.py airflow/providers/asana/operators/__init__.py airflow/providers/asana/operators/asana_tasks.py airflow/providers/celery/CHANGELOG.rst airflow/providers/celery/__init__.py airflow/providers/celery/sensors/__init__.py airflow/providers/celery/sensors/celery_queue.py airflow/providers/cloudant/CHANGELOG.rst airflow/providers/cloudant/__init__.py airflow/providers/cloudant/hooks/__init__.py airflow/providers/cloudant/hooks/cloudant.py airflow/providers/cncf/__init__.py airflow/providers/cncf/kubernetes/CHANGELOG.rst airflow/providers/cncf/kubernetes/__init__.py airflow/providers/cncf/kubernetes/backcompat/__init__.py airflow/providers/cncf/kubernetes/backcompat/backwards_compat_converters.py airflow/providers/cncf/kubernetes/backcompat/pod.py airflow/providers/cncf/kubernetes/backcompat/pod_runtime_info_env.py airflow/providers/cncf/kubernetes/backcompat/volume.py airflow/providers/cncf/kubernetes/backcompat/volume_mount.py airflow/providers/cncf/kubernetes/example_dags/__init__.py airflow/providers/cncf/kubernetes/example_dags/example_kubernetes.py airflow/providers/cncf/kubernetes/example_dags/example_spark_kubernetes.py airflow/providers/cncf/kubernetes/hooks/__init__.py airflow/providers/cncf/kubernetes/hooks/kubernetes.py airflow/providers/cncf/kubernetes/operators/__init__.py airflow/providers/cncf/kubernetes/operators/kubernetes_pod.py airflow/providers/cncf/kubernetes/operators/spark_kubernetes.py airflow/providers/cncf/kubernetes/sensors/__init__.py airflow/providers/cncf/kubernetes/sensors/spark_kubernetes.py airflow/providers/cncf/kubernetes/utils/__init__.py airflow/providers/cncf/kubernetes/utils/pod_launcher.py airflow/providers/cncf/kubernetes/utils/xcom_sidecar.py airflow/providers/databricks/CHANGELOG.rst airflow/providers/databricks/__init__.py airflow/providers/databricks/example_dags/__init__.py airflow/providers/databricks/example_dags/example_databricks.py airflow/providers/databricks/hooks/__init__.py airflow/providers/databricks/hooks/databricks.py airflow/providers/databricks/operators/__init__.py airflow/providers/databricks/operators/databricks.py airflow/providers/datadog/CHANGELOG.rst airflow/providers/datadog/__init__.py airflow/providers/datadog/hooks/__init__.py airflow/providers/datadog/hooks/datadog.py airflow/providers/datadog/sensors/__init__.py airflow/providers/datadog/sensors/datadog.py airflow/providers/dependencies.json airflow/providers/dingding/CHANGELOG.rst airflow/providers/dingding/__init__.py airflow/providers/dingding/example_dags/__init__.py airflow/providers/dingding/example_dags/example_dingding.py airflow/providers/dingding/hooks/__init__.py airflow/providers/dingding/hooks/dingding.py airflow/providers/dingding/operators/__init__.py airflow/providers/dingding/operators/dingding.py airflow/providers/discord/CHANGELOG.rst airflow/providers/discord/__init__.py airflow/providers/discord/hooks/__init__.py airflow/providers/discord/hooks/discord_webhook.py airflow/providers/discord/operators/__init__.py airflow/providers/discord/operators/discord_webhook.py airflow/providers/docker/CHANGELOG.rst airflow/providers/docker/__init__.py airflow/providers/docker/example_dags/__init__.py airflow/providers/docker/example_dags/example_docker.py airflow/providers/docker/example_dags/example_docker_copy_data.py airflow/providers/docker/example_dags/example_docker_swarm.py airflow/providers/docker/hooks/__init__.py airflow/providers/docker/hooks/docker.py airflow/providers/docker/operators/__init__.py airflow/providers/docker/operators/docker.py airflow/providers/docker/operators/docker_swarm.py airflow/providers/elasticsearch/CHANGELOG.rst airflow/providers/elasticsearch/__init__.py airflow/providers/elasticsearch/hooks/__init__.py airflow/providers/elasticsearch/hooks/elasticsearch.py airflow/providers/elasticsearch/log/__init__.py airflow/providers/elasticsearch/log/es_task_handler.py airflow/providers/exasol/CHANGELOG.rst airflow/providers/exasol/__init__.py airflow/providers/exasol/hooks/__init__.py airflow/providers/exasol/hooks/exasol.py airflow/providers/exasol/operators/__init__.py airflow/providers/exasol/operators/exasol.py airflow/providers/facebook/CHANGELOG.rst airflow/providers/facebook/__init__.py airflow/providers/facebook/ads/__init__.py airflow/providers/facebook/ads/hooks/__init__.py airflow/providers/facebook/ads/hooks/ads.py airflow/providers/ftp/CHANGELOG.rst airflow/providers/ftp/__init__.py airflow/providers/ftp/hooks/__init__.py airflow/providers/ftp/hooks/ftp.py airflow/providers/ftp/sensors/__init__.py airflow/providers/ftp/sensors/ftp.py airflow/providers/google/CHANGELOG.rst airflow/providers/google/__init__.py airflow/providers/google/ads/__init__.py airflow/providers/google/ads/example_dags/__init__.py airflow/providers/google/ads/example_dags/example_ads.py airflow/providers/google/ads/hooks/__init__.py airflow/providers/google/ads/hooks/ads.py airflow/providers/google/ads/operators/__init__.py airflow/providers/google/ads/operators/ads.py airflow/providers/google/ads/transfers/__init__.py airflow/providers/google/ads/transfers/ads_to_gcs.py airflow/providers/google/cloud/__init__.py airflow/providers/google/cloud/_internal_client/__init__.py airflow/providers/google/cloud/_internal_client/secret_manager_client.py airflow/providers/google/cloud/example_dags/__init__.py airflow/providers/google/cloud/example_dags/example_automl_nl_text_classification.py airflow/providers/google/cloud/example_dags/example_automl_nl_text_extraction.py airflow/providers/google/cloud/example_dags/example_automl_nl_text_sentiment.py airflow/providers/google/cloud/example_dags/example_automl_tables.py airflow/providers/google/cloud/example_dags/example_automl_translation.py airflow/providers/google/cloud/example_dags/example_automl_video_intelligence_classification.py airflow/providers/google/cloud/example_dags/example_automl_video_intelligence_tracking.py airflow/providers/google/cloud/example_dags/example_automl_vision_classification.py airflow/providers/google/cloud/example_dags/example_automl_vision_object_detection.py airflow/providers/google/cloud/example_dags/example_azure_fileshare_to_gcs.py airflow/providers/google/cloud/example_dags/example_bigquery_dts.py airflow/providers/google/cloud/example_dags/example_bigquery_operations.py airflow/providers/google/cloud/example_dags/example_bigquery_queries.py airflow/providers/google/cloud/example_dags/example_bigquery_query.sql airflow/providers/google/cloud/example_dags/example_bigquery_sensors.py airflow/providers/google/cloud/example_dags/example_bigquery_to_bigquery.py airflow/providers/google/cloud/example_dags/example_bigquery_to_gcs.py airflow/providers/google/cloud/example_dags/example_bigquery_transfer.py airflow/providers/google/cloud/example_dags/example_bigtable.py airflow/providers/google/cloud/example_dags/example_cloud_build.py airflow/providers/google/cloud/example_dags/example_cloud_memorystore.py airflow/providers/google/cloud/example_dags/example_cloud_sql.py airflow/providers/google/cloud/example_dags/example_cloud_sql_query.py airflow/providers/google/cloud/example_dags/example_cloud_storage_transfer_service_aws.py airflow/providers/google/cloud/example_dags/example_cloud_storage_transfer_service_gcp.py airflow/providers/google/cloud/example_dags/example_compute.py airflow/providers/google/cloud/example_dags/example_compute_igm.py airflow/providers/google/cloud/example_dags/example_compute_ssh.py airflow/providers/google/cloud/example_dags/example_datacatalog.py airflow/providers/google/cloud/example_dags/example_dataflow.py airflow/providers/google/cloud/example_dags/example_dataflow_flex_template.py airflow/providers/google/cloud/example_dags/example_dataflow_sql.py airflow/providers/google/cloud/example_dags/example_datafusion.py airflow/providers/google/cloud/example_dags/example_dataprep.py airflow/providers/google/cloud/example_dags/example_dataproc.py airflow/providers/google/cloud/example_dags/example_datastore.py airflow/providers/google/cloud/example_dags/example_dlp.py airflow/providers/google/cloud/example_dags/example_facebook_ads_to_gcs.py airflow/providers/google/cloud/example_dags/example_functions.py airflow/providers/google/cloud/example_dags/example_gcs.py airflow/providers/google/cloud/example_dags/example_gcs_timespan_file_transform.py airflow/providers/google/cloud/example_dags/example_gcs_to_bigquery.py airflow/providers/google/cloud/example_dags/example_gcs_to_gcs.py airflow/providers/google/cloud/example_dags/example_gcs_to_local.py airflow/providers/google/cloud/example_dags/example_gcs_to_sftp.py airflow/providers/google/cloud/example_dags/example_gdrive_to_gcs.py airflow/providers/google/cloud/example_dags/example_gdrive_to_local.py airflow/providers/google/cloud/example_dags/example_kubernetes_engine.py airflow/providers/google/cloud/example_dags/example_life_sciences.py airflow/providers/google/cloud/example_dags/example_local_to_gcs.py airflow/providers/google/cloud/example_dags/example_mlengine.py airflow/providers/google/cloud/example_dags/example_mysql_to_gcs.py airflow/providers/google/cloud/example_dags/example_natural_language.py airflow/providers/google/cloud/example_dags/example_oracle_to_gcs.py airflow/providers/google/cloud/example_dags/example_postgres_to_gcs.py airflow/providers/google/cloud/example_dags/example_presto_to_gcs.py airflow/providers/google/cloud/example_dags/example_pubsub.py airflow/providers/google/cloud/example_dags/example_s3_to_gcs.py airflow/providers/google/cloud/example_dags/example_salesforce_to_gcs.py airflow/providers/google/cloud/example_dags/example_sftp_to_gcs.py airflow/providers/google/cloud/example_dags/example_sheets_to_gcs.py airflow/providers/google/cloud/example_dags/example_spanner.py airflow/providers/google/cloud/example_dags/example_spanner.sql airflow/providers/google/cloud/example_dags/example_speech_to_text.py airflow/providers/google/cloud/example_dags/example_stackdriver.py airflow/providers/google/cloud/example_dags/example_tasks.py airflow/providers/google/cloud/example_dags/example_text_to_speech.py airflow/providers/google/cloud/example_dags/example_translate.py airflow/providers/google/cloud/example_dags/example_translate_speech.py airflow/providers/google/cloud/example_dags/example_trino_to_gcs.py airflow/providers/google/cloud/example_dags/example_video_intelligence.py airflow/providers/google/cloud/example_dags/example_vision.py airflow/providers/google/cloud/example_dags/example_workflows.py airflow/providers/google/cloud/hooks/__init__.py airflow/providers/google/cloud/hooks/automl.py airflow/providers/google/cloud/hooks/bigquery.py airflow/providers/google/cloud/hooks/bigquery_dts.py airflow/providers/google/cloud/hooks/bigtable.py airflow/providers/google/cloud/hooks/cloud_build.py airflow/providers/google/cloud/hooks/cloud_memorystore.py airflow/providers/google/cloud/hooks/cloud_sql.py airflow/providers/google/cloud/hooks/cloud_storage_transfer_service.py airflow/providers/google/cloud/hooks/compute.py airflow/providers/google/cloud/hooks/compute_ssh.py airflow/providers/google/cloud/hooks/datacatalog.py airflow/providers/google/cloud/hooks/dataflow.py airflow/providers/google/cloud/hooks/datafusion.py airflow/providers/google/cloud/hooks/dataprep.py airflow/providers/google/cloud/hooks/dataproc.py airflow/providers/google/cloud/hooks/datastore.py airflow/providers/google/cloud/hooks/dlp.py airflow/providers/google/cloud/hooks/functions.py airflow/providers/google/cloud/hooks/gcs.py airflow/providers/google/cloud/hooks/gdm.py airflow/providers/google/cloud/hooks/kms.py airflow/providers/google/cloud/hooks/kubernetes_engine.py airflow/providers/google/cloud/hooks/life_sciences.py airflow/providers/google/cloud/hooks/mlengine.py airflow/providers/google/cloud/hooks/natural_language.py airflow/providers/google/cloud/hooks/os_login.py airflow/providers/google/cloud/hooks/pubsub.py airflow/providers/google/cloud/hooks/secret_manager.py airflow/providers/google/cloud/hooks/spanner.py airflow/providers/google/cloud/hooks/speech_to_text.py airflow/providers/google/cloud/hooks/stackdriver.py airflow/providers/google/cloud/hooks/tasks.py airflow/providers/google/cloud/hooks/text_to_speech.py airflow/providers/google/cloud/hooks/translate.py airflow/providers/google/cloud/hooks/video_intelligence.py airflow/providers/google/cloud/hooks/vision.py airflow/providers/google/cloud/hooks/workflows.py airflow/providers/google/cloud/log/__init__.py airflow/providers/google/cloud/log/gcs_task_handler.py airflow/providers/google/cloud/log/stackdriver_task_handler.py airflow/providers/google/cloud/operators/__init__.py airflow/providers/google/cloud/operators/automl.py airflow/providers/google/cloud/operators/bigquery.py airflow/providers/google/cloud/operators/bigquery_dts.py airflow/providers/google/cloud/operators/bigtable.py airflow/providers/google/cloud/operators/cloud_build.py airflow/providers/google/cloud/operators/cloud_memorystore.py airflow/providers/google/cloud/operators/cloud_sql.py airflow/providers/google/cloud/operators/cloud_storage_transfer_service.py airflow/providers/google/cloud/operators/compute.py airflow/providers/google/cloud/operators/datacatalog.py airflow/providers/google/cloud/operators/dataflow.py airflow/providers/google/cloud/operators/datafusion.py airflow/providers/google/cloud/operators/dataprep.py airflow/providers/google/cloud/operators/dataproc.py airflow/providers/google/cloud/operators/datastore.py airflow/providers/google/cloud/operators/dlp.py airflow/providers/google/cloud/operators/functions.py airflow/providers/google/cloud/operators/gcs.py airflow/providers/google/cloud/operators/kubernetes_engine.py airflow/providers/google/cloud/operators/life_sciences.py airflow/providers/google/cloud/operators/mlengine.py airflow/providers/google/cloud/operators/natural_language.py airflow/providers/google/cloud/operators/pubsub.py airflow/providers/google/cloud/operators/spanner.py airflow/providers/google/cloud/operators/speech_to_text.py airflow/providers/google/cloud/operators/stackdriver.py airflow/providers/google/cloud/operators/tasks.py airflow/providers/google/cloud/operators/text_to_speech.py airflow/providers/google/cloud/operators/translate.py airflow/providers/google/cloud/operators/translate_speech.py airflow/providers/google/cloud/operators/video_intelligence.py airflow/providers/google/cloud/operators/vision.py airflow/providers/google/cloud/operators/workflows.py airflow/providers/google/cloud/secrets/__init__.py airflow/providers/google/cloud/secrets/secret_manager.py airflow/providers/google/cloud/sensors/__init__.py airflow/providers/google/cloud/sensors/bigquery.py airflow/providers/google/cloud/sensors/bigquery_dts.py airflow/providers/google/cloud/sensors/bigtable.py airflow/providers/google/cloud/sensors/cloud_storage_transfer_service.py airflow/providers/google/cloud/sensors/dataflow.py airflow/providers/google/cloud/sensors/dataproc.py airflow/providers/google/cloud/sensors/gcs.py airflow/providers/google/cloud/sensors/pubsub.py airflow/providers/google/cloud/sensors/workflows.py airflow/providers/google/cloud/transfers/__init__.py airflow/providers/google/cloud/transfers/adls_to_gcs.py airflow/providers/google/cloud/transfers/azure_fileshare_to_gcs.py airflow/providers/google/cloud/transfers/bigquery_to_bigquery.py airflow/providers/google/cloud/transfers/bigquery_to_gcs.py airflow/providers/google/cloud/transfers/bigquery_to_mysql.py airflow/providers/google/cloud/transfers/cassandra_to_gcs.py airflow/providers/google/cloud/transfers/facebook_ads_to_gcs.py airflow/providers/google/cloud/transfers/gcs_to_bigquery.py airflow/providers/google/cloud/transfers/gcs_to_gcs.py airflow/providers/google/cloud/transfers/gcs_to_local.py airflow/providers/google/cloud/transfers/gcs_to_sftp.py airflow/providers/google/cloud/transfers/gdrive_to_gcs.py airflow/providers/google/cloud/transfers/gdrive_to_local.py airflow/providers/google/cloud/transfers/local_to_gcs.py airflow/providers/google/cloud/transfers/mssql_to_gcs.py airflow/providers/google/cloud/transfers/mysql_to_gcs.py airflow/providers/google/cloud/transfers/oracle_to_gcs.py airflow/providers/google/cloud/transfers/postgres_to_gcs.py airflow/providers/google/cloud/transfers/presto_to_gcs.py airflow/providers/google/cloud/transfers/s3_to_gcs.py airflow/providers/google/cloud/transfers/salesforce_to_gcs.py airflow/providers/google/cloud/transfers/sftp_to_gcs.py airflow/providers/google/cloud/transfers/sheets_to_gcs.py airflow/providers/google/cloud/transfers/sql_to_gcs.py airflow/providers/google/cloud/transfers/trino_to_gcs.py airflow/providers/google/cloud/utils/__init__.py airflow/providers/google/cloud/utils/credentials_provider.py airflow/providers/google/cloud/utils/field_sanitizer.py airflow/providers/google/cloud/utils/field_validator.py airflow/providers/google/cloud/utils/mlengine_operator_utils.py airflow/providers/google/cloud/utils/mlengine_prediction_summary.py airflow/providers/google/common/__init__.py airflow/providers/google/common/auth_backend/__init__.py airflow/providers/google/common/auth_backend/google_openid.py airflow/providers/google/common/hooks/__init__.py airflow/providers/google/common/hooks/base_google.py airflow/providers/google/common/hooks/discovery_api.py airflow/providers/google/common/utils/__init__.py airflow/providers/google/common/utils/id_token_credentials.py airflow/providers/google/config_templates/default_config.cfg airflow/providers/google/firebase/__init__.py airflow/providers/google/firebase/example_dags/__init__.py airflow/providers/google/firebase/example_dags/example_firestore.py airflow/providers/google/firebase/hooks/__init__.py airflow/providers/google/firebase/hooks/firestore.py airflow/providers/google/firebase/operators/__init__.py airflow/providers/google/firebase/operators/firestore.py airflow/providers/google/leveldb/__init__.py airflow/providers/google/leveldb/example_dags/__init__.py airflow/providers/google/leveldb/example_dags/example_leveldb.py airflow/providers/google/leveldb/hooks/__init__.py airflow/providers/google/leveldb/hooks/leveldb.py airflow/providers/google/leveldb/operators/__init__.py airflow/providers/google/leveldb/operators/leveldb.py airflow/providers/google/marketing_platform/__init__.py airflow/providers/google/marketing_platform/example_dags/__init__.py airflow/providers/google/marketing_platform/example_dags/example_analytics.py airflow/providers/google/marketing_platform/example_dags/example_campaign_manager.py airflow/providers/google/marketing_platform/example_dags/example_display_video.py airflow/providers/google/marketing_platform/example_dags/example_search_ads.py airflow/providers/google/marketing_platform/hooks/__init__.py airflow/providers/google/marketing_platform/hooks/analytics.py airflow/providers/google/marketing_platform/hooks/campaign_manager.py airflow/providers/google/marketing_platform/hooks/display_video.py airflow/providers/google/marketing_platform/hooks/search_ads.py airflow/providers/google/marketing_platform/operators/__init__.py airflow/providers/google/marketing_platform/operators/analytics.py airflow/providers/google/marketing_platform/operators/campaign_manager.py airflow/providers/google/marketing_platform/operators/display_video.py airflow/providers/google/marketing_platform/operators/search_ads.py airflow/providers/google/marketing_platform/sensors/__init__.py airflow/providers/google/marketing_platform/sensors/campaign_manager.py airflow/providers/google/marketing_platform/sensors/display_video.py airflow/providers/google/marketing_platform/sensors/search_ads.py airflow/providers/google/suite/__init__.py airflow/providers/google/suite/example_dags/__init__.py airflow/providers/google/suite/example_dags/example_gcs_to_gdrive.py airflow/providers/google/suite/example_dags/example_gcs_to_sheets.py airflow/providers/google/suite/example_dags/example_sheets.py airflow/providers/google/suite/hooks/__init__.py airflow/providers/google/suite/hooks/drive.py airflow/providers/google/suite/hooks/sheets.py airflow/providers/google/suite/operators/__init__.py airflow/providers/google/suite/operators/sheets.py airflow/providers/google/suite/sensors/__init__.py airflow/providers/google/suite/sensors/drive.py airflow/providers/google/suite/transfers/__init__.py airflow/providers/google/suite/transfers/gcs_to_gdrive.py airflow/providers/google/suite/transfers/gcs_to_sheets.py airflow/providers/grpc/CHANGELOG.rst airflow/providers/grpc/__init__.py airflow/providers/grpc/hooks/__init__.py airflow/providers/grpc/hooks/grpc.py airflow/providers/grpc/operators/__init__.py airflow/providers/grpc/operators/grpc.py airflow/providers/hashicorp/CHANGELOG.rst airflow/providers/hashicorp/__init__.py airflow/providers/hashicorp/_internal_client/__init__.py airflow/providers/hashicorp/_internal_client/vault_client.py airflow/providers/hashicorp/hooks/__init__.py airflow/providers/hashicorp/hooks/vault.py airflow/providers/hashicorp/secrets/__init__.py airflow/providers/hashicorp/secrets/vault.py airflow/providers/http/CHANGELOG.rst airflow/providers/http/__init__.py airflow/providers/http/example_dags/__init__.py airflow/providers/http/example_dags/example_http.py airflow/providers/http/hooks/__init__.py airflow/providers/http/hooks/http.py airflow/providers/http/operators/__init__.py airflow/providers/http/operators/http.py airflow/providers/http/sensors/__init__.py airflow/providers/http/sensors/http.py airflow/providers/imap/CHANGELOG.rst airflow/providers/imap/__init__.py airflow/providers/imap/hooks/__init__.py airflow/providers/imap/hooks/imap.py airflow/providers/imap/sensors/__init__.py airflow/providers/imap/sensors/imap_attachment.py airflow/providers/jdbc/CHANGELOG.rst airflow/providers/jdbc/__init__.py airflow/providers/jdbc/example_dags/__init__.py airflow/providers/jdbc/example_dags/example_jdbc_queries.py airflow/providers/jdbc/hooks/__init__.py airflow/providers/jdbc/hooks/jdbc.py airflow/providers/jdbc/operators/__init__.py airflow/providers/jdbc/operators/jdbc.py airflow/providers/jenkins/CHANGELOG.rst airflow/providers/jenkins/__init__.py airflow/providers/jenkins/example_dags/__init__.py airflow/providers/jenkins/example_dags/example_jenkins_job_trigger.py airflow/providers/jenkins/hooks/__init__.py airflow/providers/jenkins/hooks/jenkins.py airflow/providers/jenkins/operators/__init__.py airflow/providers/jenkins/operators/jenkins_job_trigger.py airflow/providers/jira/CHANGELOG.rst airflow/providers/jira/__init__.py airflow/providers/jira/hooks/__init__.py airflow/providers/jira/hooks/jira.py airflow/providers/jira/operators/__init__.py airflow/providers/jira/operators/jira.py airflow/providers/jira/sensors/__init__.py airflow/providers/jira/sensors/jira.py airflow/providers/microsoft/__init__.py airflow/providers/microsoft/azure/CHANGELOG.rst airflow/providers/microsoft/azure/__init__.py airflow/providers/microsoft/azure/example_dags/__init__.py airflow/providers/microsoft/azure/example_dags/example_adls_delete.py airflow/providers/microsoft/azure/example_dags/example_azure_blob_to_gcs.py airflow/providers/microsoft/azure/example_dags/example_azure_container_instances.py airflow/providers/microsoft/azure/example_dags/example_azure_cosmosdb.py airflow/providers/microsoft/azure/example_dags/example_file_to_wasb.py airflow/providers/microsoft/azure/example_dags/example_fileshare.py airflow/providers/microsoft/azure/example_dags/example_local_to_adls.py airflow/providers/microsoft/azure/hooks/__init__.py airflow/providers/microsoft/azure/hooks/adx.py airflow/providers/microsoft/azure/hooks/azure_batch.py airflow/providers/microsoft/azure/hooks/azure_container_instance.py airflow/providers/microsoft/azure/hooks/azure_container_registry.py airflow/providers/microsoft/azure/hooks/azure_container_volume.py airflow/providers/microsoft/azure/hooks/azure_cosmos.py airflow/providers/microsoft/azure/hooks/azure_data_factory.py airflow/providers/microsoft/azure/hooks/azure_data_lake.py airflow/providers/microsoft/azure/hooks/azure_fileshare.py airflow/providers/microsoft/azure/hooks/base_azure.py airflow/providers/microsoft/azure/hooks/wasb.py airflow/providers/microsoft/azure/log/__init__.py airflow/providers/microsoft/azure/log/wasb_task_handler.py airflow/providers/microsoft/azure/operators/__init__.py airflow/providers/microsoft/azure/operators/adls_delete.py airflow/providers/microsoft/azure/operators/adls_list.py airflow/providers/microsoft/azure/operators/adx.py airflow/providers/microsoft/azure/operators/azure_batch.py airflow/providers/microsoft/azure/operators/azure_container_instances.py airflow/providers/microsoft/azure/operators/azure_cosmos.py airflow/providers/microsoft/azure/operators/wasb_delete_blob.py airflow/providers/microsoft/azure/secrets/__init__.py airflow/providers/microsoft/azure/secrets/azure_key_vault.py airflow/providers/microsoft/azure/sensors/__init__.py airflow/providers/microsoft/azure/sensors/azure_cosmos.py airflow/providers/microsoft/azure/sensors/wasb.py airflow/providers/microsoft/azure/transfers/__init__.py airflow/providers/microsoft/azure/transfers/azure_blob_to_gcs.py airflow/providers/microsoft/azure/transfers/file_to_wasb.py airflow/providers/microsoft/azure/transfers/local_to_adls.py airflow/providers/microsoft/azure/transfers/oracle_to_azure_data_lake.py airflow/providers/microsoft/mssql/CHANGELOG.rst airflow/providers/microsoft/mssql/__init__.py airflow/providers/microsoft/mssql/hooks/__init__.py airflow/providers/microsoft/mssql/hooks/mssql.py airflow/providers/microsoft/mssql/operators/__init__.py airflow/providers/microsoft/mssql/operators/mssql.py airflow/providers/microsoft/winrm/CHANGELOG.rst airflow/providers/microsoft/winrm/__init__.py airflow/providers/microsoft/winrm/example_dags/__init__.py airflow/providers/microsoft/winrm/example_dags/example_winrm.py airflow/providers/microsoft/winrm/hooks/__init__.py airflow/providers/microsoft/winrm/hooks/winrm.py airflow/providers/microsoft/winrm/operators/__init__.py airflow/providers/microsoft/winrm/operators/winrm.py airflow/providers/mongo/CHANGELOG.rst airflow/providers/mongo/__init__.py airflow/providers/mongo/hooks/__init__.py airflow/providers/mongo/hooks/mongo.py airflow/providers/mongo/sensors/__init__.py airflow/providers/mongo/sensors/mongo.py airflow/providers/mysql/CHANGELOG.rst airflow/providers/mysql/__init__.py airflow/providers/mysql/example_dags/__init__.py airflow/providers/mysql/example_dags/example_mysql.py airflow/providers/mysql/hooks/__init__.py airflow/providers/mysql/hooks/mysql.py airflow/providers/mysql/operators/__init__.py airflow/providers/mysql/operators/mysql.py airflow/providers/mysql/transfers/__init__.py airflow/providers/mysql/transfers/presto_to_mysql.py airflow/providers/mysql/transfers/s3_to_mysql.py airflow/providers/mysql/transfers/trino_to_mysql.py airflow/providers/mysql/transfers/vertica_to_mysql.py airflow/providers/neo4j/CHANGELOG.rst airflow/providers/neo4j/__init__.py airflow/providers/neo4j/example_dags/__init__.py airflow/providers/neo4j/example_dags/example_neo4j.py airflow/providers/neo4j/hooks/__init__.py airflow/providers/neo4j/hooks/neo4j.py airflow/providers/neo4j/operators/__init__.py airflow/providers/neo4j/operators/neo4j.py airflow/providers/odbc/CHANGELOG.rst airflow/providers/odbc/__init__.py airflow/providers/odbc/hooks/__init__.py airflow/providers/odbc/hooks/odbc.py airflow/providers/openfaas/CHANGELOG.rst airflow/providers/openfaas/__init__.py airflow/providers/openfaas/hooks/__init__.py airflow/providers/openfaas/hooks/openfaas.py airflow/providers/opsgenie/CHANGELOG.rst airflow/providers/opsgenie/__init__.py airflow/providers/opsgenie/hooks/__init__.py airflow/providers/opsgenie/hooks/opsgenie_alert.py airflow/providers/opsgenie/operators/__init__.py airflow/providers/opsgenie/operators/opsgenie_alert.py airflow/providers/oracle/CHANGELOG.rst airflow/providers/oracle/__init__.py airflow/providers/oracle/hooks/__init__.py airflow/providers/oracle/hooks/oracle.py airflow/providers/oracle/operators/__init__.py airflow/providers/oracle/operators/oracle.py airflow/providers/oracle/transfers/__init__.py airflow/providers/oracle/transfers/oracle_to_oracle.py airflow/providers/pagerduty/CHANGELOG.rst airflow/providers/pagerduty/__init__.py airflow/providers/pagerduty/hooks/__init__.py airflow/providers/pagerduty/hooks/pagerduty.py airflow/providers/papermill/CHANGELOG.rst airflow/providers/papermill/__init__.py airflow/providers/papermill/example_dags/__init__.py airflow/providers/papermill/example_dags/example_papermill.py airflow/providers/papermill/example_dags/input_notebook.ipynb airflow/providers/papermill/operators/__init__.py airflow/providers/papermill/operators/papermill.py airflow/providers/plexus/CHANGELOG.rst airflow/providers/plexus/__init__.py airflow/providers/plexus/example_dags/__init__.py airflow/providers/plexus/example_dags/example_plexus.py airflow/providers/plexus/hooks/__init__.py airflow/providers/plexus/hooks/plexus.py airflow/providers/plexus/operators/__init__.py airflow/providers/plexus/operators/job.py airflow/providers/postgres/CHANGELOG.rst airflow/providers/postgres/__init__.py airflow/providers/postgres/example_dags/__init__.py airflow/providers/postgres/example_dags/example_postgres.py airflow/providers/postgres/hooks/__init__.py airflow/providers/postgres/hooks/postgres.py airflow/providers/postgres/operators/__init__.py airflow/providers/postgres/operators/postgres.py airflow/providers/presto/CHANGELOG.rst airflow/providers/presto/__init__.py airflow/providers/presto/hooks/__init__.py airflow/providers/presto/hooks/presto.py airflow/providers/qubole/CHANGELOG.rst airflow/providers/qubole/__init__.py airflow/providers/qubole/example_dags/__init__.py airflow/providers/qubole/example_dags/example_qubole.py airflow/providers/qubole/hooks/__init__.py airflow/providers/qubole/hooks/qubole.py airflow/providers/qubole/hooks/qubole_check.py airflow/providers/qubole/operators/__init__.py airflow/providers/qubole/operators/qubole.py airflow/providers/qubole/operators/qubole_check.py airflow/providers/qubole/sensors/__init__.py airflow/providers/qubole/sensors/qubole.py airflow/providers/redis/CHANGELOG.rst airflow/providers/redis/__init__.py airflow/providers/redis/hooks/__init__.py airflow/providers/redis/hooks/redis.py airflow/providers/redis/operators/__init__.py airflow/providers/redis/operators/redis_publish.py airflow/providers/redis/sensors/__init__.py airflow/providers/redis/sensors/redis_key.py airflow/providers/redis/sensors/redis_pub_sub.py airflow/providers/salesforce/CHANGELOG.rst airflow/providers/salesforce/__init__.py airflow/providers/salesforce/example_dags/__init__.py airflow/providers/salesforce/hooks/__init__.py airflow/providers/salesforce/hooks/salesforce.py airflow/providers/salesforce/hooks/tableau.py airflow/providers/salesforce/operators/__init__.py airflow/providers/salesforce/operators/tableau_refresh_workbook.py airflow/providers/salesforce/sensors/__init__.py airflow/providers/salesforce/sensors/tableau_job_status.py airflow/providers/samba/CHANGELOG.rst airflow/providers/samba/__init__.py airflow/providers/samba/hooks/__init__.py airflow/providers/samba/hooks/samba.py airflow/providers/segment/CHANGELOG.rst airflow/providers/segment/__init__.py airflow/providers/segment/hooks/__init__.py airflow/providers/segment/hooks/segment.py airflow/providers/segment/operators/__init__.py airflow/providers/segment/operators/segment_track_event.py airflow/providers/sendgrid/CHANGELOG.rst airflow/providers/sendgrid/__init__.py airflow/providers/sendgrid/utils/__init__.py airflow/providers/sendgrid/utils/emailer.py airflow/providers/sftp/CHANGELOG.rst airflow/providers/sftp/__init__.py airflow/providers/sftp/hooks/__init__.py airflow/providers/sftp/hooks/sftp.py airflow/providers/sftp/operators/__init__.py airflow/providers/sftp/operators/sftp.py airflow/providers/sftp/sensors/__init__.py airflow/providers/sftp/sensors/sftp.py airflow/providers/singularity/CHANGELOG.rst airflow/providers/singularity/__init__.py airflow/providers/singularity/example_dags/__init__.py airflow/providers/singularity/example_dags/example_singularity.py airflow/providers/singularity/operators/__init__.py airflow/providers/singularity/operators/singularity.py airflow/providers/slack/CHANGELOG.rst airflow/providers/slack/__init__.py airflow/providers/slack/hooks/__init__.py airflow/providers/slack/hooks/slack.py airflow/providers/slack/hooks/slack_webhook.py airflow/providers/slack/operators/__init__.py airflow/providers/slack/operators/slack.py airflow/providers/slack/operators/slack_webhook.py airflow/providers/snowflake/CHANGELOG.rst airflow/providers/snowflake/__init__.py airflow/providers/snowflake/example_dags/__init__.py airflow/providers/snowflake/example_dags/example_snowflake.py airflow/providers/snowflake/hooks/__init__.py airflow/providers/snowflake/hooks/snowflake.py airflow/providers/snowflake/operators/__init__.py airflow/providers/snowflake/operators/snowflake.py airflow/providers/snowflake/transfers/__init__.py airflow/providers/snowflake/transfers/s3_to_snowflake.py airflow/providers/snowflake/transfers/snowflake_to_slack.py airflow/providers/sqlite/CHANGELOG.rst airflow/providers/sqlite/__init__.py airflow/providers/sqlite/example_dags/__init__.py airflow/providers/sqlite/example_dags/example_sqlite.py airflow/providers/sqlite/hooks/__init__.py airflow/providers/sqlite/hooks/sqlite.py airflow/providers/sqlite/operators/__init__.py airflow/providers/sqlite/operators/sqlite.py airflow/providers/ssh/CHANGELOG.rst airflow/providers/ssh/__init__.py airflow/providers/ssh/hooks/__init__.py airflow/providers/ssh/hooks/ssh.py airflow/providers/ssh/operators/__init__.py airflow/providers/ssh/operators/ssh.py airflow/providers/tableau/CHANGELOG.rst airflow/providers/tableau/__init__.py airflow/providers/tableau/example_dags/__init__.py airflow/providers/tableau/example_dags/example_tableau_refresh_workbook.py airflow/providers/tableau/hooks/__init__.py airflow/providers/tableau/hooks/tableau.py airflow/providers/tableau/operators/__init__.py airflow/providers/tableau/operators/tableau_refresh_workbook.py airflow/providers/tableau/sensors/__init__.py airflow/providers/tableau/sensors/tableau_job_status.py airflow/providers/telegram/CHANGELOG.rst airflow/providers/telegram/__init__.py airflow/providers/telegram/example_dags/__init__.py airflow/providers/telegram/example_dags/example_telegram.py airflow/providers/telegram/hooks/__init__.py airflow/providers/telegram/hooks/telegram.py airflow/providers/telegram/operators/__init__.py airflow/providers/telegram/operators/telegram.py airflow/providers/trino/CHANGELOG.rst airflow/providers/trino/__init__.py airflow/providers/trino/hooks/__init__.py airflow/providers/trino/hooks/trino.py airflow/providers/vertica/CHANGELOG.rst airflow/providers/vertica/__init__.py airflow/providers/vertica/hooks/__init__.py airflow/providers/vertica/hooks/vertica.py airflow/providers/vertica/operators/__init__.py airflow/providers/vertica/operators/vertica.py airflow/providers/yandex/CHANGELOG.rst airflow/providers/yandex/__init__.py airflow/providers/yandex/example_dags/__init__.py airflow/providers/yandex/example_dags/example_yandexcloud_dataproc.py airflow/providers/yandex/hooks/__init__.py airflow/providers/yandex/hooks/yandex.py airflow/providers/yandex/hooks/yandexcloud_dataproc.py airflow/providers/yandex/operators/__init__.py airflow/providers/yandex/operators/yandexcloud_dataproc.py airflow/providers/zendesk/CHANGELOG.rst airflow/providers/zendesk/__init__.py airflow/providers/zendesk/hooks/__init__.py airflow/providers/zendesk/hooks/zendesk.py airflow/providers_manager.py airflow/py.typed airflow/secrets/__init__.py airflow/secrets/base_secrets.py airflow/secrets/environment_variables.py airflow/secrets/local_filesystem.py airflow/secrets/metastore.py airflow/security/__init__.py airflow/security/kerberos.py airflow/security/permissions.py airflow/security/utils.py airflow/sensors/__init__.py airflow/sensors/base.py airflow/sensors/base_sensor_operator.py airflow/sensors/bash.py airflow/sensors/date_time.py airflow/sensors/date_time_sensor.py airflow/sensors/external_task.py airflow/sensors/external_task_sensor.py airflow/sensors/filesystem.py airflow/sensors/hdfs_sensor.py airflow/sensors/hive_partition_sensor.py airflow/sensors/http_sensor.py airflow/sensors/metastore_partition_sensor.py airflow/sensors/named_hive_partition_sensor.py airflow/sensors/python.py airflow/sensors/s3_key_sensor.py airflow/sensors/s3_prefix_sensor.py airflow/sensors/smart_sensor.py airflow/sensors/sql.py airflow/sensors/sql_sensor.py airflow/sensors/time_delta.py airflow/sensors/time_delta_sensor.py airflow/sensors/time_sensor.py airflow/sensors/web_hdfs_sensor.py airflow/sensors/weekday.py airflow/sentry.py airflow/serialization/__init__.py airflow/serialization/enums.py airflow/serialization/helpers.py airflow/serialization/json_schema.py airflow/serialization/schema.json airflow/serialization/serialized_objects.py airflow/settings.py airflow/smart_sensor_dags/__init__.py airflow/smart_sensor_dags/smart_sensor_group.py airflow/stats.py airflow/task/__init__.py airflow/task/task_runner/__init__.py airflow/task/task_runner/base_task_runner.py airflow/task/task_runner/cgroup_task_runner.py airflow/task/task_runner/standard_task_runner.py airflow/templates.py airflow/ti_deps/__init__.py airflow/ti_deps/dep_context.py airflow/ti_deps/dependencies_deps.py airflow/ti_deps/dependencies_states.py airflow/ti_deps/deps/__init__.py airflow/ti_deps/deps/base_ti_dep.py airflow/ti_deps/deps/dag_ti_slots_available_dep.py airflow/ti_deps/deps/dag_unpaused_dep.py airflow/ti_deps/deps/dagrun_exists_dep.py airflow/ti_deps/deps/dagrun_id_dep.py airflow/ti_deps/deps/exec_date_after_start_date_dep.py airflow/ti_deps/deps/not_in_retry_period_dep.py airflow/ti_deps/deps/not_previously_skipped_dep.py airflow/ti_deps/deps/pool_slots_available_dep.py airflow/ti_deps/deps/prev_dagrun_dep.py airflow/ti_deps/deps/ready_to_reschedule.py airflow/ti_deps/deps/runnable_exec_date_dep.py airflow/ti_deps/deps/task_concurrency_dep.py airflow/ti_deps/deps/task_not_running_dep.py airflow/ti_deps/deps/trigger_rule_dep.py airflow/ti_deps/deps/valid_state_dep.py airflow/typing_compat.py airflow/ui/.env.example airflow/ui/.eslintrc.js airflow/ui/.neutrinorc.js airflow/ui/jest.config.js airflow/ui/package.json airflow/ui/src/App.tsx airflow/ui/src/api/defaults.ts airflow/ui/src/api/index.ts airflow/ui/src/components/AppContainer/AppHeader.tsx airflow/ui/src/components/AppContainer/AppNav.tsx airflow/ui/src/components/AppContainer/AppNavBtn.tsx airflow/ui/src/components/AppContainer/TimezoneDropdown.tsx airflow/ui/src/components/AppContainer/index.tsx airflow/ui/src/components/MultiSelect.tsx airflow/ui/src/components/PipelineBreadcrumb.tsx airflow/ui/src/components/SectionNav.tsx airflow/ui/src/components/SectionNavBtn.tsx airflow/ui/src/components/SectionWrapper.tsx airflow/ui/src/components/Table.tsx airflow/ui/src/components/TriggerRunModal.tsx airflow/ui/src/components/icons/ApacheAirflowLogo.tsx airflow/ui/src/components/icons/PinwheelLogo.tsx airflow/ui/src/components/icons/PipelineIcon.tsx airflow/ui/src/index.tsx airflow/ui/src/interfaces/api.ts airflow/ui/src/interfaces/index.ts airflow/ui/src/interfaces/react-table-config.d.ts airflow/ui/src/providers/DateProvider.tsx airflow/ui/src/providers/auth/AuthProvider.tsx airflow/ui/src/providers/auth/PrivateRoute.tsx airflow/ui/src/providers/auth/context.ts airflow/ui/src/static/favicon.ico airflow/ui/src/theme.ts airflow/ui/src/utils/localStorage.ts airflow/ui/src/utils/memo.ts airflow/ui/src/views/Access/AccessContainer.tsx airflow/ui/src/views/Access/Permissions.tsx airflow/ui/src/views/Access/Roles.tsx airflow/ui/src/views/Access/Users.tsx airflow/ui/src/views/Access/index.tsx airflow/ui/src/views/Activity/ActivityContainer.tsx airflow/ui/src/views/Activity/EventLogs.tsx airflow/ui/src/views/Activity/Jobs.tsx airflow/ui/src/views/Activity/Runs.tsx airflow/ui/src/views/Activity/SLAMisses.tsx airflow/ui/src/views/Activity/TaskInstances.tsx airflow/ui/src/views/Activity/TaskReschedules.tsx airflow/ui/src/views/Activity/XComs.tsx airflow/ui/src/views/Config/ConfigContainer.tsx airflow/ui/src/views/Config/Connections.tsx airflow/ui/src/views/Config/Pools.tsx airflow/ui/src/views/Config/Variables.tsx airflow/ui/src/views/Config/index.tsx airflow/ui/src/views/Docs.tsx airflow/ui/src/views/Login.tsx airflow/ui/src/views/NotFound.tsx airflow/ui/src/views/Pipeline/PipelineContainer.tsx airflow/ui/src/views/Pipeline/run/Gantt.tsx airflow/ui/src/views/Pipeline/run/Graph.tsx airflow/ui/src/views/Pipeline/run/RunContainer.tsx airflow/ui/src/views/Pipeline/runs/Code.tsx airflow/ui/src/views/Pipeline/runs/Details.tsx airflow/ui/src/views/Pipeline/runs/LandingTimes.tsx airflow/ui/src/views/Pipeline/runs/RunsContainer.tsx airflow/ui/src/views/Pipeline/runs/TaskDuration.tsx airflow/ui/src/views/Pipeline/runs/TaskTries.tsx airflow/ui/src/views/Pipeline/ti/Details.tsx airflow/ui/src/views/Pipeline/ti/Log.tsx airflow/ui/src/views/Pipeline/ti/RenderedK8s.tsx airflow/ui/src/views/Pipeline/ti/RenderedTemplate.tsx airflow/ui/src/views/Pipeline/ti/TIContainer.tsx airflow/ui/src/views/Pipeline/ti/XCom.tsx airflow/ui/src/views/Pipelines/PipelinesTable.tsx airflow/ui/src/views/Pipelines/Row.tsx airflow/ui/src/views/Pipelines/index.tsx airflow/ui/test/Login.test.tsx airflow/ui/test/Pipelines.test.tsx airflow/ui/test/TimezoneDropdown.test.tsx airflow/ui/test/utils.tsx airflow/ui/tsconfig.json airflow/ui/webpack.config.js airflow/ui/yarn.lock airflow/utils/__init__.py airflow/utils/callback_requests.py airflow/utils/cli.py airflow/utils/cli_action_loggers.py airflow/utils/code_utils.py airflow/utils/compression.py airflow/utils/configuration.py airflow/utils/dag_cycle_tester.py airflow/utils/dag_processing.py airflow/utils/dates.py airflow/utils/db.py airflow/utils/decorators.py airflow/utils/docs.py airflow/utils/dot_renderer.py airflow/utils/edgemodifier.py airflow/utils/email.py airflow/utils/entry_points.py airflow/utils/event_scheduler.py airflow/utils/file.py airflow/utils/helpers.py airflow/utils/json.py airflow/utils/log/__init__.py airflow/utils/log/cloudwatch_task_handler.py airflow/utils/log/colored_log.py airflow/utils/log/es_task_handler.py airflow/utils/log/file_processor_handler.py airflow/utils/log/file_task_handler.py airflow/utils/log/gcs_task_handler.py airflow/utils/log/json_formatter.py airflow/utils/log/log_reader.py airflow/utils/log/logging_mixin.py airflow/utils/log/s3_task_handler.py airflow/utils/log/secrets_masker.py airflow/utils/log/stackdriver_task_handler.py airflow/utils/log/task_handler_with_custom_formatter.py airflow/utils/log/wasb_task_handler.py airflow/utils/mixins.py airflow/utils/module_loading.py airflow/utils/net.py airflow/utils/operator_helpers.py airflow/utils/operator_resources.py airflow/utils/orm_event_handlers.py airflow/utils/platform.py airflow/utils/process_utils.py airflow/utils/python_virtualenv.py airflow/utils/python_virtualenv_script.jinja2 airflow/utils/retries.py airflow/utils/serve_logs.py airflow/utils/session.py airflow/utils/sqlalchemy.py airflow/utils/state.py airflow/utils/strings.py airflow/utils/task_group.py airflow/utils/timeout.py airflow/utils/timezone.py airflow/utils/trigger_rule.py airflow/utils/types.py airflow/utils/weekday.py airflow/utils/weight_rule.py airflow/utils/yaml.py airflow/version.py airflow/www/.eslintignore airflow/www/.eslintrc airflow/www/.stylelintignore airflow/www/.stylelintrc airflow/www/__init__.py airflow/www/api/__init__.py airflow/www/api/experimental/__init__.py airflow/www/api/experimental/endpoints.py airflow/www/app.py airflow/www/ask_for_recompile_assets_if_needed.sh airflow/www/auth.py airflow/www/blueprints.py airflow/www/compile_assets.sh airflow/www/decorators.py airflow/www/extensions/__init__.py airflow/www/extensions/init_appbuilder.py airflow/www/extensions/init_appbuilder_links.py airflow/www/extensions/init_dagbag.py airflow/www/extensions/init_jinja_globals.py airflow/www/extensions/init_manifest_files.py airflow/www/extensions/init_security.py airflow/www/extensions/init_session.py airflow/www/extensions/init_views.py airflow/www/extensions/init_wsgi_middlewares.py airflow/www/forms.py airflow/www/gunicorn_config.py airflow/www/package.json airflow/www/security.py airflow/www/static/css/bootstrap-theme.css airflow/www/static/css/calendar.css airflow/www/static/css/dags.css airflow/www/static/css/flash.css airflow/www/static/css/gantt.css airflow/www/static/css/graph.css airflow/www/static/css/loading-dots.css airflow/www/static/css/main.css airflow/www/static/css/material-icons.css airflow/www/static/css/switch.css airflow/www/static/css/tree.css airflow/www/static/js/calendar.js airflow/www/static/js/circles.js airflow/www/static/js/connection_form.js airflow/www/static/js/dag.js airflow/www/static/js/dag_code.js airflow/www/static/js/dag_dependencies.js airflow/www/static/js/dags.js airflow/www/static/js/datetime_utils.js airflow/www/static/js/duration_chart.js airflow/www/static/js/gantt.js airflow/www/static/js/graph.js airflow/www/static/js/ie.js airflow/www/static/js/main.js airflow/www/static/js/meta_value.js airflow/www/static/js/task_instance.js airflow/www/static/js/task_instances.js airflow/www/static/js/ti_log.js airflow/www/static/js/tree.js airflow/www/static/js/trigger.js airflow/www/static/js/variable_edit.js airflow/www/static/pin.svg airflow/www/utils.py airflow/www/validators.py airflow/www/views.py airflow/www/webpack.config.js airflow/www/widgets.py airflow/www/yarn.lock breeze breeze-complete chart/.helmignore chart/INSTALL chart/LICENSE chart/NOTICE chart/dockerfiles/pgbouncer-exporter/Dockerfile chart/dockerfiles/pgbouncer-exporter/build_and_push.sh chart/dockerfiles/pgbouncer/Dockerfile chart/dockerfiles/pgbouncer/build_and_push.sh chart/dockerfiles/statsd-exporter/Dockerfile chart/dockerfiles/statsd-exporter/build_and_push.sh chart/requirements.lock chart/tests/__init__.py chart/tests/conftest.py chart/tests/helm_template_generator.py chart/tests/test_airflow_common.py chart/tests/test_annotations.py chart/tests/test_basic_helm_chart.py chart/tests/test_celery_kubernetes_executor.py chart/tests/test_chart_quality.py chart/tests/test_cleanup_pods.py chart/tests/test_configmap.py chart/tests/test_create_user_job.py chart/tests/test_dags_persistent_volume_claim.py chart/tests/test_elasticsearch_secret.py chart/tests/test_extra_configmaps_secrets.py chart/tests/test_extra_env_env_from.py chart/tests/test_flower.py chart/tests/test_git_sync_scheduler.py chart/tests/test_git_sync_webserver.py chart/tests/test_git_sync_worker.py chart/tests/test_ingress_flower.py chart/tests/test_ingress_web.py chart/tests/test_keda.py chart/tests/test_kerberos.py chart/tests/test_limit_ranges.py chart/tests/test_logs_persistent_volume_claim.py chart/tests/test_metadata_connection_secret.py chart/tests/test_migrate_database_job.py chart/tests/test_pgbouncer.py chart/tests/test_pod_launcher_role.py chart/tests/test_pod_template_file.py chart/tests/test_rbac.py chart/tests/test_redis.py chart/tests/test_resource_quota.py chart/tests/test_result_backend_connection_secret.py chart/tests/test_scheduler.py chart/tests/test_statsd.py chart/tests/test_webserver.py chart/tests/test_worker.py chart/values.schema.json chart/values_schema.schema.json clients/gen/common.sh clients/gen/go.sh clients/gen/python.sh confirm dags/test_dag.py dev/__init__.py dev/airflow-github dev/airflow-license dev/check_files.py dev/import_all_classes.py dev/provider_packages/MANIFEST_TEMPLATE.in.jinja2 dev/provider_packages/PROVIDER_COMMITS_TEMPLATE.rst.jinja2 dev/provider_packages/PROVIDER_INDEX_TEMPLATE.rst.jinja2 dev/provider_packages/PROVIDER_README_TEMPLATE.rst.jinja2 dev/provider_packages/SETUP_TEMPLATE.cfg.jinja2 dev/provider_packages/SETUP_TEMPLATE.py.jinja2 dev/provider_packages/__init__.py dev/provider_packages/build_provider_documentation.sh dev/provider_packages/enter_breeze_provider_package_tests.sh dev/provider_packages/get_provider_info_TEMPLATE.py.jinja2 dev/provider_packages/prepare_provider_packages.py dev/provider_packages/publish_provider_documentation.sh dev/provider_packages/remove_old_releases.py dev/provider_packages/tag_providers.sh dev/remove_artifacts.sh dev/retag_docker_images.py dev/send_email.py dev/sign.sh dev/templates/announce_email.j2 dev/templates/result_email.j2 dev/templates/slack.j2 dev/templates/twitter.j2 dev/templates/vote_email.j2 docs/README.rst docs/apache-airflow-providers-airbyte/commits.rst docs/apache-airflow-providers-airbyte/connections.rst docs/apache-airflow-providers-airbyte/index.rst docs/apache-airflow-providers-airbyte/operators/airbyte.rst docs/apache-airflow-providers-amazon/commits.rst docs/apache-airflow-providers-amazon/connections/aws.rst docs/apache-airflow-providers-amazon/index.rst docs/apache-airflow-providers-amazon/logging/cloud-watch-task-handlers.rst docs/apache-airflow-providers-amazon/logging/index.rst docs/apache-airflow-providers-amazon/logging/s3-task-handler.rst docs/apache-airflow-providers-amazon/operators/_partials/prerequisite_tasks.rst docs/apache-airflow-providers-amazon/operators/datasync.rst docs/apache-airflow-providers-amazon/operators/ecs.rst docs/apache-airflow-providers-amazon/operators/emr.rst docs/apache-airflow-providers-amazon/operators/glacier.rst docs/apache-airflow-providers-amazon/operators/google_api_to_s3_transfer.rst docs/apache-airflow-providers-amazon/operators/imap_attachment_to_s3.rst docs/apache-airflow-providers-amazon/operators/index.rst docs/apache-airflow-providers-amazon/operators/s3.rst docs/apache-airflow-providers-amazon/operators/s3_to_redshift.rst docs/apache-airflow-providers-amazon/operators/transfer/glacier_to_gcs.rst docs/apache-airflow-providers-amazon/operators/transfer/index.rst docs/apache-airflow-providers-amazon/secrets-backends/aws-secrets-manager.rst docs/apache-airflow-providers-amazon/secrets-backends/aws-ssm-parameter-store.rst docs/apache-airflow-providers-amazon/secrets-backends/index.rst docs/apache-airflow-providers-apache-beam/commits.rst docs/apache-airflow-providers-apache-beam/index.rst docs/apache-airflow-providers-apache-beam/operators.rst docs/apache-airflow-providers-apache-cassandra/commits.rst docs/apache-airflow-providers-apache-cassandra/connections/cassandra.rst docs/apache-airflow-providers-apache-cassandra/index.rst docs/apache-airflow-providers-apache-cassandra/operators.rst docs/apache-airflow-providers-apache-druid/commits.rst docs/apache-airflow-providers-apache-druid/index.rst docs/apache-airflow-providers-apache-hdfs/commits.rst docs/apache-airflow-providers-apache-hdfs/connections.rst docs/apache-airflow-providers-apache-hdfs/index.rst docs/apache-airflow-providers-apache-hdfs/operators.rst docs/apache-airflow-providers-apache-hive/commits.rst docs/apache-airflow-providers-apache-hive/connections/hive_cli.rst docs/apache-airflow-providers-apache-hive/connections/hive_metastore.rst docs/apache-airflow-providers-apache-hive/connections/hiveserver2.rst docs/apache-airflow-providers-apache-hive/connections/index.rst docs/apache-airflow-providers-apache-hive/index.rst docs/apache-airflow-providers-apache-kylin/commits.rst docs/apache-airflow-providers-apache-kylin/index.rst docs/apache-airflow-providers-apache-livy/commits.rst docs/apache-airflow-providers-apache-livy/index.rst docs/apache-airflow-providers-apache-pig/commits.rst docs/apache-airflow-providers-apache-pig/index.rst docs/apache-airflow-providers-apache-pinot/commits.rst docs/apache-airflow-providers-apache-pinot/index.rst docs/apache-airflow-providers-apache-spark/commits.rst docs/apache-airflow-providers-apache-spark/connections/spark.rst docs/apache-airflow-providers-apache-spark/index.rst docs/apache-airflow-providers-apache-spark/operators.rst docs/apache-airflow-providers-apache-sqoop/commits.rst docs/apache-airflow-providers-apache-sqoop/index.rst docs/apache-airflow-providers-asana/commits.rst docs/apache-airflow-providers-asana/connections/asana.rst docs/apache-airflow-providers-asana/index.rst docs/apache-airflow-providers-asana/operators/asana.rst docs/apache-airflow-providers-celery/commits.rst docs/apache-airflow-providers-celery/index.rst docs/apache-airflow-providers-cloudant/commits.rst docs/apache-airflow-providers-cloudant/index.rst docs/apache-airflow-providers-cncf-kubernetes/commits.rst docs/apache-airflow-providers-cncf-kubernetes/connections/kubernetes.rst docs/apache-airflow-providers-cncf-kubernetes/index.rst docs/apache-airflow-providers-cncf-kubernetes/operators.rst docs/apache-airflow-providers-databricks/commits.rst docs/apache-airflow-providers-databricks/connections/databricks.rst docs/apache-airflow-providers-databricks/index.rst docs/apache-airflow-providers-databricks/operators.rst docs/apache-airflow-providers-datadog/commits.rst docs/apache-airflow-providers-datadog/index.rst docs/apache-airflow-providers-dingding/commits.rst docs/apache-airflow-providers-dingding/index.rst docs/apache-airflow-providers-dingding/operators.rst docs/apache-airflow-providers-discord/commits.rst docs/apache-airflow-providers-discord/index.rst docs/apache-airflow-providers-docker/commits.rst docs/apache-airflow-providers-docker/connections/docker.rst docs/apache-airflow-providers-docker/index.rst docs/apache-airflow-providers-elasticsearch/commits.rst docs/apache-airflow-providers-elasticsearch/index.rst docs/apache-airflow-providers-elasticsearch/logging.rst docs/apache-airflow-providers-exasol/commits.rst docs/apache-airflow-providers-exasol/index.rst docs/apache-airflow-providers-facebook/commits.rst docs/apache-airflow-providers-facebook/index.rst docs/apache-airflow-providers-ftp/commits.rst docs/apache-airflow-providers-ftp/connections/ftp.rst docs/apache-airflow-providers-ftp/index.rst docs/apache-airflow-providers-google/api-auth-backend/google-openid.rst docs/apache-airflow-providers-google/commits.rst docs/apache-airflow-providers-google/configurations-ref.rst docs/apache-airflow-providers-google/connections/gcp.rst docs/apache-airflow-providers-google/connections/gcp_sql.rst docs/apache-airflow-providers-google/connections/gcp_ssh.rst docs/apache-airflow-providers-google/connections/index.rst docs/apache-airflow-providers-google/example-dags.rst docs/apache-airflow-providers-google/index.rst docs/apache-airflow-providers-google/logging/gcs.rst docs/apache-airflow-providers-google/logging/index.rst docs/apache-airflow-providers-google/logging/stackdriver.rst docs/apache-airflow-providers-google/operators/_partials/prerequisite_tasks.rst docs/apache-airflow-providers-google/operators/ads.rst docs/apache-airflow-providers-google/operators/cloud/automl.rst docs/apache-airflow-providers-google/operators/cloud/bigquery.rst docs/apache-airflow-providers-google/operators/cloud/bigquery_dts.rst docs/apache-airflow-providers-google/operators/cloud/bigtable.rst docs/apache-airflow-providers-google/operators/cloud/cloud_build.rst docs/apache-airflow-providers-google/operators/cloud/cloud_memorystore.rst docs/apache-airflow-providers-google/operators/cloud/cloud_memorystore_memcached.rst docs/apache-airflow-providers-google/operators/cloud/cloud_sql.rst docs/apache-airflow-providers-google/operators/cloud/cloud_storage_transfer_service.rst docs/apache-airflow-providers-google/operators/cloud/compute.rst docs/apache-airflow-providers-google/operators/cloud/compute_ssh.rst docs/apache-airflow-providers-google/operators/cloud/data_loss_prevention.rst docs/apache-airflow-providers-google/operators/cloud/datacatalog.rst docs/apache-airflow-providers-google/operators/cloud/dataflow.rst docs/apache-airflow-providers-google/operators/cloud/datafusion.rst docs/apache-airflow-providers-google/operators/cloud/dataprep.rst docs/apache-airflow-providers-google/operators/cloud/dataproc.rst docs/apache-airflow-providers-google/operators/cloud/datastore.rst docs/apache-airflow-providers-google/operators/cloud/functions.rst docs/apache-airflow-providers-google/operators/cloud/gcs.rst docs/apache-airflow-providers-google/operators/cloud/index.rst docs/apache-airflow-providers-google/operators/cloud/kubernetes_engine.rst docs/apache-airflow-providers-google/operators/cloud/life_sciences.rst docs/apache-airflow-providers-google/operators/cloud/mlengine.rst docs/apache-airflow-providers-google/operators/cloud/natural_language.rst docs/apache-airflow-providers-google/operators/cloud/pubsub.rst docs/apache-airflow-providers-google/operators/cloud/spanner.rst docs/apache-airflow-providers-google/operators/cloud/speech_to_text.rst docs/apache-airflow-providers-google/operators/cloud/stackdriver.rst docs/apache-airflow-providers-google/operators/cloud/text_to_speech.rst docs/apache-airflow-providers-google/operators/cloud/translate.rst docs/apache-airflow-providers-google/operators/cloud/translate_speech.rst docs/apache-airflow-providers-google/operators/cloud/video_intelligence.rst docs/apache-airflow-providers-google/operators/cloud/vision.rst docs/apache-airflow-providers-google/operators/cloud/workflows.rst docs/apache-airflow-providers-google/operators/firebase/firestore.rst docs/apache-airflow-providers-google/operators/index.rst docs/apache-airflow-providers-google/operators/leveldb/leveldb.rst docs/apache-airflow-providers-google/operators/marketing_platform/analytics.rst docs/apache-airflow-providers-google/operators/marketing_platform/campaign_manager.rst docs/apache-airflow-providers-google/operators/marketing_platform/display_video.rst docs/apache-airflow-providers-google/operators/marketing_platform/index.rst docs/apache-airflow-providers-google/operators/marketing_platform/search_ads.rst docs/apache-airflow-providers-google/operators/suite/sheets.rst docs/apache-airflow-providers-google/operators/transfer/azure_fileshare_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/facebook_ads_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/gcs_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/gcs_to_gdrive.rst docs/apache-airflow-providers-google/operators/transfer/gcs_to_local.rst docs/apache-airflow-providers-google/operators/transfer/gcs_to_sftp.rst docs/apache-airflow-providers-google/operators/transfer/gcs_to_sheets.rst docs/apache-airflow-providers-google/operators/transfer/gdrive_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/gdrive_to_local.rst docs/apache-airflow-providers-google/operators/transfer/index.rst docs/apache-airflow-providers-google/operators/transfer/local_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/mysql_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/oracle_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/presto_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/s3_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/salesforce_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/sftp_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/sheets_to_gcs.rst docs/apache-airflow-providers-google/operators/transfer/trino_to_gcs.rst docs/apache-airflow-providers-google/secrets-backends/google-cloud-secret-manager-backend.rst docs/apache-airflow-providers-grpc/commits.rst docs/apache-airflow-providers-grpc/connections/grpc.rst docs/apache-airflow-providers-grpc/index.rst docs/apache-airflow-providers-hashicorp/commits.rst docs/apache-airflow-providers-hashicorp/index.rst docs/apache-airflow-providers-hashicorp/secrets-backends/hashicorp-vault.rst docs/apache-airflow-providers-http/commits.rst docs/apache-airflow-providers-http/connections/http.rst docs/apache-airflow-providers-http/index.rst docs/apache-airflow-providers-http/operators.rst docs/apache-airflow-providers-imap/commits.rst docs/apache-airflow-providers-imap/connections/imap.rst docs/apache-airflow-providers-imap/index.rst docs/apache-airflow-providers-jdbc/commits.rst docs/apache-airflow-providers-jdbc/connections/jdbc.rst docs/apache-airflow-providers-jdbc/index.rst docs/apache-airflow-providers-jdbc/operators.rst docs/apache-airflow-providers-jenkins/commits.rst docs/apache-airflow-providers-jenkins/index.rst docs/apache-airflow-providers-jira/commits.rst docs/apache-airflow-providers-jira/index.rst docs/apache-airflow-providers-microsoft-azure/commits.rst docs/apache-airflow-providers-microsoft-azure/connections/acr.rst docs/apache-airflow-providers-microsoft-azure/connections/adf.rst docs/apache-airflow-providers-microsoft-azure/connections/adl.rst docs/apache-airflow-providers-microsoft-azure/connections/adx.rst docs/apache-airflow-providers-microsoft-azure/connections/azure.rst docs/apache-airflow-providers-microsoft-azure/connections/azure_batch.rst docs/apache-airflow-providers-microsoft-azure/connections/azure_cosmos.rst docs/apache-airflow-providers-microsoft-azure/connections/index.rst docs/apache-airflow-providers-microsoft-azure/connections/wasb.rst docs/apache-airflow-providers-microsoft-azure/index.rst docs/apache-airflow-providers-microsoft-azure/logging.rst docs/apache-airflow-providers-microsoft-azure/operators/_partials/prerequisite_tasks.rst docs/apache-airflow-providers-microsoft-azure/operators/adls.rst docs/apache-airflow-providers-microsoft-azure/operators/azure_blob_to_gcs.rst docs/apache-airflow-providers-microsoft-azure/operators/index.rst docs/apache-airflow-providers-microsoft-azure/operators/local_to_adls.rst docs/apache-airflow-providers-microsoft-azure/secrets-backends/azure-key-vault.rst docs/apache-airflow-providers-microsoft-mssql/commits.rst docs/apache-airflow-providers-microsoft-mssql/index.rst docs/apache-airflow-providers-microsoft-winrm/commits.rst docs/apache-airflow-providers-microsoft-winrm/index.rst docs/apache-airflow-providers-mongo/commits.rst docs/apache-airflow-providers-mongo/connections/mongo.rst docs/apache-airflow-providers-mongo/index.rst docs/apache-airflow-providers-mysql/commits.rst docs/apache-airflow-providers-mysql/connections/mysql.rst docs/apache-airflow-providers-mysql/index.rst docs/apache-airflow-providers-mysql/operators.rst docs/apache-airflow-providers-neo4j/commits.rst docs/apache-airflow-providers-neo4j/connections/neo4j.rst docs/apache-airflow-providers-neo4j/index.rst docs/apache-airflow-providers-neo4j/operators/neo4j.rst docs/apache-airflow-providers-odbc/commits.rst docs/apache-airflow-providers-odbc/connections/odbc.rst docs/apache-airflow-providers-odbc/index.rst docs/apache-airflow-providers-openfaas/commits.rst docs/apache-airflow-providers-openfaas/index.rst docs/apache-airflow-providers-opsgenie/commits.rst docs/apache-airflow-providers-opsgenie/index.rst docs/apache-airflow-providers-oracle/commits.rst docs/apache-airflow-providers-oracle/connections/oracle.rst docs/apache-airflow-providers-oracle/index.rst docs/apache-airflow-providers-pagerduty/commits.rst docs/apache-airflow-providers-pagerduty/index.rst docs/apache-airflow-providers-papermill/commits.rst docs/apache-airflow-providers-papermill/index.rst docs/apache-airflow-providers-papermill/operators.rst docs/apache-airflow-providers-plexus/commits.rst docs/apache-airflow-providers-plexus/index.rst docs/apache-airflow-providers-postgres/commits.rst docs/apache-airflow-providers-postgres/connections/postgres.rst docs/apache-airflow-providers-postgres/index.rst docs/apache-airflow-providers-postgres/operators/postgres_operator_howto_guide.rst docs/apache-airflow-providers-presto/commits.rst docs/apache-airflow-providers-presto/index.rst docs/apache-airflow-providers-qubole/commits.rst docs/apache-airflow-providers-qubole/index.rst docs/apache-airflow-providers-redis/commits.rst docs/apache-airflow-providers-redis/index.rst docs/apache-airflow-providers-salesforce/commits.rst docs/apache-airflow-providers-salesforce/connections/salesforce.rst docs/apache-airflow-providers-salesforce/index.rst docs/apache-airflow-providers-samba/commits.rst docs/apache-airflow-providers-samba/index.rst docs/apache-airflow-providers-segment/commits.rst docs/apache-airflow-providers-segment/index.rst docs/apache-airflow-providers-sendgrid/commits.rst docs/apache-airflow-providers-sendgrid/index.rst docs/apache-airflow-providers-sftp/commits.rst docs/apache-airflow-providers-sftp/connections/sftp.rst docs/apache-airflow-providers-sftp/index.rst docs/apache-airflow-providers-singularity/commits.rst docs/apache-airflow-providers-singularity/index.rst docs/apache-airflow-providers-slack/commits.rst docs/apache-airflow-providers-slack/connections/slack.rst docs/apache-airflow-providers-slack/index.rst docs/apache-airflow-providers-snowflake/commits.rst docs/apache-airflow-providers-snowflake/connections/snowflake.rst docs/apache-airflow-providers-snowflake/index.rst docs/apache-airflow-providers-snowflake/operators/index.rst docs/apache-airflow-providers-snowflake/operators/s3_to_snowflake.rst docs/apache-airflow-providers-snowflake/operators/snowflake.rst docs/apache-airflow-providers-snowflake/operators/snowflake_to_slack.rst docs/apache-airflow-providers-sqlite/commits.rst docs/apache-airflow-providers-sqlite/connections/sqlite.rst docs/apache-airflow-providers-sqlite/index.rst docs/apache-airflow-providers-sqlite/operators.rst docs/apache-airflow-providers-ssh/commits.rst docs/apache-airflow-providers-ssh/connections/ssh.rst docs/apache-airflow-providers-ssh/index.rst docs/apache-airflow-providers-tableau/commits.rst docs/apache-airflow-providers-tableau/connections/tableau.rst docs/apache-airflow-providers-tableau/index.rst docs/apache-airflow-providers-telegram/commits.rst docs/apache-airflow-providers-telegram/index.rst docs/apache-airflow-providers-telegram/operators.rst docs/apache-airflow-providers-trino/commits.rst docs/apache-airflow-providers-trino/index.rst docs/apache-airflow-providers-vertica/commits.rst docs/apache-airflow-providers-vertica/index.rst docs/apache-airflow-providers-yandex/commits.rst docs/apache-airflow-providers-yandex/connections/yandexcloud.rst docs/apache-airflow-providers-yandex/index.rst docs/apache-airflow-providers-yandex/operators.rst docs/apache-airflow-providers-zendesk/commits.rst docs/apache-airflow-providers-zendesk/index.rst docs/apache-airflow-providers/howto/create-update-providers.rst docs/apache-airflow-providers/index.rst docs/apache-airflow-providers/operators-and-hooks-ref/apache.rst docs/apache-airflow-providers/operators-and-hooks-ref/aws.rst docs/apache-airflow-providers/operators-and-hooks-ref/azure.rst docs/apache-airflow-providers/operators-and-hooks-ref/google.rst docs/apache-airflow-providers/operators-and-hooks-ref/index.rst docs/apache-airflow-providers/operators-and-hooks-ref/protocol.rst docs/apache-airflow-providers/operators-and-hooks-ref/services.rst docs/apache-airflow-providers/operators-and-hooks-ref/software.rst docs/apache-airflow-providers/packages-ref.rst docs/apache-airflow/backport-providers.rst docs/apache-airflow/best-practices.rst docs/apache-airflow/changelog.rst docs/apache-airflow/cli-and-env-variables-ref.rst docs/apache-airflow/concepts/cluster-policies.rst docs/apache-airflow/concepts/connections.rst docs/apache-airflow/concepts/dags.rst docs/apache-airflow/concepts/index.rst docs/apache-airflow/concepts/operators.rst docs/apache-airflow/concepts/overview.rst docs/apache-airflow/concepts/pools.rst docs/apache-airflow/concepts/priority-weight.rst docs/apache-airflow/concepts/scheduler.rst docs/apache-airflow/concepts/sensors.rst docs/apache-airflow/concepts/smart-sensors.rst docs/apache-airflow/concepts/taskflow.rst docs/apache-airflow/concepts/tasks.rst docs/apache-airflow/concepts/variables.rst docs/apache-airflow/concepts/xcoms.rst docs/apache-airflow/configurations-ref.rst docs/apache-airflow/dag-run.rst docs/apache-airflow/dag-serialization.rst docs/apache-airflow/deprecated-rest-api-ref.rst docs/apache-airflow/executor/celery.rst docs/apache-airflow/executor/celery_kubernetes.rst docs/apache-airflow/executor/dask.rst docs/apache-airflow/executor/debug.rst docs/apache-airflow/executor/index.rst docs/apache-airflow/executor/kubernetes.rst docs/apache-airflow/executor/local.rst docs/apache-airflow/executor/sequential.rst docs/apache-airflow/extra-packages-ref.rst docs/apache-airflow/faq.rst docs/apache-airflow/howto/add-dag-tags.rst docs/apache-airflow/howto/connection.rst docs/apache-airflow/howto/custom-operator.rst docs/apache-airflow/howto/customize-dag-ui-page-instance-name.rst docs/apache-airflow/howto/customize-state-colors-ui.rst docs/apache-airflow/howto/define_extra_link.rst docs/apache-airflow/howto/email-config.rst docs/apache-airflow/howto/index.rst docs/apache-airflow/howto/operator/bash.rst docs/apache-airflow/howto/operator/datetime.rst docs/apache-airflow/howto/operator/external_task_sensor.rst docs/apache-airflow/howto/operator/index.rst docs/apache-airflow/howto/operator/python.rst docs/apache-airflow/howto/operator/weekday.rst docs/apache-airflow/howto/run-behind-proxy.rst docs/apache-airflow/howto/run-with-systemd.rst docs/apache-airflow/howto/run-with-upstart.rst docs/apache-airflow/howto/set-config.rst docs/apache-airflow/howto/set-up-database.rst docs/apache-airflow/howto/use-test-config.rst docs/apache-airflow/howto/variable.rst docs/apache-airflow/img/logos/wordmark_1.svg docs/apache-airflow/img/logos/wordmark_2.svg docs/apache-airflow/img/run_task_on_celery_executor.puml docs/apache-airflow/index.rst docs/apache-airflow/installation.rst docs/apache-airflow/integration.rst docs/apache-airflow/kubernetes.rst docs/apache-airflow/license.rst docs/apache-airflow/lineage.rst docs/apache-airflow/logging-monitoring/check-health.rst docs/apache-airflow/logging-monitoring/errors.rst docs/apache-airflow/logging-monitoring/index.rst docs/apache-airflow/logging-monitoring/logging-architecture.rst docs/apache-airflow/logging-monitoring/logging-tasks.rst docs/apache-airflow/logging-monitoring/metrics.rst docs/apache-airflow/logging-monitoring/tracking-user-activity.rst docs/apache-airflow/macros-ref.rst docs/apache-airflow/modules_management.rst docs/apache-airflow/operators-and-hooks-ref.rst docs/apache-airflow/plugins.rst docs/apache-airflow/privacy_notice.rst docs/apache-airflow/production-deployment.rst docs/apache-airflow/project.rst docs/apache-airflow/python-api-ref.rst docs/apache-airflow/release-process.rst docs/apache-airflow/security/access-control.rst docs/apache-airflow/security/api.rst docs/apache-airflow/security/flower.rst docs/apache-airflow/security/index.rst docs/apache-airflow/security/kerberos.rst docs/apache-airflow/security/secrets/fernet.rst docs/apache-airflow/security/secrets/index.rst docs/apache-airflow/security/secrets/secrets-backend/index.rst docs/apache-airflow/security/secrets/secrets-backend/local-filesystem-secrets-backend.rst docs/apache-airflow/security/webserver.rst docs/apache-airflow/security/workload.rst docs/apache-airflow/stable-rest-api-ref.rst docs/apache-airflow/start/airflow.sh docs/apache-airflow/start/docker.rst docs/apache-airflow/start/index.rst docs/apache-airflow/start/local.rst docs/apache-airflow/static/exampleinclude.css docs/apache-airflow/static/jira-links.js docs/apache-airflow/timezone.rst docs/apache-airflow/tutorial.rst docs/apache-airflow/tutorial_taskflow_api.rst docs/apache-airflow/ui.rst docs/apache-airflow/upgrade-check.rst docs/apache-airflow/upgrading-to-2.rst docs/apache-airflow/usage-cli.rst docs/build_docs.py docs/conf.py docs/docker-stack/build-arg-ref.rst docs/docker-stack/build.rst docs/docker-stack/docker-examples/customizing/add-build-essential-custom.sh docs/docker-stack/docker-examples/customizing/custom-sources.sh docs/docker-stack/docker-examples/customizing/github-different-repository.sh docs/docker-stack/docker-examples/customizing/github-master.sh docs/docker-stack/docker-examples/customizing/github-v2-1-test.sh docs/docker-stack/docker-examples/customizing/pypi-dev-runtime-deps.sh docs/docker-stack/docker-examples/customizing/pypi-extras-and-deps.sh docs/docker-stack/docker-examples/customizing/pypi-selected-version.sh docs/docker-stack/docker-examples/customizing/stable-airflow.sh docs/docker-stack/docker-examples/extending/add-apt-packages/Dockerfile docs/docker-stack/docker-examples/extending/add-build-essential-extend/Dockerfile docs/docker-stack/docker-examples/extending/add-pypi-packages/Dockerfile docs/docker-stack/docker-examples/extending/embedding-dags/Dockerfile docs/docker-stack/docker-examples/extending/embedding-dags/test_dag.py docs/docker-stack/docker-examples/extending/writable-directory/Dockerfile docs/docker-stack/docker-examples/restricted/restricted_environments.sh docs/docker-stack/docker-images-recipes/gcloud.Dockerfile docs/docker-stack/docker-images-recipes/hadoop.Dockerfile docs/docker-stack/entrypoint.rst docs/docker-stack/index.rst docs/docker-stack/recipes.rst docs/exts/__init__.py docs/exts/airflow_intersphinx.py docs/exts/docroles.py docs/exts/docs_build/__init__.py docs/exts/docs_build/code_utils.py docs/exts/docs_build/dev_index_generator.py docs/exts/docs_build/dev_index_template.html.jinja2 docs/exts/docs_build/docs_builder.py docs/exts/docs_build/errors.py docs/exts/docs_build/fetch_inventories.py docs/exts/docs_build/github_action_utils.py docs/exts/docs_build/lint_checks.py docs/exts/docs_build/package_filter.py docs/exts/docs_build/run_patched_sphinx.py docs/exts/docs_build/spelling_checks.py docs/exts/docs_build/third_party_inventories.py docs/exts/exampleinclude.py docs/exts/extra_files_with_substitutions.py docs/exts/operators_and_hooks_ref-transfers.rst.jinja2 docs/exts/operators_and_hooks_ref.py docs/exts/operators_and_hooks_ref.rst.jinja2 docs/exts/provider_init_hack.py docs/exts/provider_yaml_utils.py docs/exts/providers_packages_ref.py docs/exts/redirects.py docs/exts/removemarktransform.py docs/exts/sphinx_script_update.py docs/exts/substitution_extensions.py docs/helm-chart/adding-connections-and-variables.rst docs/helm-chart/airflow-configuration.rst docs/helm-chart/img/helm-logo.svg docs/helm-chart/index.rst docs/helm-chart/keda.rst docs/helm-chart/manage-dags-files.rst docs/helm-chart/manage-logs.rst docs/helm-chart/parameters-ref.rst docs/helm-chart/production-guide.rst docs/helm-chart/quick-start.rst docs/helm-chart/using-additional-containers.rst docs/integration-logos/azure/Azure Cosmos DB.svg docs/integration-logos/azure/Azure Data Factory.svg docs/integration-logos/azure/Azure Files.svg docs/integration-logos/azure/Blob Storage.svg docs/integration-logos/azure/Container Instances.svg docs/integration-logos/azure/Data Lake Storage.svg docs/list-roles.sh docs/publish_docs.py docs/rtd-deprecation/conf.py docs/rtd-deprecation/index.rst docs/start_doc_server.sh hooks/build hooks/push images/breeze/add_overlay.sh images/ci/pull_request_ci_flow.md5 images/ci/pull_request_ci_flow.mermaid images/ci/push_ci_flow.md5 images/ci/push_ci_flow.mermaid images/ci/scheduled_ci_flow.md5 images/ci/scheduled_ci_flow.mermaid images/pr/selective_checks.md5 images/pr/selective_checks.mermaid kubernetes_tests/__init__.py kubernetes_tests/test_base.py kubernetes_tests/test_kubernetes_executor.py kubernetes_tests/test_kubernetes_pod_operator.py kubernetes_tests/test_kubernetes_pod_operator_backcompat.py kubernetes_tests/test_other_executors.py license-templates/LICENSE.rst metastore_browser/hive_metastore.py provider_packages/.flake8 provider_packages/INSTALL provider_packages/LICENSE provider_packages/NOTICE provider_packages/dist provider_packages/pyproject.toml pylintrc pylintrc-tests pyproject.toml pytest.ini scripts/ci/build_airflow/ci_build_airflow_packages.sh scripts/ci/constraints/ci_branch_constraints.sh scripts/ci/constraints/ci_commit_constraints.sh scripts/ci/constraints/ci_generate_all_constraints.sh scripts/ci/constraints/ci_generate_constraints.sh scripts/ci/docker-compose/_docker.env scripts/ci/dockerfiles/apache-rat/Dockerfile scripts/ci/dockerfiles/apache-rat/build_and_push.sh scripts/ci/dockerfiles/bats/Dockerfile scripts/ci/dockerfiles/bats/build_and_push.sh scripts/ci/dockerfiles/bats/load.bash scripts/ci/dockerfiles/krb5-kdc-server/Dockerfile scripts/ci/dockerfiles/krb5-kdc-server/build_and_push.sh scripts/ci/dockerfiles/krb5-kdc-server/entrypoint.sh scripts/ci/dockerfiles/krb5-kdc-server/kadm5.acl scripts/ci/dockerfiles/krb5-kdc-server/kdc.conf scripts/ci/dockerfiles/krb5-kdc-server/krb5.conf scripts/ci/dockerfiles/krb5-kdc-server/supervisord.conf scripts/ci/dockerfiles/krb5-kdc-server/utils/create_admin.sh scripts/ci/dockerfiles/krb5-kdc-server/utils/create_client.sh scripts/ci/dockerfiles/krb5-kdc-server/utils/create_service.sh scripts/ci/dockerfiles/stress/Dockerfile scripts/ci/dockerfiles/stress/build_and_push.sh scripts/ci/dockerfiles/trino/Dockerfile scripts/ci/dockerfiles/trino/build_and_push.sh scripts/ci/dockerfiles/trino/entrypoint.sh scripts/ci/docs/ci_docs.sh scripts/ci/docs/ci_docs_prepare.sh scripts/ci/images/ci_build_dockerhub.sh scripts/ci/images/ci_prepare_ci_image_on_ci.sh scripts/ci/images/ci_prepare_prod_image_on_ci.sh scripts/ci/images/ci_push_ci_images.sh scripts/ci/images/ci_push_production_images.sh scripts/ci/images/ci_run_prod_image_test.sh scripts/ci/images/ci_test_examples_of_prod_image_building.sh scripts/ci/images/ci_wait_for_and_verify_all_ci_images.sh scripts/ci/images/ci_wait_for_and_verify_all_prod_images.sh scripts/ci/images/ci_wait_for_and_verify_ci_image.sh scripts/ci/images/ci_wait_for_and_verify_prod_image.sh scripts/ci/kubernetes/ci_run_kubernetes_tests.sh scripts/ci/kubernetes/ci_setup_cluster_and_deploy_airflow_to_kubernetes.sh scripts/ci/kubernetes/ci_setup_cluster_and_run_kubernetes_tests_single_job.sh scripts/ci/kubernetes/ci_setup_clusters_and_run_kubernetes_tests_in_parallel.sh scripts/ci/kubernetes/redeploy_airflow.sh scripts/ci/libraries/_all_libs.sh scripts/ci/libraries/_build_images.sh scripts/ci/libraries/_docker_engine_resources.sh scripts/ci/libraries/_initialization.sh scripts/ci/libraries/_kind.sh scripts/ci/libraries/_local_mounts.sh scripts/ci/libraries/_md5sum.sh scripts/ci/libraries/_parallel.sh scripts/ci/libraries/_parameters.sh scripts/ci/libraries/_permissions.sh scripts/ci/libraries/_push_pull_remove_images.sh scripts/ci/libraries/_pylint.sh scripts/ci/libraries/_repeats.sh scripts/ci/libraries/_runs.sh scripts/ci/libraries/_sanity_checks.sh scripts/ci/libraries/_script_init.sh scripts/ci/libraries/_spinner.sh scripts/ci/libraries/_start_end.sh scripts/ci/libraries/_testing.sh scripts/ci/libraries/_traps.sh scripts/ci/libraries/_verbosity.sh scripts/ci/libraries/_verify_image.sh scripts/ci/mysql/conf.d/airflow.cnf scripts/ci/openapi/client_codegen_diff.sh scripts/ci/openldap/ldif/01-users.example.com.ldif scripts/ci/openldap/ldif/02-groups.example.com.ldif scripts/ci/openldap/ldif/03-manager.example.com.ldif scripts/ci/openldap/ldif/04-rootdn.ldif scripts/ci/openldap/slapd.conf scripts/ci/pre_commit/pre_commit_bat_tests.sh scripts/ci/pre_commit/pre_commit_breeze_cmd_line.sh scripts/ci/pre_commit/pre_commit_build_providers_dependencies.sh scripts/ci/pre_commit/pre_commit_check_extras_have_providers.py scripts/ci/pre_commit/pre_commit_check_integrations.sh scripts/ci/pre_commit/pre_commit_check_license.sh scripts/ci/pre_commit/pre_commit_check_order_setup.py scripts/ci/pre_commit/pre_commit_check_pre_commit_hook_names.py scripts/ci/pre_commit/pre_commit_check_pre_commits.sh scripts/ci/pre_commit/pre_commit_check_provider_yaml_files.py scripts/ci/pre_commit/pre_commit_check_providers_init.sh scripts/ci/pre_commit/pre_commit_check_setup_extra_packages_ref.py scripts/ci/pre_commit/pre_commit_ci_build.sh scripts/ci/pre_commit/pre_commit_flake8.sh scripts/ci/pre_commit/pre_commit_helm_lint.sh scripts/ci/pre_commit/pre_commit_in_container_bats_test.sh scripts/ci/pre_commit/pre_commit_insert_extras.py scripts/ci/pre_commit/pre_commit_json_schema.py scripts/ci/pre_commit/pre_commit_lint_dockerfile.sh scripts/ci/pre_commit/pre_commit_local_yml_mounts.sh scripts/ci/pre_commit/pre_commit_mermaid.sh scripts/ci/pre_commit/pre_commit_mypy.sh scripts/ci/pre_commit/pre_commit_pylint.sh scripts/ci/pre_commit/pre_commit_setup_cfg_file.sh scripts/ci/pre_commit/pre_commit_sort_in_the_wild.sh scripts/ci/pre_commit/pre_commit_sort_spelling_wordlist.sh scripts/ci/pre_commit/pre_commit_yaml_to_cfg.py scripts/ci/provider_packages/ci_install_and_test_provider_packages.sh scripts/ci/provider_packages/ci_prepare_provider_documentation.sh scripts/ci/provider_packages/ci_prepare_provider_packages.sh scripts/ci/selective_ci_checks.sh scripts/ci/static_checks/bats_tests.sh scripts/ci/static_checks/check_license.sh scripts/ci/static_checks/flake8.sh scripts/ci/static_checks/helm_lint.sh scripts/ci/static_checks/in_container_bats_tests.sh scripts/ci/static_checks/lint_dockerfile.sh scripts/ci/static_checks/mypy.sh scripts/ci/static_checks/pylint.sh scripts/ci/static_checks/refresh_pylint_todo.sh scripts/ci/static_checks/run_basic_static_checks.sh scripts/ci/static_checks/run_static_checks.sh scripts/ci/static_checks/ui_lint.sh scripts/ci/static_checks/www_lint.sh scripts/ci/testing/ci_run_airflow_testing.sh scripts/ci/testing/ci_run_quarantined_tests.sh scripts/ci/testing/ci_run_single_airflow_test_in_docker.sh scripts/ci/tools/ci_clear_tmp.sh scripts/ci/tools/ci_fix_ownership.sh scripts/ci/tools/ci_free_space_on_ci.sh scripts/ci/tools/verify_docker_image.sh scripts/docker/common.sh scripts/docker/compile_www_assets.sh scripts/docker/install_additional_dependencies.sh scripts/docker/install_airflow.sh scripts/docker/install_airflow_from_branch_tip.sh scripts/docker/install_from_docker_context_files.sh scripts/docker/install_mysql.sh scripts/docker/install_pip_version.sh scripts/docker/load.bash scripts/in_container/_in_container_script_init.sh scripts/in_container/_in_container_utils.sh scripts/in_container/airflow_ci.cfg scripts/in_container/bin/install_aws.sh scripts/in_container/bin/install_az.sh scripts/in_container/bin/install_gcloud.sh scripts/in_container/bin/install_imgcat.sh scripts/in_container/bin/install_java.sh scripts/in_container/bin/install_kubectl.sh scripts/in_container/bin/install_terraform.sh scripts/in_container/bin/run_tmux scripts/in_container/check_environment.sh scripts/in_container/configure_environment.sh scripts/in_container/entrypoint_ci.sh scripts/in_container/entrypoint_exec.sh scripts/in_container/prod/airflow_scheduler_autorestart.sh scripts/in_container/prod/clean-logs.sh scripts/in_container/prod/entrypoint_prod.sh scripts/in_container/refresh_pylint_todo.sh scripts/in_container/run_anything.sh scripts/in_container/run_ci_tests.sh scripts/in_container/run_clear_tmp.sh scripts/in_container/run_docs_build.sh scripts/in_container/run_extract_tests.sh scripts/in_container/run_fix_ownership.sh scripts/in_container/run_flake8.sh scripts/in_container/run_generate_constraints.sh scripts/in_container/run_init_script.sh scripts/in_container/run_install_and_test_provider_packages.sh scripts/in_container/run_mypy.sh scripts/in_container/run_prepare_airflow_packages.sh scripts/in_container/run_prepare_provider_documentation.sh scripts/in_container/run_prepare_provider_packages.sh scripts/in_container/run_pylint.sh scripts/in_container/run_system_tests.sh scripts/in_container/run_tmux_welcome.sh scripts/in_container/stop_tmux_airflow.sh scripts/in_container/update_quarantined_test_status.py scripts/systemd/README scripts/systemd/airflow scripts/systemd/airflow-flower.service scripts/systemd/airflow-kerberos.service scripts/systemd/airflow-scheduler.service scripts/systemd/airflow-webserver.service scripts/systemd/airflow-worker.service scripts/systemd/airflow.conf scripts/tools/generate-integrations-json.py scripts/tools/list-integrations.py scripts/upstart/README scripts/upstart/airflow-flower.conf scripts/upstart/airflow-scheduler.conf scripts/upstart/airflow-webserver.conf scripts/upstart/airflow-worker.conf setup.cfg setup.py tests/__init__.py tests/always/test_example_dags.py tests/always/test_project_structure.py tests/api/__init__.py tests/api/auth/__init__.py tests/api/auth/backend/__init__.py tests/api/auth/backend/test_basic_auth.py tests/api/auth/backend/test_kerberos_auth.py tests/api/auth/test_client.py tests/api/client/__init__.py tests/api/client/test_local_client.py tests/api/common/__init__.py tests/api/common/experimental/__init__.py tests/api/common/experimental/test_delete_dag.py tests/api/common/experimental/test_mark_tasks.py tests/api/common/experimental/test_pool.py tests/api/common/experimental/test_trigger_dag.py tests/api/conftest.py tests/api_connexion/__init__.py tests/api_connexion/conftest.py tests/api_connexion/endpoints/__init__.py tests/api_connexion/endpoints/test_config_endpoint.py tests/api_connexion/endpoints/test_connection_endpoint.py tests/api_connexion/endpoints/test_dag_endpoint.py tests/api_connexion/endpoints/test_dag_run_endpoint.py tests/api_connexion/endpoints/test_dag_source_endpoint.py tests/api_connexion/endpoints/test_event_log_endpoint.py tests/api_connexion/endpoints/test_extra_link_endpoint.py tests/api_connexion/endpoints/test_health_endpoint.py tests/api_connexion/endpoints/test_import_error_endpoint.py tests/api_connexion/endpoints/test_log_endpoint.py tests/api_connexion/endpoints/test_plugin_endpoint.py tests/api_connexion/endpoints/test_pool_endpoint.py tests/api_connexion/endpoints/test_provider_endpoint.py tests/api_connexion/endpoints/test_role_and_permission_endpoint.py tests/api_connexion/endpoints/test_task_endpoint.py tests/api_connexion/endpoints/test_task_instance_endpoint.py tests/api_connexion/endpoints/test_user_endpoint.py tests/api_connexion/endpoints/test_variable_endpoint.py tests/api_connexion/endpoints/test_version_endpoint.py tests/api_connexion/endpoints/test_xcom_endpoint.py tests/api_connexion/schemas/__init__.py tests/api_connexion/schemas/test_common_schema.py tests/api_connexion/schemas/test_config_schema.py tests/api_connexion/schemas/test_connection_schema.py tests/api_connexion/schemas/test_dag_run_schema.py tests/api_connexion/schemas/test_dag_schema.py tests/api_connexion/schemas/test_error_schema.py tests/api_connexion/schemas/test_event_log_schema.py tests/api_connexion/schemas/test_health_schema.py tests/api_connexion/schemas/test_plugin_schema.py tests/api_connexion/schemas/test_pool_schemas.py tests/api_connexion/schemas/test_role_and_permission_schema.py tests/api_connexion/schemas/test_task_instance_schema.py tests/api_connexion/schemas/test_task_schema.py tests/api_connexion/schemas/test_user_schema.py tests/api_connexion/schemas/test_version_schema.py tests/api_connexion/schemas/test_xcom_schema.py tests/api_connexion/test_basic_auth.py tests/api_connexion/test_error_handling.py tests/api_connexion/test_parameters.py tests/api_connexion/test_security.py tests/bats/bats_utils.bash tests/bats/breeze/test_breeze_complete.bats tests/bats/breeze/test_breeze_params.bats tests/bats/ci/libraries/_local_mounts.bats tests/bats/in_container/test_in_container.bats tests/bats/mocks/docker.sh tests/bats/mocks/helm.sh tests/bats/mocks/kind.sh tests/bats/mocks/kubectl.sh tests/build_provider_packages_dependencies.py tests/cli/__init__.py tests/cli/commands/__init__.py tests/cli/commands/test_celery_command.py tests/cli/commands/test_cheat_sheet_command.py tests/cli/commands/test_config_command.py tests/cli/commands/test_connection_command.py tests/cli/commands/test_dag_command.py tests/cli/commands/test_db_command.py tests/cli/commands/test_info_command.py tests/cli/commands/test_jobs_command.py tests/cli/commands/test_kubernetes_command.py tests/cli/commands/test_legacy_commands.py tests/cli/commands/test_plugins_command.py tests/cli/commands/test_pool_command.py tests/cli/commands/test_role_command.py tests/cli/commands/test_scheduler_command.py tests/cli/commands/test_sync_perm_command.py tests/cli/commands/test_task_command.py tests/cli/commands/test_user_command.py tests/cli/commands/test_variable_command.py tests/cli/commands/test_version_command.py tests/cli/commands/test_webserver_command.py tests/cli/conftest.py tests/cli/test_cli_parser.py tests/cluster_policies/__init__.py tests/conftest.py tests/core/test_config_templates.py tests/core/test_configuration.py tests/core/test_core.py tests/core/test_core_to_contrib.py tests/core/test_example_dags_system.py tests/core/test_impersonation_tests.py tests/core/test_logging_config.py tests/core/test_providers_manager.py tests/core/test_sentry.py tests/core/test_settings.py tests/core/test_sqlalchemy_config.py tests/core/test_stats.py tests/core/test_templates.py tests/dags/.airflowignore tests/dags/no_dags.py tests/dags/subdir1/.airflowignore tests/dags/subdir1/test_ignore_this.py tests/dags/subdir2/test_dont_ignore_this.py tests/dags/test_clear_subdag.py tests/dags/test_cli_triggered_dags.py tests/dags/test_dag_with_no_tags.py tests/dags/test_default_impersonation.py tests/dags/test_default_views.py tests/dags/test_double_trigger.py tests/dags/test_example_bash_operator.py tests/dags/test_heartbeat_failed_fast.py tests/dags/test_impersonation.py tests/dags/test_impersonation_subdag.py tests/dags/test_invalid_cron.py tests/dags/test_issue_1225.py tests/dags/test_latest_runs.py tests/dags/test_logging_in_dag.py tests/dags/test_mark_success.py tests/dags/test_miscellaneous.py tests/dags/test_missing_owner.py tests/dags/test_multiple_dags.py tests/dags/test_no_impersonation.py tests/dags/test_on_failure_callback.py tests/dags/test_on_kill.py tests/dags/test_only_dummy_tasks.py tests/dags/test_prev_dagrun_dep.py tests/dags/test_retry_handling_job.py tests/dags/test_scheduler_dags.py tests/dags/test_subdag.py tests/dags/test_task_view_type_check.py tests/dags/test_with_non_default_owner.py tests/dags/test_zip.zip tests/dags/test_zip_invalid_cron.zip tests/dags_corrupted/test_impersonation_custom.py tests/dags_with_system_exit/a_system_exit.py tests/dags_with_system_exit/b_test_scheduler_dags.py tests/dags_with_system_exit/c_system_exit.py tests/decorators/__init__.py tests/decorators/test_python.py tests/decorators/test_python_virtualenv.py tests/deprecated_classes.py tests/executors/__init__.py tests/executors/test_base_executor.py tests/executors/test_celery_executor.py tests/executors/test_celery_kubernetes_executor.py tests/executors/test_dask_executor.py tests/executors/test_debug_executor.py tests/executors/test_executor_loader.py tests/executors/test_kubernetes_executor.py tests/executors/test_local_executor.py tests/executors/test_sequential_executor.py tests/hooks/__init__.py tests/hooks/test_dbapi.py tests/hooks/test_subprocess.py tests/jobs/__init__.py tests/jobs/test_backfill_job.py tests/jobs/test_base_job.py tests/jobs/test_local_task_job.py tests/jobs/test_scheduler_job.py tests/kubernetes/__init__.py tests/kubernetes/models/__init__.py tests/kubernetes/models/test_secret.py tests/kubernetes/test_client.py tests/kubernetes/test_pod_generator.py tests/kubernetes/test_refresh_config.py tests/lineage/__init__.py tests/lineage/test_lineage.py tests/macros/__init__.py tests/macros/test_hive.py tests/models/__init__.py tests/models/test_baseoperator.py tests/models/test_cleartasks.py tests/models/test_connection.py tests/models/test_dag.py tests/models/test_dagbag.py tests/models/test_dagcode.py tests/models/test_dagparam.py tests/models/test_dagrun.py tests/models/test_pool.py tests/models/test_renderedtifields.py tests/models/test_sensorinstance.py tests/models/test_serialized_dag.py tests/models/test_skipmixin.py tests/models/test_taskinstance.py tests/models/test_timestamp.py tests/models/test_variable.py tests/models/test_xcom.py tests/models/test_xcom_arg.py tests/operators/__init__.py tests/operators/test_bash.py tests/operators/test_branch_operator.py tests/operators/test_datetime.py tests/operators/test_email.py tests/operators/test_generic_transfer.py tests/operators/test_latest_only_operator.py tests/operators/test_python.py tests/operators/test_sql.py tests/operators/test_subdag_operator.py tests/operators/test_trigger_dagrun.py tests/operators/test_weekday.py tests/plugins/__init__.py tests/plugins/test_plugin.py tests/plugins/test_plugin_ignore.py tests/plugins/test_plugins_manager.py tests/providers/__init__.py tests/providers/airbyte/__init__.py tests/providers/airbyte/hooks/__init__.py tests/providers/airbyte/hooks/test_airbyte.py tests/providers/airbyte/operators/__init__.py tests/providers/airbyte/operators/test_airbyte.py tests/providers/airbyte/sensors/__init__.py tests/providers/airbyte/sensors/test_airbyte.py tests/providers/amazon/__init__.py tests/providers/amazon/aws/__init__.py tests/providers/amazon/aws/config_templates/args.json tests/providers/amazon/aws/config_templates/job.j2.json tests/providers/amazon/aws/config_templates/steps.j2.json tests/providers/amazon/aws/config_templates/steps.json tests/providers/amazon/aws/hooks/__init__.py tests/providers/amazon/aws/hooks/conftest.py tests/providers/amazon/aws/hooks/test_athena.py tests/providers/amazon/aws/hooks/test_base_aws.py tests/providers/amazon/aws/hooks/test_base_aws_system.py tests/providers/amazon/aws/hooks/test_batch_client.py tests/providers/amazon/aws/hooks/test_batch_waiters.py tests/providers/amazon/aws/hooks/test_cloud_formation.py tests/providers/amazon/aws/hooks/test_datasync.py tests/providers/amazon/aws/hooks/test_dynamodb.py tests/providers/amazon/aws/hooks/test_ec2.py tests/providers/amazon/aws/hooks/test_elasticache_replication_group.py tests/providers/amazon/aws/hooks/test_emr.py tests/providers/amazon/aws/hooks/test_glacier.py tests/providers/amazon/aws/hooks/test_glue.py tests/providers/amazon/aws/hooks/test_glue_catalog.py tests/providers/amazon/aws/hooks/test_glue_crawler.py tests/providers/amazon/aws/hooks/test_kinesis.py tests/providers/amazon/aws/hooks/test_lambda_function.py tests/providers/amazon/aws/hooks/test_logs.py tests/providers/amazon/aws/hooks/test_redshift.py tests/providers/amazon/aws/hooks/test_s3.py tests/providers/amazon/aws/hooks/test_sagemaker.py tests/providers/amazon/aws/hooks/test_secrets_manager.py tests/providers/amazon/aws/hooks/test_ses.py tests/providers/amazon/aws/hooks/test_sns.py tests/providers/amazon/aws/hooks/test_sqs.py tests/providers/amazon/aws/hooks/test_step_function.py tests/providers/amazon/aws/infrastructure/example_s3_to_redshift/outputs.tf tests/providers/amazon/aws/infrastructure/example_s3_to_redshift/resources.tf tests/providers/amazon/aws/infrastructure/example_s3_to_redshift/variables.tf tests/providers/amazon/aws/log/__init__.py tests/providers/amazon/aws/log/test_cloudwatch_task_handler.py tests/providers/amazon/aws/log/test_s3_task_handler.py tests/providers/amazon/aws/operators/__init__.py tests/providers/amazon/aws/operators/test_athena.py tests/providers/amazon/aws/operators/test_batch.py tests/providers/amazon/aws/operators/test_cloud_formation.py tests/providers/amazon/aws/operators/test_datasync.py tests/providers/amazon/aws/operators/test_ec2_start_instance.py tests/providers/amazon/aws/operators/test_ec2_stop_instance.py tests/providers/amazon/aws/operators/test_ecs.py tests/providers/amazon/aws/operators/test_ecs_system.py tests/providers/amazon/aws/operators/test_emr_add_steps.py tests/providers/amazon/aws/operators/test_emr_create_job_flow.py tests/providers/amazon/aws/operators/test_emr_modify_cluster.py tests/providers/amazon/aws/operators/test_emr_system.py tests/providers/amazon/aws/operators/test_emr_terminate_job_flow.py tests/providers/amazon/aws/operators/test_example_s3_bucket.py tests/providers/amazon/aws/operators/test_glacier.py tests/providers/amazon/aws/operators/test_glacier_system.py tests/providers/amazon/aws/operators/test_glue.py tests/providers/amazon/aws/operators/test_glue_crawler.py tests/providers/amazon/aws/operators/test_s3_bucket.py tests/providers/amazon/aws/operators/test_s3_bucket_tagging.py tests/providers/amazon/aws/operators/test_s3_bucket_tagging_system.py tests/providers/amazon/aws/operators/test_s3_copy_object.py tests/providers/amazon/aws/operators/test_s3_delete_objects.py tests/providers/amazon/aws/operators/test_s3_file_transform.py tests/providers/amazon/aws/operators/test_s3_list.py tests/providers/amazon/aws/operators/test_sagemaker_base.py tests/providers/amazon/aws/operators/test_sagemaker_endpoint.py tests/providers/amazon/aws/operators/test_sagemaker_endpoint_config.py tests/providers/amazon/aws/operators/test_sagemaker_model.py tests/providers/amazon/aws/operators/test_sagemaker_processing.py tests/providers/amazon/aws/operators/test_sagemaker_training.py tests/providers/amazon/aws/operators/test_sagemaker_transform.py tests/providers/amazon/aws/operators/test_sagemaker_tuning.py tests/providers/amazon/aws/operators/test_sns.py tests/providers/amazon/aws/operators/test_sqs.py tests/providers/amazon/aws/operators/test_step_function_get_execution_output.py tests/providers/amazon/aws/operators/test_step_function_start_execution.py tests/providers/amazon/aws/secrets/test_secrets_manager.py tests/providers/amazon/aws/secrets/test_systems_manager.py tests/providers/amazon/aws/sensors/__init__.py tests/providers/amazon/aws/sensors/test_athena.py tests/providers/amazon/aws/sensors/test_cloud_formation.py tests/providers/amazon/aws/sensors/test_ec2_instance_state.py tests/providers/amazon/aws/sensors/test_emr_base.py tests/providers/amazon/aws/sensors/test_emr_job_flow.py tests/providers/amazon/aws/sensors/test_emr_step.py tests/providers/amazon/aws/sensors/test_glacier.py tests/providers/amazon/aws/sensors/test_glue.py tests/providers/amazon/aws/sensors/test_glue_catalog_partition.py tests/providers/amazon/aws/sensors/test_glue_crawler.py tests/providers/amazon/aws/sensors/test_redshift.py tests/providers/amazon/aws/sensors/test_s3_key.py tests/providers/amazon/aws/sensors/test_s3_keys_unchanged.py tests/providers/amazon/aws/sensors/test_s3_prefix.py tests/providers/amazon/aws/sensors/test_sagemaker_base.py tests/providers/amazon/aws/sensors/test_sagemaker_endpoint.py tests/providers/amazon/aws/sensors/test_sagemaker_training.py tests/providers/amazon/aws/sensors/test_sagemaker_transform.py tests/providers/amazon/aws/sensors/test_sagemaker_tuning.py tests/providers/amazon/aws/sensors/test_sqs.py tests/providers/amazon/aws/sensors/test_step_function_execution.py tests/providers/amazon/aws/transfers/__init__.py tests/providers/amazon/aws/transfers/test_dynamodb_to_s3.py tests/providers/amazon/aws/transfers/test_exasol_to_s3.py tests/providers/amazon/aws/transfers/test_ftp_to_s3.py tests/providers/amazon/aws/transfers/test_gcs_to_s3.py tests/providers/amazon/aws/transfers/test_glacier_to_gcs.py tests/providers/amazon/aws/transfers/test_google_api_to_s3.py tests/providers/amazon/aws/transfers/test_google_api_to_s3_system.py tests/providers/amazon/aws/transfers/test_hive_to_dynamodb.py tests/providers/amazon/aws/transfers/test_imap_attachment_to_s3.py tests/providers/amazon/aws/transfers/test_imap_attachment_to_s3_system.py tests/providers/amazon/aws/transfers/test_mongo_to_s3.py tests/providers/amazon/aws/transfers/test_mysql_to_s3.py tests/providers/amazon/aws/transfers/test_redshift_to_s3.py tests/providers/amazon/aws/transfers/test_s3_to_ftp.py tests/providers/amazon/aws/transfers/test_s3_to_redshift.py tests/providers/amazon/aws/transfers/test_s3_to_redshift_system.py tests/providers/amazon/aws/transfers/test_s3_to_sftp.py tests/providers/amazon/aws/transfers/test_sftp_to_s3.py tests/providers/amazon/aws/utils/__init__.py tests/providers/amazon/aws/utils/test_emailer.py tests/providers/amazon/aws/utils/test_redshift.py tests/providers/apache/__init__.py tests/providers/apache/beam/__init__.py tests/providers/apache/beam/hooks/__init__.py tests/providers/apache/beam/hooks/test_beam.py tests/providers/apache/beam/operators/__init__.py tests/providers/apache/beam/operators/test_beam.py tests/providers/apache/beam/operators/test_beam_system.py tests/providers/apache/cassandra/__init__.py tests/providers/apache/cassandra/hooks/__init__.py tests/providers/apache/cassandra/hooks/test_cassandra.py tests/providers/apache/cassandra/sensors/__init__.py tests/providers/apache/cassandra/sensors/test_record.py tests/providers/apache/cassandra/sensors/test_table.py tests/providers/apache/druid/__init__.py tests/providers/apache/druid/hooks/__init__.py tests/providers/apache/druid/hooks/test_druid.py tests/providers/apache/druid/operators/__init__.py tests/providers/apache/druid/operators/test_druid.py tests/providers/apache/druid/transfers/__init__.py tests/providers/apache/druid/transfers/test_hive_to_druid.py tests/providers/apache/hdfs/__init__.py tests/providers/apache/hdfs/hooks/__init__.py tests/providers/apache/hdfs/hooks/test_hdfs.py tests/providers/apache/hdfs/hooks/test_webhdfs.py tests/providers/apache/hdfs/sensors/__init__.py tests/providers/apache/hdfs/sensors/test_hdfs.py tests/providers/apache/hdfs/sensors/test_web_hdfs.py tests/providers/apache/hive/__init__.py tests/providers/apache/hive/hooks/__init__.py tests/providers/apache/hive/hooks/test_hive.py tests/providers/apache/hive/operators/__init__.py tests/providers/apache/hive/operators/test_hive.py tests/providers/apache/hive/operators/test_hive_stats.py tests/providers/apache/hive/sensors/__init__.py tests/providers/apache/hive/sensors/test_hdfs.py tests/providers/apache/hive/sensors/test_hive_partition.py tests/providers/apache/hive/sensors/test_metastore_partition.py tests/providers/apache/hive/sensors/test_named_hive_partition.py tests/providers/apache/hive/transfers/__init__.py tests/providers/apache/hive/transfers/test_hive_to_mysql.py tests/providers/apache/hive/transfers/test_hive_to_samba.py tests/providers/apache/hive/transfers/test_mssql_to_hive.py tests/providers/apache/hive/transfers/test_mysql_to_hive.py tests/providers/apache/hive/transfers/test_s3_to_hive.py tests/providers/apache/hive/transfers/test_vertica_to_hive.py tests/providers/apache/kylin/__init__.py tests/providers/apache/kylin/hooks/__init__.py tests/providers/apache/kylin/hooks/test_kylin.py tests/providers/apache/kylin/operators/__init__.py tests/providers/apache/kylin/operators/test_kylin_cube.py tests/providers/apache/livy/__init__.py tests/providers/apache/livy/hooks/__init__.py tests/providers/apache/livy/hooks/test_livy.py tests/providers/apache/livy/operators/__init__.py tests/providers/apache/livy/operators/test_livy.py tests/providers/apache/livy/sensors/__init__.py tests/providers/apache/livy/sensors/test_livy.py tests/providers/apache/pig/__init__.py tests/providers/apache/pig/hooks/__init__.py tests/providers/apache/pig/hooks/test_pig.py tests/providers/apache/pig/operators/__init__.py tests/providers/apache/pig/operators/test_pig.py tests/providers/apache/pinot/__init__.py tests/providers/apache/pinot/hooks/__init__.py tests/providers/apache/pinot/hooks/test_pinot.py tests/providers/apache/spark/__init__.py tests/providers/apache/spark/hooks/__init__.py tests/providers/apache/spark/hooks/test_spark_jdbc.py tests/providers/apache/spark/hooks/test_spark_jdbc_script.py tests/providers/apache/spark/hooks/test_spark_sql.py tests/providers/apache/spark/hooks/test_spark_submit.py tests/providers/apache/spark/operators/__init__.py tests/providers/apache/spark/operators/test_spark_jdbc.py tests/providers/apache/spark/operators/test_spark_sql.py tests/providers/apache/spark/operators/test_spark_submit.py tests/providers/apache/sqoop/__init__.py tests/providers/apache/sqoop/hooks/__init__.py tests/providers/apache/sqoop/hooks/test_sqoop.py tests/providers/apache/sqoop/operators/__init__.py tests/providers/apache/sqoop/operators/test_sqoop.py tests/providers/asana/__init__.py tests/providers/asana/hooks/__init__.py tests/providers/asana/hooks/test_asana.py tests/providers/asana/operators/__init__.py tests/providers/asana/operators/test_asana_tasks.py tests/providers/celery/__init__.py tests/providers/celery/sensors/__init__.py tests/providers/celery/sensors/test_celery_queue.py tests/providers/cloudant/__init__.py tests/providers/cloudant/hooks/__init__.py tests/providers/cloudant/hooks/test_cloudant.py tests/providers/cncf/__init__.py tests/providers/cncf/kubernetes/__init__.py tests/providers/cncf/kubernetes/hooks/__init__.py tests/providers/cncf/kubernetes/hooks/test_kubernetes.py tests/providers/cncf/kubernetes/operators/__init__.py tests/providers/cncf/kubernetes/operators/test_kubernetes_pod.py tests/providers/cncf/kubernetes/operators/test_spark_kubernetes.py tests/providers/cncf/kubernetes/operators/test_spark_kubernetes_system.py tests/providers/cncf/kubernetes/sensors/__init__.py tests/providers/cncf/kubernetes/sensors/test_spark_kubernetes.py tests/providers/cncf/kubernetes/utils/__init__.py tests/providers/cncf/kubernetes/utils/test_pod_launcher.py tests/providers/databricks/__init__.py tests/providers/databricks/hooks/__init__.py tests/providers/databricks/hooks/test_databricks.py tests/providers/databricks/operators/__init__.py tests/providers/databricks/operators/test_databricks.py tests/providers/datadog/__init__.py tests/providers/datadog/hooks/__init__.py tests/providers/datadog/hooks/test_datadog.py tests/providers/datadog/sensors/__init__.py tests/providers/datadog/sensors/test_datadog.py tests/providers/dingding/__init__.py tests/providers/dingding/hooks/__init__.py tests/providers/dingding/hooks/test_dingding.py tests/providers/dingding/operators/__init__.py tests/providers/dingding/operators/test_dingding.py tests/providers/discord/__init__.py tests/providers/discord/hooks/__init__.py tests/providers/discord/hooks/test_discord_webhook.py tests/providers/discord/operators/__init__.py tests/providers/discord/operators/test_discord_webhook.py tests/providers/docker/__init__.py tests/providers/docker/hooks/__init__.py tests/providers/docker/hooks/test_docker.py tests/providers/docker/operators/__init__.py tests/providers/docker/operators/test_docker.py tests/providers/docker/operators/test_docker_swarm.py tests/providers/elasticsearch/__init__.py tests/providers/elasticsearch/hooks/__init__.py tests/providers/elasticsearch/hooks/test_elasticsearch.py tests/providers/elasticsearch/log/__init__.py tests/providers/elasticsearch/log/elasticmock/__init__.py tests/providers/elasticsearch/log/elasticmock/fake_elasticsearch.py tests/providers/elasticsearch/log/elasticmock/utilities/__init__.py tests/providers/elasticsearch/log/test_es_task_handler.py tests/providers/email/__init__.py tests/providers/email/operators/__init__.py tests/providers/exasol/__init__.py tests/providers/exasol/hooks/__init__.py tests/providers/exasol/hooks/test_exasol.py tests/providers/exasol/operators/__init__.py tests/providers/exasol/operators/test_exasol.py tests/providers/facebook/__init__.py tests/providers/facebook/ads/__init__.py tests/providers/facebook/ads/hooks/__init__.py tests/providers/facebook/ads/hooks/test_ads.py tests/providers/ftp/__init__.py tests/providers/ftp/hooks/__init__.py tests/providers/ftp/hooks/test_ftp.py tests/providers/ftp/sensors/__init__.py tests/providers/ftp/sensors/test_ftp.py tests/providers/google/__init__.py tests/providers/google/ads/__init__.py tests/providers/google/ads/hooks/__init__.py tests/providers/google/ads/hooks/test_ads.py tests/providers/google/ads/operators/test_ads.py tests/providers/google/ads/transfers/__init__.py tests/providers/google/ads/transfers/test_ads_to_gcs.py tests/providers/google/cloud/__init__.py tests/providers/google/cloud/_internal_client/__init__.py tests/providers/google/cloud/_internal_client/test_secret_manager_client.py tests/providers/google/cloud/hooks/__init__.py tests/providers/google/cloud/hooks/test_automl.py tests/providers/google/cloud/hooks/test_bigquery.py tests/providers/google/cloud/hooks/test_bigquery_dts.py tests/providers/google/cloud/hooks/test_bigquery_system.py tests/providers/google/cloud/hooks/test_bigtable.py tests/providers/google/cloud/hooks/test_cloud_build.py tests/providers/google/cloud/hooks/test_cloud_memorystore.py tests/providers/google/cloud/hooks/test_cloud_sql.py tests/providers/google/cloud/hooks/test_cloud_storage_transfer_service.py tests/providers/google/cloud/hooks/test_compute.py tests/providers/google/cloud/hooks/test_compute_ssh.py tests/providers/google/cloud/hooks/test_compute_ssh_system.py tests/providers/google/cloud/hooks/test_datacatalog.py tests/providers/google/cloud/hooks/test_dataflow.py tests/providers/google/cloud/hooks/test_datafusion.py tests/providers/google/cloud/hooks/test_dataprep.py tests/providers/google/cloud/hooks/test_dataproc.py tests/providers/google/cloud/hooks/test_datastore.py tests/providers/google/cloud/hooks/test_dlp.py tests/providers/google/cloud/hooks/test_functions.py tests/providers/google/cloud/hooks/test_gcs.py tests/providers/google/cloud/hooks/test_gdm.py tests/providers/google/cloud/hooks/test_kms.py tests/providers/google/cloud/hooks/test_kms_system.py tests/providers/google/cloud/hooks/test_kubernetes_engine.py tests/providers/google/cloud/hooks/test_life_sciences.py tests/providers/google/cloud/hooks/test_mlengine.py tests/providers/google/cloud/hooks/test_natural_language.py tests/providers/google/cloud/hooks/test_os_login.py tests/providers/google/cloud/hooks/test_pubsub.py tests/providers/google/cloud/hooks/test_secret_manager.py tests/providers/google/cloud/hooks/test_secret_manager_system.py tests/providers/google/cloud/hooks/test_spanner.py tests/providers/google/cloud/hooks/test_speech_to_text.py tests/providers/google/cloud/hooks/test_stackdriver.py tests/providers/google/cloud/hooks/test_tasks.py tests/providers/google/cloud/hooks/test_text_to_speech.py tests/providers/google/cloud/hooks/test_translate.py tests/providers/google/cloud/hooks/test_video_intelligence.py tests/providers/google/cloud/hooks/test_vision.py tests/providers/google/cloud/hooks/test_workflows.py tests/providers/google/cloud/log/__init__.py tests/providers/google/cloud/log/test_gcs_task_handler.py tests/providers/google/cloud/log/test_gcs_task_handler_system.py tests/providers/google/cloud/log/test_stackdriver_task_handler.py tests/providers/google/cloud/log/test_stackdriver_task_handler_system.py tests/providers/google/cloud/operators/__init__.py tests/providers/google/cloud/operators/test_automl.py tests/providers/google/cloud/operators/test_automl_system.py tests/providers/google/cloud/operators/test_bigquery.py tests/providers/google/cloud/operators/test_bigquery_dts.py tests/providers/google/cloud/operators/test_bigquery_dts_system.py tests/providers/google/cloud/operators/test_bigquery_system.py tests/providers/google/cloud/operators/test_bigtable.py tests/providers/google/cloud/operators/test_bigtable_system.py tests/providers/google/cloud/operators/test_cloud_build.py tests/providers/google/cloud/operators/test_cloud_build_system.py tests/providers/google/cloud/operators/test_cloud_build_system_helper.py tests/providers/google/cloud/operators/test_cloud_memorystore.py tests/providers/google/cloud/operators/test_cloud_memorystore_system.py tests/providers/google/cloud/operators/test_cloud_sql.py tests/providers/google/cloud/operators/test_cloud_sql_system.py tests/providers/google/cloud/operators/test_cloud_sql_system_helper.py tests/providers/google/cloud/operators/test_cloud_storage_transfer_service.py tests/providers/google/cloud/operators/test_cloud_storage_transfer_service_system.py tests/providers/google/cloud/operators/test_compute.py tests/providers/google/cloud/operators/test_compute_system.py tests/providers/google/cloud/operators/test_compute_system_helper.py tests/providers/google/cloud/operators/test_datacatalog.py tests/providers/google/cloud/operators/test_datacatalog_system.py tests/providers/google/cloud/operators/test_dataflow.py tests/providers/google/cloud/operators/test_dataflow_system.py tests/providers/google/cloud/operators/test_datafusion.py tests/providers/google/cloud/operators/test_datafusion_system.py tests/providers/google/cloud/operators/test_dataprep.py tests/providers/google/cloud/operators/test_dataprep_system.py tests/providers/google/cloud/operators/test_dataproc.py tests/providers/google/cloud/operators/test_dataproc_system.py tests/providers/google/cloud/operators/test_datastore.py tests/providers/google/cloud/operators/test_datastore_system.py tests/providers/google/cloud/operators/test_dlp.py tests/providers/google/cloud/operators/test_dlp_system.py tests/providers/google/cloud/operators/test_functions.py tests/providers/google/cloud/operators/test_functions_system.py tests/providers/google/cloud/operators/test_gcs.py tests/providers/google/cloud/operators/test_gcs_system.py tests/providers/google/cloud/operators/test_gcs_system_helper.py tests/providers/google/cloud/operators/test_gcs_timespan_file_transform_system.py tests/providers/google/cloud/operators/test_kubernetes_engine.py tests/providers/google/cloud/operators/test_kubernetes_engine_system.py tests/providers/google/cloud/operators/test_life_sciences.py tests/providers/google/cloud/operators/test_life_sciences_system.py tests/providers/google/cloud/operators/test_mlengine.py tests/providers/google/cloud/operators/test_mlengine_system.py tests/providers/google/cloud/operators/test_mlengine_utils.py tests/providers/google/cloud/operators/test_natural_language.py tests/providers/google/cloud/operators/test_natural_language_system.py tests/providers/google/cloud/operators/test_pubsub.py tests/providers/google/cloud/operators/test_pubsub_system.py tests/providers/google/cloud/operators/test_spanner.py tests/providers/google/cloud/operators/test_spanner_system.py tests/providers/google/cloud/operators/test_speech_to_text.py tests/providers/google/cloud/operators/test_speech_to_text_system.py tests/providers/google/cloud/operators/test_stackdriver.py tests/providers/google/cloud/operators/test_stackdriver_system.py tests/providers/google/cloud/operators/test_tasks.py tests/providers/google/cloud/operators/test_tasks_system.py tests/providers/google/cloud/operators/test_text_to_speech.py tests/providers/google/cloud/operators/test_text_to_speech_system.py tests/providers/google/cloud/operators/test_translate.py tests/providers/google/cloud/operators/test_translate_speech.py tests/providers/google/cloud/operators/test_translate_speech_system.py tests/providers/google/cloud/operators/test_translate_system.py tests/providers/google/cloud/operators/test_video_intelligence.py tests/providers/google/cloud/operators/test_video_intelligence_system.py tests/providers/google/cloud/operators/test_vision.py tests/providers/google/cloud/operators/test_vision_system.py tests/providers/google/cloud/operators/test_workflows.py tests/providers/google/cloud/operators/test_workflows_system.py tests/providers/google/cloud/secrets/__init__.py tests/providers/google/cloud/secrets/test_secret_manager.py tests/providers/google/cloud/secrets/test_secret_manager_system.py tests/providers/google/cloud/sensors/__init__.py tests/providers/google/cloud/sensors/test_bigquery.py tests/providers/google/cloud/sensors/test_bigquery_dts.py tests/providers/google/cloud/sensors/test_bigtable.py tests/providers/google/cloud/sensors/test_cloud_storage_transfer_service.py tests/providers/google/cloud/sensors/test_dataflow.py tests/providers/google/cloud/sensors/test_dataproc.py tests/providers/google/cloud/sensors/test_gcs.py tests/providers/google/cloud/sensors/test_pubsub.py tests/providers/google/cloud/sensors/test_workflows.py tests/providers/google/cloud/transfers/__init__.py tests/providers/google/cloud/transfers/test_adls_to_gcs.py tests/providers/google/cloud/transfers/test_azure_fileshare_to_gcs.py tests/providers/google/cloud/transfers/test_azure_fileshare_to_gcs_system.py tests/providers/google/cloud/transfers/test_bigquery_to_bigquery.py tests/providers/google/cloud/transfers/test_bigquery_to_bigquery_system.py tests/providers/google/cloud/transfers/test_bigquery_to_gcs.py tests/providers/google/cloud/transfers/test_bigquery_to_gcs_system.py tests/providers/google/cloud/transfers/test_bigquery_to_mysql.py tests/providers/google/cloud/transfers/test_cassandra_to_gcs.py tests/providers/google/cloud/transfers/test_facebook_ads_to_gcs.py tests/providers/google/cloud/transfers/test_facebook_ads_to_gcs_system.py tests/providers/google/cloud/transfers/test_gcs_to_bigquery.py tests/providers/google/cloud/transfers/test_gcs_to_bigquery_system.py tests/providers/google/cloud/transfers/test_gcs_to_gcs.py tests/providers/google/cloud/transfers/test_gcs_to_gcs_system.py tests/providers/google/cloud/transfers/test_gcs_to_local.py tests/providers/google/cloud/transfers/test_gcs_to_local_system.py tests/providers/google/cloud/transfers/test_gcs_to_sftp.py tests/providers/google/cloud/transfers/test_gcs_to_sftp_system.py tests/providers/google/cloud/transfers/test_gdrive_to_gcs.py tests/providers/google/cloud/transfers/test_gdrive_to_gcs_system.py tests/providers/google/cloud/transfers/test_gdrive_to_local.py tests/providers/google/cloud/transfers/test_local_to_gcs.py tests/providers/google/cloud/transfers/test_local_to_gcs_system.py tests/providers/google/cloud/transfers/test_mssql_to_gcs.py tests/providers/google/cloud/transfers/test_mysql_to_gcs.py tests/providers/google/cloud/transfers/test_mysql_to_gcs_system.py tests/providers/google/cloud/transfers/test_oracle_to_gcs.py tests/providers/google/cloud/transfers/test_postgres_to_gcs.py tests/providers/google/cloud/transfers/test_postgres_to_gcs_system.py tests/providers/google/cloud/transfers/test_presto_to_gcs.py tests/providers/google/cloud/transfers/test_presto_to_gcs_system.py tests/providers/google/cloud/transfers/test_s3_to_gcs.py tests/providers/google/cloud/transfers/test_s3_to_gcs_system.py tests/providers/google/cloud/transfers/test_salesforce_to_gcs.py tests/providers/google/cloud/transfers/test_salesforce_to_gcs_system.py tests/providers/google/cloud/transfers/test_sftp_to_gcs.py tests/providers/google/cloud/transfers/test_sftp_to_gcs_system.py tests/providers/google/cloud/transfers/test_sheets_to_gcs.py tests/providers/google/cloud/transfers/test_sheets_to_gcs_system.py tests/providers/google/cloud/transfers/test_sql_to_gcs.py tests/providers/google/cloud/transfers/test_trino_to_gcs.py tests/providers/google/cloud/transfers/test_trino_to_gcs_system.py tests/providers/google/cloud/utils/__init__.py tests/providers/google/cloud/utils/base_gcp_mock.py tests/providers/google/cloud/utils/gcp_authenticator.py tests/providers/google/cloud/utils/test_credentials_provider.py tests/providers/google/cloud/utils/test_field_sanitizer.py tests/providers/google/cloud/utils/test_field_validator.py tests/providers/google/cloud/utils/test_mlengine_operator_utils.py tests/providers/google/cloud/utils/test_mlengine_prediction_summary.py tests/providers/google/common/__init__.py tests/providers/google/common/auth_backend/__init__.py tests/providers/google/common/auth_backend/test_google_openid.py tests/providers/google/common/hooks/__init__.py tests/providers/google/common/hooks/test_base_google.py tests/providers/google/common/hooks/test_discovery_api.py tests/providers/google/common/utils/__init__.py tests/providers/google/common/utils/test_id_token_credentials.py tests/providers/google/firebase/__init__.py tests/providers/google/firebase/hooks/__init__.py tests/providers/google/firebase/hooks/test_firestore.py tests/providers/google/firebase/operators/__init__.py tests/providers/google/firebase/operators/test_firestore.py tests/providers/google/firebase/operators/test_firestore_system.py tests/providers/google/leveldb/__init__.py tests/providers/google/leveldb/hooks/__init__.py tests/providers/google/leveldb/hooks/test_leveldb.py tests/providers/google/leveldb/operators/__init__.py tests/providers/google/leveldb/operators/test_leveldb.py tests/providers/google/leveldb/operators/test_leveldb_system.py tests/providers/google/marketing_platform/__init__.py tests/providers/google/marketing_platform/hooks/__init__.py tests/providers/google/marketing_platform/hooks/test_analytics.py tests/providers/google/marketing_platform/hooks/test_campaign_manager.py tests/providers/google/marketing_platform/hooks/test_display_video.py tests/providers/google/marketing_platform/hooks/test_search_ads.py tests/providers/google/marketing_platform/operators/__init__.py tests/providers/google/marketing_platform/operators/test_analytics.py tests/providers/google/marketing_platform/operators/test_analytics_system.py tests/providers/google/marketing_platform/operators/test_campaign_manager.py tests/providers/google/marketing_platform/operators/test_campaign_manager_system.py tests/providers/google/marketing_platform/operators/test_display_video.py tests/providers/google/marketing_platform/operators/test_display_video_system.py tests/providers/google/marketing_platform/operators/test_search_ads.py tests/providers/google/marketing_platform/operators/test_search_ads_system.py tests/providers/google/marketing_platform/sensors/__init__.py tests/providers/google/marketing_platform/sensors/test_campaign_manager.py tests/providers/google/marketing_platform/sensors/test_display_video.py tests/providers/google/marketing_platform/sensors/test_search_ads.py tests/providers/google/suite/__init__.py tests/providers/google/suite/hooks/__init__.py tests/providers/google/suite/hooks/test_drive.py tests/providers/google/suite/hooks/test_sheets.py tests/providers/google/suite/operators/__init__.py tests/providers/google/suite/operators/test_sheets.py tests/providers/google/suite/operators/test_sheets_system.py tests/providers/google/suite/sensors/__init__.py tests/providers/google/suite/sensors/test_drive.py tests/providers/google/suite/transfers/__init__.py tests/providers/google/suite/transfers/test_gcs_to_gdrive.py tests/providers/google/suite/transfers/test_gcs_to_sheets.py tests/providers/google/suite/transfers/test_gcs_to_sheets_system.py tests/providers/grpc/__init__.py tests/providers/grpc/hooks/__init__.py tests/providers/grpc/hooks/test_grpc.py tests/providers/grpc/operators/__init__.py tests/providers/grpc/operators/test_grpc.py tests/providers/hashicorp/__init__.py tests/providers/hashicorp/_internal_client/__init__.py tests/providers/hashicorp/_internal_client/test_vault_client.py tests/providers/hashicorp/hooks/__init__.py tests/providers/hashicorp/hooks/test_vault.py tests/providers/hashicorp/secrets/__init__.py tests/providers/hashicorp/secrets/test_vault.py tests/providers/http/__init__.py tests/providers/http/hooks/__init__.py tests/providers/http/hooks/test_http.py tests/providers/http/operators/__init__.py tests/providers/http/operators/test_http.py tests/providers/http/operators/test_http_system.py tests/providers/http/sensors/__init__.py tests/providers/http/sensors/test_http.py tests/providers/imap/__init__.py tests/providers/imap/hooks/__init__.py tests/providers/imap/hooks/test_imap.py tests/providers/imap/sensors/__init__.py tests/providers/imap/sensors/test_imap_attachment.py tests/providers/jdbc/__init__.py tests/providers/jdbc/hooks/__init__.py tests/providers/jdbc/hooks/test_jdbc.py tests/providers/jdbc/operators/__init__.py tests/providers/jdbc/operators/test_jdbc.py tests/providers/jenkins/__init__.py tests/providers/jenkins/hooks/test_jenkins.py tests/providers/jenkins/operators/__init__.py tests/providers/jenkins/operators/test_jenkins_job_trigger.py tests/providers/jira/__init__.py tests/providers/jira/hooks/__init__.py tests/providers/jira/hooks/test_jira.py tests/providers/jira/operators/__init__.py tests/providers/jira/operators/test_jira.py tests/providers/jira/sensors/__init__.py tests/providers/jira/sensors/test_jira.py tests/providers/microsoft/__init__.py tests/providers/microsoft/azure/__init__.py tests/providers/microsoft/azure/hooks/__init__.py tests/providers/microsoft/azure/hooks/test_adx.py tests/providers/microsoft/azure/hooks/test_azure_batch.py tests/providers/microsoft/azure/hooks/test_azure_container_instance.py tests/providers/microsoft/azure/hooks/test_azure_container_registry.py tests/providers/microsoft/azure/hooks/test_azure_container_volume.py tests/providers/microsoft/azure/hooks/test_azure_cosmos.py tests/providers/microsoft/azure/hooks/test_azure_data_factory.py tests/providers/microsoft/azure/hooks/test_azure_data_lake.py tests/providers/microsoft/azure/hooks/test_azure_fileshare.py tests/providers/microsoft/azure/hooks/test_base_azure.py tests/providers/microsoft/azure/hooks/test_fileshare_system.py tests/providers/microsoft/azure/hooks/test_wasb.py tests/providers/microsoft/azure/log/__init__.py tests/providers/microsoft/azure/log/test_wasb_task_handler.py tests/providers/microsoft/azure/operators/__init__.py tests/providers/microsoft/azure/operators/test_adls_delete.py tests/providers/microsoft/azure/operators/test_adls_delete_system.py tests/providers/microsoft/azure/operators/test_adls_list.py tests/providers/microsoft/azure/operators/test_adx.py tests/providers/microsoft/azure/operators/test_azure_batch.py tests/providers/microsoft/azure/operators/test_azure_container_instances.py tests/providers/microsoft/azure/operators/test_azure_cosmos.py tests/providers/microsoft/azure/operators/test_wasb_delete_blob.py tests/providers/microsoft/azure/secrets/test_azure_key_vault.py tests/providers/microsoft/azure/sensors/__init__.py tests/providers/microsoft/azure/sensors/test_azure_cosmos.py tests/providers/microsoft/azure/sensors/test_wasb.py tests/providers/microsoft/azure/transfers/__init__.py tests/providers/microsoft/azure/transfers/test_azure_blob_to_gcs.py tests/providers/microsoft/azure/transfers/test_file_to_wasb.py tests/providers/microsoft/azure/transfers/test_file_to_wasb_system.py tests/providers/microsoft/azure/transfers/test_local_to_adls.py tests/providers/microsoft/azure/transfers/test_local_to_adls_system.py tests/providers/microsoft/azure/transfers/test_oracle_to_azure_data_lake.py tests/providers/microsoft/mssql/__init__.py tests/providers/microsoft/mssql/hooks/__init__.py tests/providers/microsoft/mssql/hooks/test_mssql.py tests/providers/microsoft/mssql/operators/test_mssql.py tests/providers/microsoft/winrm/__init__.py tests/providers/microsoft/winrm/hooks/__init__.py tests/providers/microsoft/winrm/hooks/test_winrm.py tests/providers/microsoft/winrm/operators/__init__.py tests/providers/microsoft/winrm/operators/test_winrm.py tests/providers/mongo/__init__.py tests/providers/mongo/hooks/__init__.py tests/providers/mongo/hooks/test_mongo.py tests/providers/mongo/sensors/__init__.py tests/providers/mongo/sensors/test_mongo.py tests/providers/mysql/__init__.py tests/providers/mysql/hooks/__init__.py tests/providers/mysql/hooks/test_mysql.py tests/providers/mysql/operators/__init__.py tests/providers/mysql/operators/test_mysql.py tests/providers/mysql/transfers/__init__.py tests/providers/mysql/transfers/test_presto_to_mysql.py tests/providers/mysql/transfers/test_s3_to_mysql.py tests/providers/mysql/transfers/test_trino_to_mysql.py tests/providers/mysql/transfers/test_vertica_to_mysql.py tests/providers/neo4j/__init__.py tests/providers/neo4j/hooks/__init__.py tests/providers/neo4j/hooks/test_neo4j.py tests/providers/neo4j/operators/__init__.py tests/providers/neo4j/operators/test_neo4j.py tests/providers/odbc/hooks/test_odbc.py tests/providers/openfaas/__init__.py tests/providers/openfaas/hooks/__init__.py tests/providers/openfaas/hooks/test_openfaas.py tests/providers/opsgenie/__init__.py tests/providers/opsgenie/hooks/__init__.py tests/providers/opsgenie/hooks/test_opsgenie_alert.py tests/providers/opsgenie/operators/__init__.py tests/providers/opsgenie/operators/test_opsgenie_alert.py tests/providers/oracle/__init__.py tests/providers/oracle/hooks/__init__.py tests/providers/oracle/hooks/test_oracle.py tests/providers/oracle/operators/__init__.py tests/providers/oracle/operators/test_oracle.py tests/providers/oracle/transfers/__init__.py tests/providers/oracle/transfers/test_oracle_to_oracle.py tests/providers/pagerduty/__init__.py tests/providers/pagerduty/hooks/__init__.py tests/providers/pagerduty/hooks/test_pagerduty.py tests/providers/papermill/__init__.py tests/providers/papermill/operators/__init__.py tests/providers/papermill/operators/test_papermill.py tests/providers/plexus/__init__.py tests/providers/plexus/hooks/test_plexus.py tests/providers/plexus/operators/__init__.py tests/providers/plexus/operators/test_job.py tests/providers/postgres/__init__.py tests/providers/postgres/hooks/__init__.py tests/providers/postgres/hooks/test_postgres.py tests/providers/postgres/operators/__init__.py tests/providers/postgres/operators/test_postgres.py tests/providers/postgres/operators/test_postgres_system.py tests/providers/presto/__init__.py tests/providers/presto/hooks/__init__.py tests/providers/presto/hooks/test_presto.py tests/providers/qubole/__init__.py tests/providers/qubole/hooks/__init__.py tests/providers/qubole/hooks/test_qubole.py tests/providers/qubole/hooks/test_qubole_check.py tests/providers/qubole/operators/__init__.py tests/providers/qubole/operators/test_qubole.py tests/providers/qubole/operators/test_qubole_check.py tests/providers/qubole/sensors/__init__.py tests/providers/qubole/sensors/test_qubole.py tests/providers/redis/__init__.py tests/providers/redis/hooks/__init__.py tests/providers/redis/hooks/test_redis.py tests/providers/redis/operators/__init__.py tests/providers/redis/operators/test_redis_publish.py tests/providers/redis/sensors/__init__.py tests/providers/redis/sensors/test_redis_key.py tests/providers/redis/sensors/test_redis_pub_sub.py tests/providers/salesforce/__init__.py tests/providers/salesforce/hooks/__init__.py tests/providers/salesforce/hooks/test_salesforce.py tests/providers/salesforce/operators/__init__.py tests/providers/salesforce/sensors/__init__.py tests/providers/samba/__init__.py tests/providers/samba/hooks/__init__.py tests/providers/samba/hooks/test_samba.py tests/providers/segment/__init__.py tests/providers/segment/hooks/__init__.py tests/providers/segment/hooks/test_segment.py tests/providers/segment/operators/__init__.py tests/providers/segment/operators/test_segment_track_event.py tests/providers/sendgrid/__init__.py tests/providers/sendgrid/utils/__init__.py tests/providers/sendgrid/utils/test_emailer.py tests/providers/sftp/__init__.py tests/providers/sftp/hooks/__init__.py tests/providers/sftp/hooks/test_sftp.py tests/providers/sftp/operators/__init__.py tests/providers/sftp/operators/test_sftp.py tests/providers/sftp/sensors/__init__.py tests/providers/sftp/sensors/test_sftp.py tests/providers/singularity/__init__.py tests/providers/singularity/operators/__init__.py tests/providers/singularity/operators/test_singularity.py tests/providers/slack/__init__.py tests/providers/slack/hooks/__init__.py tests/providers/slack/hooks/test_slack.py tests/providers/slack/hooks/test_slack_webhook.py tests/providers/slack/operators/__init__.py tests/providers/slack/operators/test_slack.py tests/providers/slack/operators/test_slack_webhook.py tests/providers/snowflake/__init__.py tests/providers/snowflake/hooks/__init__.py tests/providers/snowflake/hooks/test_snowflake.py tests/providers/snowflake/operators/__init__.py tests/providers/snowflake/operators/test_snowflake.py tests/providers/snowflake/operators/test_snowflake_system.py tests/providers/snowflake/transfers/__init__.py tests/providers/snowflake/transfers/test_s3_to_snowflake.py tests/providers/snowflake/transfers/test_snowflake_to_slack.py tests/providers/sqlite/__init__.py tests/providers/sqlite/hooks/__init__.py tests/providers/sqlite/hooks/test_sqlite.py tests/providers/sqlite/operators/__init__.py tests/providers/sqlite/operators/test_sqlite.py tests/providers/ssh/__init__.py tests/providers/ssh/hooks/__init__.py tests/providers/ssh/hooks/test_ssh.py tests/providers/ssh/operators/__init__.py tests/providers/ssh/operators/test_ssh.py tests/providers/tableau/hooks/__init__.py tests/providers/tableau/hooks/test_tableau.py tests/providers/tableau/operators/__init__.py tests/providers/tableau/operators/test_tableau_refresh_workbook.py tests/providers/tableau/sensors/__init__.py tests/providers/tableau/sensors/test_tableau_job_status.py tests/providers/telegram/__init__.py tests/providers/telegram/hooks/__init__.py tests/providers/telegram/hooks/test_telegram.py tests/providers/telegram/operators/__init__.py tests/providers/telegram/operators/test_telegram.py tests/providers/trino/__init__.py tests/providers/trino/hooks/__init__.py tests/providers/trino/hooks/test_trino.py tests/providers/vertica/__init__.py tests/providers/vertica/hooks/__init__.py tests/providers/vertica/hooks/test_vertica.py tests/providers/vertica/operators/__init__.py tests/providers/vertica/operators/test_vertica.py tests/providers/yandex/__init__.py tests/providers/yandex/hooks/__init__.py tests/providers/yandex/hooks/test_yandex.py tests/providers/yandex/hooks/test_yandexcloud_dataproc.py tests/providers/yandex/operators/__init__.py tests/providers/yandex/operators/test_yandexcloud_dataproc.py tests/providers/zendesk/__init__.py tests/providers/zendesk/hooks/__init__.py tests/providers/zendesk/hooks/test_zendesk.py tests/secrets/test_local_filesystem.py tests/secrets/test_secrets.py tests/secrets/test_secrets_backends.py tests/security/__init__.py tests/security/test_kerberos.py tests/sensors/__init__.py tests/sensors/test_base.py tests/sensors/test_bash.py tests/sensors/test_date_time.py tests/sensors/test_external_task_sensor.py tests/sensors/test_filesystem.py tests/sensors/test_python.py tests/sensors/test_smart_sensor_operator.py tests/sensors/test_sql_sensor.py tests/sensors/test_time_delta.py tests/sensors/test_time_sensor.py tests/sensors/test_timeout_sensor.py tests/sensors/test_weekday_sensor.py tests/serialization/__init__.py tests/serialization/test_dag_serialization.py tests/task/__init__.py tests/task/task_runner/__init__.py tests/task/task_runner/test_cgroup_task_runner.py tests/task/task_runner/test_standard_task_runner.py tests/task/task_runner/test_task_runner.py tests/test_utils/__init__.py tests/test_utils/amazon_system_helpers.py tests/test_utils/api_connexion_utils.py tests/test_utils/asserts.py tests/test_utils/azure_system_helpers.py tests/test_utils/config.py tests/test_utils/db.py tests/test_utils/decorators.py tests/test_utils/fake_datetime.py tests/test_utils/gcp_system_helpers.py tests/test_utils/get_all_tests.py tests/test_utils/hdfs_utils.py tests/test_utils/logging_command_executor.py tests/test_utils/mock_executor.py tests/test_utils/mock_hooks.py tests/test_utils/mock_operators.py tests/test_utils/mock_plugins.py tests/test_utils/mock_process.py tests/test_utils/mock_security_manager.py tests/test_utils/operators/postgres_local_executor.cfg tests/test_utils/perf/dags/elastic_dag.py tests/test_utils/perf/dags/perf_dag_1.py tests/test_utils/perf/dags/perf_dag_2.py tests/test_utils/perf/dags/sql_perf_dag.py tests/test_utils/perf/perf_kit/__init__.py tests/test_utils/perf/perf_kit/memory.py tests/test_utils/perf/perf_kit/python.py tests/test_utils/perf/perf_kit/repeat_and_time.py tests/test_utils/perf/perf_kit/sqlalchemy.py tests/test_utils/perf/scheduler_dag_execution_timing.py tests/test_utils/perf/scheduler_ops_metrics.py tests/test_utils/perf/sql_queries.py tests/test_utils/permissions.py tests/test_utils/remote_user_api_auth_backend.py tests/test_utils/reset_warning_registry.py tests/test_utils/salesforce_system_helpers.py tests/test_utils/system_tests_class.py tests/test_utils/terraform.py tests/test_utils/www.py tests/testconfig/conf/core-with-trash.xml tests/testconfig/conf/emr-core-site.xml tests/testconfig/conf/ha-core-site.xml tests/testconfig/conf/ha-noport-hdfs-site.xml tests/testconfig/conf/ha-noport-trash-hdfs-site.xml tests/testconfig/conf/ha-port-hdfs-site.xml tests/testconfig/conf/non-ha-port-core-site.xml tests/ti_deps/__init__.py tests/ti_deps/contexts/__init__.py tests/ti_deps/deps/__init__.py tests/ti_deps/deps/fake_models.py tests/ti_deps/deps/test_dag_ti_slots_available_dep.py tests/ti_deps/deps/test_dag_unpaused_dep.py tests/ti_deps/deps/test_dagrun_exists_dep.py tests/ti_deps/deps/test_dagrun_id_dep.py tests/ti_deps/deps/test_not_in_retry_period_dep.py tests/ti_deps/deps/test_not_previously_skipped_dep.py tests/ti_deps/deps/test_pool_slots_available_dep.py tests/ti_deps/deps/test_prev_dagrun_dep.py tests/ti_deps/deps/test_ready_to_reschedule_dep.py tests/ti_deps/deps/test_runnable_exec_date_dep.py tests/ti_deps/deps/test_task_concurrency.py tests/ti_deps/deps/test_task_not_running_dep.py tests/ti_deps/deps/test_trigger_rule_dep.py tests/ti_deps/deps/test_valid_state_dep.py tests/utils/__init__.py tests/utils/log/__init__.py tests/utils/log/test_file_processor_handler.py tests/utils/log/test_json_formatter.py tests/utils/log/test_log_reader.py tests/utils/log/test_secrets_masker.py tests/utils/test_cli_util.py tests/utils/test_compression.py tests/utils/test_dag_cycle.py tests/utils/test_dag_processing.py tests/utils/test_dates.py tests/utils/test_db.py tests/utils/test_docs.py tests/utils/test_dot_renderer.py tests/utils/test_edgemodifier.py tests/utils/test_email.py tests/utils/test_event_scheduler.py tests/utils/test_file.py tests/utils/test_helpers.py tests/utils/test_json.py tests/utils/test_log_handlers.py tests/utils/test_logging_mixin.py tests/utils/test_module_loading.py tests/utils/test_net.py tests/utils/test_operator_helpers.py tests/utils/test_process_utils.py tests/utils/test_python_virtualenv.py tests/utils/test_retries.py tests/utils/test_serve_logs.py tests/utils/test_session.py tests/utils/test_sqlalchemy.py tests/utils/test_task_group.py tests/utils/test_task_handler_with_custom_formatter.py tests/utils/test_timezone.py tests/utils/test_trigger_rule.py tests/utils/test_types.py tests/utils/test_weekday.py tests/utils/test_weight_rule.py tests/www/__init__.py tests/www/api/__init__.py tests/www/api/experimental/__init__.py tests/www/api/experimental/conftest.py tests/www/api/experimental/test_dag_runs_endpoint.py tests/www/api/experimental/test_endpoints.py tests/www/test_app.py tests/www/test_init_views.py tests/www/test_logs/dag_for_testing_log_view/task_for_testing_log_view/2017-09-01T00.00.00+00.00/1.log tests/www/test_security.py tests/www/test_utils.py tests/www/test_validators.py tests/www/views/conftest.py tests/www/views/test_views.py tests/www/views/test_views_acl.py tests/www/views/test_views_base.py tests/www/views/test_views_connection.py tests/www/views/test_views_dagrun.py tests/www/views/test_views_decorators.py tests/www/views/test_views_extra_links.py tests/www/views/test_views_graph_gantt.py tests/www/views/test_views_log.py tests/www/views/test_views_mount.py tests/www/views/test_views_pool.py tests/www/views/test_views_rendered.py tests/www/views/test_views_tasks.py tests/www/views/test_views_trigger_dag.py tests/www/views/test_views_variable.py <<<<<< network # path=./coverage-files/coverage-sqlite-3.6/coverage-Providers-sqlite.xml airflow/