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

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


    from 41178d9534 Update RELEASE_NOTES.rst
     new c2f5190491 Upper bound `pendulum` requirement to <3.0 (#35336)
     new 86419a6407 Add pytest db_test markers to our tests (#35264)
     new 49b2a8d0d1 Improve testing harness to separate DB and non-db test 
(#35160)
     new fe1d8f4969 Add pip caching for faster build (#35026)
     new 8fcef7e14a Use slightly nicer job name for Non-DB tests in CI (#35333)

The 5 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .github/actions/post_tests_success/action.yml      |   4 +-
 .github/workflows/ci.yml                           | 123 ++--
 BREEZE.rst                                         | 142 ++++-
 CI.rst                                             |  56 +-
 CI_DIAGRAMS.md                                     |   2 +-
 Dockerfile                                         |  26 +-
 Dockerfile.ci                                      | 277 +--------
 TESTING.rst                                        | 665 +++++++++++++++++++--
 airflow/__main__.py                                |   2 -
 airflow/configuration.py                           |  13 -
 airflow/settings.py                                |  24 +-
 dev/breeze/SELECTIVE_CHECKS.md                     |  42 +-
 .../airflow_breeze/commands/developer_commands.py  |   8 +
 .../commands/developer_commands_config.py          |   7 +
 .../src/airflow_breeze/commands/main_command.py    |   4 +-
 .../airflow_breeze/commands/testing_commands.py    | 346 ++++++++---
 .../commands/testing_commands_config.py            | 149 ++++-
 dev/breeze/src/airflow_breeze/global_constants.py  |  21 +-
 .../src/airflow_breeze/params/shell_params.py      |  10 +-
 .../src/airflow_breeze/utils/common_options.py     |  90 ++-
 .../airflow_breeze/utils/docker_command_utils.py   |  10 +-
 dev/breeze/src/airflow_breeze/utils/run_tests.py   | 276 +++++++++
 .../src/airflow_breeze/utils/selective_checks.py   |  33 +-
 .../airflow_breeze/utils/suspended_providers.py    |   6 +-
 dev/breeze/tests/conftest.py                       |   1 -
 dev/breeze/tests/test_cache.py                     |   4 +-
 .../tests/test_pytest_args_for_test_types.py       | 316 ++++++++++
 dev/breeze/tests/test_selective_checks.py          |  96 ++-
 docs/docker-stack/build-arg-ref.rst                |   3 +
 docs/docker-stack/build.rst                        |  12 +
 docs/docker-stack/changelog.rst                    |   4 +
 images/breeze/output-commands-hash.txt             |  24 +-
 images/breeze/output-commands.svg                  | 114 ++--
 .../output_setup_check-all-params-in-groups.svg    |  26 +-
 images/breeze/output_setup_config.svg              |  40 +-
 .../output_setup_regenerate-command-images.svg     |   4 +-
 images/breeze/output_shell.svg                     | 152 +++--
 images/breeze/output_start-airflow.svg             | 122 ++--
 images/breeze/output_testing.svg                   |  52 +-
 images/breeze/output_testing_db-tests.svg          | 336 +++++++++++
 images/breeze/output_testing_helm-tests.svg        |  68 ++-
 images/breeze/output_testing_integration-tests.svg |  90 ++-
 images/breeze/output_testing_non-db-tests.svg      | 304 ++++++++++
 images/breeze/output_testing_tests.svg             | 226 +++++--
 ...ock.txt => LICENSE-pytest-capture-warnings.txt} |   5 +-
 scripts/ci/docker-compose/_docker.env              |   6 +-
 .../{backend-sqlite.yml => backend-none.yml}       |   8 +-
 scripts/ci/docker-compose/base.yml                 |   6 +-
 scripts/ci/docker-compose/devcontainer.env         |   2 -
 scripts/docker/common.sh                           |   4 +-
 scripts/docker/entrypoint_ci.sh                    | 266 +--------
 scripts/docker/entrypoint_prod.sh                  |   2 +-
 scripts/in_container/check_environment.sh          |   3 +
 scripts/in_container/filter_out_warnings.py        |  33 -
 scripts/in_container/run_ci_tests.sh               |   7 +-
 setup.cfg                                          |   4 +-
 setup.py                                           |   1 -
 tests/always/test_connection.py                    |   2 +
 tests/always/test_example_dags.py                  |   2 +
 tests/always/test_secrets.py                       |   3 +
 tests/always/test_secrets_backends.py              |   2 +
 .../endpoints/test_config_endpoint.py              |   3 +
 .../endpoints/test_connection_endpoint.py          |   2 +
 tests/api_connexion/endpoints/test_dag_endpoint.py |   2 +
 .../endpoints/test_dag_run_endpoint.py             |   8 +-
 .../endpoints/test_dag_source_endpoint.py          |   3 +
 .../endpoints/test_dag_warning_endpoint.py         |   2 +
 .../endpoints/test_dataset_endpoint.py             |   2 +
 .../endpoints/test_event_log_endpoint.py           |   2 +
 .../endpoints/test_extra_link_endpoint.py          |   2 +
 .../endpoints/test_health_endpoint.py              |   2 +
 .../endpoints/test_import_error_endpoint.py        |   2 +
 tests/api_connexion/endpoints/test_log_endpoint.py |   2 +
 .../test_mapped_task_instance_endpoint.py          |   2 +
 .../endpoints/test_plugin_endpoint.py              |   2 +
 .../api_connexion/endpoints/test_pool_endpoint.py  |   2 +
 .../endpoints/test_provider_endpoint.py            |   2 +
 .../endpoints/test_role_and_permission_endpoint.py |   2 +
 .../api_connexion/endpoints/test_task_endpoint.py  |   2 +
 .../endpoints/test_task_instance_endpoint.py       |   2 +
 .../api_connexion/endpoints/test_user_endpoint.py  |   2 +
 .../endpoints/test_variable_endpoint.py            |   2 +
 .../endpoints/test_version_endpoint.py             |   2 +
 .../api_connexion/endpoints/test_xcom_endpoint.py  |   2 +
 .../schemas/test_connection_schema.py              |   2 +
 tests/api_connexion/schemas/test_dag_run_schema.py |   2 +
 tests/api_connexion/schemas/test_dag_schema.py     |   3 +
 tests/api_connexion/schemas/test_dataset_schema.py |   3 +
 tests/api_connexion/schemas/test_error_schema.py   |   4 +
 .../api_connexion/schemas/test_event_log_schema.py |   2 +
 tests/api_connexion/schemas/test_pool_schemas.py   |   4 +
 .../schemas/test_role_and_permission_schema.py     |   2 +
 .../schemas/test_task_instance_schema.py           |   1 +
 tests/api_connexion/schemas/test_user_schema.py    |   2 +
 tests/api_connexion/schemas/test_xcom_schema.py    |   2 +
 tests/api_connexion/test_auth.py                   |   2 +
 tests/api_connexion/test_cors.py                   |   2 +
 tests/api_connexion/test_error_handling.py         |   4 +
 tests/api_connexion/test_security.py               |   2 +
 .../auth/backend/test_basic_auth.py                |   2 +
 tests/api_experimental/client/test_local_client.py |   2 +
 .../common/experimental/test_pool.py               |   2 +
 tests/api_experimental/common/test_delete_dag.py   |   2 +
 tests/api_experimental/common/test_mark_tasks.py   |   2 +
 tests/api_experimental/common/test_trigger_dag.py  |   2 +
 .../endpoints/test_rpc_api_endpoint.py             |   3 +
 tests/callbacks/test_callback_requests.py          |  28 +-
 tests/cli/commands/test_celery_command.py          |  49 +-
 tests/cli/commands/test_connection_command.py      |   2 +
 tests/cli/commands/test_dag_command.py             |   2 +
 tests/cli/commands/test_dag_processor_command.py   |   2 +
 tests/cli/commands/test_db_command.py              |   2 +
 tests/cli/commands/test_info_command.py            |   2 +
 tests/cli/commands/test_internal_api_command.py    |   1 +
 tests/cli/commands/test_jobs_command.py            |   1 +
 tests/cli/commands/test_kerberos_command.py        |   4 +
 tests/cli/commands/test_kubernetes_command.py      |  50 +-
 tests/cli/commands/test_pool_command.py            |   2 +
 tests/cli/commands/test_role_command.py            |   3 +
 .../cli/commands/test_rotate_fernet_key_command.py |   3 +
 tests/cli/commands/test_scheduler_command.py       |   2 +
 tests/cli/commands/test_sync_perm_command.py       |   4 +
 tests/cli/commands/test_task_command.py            |   3 +
 tests/cli/commands/test_triggerer_command.py       |   4 +
 tests/cli/commands/test_user_command.py            |   2 +
 tests/cli/commands/test_variable_command.py        |   2 +
 tests/cli/commands/test_webserver_command.py       |   1 +
 tests/conftest.py                                  | 393 ++++++++++--
 tests/core/test_configuration.py                   |   1 -
 tests/core/test_core.py                            |   2 +
 tests/core/test_impersonation_tests.py             |   2 +
 tests/core/test_sentry.py                          |   2 +
 tests/core/test_sqlalchemy_config.py               |   2 +
 tests/dag_processing/test_job_runner.py            |   3 +
 tests/dag_processing/test_processor.py             |   2 +
 tests/dags/test_clear_subdag.py                    |   4 +-
 tests/datasets/test_manager.py                     |   2 +
 tests/decorators/test_branch_python.py             |   2 +
 tests/decorators/test_external_python.py           |   3 +
 tests/decorators/test_python.py                    |   3 +
 tests/decorators/test_python_virtualenv.py         |   2 +
 tests/decorators/test_sensor.py                    |   2 +
 tests/decorators/test_setup_teardown.py            |   2 +
 tests/decorators/test_short_circuit.py             |   4 +
 tests/decorators/test_task_group.py                |   2 +
 tests/executors/test_base_executor.py              |   7 +-
 tests/executors/test_executor_loader.py            |   2 +
 tests/executors/test_local_executor.py             |   4 +
 tests/jobs/test_backfill_job.py                    |   2 +
 tests/jobs/test_base_job.py                        |   2 +
 tests/jobs/test_local_task_job.py                  |   2 +
 tests/jobs/test_scheduler_job.py                   |   4 +-
 tests/jobs/test_triggerer_job.py                   |   5 +
 tests/lineage/test_lineage.py                      |   4 +
 tests/listeners/test_listeners.py                  |   3 +
 tests/models/test_base.py                          |   2 +
 tests/models/test_baseoperator.py                  |  13 +
 tests/models/test_cleartasks.py                    |   2 +
 tests/models/test_dag.py                           |   2 +
 tests/models/test_dagbag.py                        |   2 +
 tests/models/test_dagcode.py                       |   2 +
 tests/models/test_dagrun.py                        |   3 +
 tests/models/test_dagwarning.py                    |   3 +
 tests/models/test_mappedoperator.py                |   2 +
 tests/models/test_param.py                         |   4 +
 tests/models/test_pool.py                          |   2 +
 tests/models/test_renderedtifields.py              |   3 +
 tests/models/test_serialized_dag.py                |   2 +
 tests/models/test_skipmixin.py                     |   3 +
 tests/models/test_taskinstance.py                  |   2 +
 tests/models/test_taskmixin.py                     |   2 +
 tests/models/test_timestamp.py                     |   2 +
 tests/models/test_trigger.py                       |   2 +
 tests/models/test_variable.py                      |   2 +
 tests/models/test_xcom.py                          |   2 +
 tests/models/test_xcom_arg.py                      |   3 +
 tests/models/test_xcom_arg_map.py                  |   2 +
 tests/notifications/test_basenotifier.py           |   2 +
 tests/operators/test_bash.py                       |   2 +
 tests/operators/test_branch_operator.py            |   4 +
 tests/operators/test_datetime.py                   |   2 +
 tests/operators/test_email.py                      |   4 +
 tests/operators/test_generic_transfer.py           |   2 +
 tests/operators/test_latest_only_operator.py       |   4 +
 tests/operators/test_python.py                     |  23 +-
 tests/operators/test_subdag_operator.py            |   2 +
 tests/operators/test_trigger_dagrun.py             |   2 +
 tests/operators/test_weekday.py                    |   2 +
 tests/plugins/test_plugins_manager.py              |   4 +
 tests/providers/airbyte/hooks/test_airbyte.py      |   2 +
 .../alibaba/cloud/log/test_oss_task_handler.py     |   2 +
 tests/providers/amazon/aws/hooks/test_base_aws.py  |  60 +-
 .../amazon/aws/hooks/test_batch_waiters.py         |   2 +-
 tests/providers/amazon/aws/hooks/test_chime.py     |   2 +
 tests/providers/amazon/aws/hooks/test_s3.py        |  33 +-
 tests/providers/amazon/aws/links/test_links.py     |   1 +
 .../amazon/aws/log/test_cloudwatch_task_handler.py |   1 +
 .../amazon/aws/log/test_s3_task_handler.py         |   1 +
 .../amazon/aws/notifications/test_chime.py         |   4 +
 .../providers/amazon/aws/operators/test_appflow.py |   7 +
 .../providers/amazon/aws/operators/test_athena.py  |   1 +
 .../amazon/aws/operators/test_datasync.py          |   5 +
 .../aws/operators/test_dms_describe_tasks.py       |   3 +
 .../amazon/aws/operators/test_emr_add_steps.py     |   4 +-
 .../amazon/aws/operators/test_emr_containers.py    |   5 -
 .../aws/operators/test_emr_create_job_flow.py      |   4 +-
 tests/providers/amazon/aws/operators/test_glue.py  |   6 +-
 .../amazon/aws/operators/test_sagemaker_base.py    |   1 +
 tests/providers/amazon/aws/sensors/test_ecs.py     |   3 +
 tests/providers/amazon/aws/sensors/test_eks.py     |  37 +-
 tests/providers/amazon/aws/sensors/test_glue.py    |   4 -
 tests/providers/amazon/aws/sensors/test_s3_key.py  |   2 +
 .../amazon/aws/sensors/test_s3_keys_unchanged.py   |   1 +
 tests/providers/amazon/aws/transfers/test_base.py  |   1 +
 .../amazon/aws/transfers/test_dynamodb_to_s3.py    |   1 +
 .../amazon/aws/transfers/test_google_api_to_s3.py  |   5 +-
 .../amazon/aws/transfers/test_mongo_to_s3.py       |   3 +
 .../amazon/aws/transfers/test_s3_to_sftp.py        |   4 +
 .../amazon/aws/transfers/test_s3_to_sql.py         |   6 +-
 .../amazon/aws/transfers/test_salesforce_to_s3.py  |   5 +
 .../amazon/aws/transfers/test_sftp_to_s3.py        |   2 +
 .../amazon/aws/utils/test_connection_wrapper.py    |   8 +-
 tests/providers/apache/druid/hooks/test_druid.py   |  12 +-
 .../providers/apache/druid/operators/test_druid.py |   4 +
 .../flink/operators/test_flink_kubernetes.py       |   5 +
 .../apache/flink/sensors/test_flink_kubernetes.py  |   3 +
 tests/providers/apache/hdfs/hooks/test_webhdfs.py  | 249 ++++----
 tests/providers/apache/hive/hooks/test_hive.py     |  21 +-
 .../hive/sensors/test_named_hive_partition.py      |   2 +
 .../apache/hive/transfers/test_vertica_to_hive.py  |   4 +
 .../apache/kafka/hooks/test_admin_client.py        |   2 +
 .../providers/apache/kafka/hooks/test_consumer.py  |   2 +
 .../providers/apache/kafka/hooks/test_producer.py  |   3 +
 .../apache/kafka/operators/test_consume.py         |   5 +
 .../apache/kafka/operators/test_produce.py         |   5 +
 tests/providers/apache/kafka/sensors/test_kafka.py |   3 +
 .../apache/kafka/triggers/test_await_message.py    |   2 +
 tests/providers/apache/kylin/hooks/test_kylin.py   |   2 +
 .../apache/kylin/operators/test_kylin_cube.py      |   1 +
 tests/providers/apache/livy/hooks/test_livy.py     |   5 +-
 tests/providers/apache/livy/operators/test_livy.py |   3 +
 tests/providers/apache/livy/sensors/test_livy.py   |   3 +
 tests/providers/apache/livy/triggers/test_livy.py  |   2 +
 tests/providers/apache/pig/hooks/test_pig.py       |   1 +
 tests/providers/apache/pig/operators/test_pig.py   |   5 +
 tests/providers/apache/pinot/hooks/test_pinot.py   |   1 +
 .../apache/spark/hooks/test_spark_jdbc.py          |   2 +
 .../providers/apache/spark/hooks/test_spark_sql.py |   2 +
 .../apache/spark/hooks/test_spark_submit.py        |   2 +
 .../apache/spark/operators/test_spark_submit.py    |   3 +
 tests/providers/apache/sqoop/hooks/test_sqoop.py   |   2 +
 .../apprise/notifications/test_apprise.py          |   3 +
 tests/providers/arangodb/hooks/test_arangodb.py    |   5 +
 tests/providers/arangodb/sensors/test_arangodb.py  |   5 +
 .../providers/asana/operators/test_asana_tasks.py  |   5 +
 tests/providers/atlassian/jira/hooks/test_jira.py  |   5 +
 .../atlassian/jira/operators/test_jira.py          |   5 +
 .../providers/atlassian/jira/sensors/test_jira.py  |   4 +
 .../celery/executors/test_celery_executor.py       |   3 +
 tests/providers/cloudant/hooks/test_cloudant.py    |   2 +
 .../cncf/kubernetes/decorators/test_kubernetes.py  |   3 +
 .../executors/test_kubernetes_executor.py          |  22 +
 .../cncf/kubernetes/hooks/test_kubernetes.py       |   3 +
 .../cncf/kubernetes/operators/test_pod.py          |   3 +
 .../kubernetes/sensors/test_spark_kubernetes.py    |   3 +
 .../cncf/kubernetes/test_template_rendering.py     |   3 +
 tests/providers/common/sql/hooks/test_sql.py       |   2 +
 tests/providers/common/sql/operators/test_sql.py   | 101 ++--
 tests/providers/common/sql/sensors/test_sql.py     |   2 +
 tests/providers/daskexecutor/test_dask_executor.py |   2 +
 .../providers/databricks/hooks/test_databricks.py  |  13 +
 .../databricks/hooks/test_databricks_sql.py        |   2 +
 .../databricks/operators/test_databricks.py        |   4 +
 .../sensors/test_databricks_partition.py           |   1 +
 .../databricks/sensors/test_databricks_sql.py      |   1 +
 .../databricks/triggers/test_databricks.py         |   3 +
 tests/providers/datadog/sensors/test_datadog.py    |   4 +
 tests/providers/dbt/cloud/hooks/test_dbt_cloud.py  |   2 +
 .../dbt/cloud/operators/test_dbt_cloud.py          |   2 +
 .../providers/dbt/cloud/sensors/test_dbt_cloud.py  |   3 +
 tests/providers/dingding/hooks/test_dingding.py    |   2 +
 .../discord/hooks/test_discord_webhook.py          |   2 +
 .../discord/notifications/test_discord.py          |   2 +
 tests/providers/docker/decorators/test_docker.py   |   3 +
 .../elasticsearch/log/test_es_task_handler.py      |   2 +
 tests/providers/exasol/hooks/test_sql.py           |   3 +
 tests/providers/ftp/hooks/test_ftp.py              |   3 +
 tests/providers/github/hooks/test_github.py        |   4 +
 tests/providers/github/operators/test_github.py    |   5 +
 tests/providers/github/sensors/test_github.py      |   5 +
 .../providers/google/cloud/hooks/test_bigquery.py  |  12 +
 .../google/cloud/hooks/test_bigquery_dts.py        |   1 +
 .../google/cloud/hooks/test_cloud_build.py         |   1 +
 .../google/cloud/hooks/test_compute_ssh.py         |   3 +
 .../providers/google/cloud/hooks/test_dataflow.py  |   2 +
 .../providers/google/cloud/hooks/test_dataform.py  |   5 +-
 .../providers/google/cloud/hooks/test_dataproc.py  |   1 +
 tests/providers/google/cloud/hooks/test_gcs.py     |   1 +
 .../google/cloud/hooks/test_kubernetes_engine.py   |   1 +
 .../providers/google/cloud/hooks/test_mlengine.py  |   1 +
 .../google/cloud/hooks/test_stackdriver.py         |   1 +
 .../google/cloud/log/test_gcs_task_handler.py      |   1 +
 .../cloud/log/test_stackdriver_task_handler.py     |   1 +
 .../google/cloud/operators/test_bigquery.py        |  16 +
 .../test_cloud_storage_transfer_service.py         |  10 +
 .../google/cloud/operators/test_compute.py         |   4 +
 .../google/cloud/operators/test_dataflow.py        |   2 +
 .../google/cloud/operators/test_dataprep.py        |   3 +
 .../google/cloud/operators/test_dataproc.py        |   7 +
 .../google/cloud/operators/test_functions.py       |   1 +
 .../cloud/operators/test_kubernetes_engine.py      |   1 +
 .../google/cloud/secrets/test_secret_manager.py    |   2 +
 .../google/cloud/sensors/test_cloud_composer.py    |   1 +
 .../cloud/transfers/test_cassandra_to_gcs.py       |   3 +
 .../google/cloud/transfers/test_gcs_to_bigquery.py |   1 +
 .../google/cloud/transfers/test_local_to_gcs.py    |   3 +
 .../google/cloud/transfers/test_s3_to_gcs.py       |   1 +
 .../cloud/transfers/test_salesforce_to_gcs.py      |   3 +
 .../google/cloud/transfers/test_sql_to_gcs.py      |   1 +
 .../google/cloud/triggers/test_bigquery.py         |   3 +
 .../google/cloud/triggers/test_dataproc.py         |   2 +
 .../cloud/triggers/test_kubernetes_engine.py       |   1 +
 .../providers/google/cloud/utils/base_gcp_mock.py  |   9 +-
 .../cloud/utils/test_credentials_provider.py       |   1 +
 .../cloud/utils/test_mlengine_operator_utils.py    |   1 +
 .../common/auth_backend/test_google_openid.py      |   1 +
 .../google/common/hooks/test_base_google.py        |   2 +
 .../google/common/hooks/test_discovery_api.py      |   7 +-
 .../operators/test_campaign_manager.py             |   1 +
 .../operators/test_display_video.py                |   1 +
 .../operators/test_search_ads.py                   |   1 +
 .../marketing_platform/sensors/test_search_ads.py  |   4 +
 tests/providers/google/suite/hooks/test_drive.py   |   3 +
 tests/providers/http/hooks/test_http.py            |   4 +
 tests/providers/http/sensors/test_http.py          |   3 +
 tests/providers/imap/hooks/test_imap.py            |   3 +
 tests/providers/jdbc/hooks/test_jdbc.py            |   5 +
 tests/providers/microsoft/azure/hooks/test_adx.py  |   2 +
 .../microsoft/azure/hooks/test_base_azure.py       |   4 +
 tests/providers/microsoft/azure/hooks/test_wasb.py |   3 +
 .../microsoft/azure/log/test_wasb_task_handler.py  |   3 +
 .../microsoft/azure/operators/test_adx.py          |   2 +
 .../azure/operators/test_azure_data_factory.py     |   5 +-
 .../providers/microsoft/mssql/hooks/test_mssql.py  |   1 +
 .../providers/microsoft/winrm/hooks/test_winrm.py  |   2 +
 tests/providers/mongo/hooks/test_mongo.py          |   3 +
 .../providers/mysql/transfers/test_s3_to_mysql.py  |   6 +-
 .../openlineage/extractors/test_bash_extractor.py  |   2 +
 .../extractors/test_default_extractor.py           |   4 +
 .../extractors/test_python_extractor.py            |   2 +
 .../providers/openlineage/plugins/test_listener.py |   3 +
 .../plugins/test_openlineage_adapter.py            |   2 +
 tests/providers/openlineage/plugins/test_utils.py  |   2 +
 .../providers/opensearch/hooks/test_opensearch.py  |   5 +
 .../opensearch/operators/test_opensearch.py        |   3 +
 tests/providers/opsgenie/hooks/test_opsgenie.py    |   2 +
 tests/providers/oracle/operators/test_oracle.py    |   1 +
 tests/providers/pagerduty/hooks/test_pagerduty.py  |   3 +
 .../pagerduty/hooks/test_pagerduty_events.py       |   2 +
 .../pagerduty/notifications/test_pagerduty.py      |   5 +
 .../papermill/operators/test_papermill.py          |   1 +
 tests/providers/redis/hooks/test_redis.py          |   4 +
 .../providers/redis/log/test_redis_task_handler.py |   2 +
 .../providers/salesforce/hooks/test_salesforce.py  |   5 +
 .../providers/sftp/decorators/sensors/test_sftp.py |   3 +
 tests/providers/sftp/hooks/test_sftp.py            |   2 +
 tests/providers/sftp/operators/test_sftp.py        |   3 +
 tests/providers/slack/notifications/test_slack.py  |   4 +
 .../providers/slack/transfers/test_sql_to_slack.py |   1 +
 tests/providers/smtp/hooks/test_smtp.py            |   3 +
 tests/providers/smtp/notifications/test_smtp.py    |   4 +
 .../snowflake/operators/test_snowflake.py          |   1 +
 tests/providers/sqlite/hooks/test_sqlite.py        |   3 +
 tests/providers/ssh/hooks/test_ssh.py              |   3 +
 tests/providers/ssh/operators/test_ssh.py          |   3 +
 tests/providers/tableau/hooks/test_tableau.py      |   2 +
 tests/providers/tabular/hooks/test_tabular.py      |   3 +
 tests/providers/telegram/hooks/test_telegram.py    |   3 +
 .../providers/telegram/operators/test_telegram.py  |   2 +
 tests/providers/zendesk/hooks/test_zendesk.py      |   2 +
 tests/security/test_kerberos.py                    |   2 +
 tests/sensors/test_base.py                         |   2 +
 tests/sensors/test_external_task_sensor.py         |   3 +
 tests/sensors/test_filesystem.py                   |   3 +
 tests/sensors/test_python.py                       |   2 +
 tests/sensors/test_time_delta.py                   |   5 +
 tests/sensors/test_timeout_sensor.py               |   3 +
 tests/sensors/test_weekday_sensor.py               |   3 +
 tests/serialization/test_dag_serialization.py      |  13 +
 tests/serialization/test_pydantic_models.py        |   4 +
 tests/serialization/test_serialized_objects.py     |   1 +
 .../system/providers/amazon/aws/utils/__init__.py  |   2 +
 tests/task/task_runner/test_base_task_runner.py    |   2 +
 .../task/task_runner/test_standard_task_runner.py  |   4 +
 tests/task/task_runner/test_task_runner.py         |   3 +
 .../deps/test_dag_ti_slots_available_dep.py        |   4 +
 tests/ti_deps/deps/test_dag_unpaused_dep.py        |   4 +
 tests/ti_deps/deps/test_dagrun_exists_dep.py       |   4 +
 tests/ti_deps/deps/test_dagrun_id_dep.py           |   4 +
 tests/ti_deps/deps/test_not_in_retry_period_dep.py |   3 +
 .../deps/test_not_previously_skipped_dep.py        |   2 +
 .../ti_deps/deps/test_pool_slots_available_dep.py  |   4 +
 tests/ti_deps/deps/test_prev_dagrun_dep.py         |   2 +
 tests/ti_deps/deps/test_ready_to_reschedule_dep.py |   4 +
 tests/ti_deps/deps/test_runnable_exec_date_dep.py  |   2 +
 tests/ti_deps/deps/test_task_concurrency.py        |   2 +
 tests/ti_deps/deps/test_task_not_running_dep.py    |   4 +
 tests/ti_deps/deps/test_trigger_rule_dep.py        |   3 +
 tests/ti_deps/deps/test_valid_state_dep.py         |   2 +
 tests/triggers/test_external_task.py               |   2 +
 tests/utils/log/test_colored_log.py                |   4 +
 tests/utils/log/test_log_reader.py                 |   2 +
 tests/utils/test_cli_util.py                       |   2 +
 tests/utils/test_db.py                             |   2 +
 tests/utils/test_db_cleanup.py                     |   2 +
 tests/utils/test_dot_renderer.py                   |   4 +
 tests/utils/test_helpers.py                        |   2 +
 tests/utils/test_log_handlers.py                   |   2 +
 tests/utils/test_process_utils.py                  |   2 +
 tests/utils/test_retries.py                        |   1 +
 tests/utils/test_session.py                        |   2 +
 tests/utils/test_sqlalchemy.py                     |   3 +
 tests/utils/test_state.py                          |   4 +
 .../test_task_handler_with_custom_formatter.py     |   3 +
 tests/utils/test_types.py                          |   4 +
 .../www/api/experimental/test_dag_runs_endpoint.py |   2 +
 tests/www/api/experimental/test_endpoints.py       |   2 +
 tests/www/test_app.py                              |   2 +
 tests/www/test_init_views.py                       |   2 +
 tests/www/test_security.py                         |   2 +
 tests/www/test_utils.py                            |   6 +
 tests/www/views/test_session.py                    |   2 +
 tests/www/views/test_views.py                      |   2 +
 tests/www/views/test_views_acl.py                  |   2 +
 tests/www/views/test_views_base.py                 |   2 +
 tests/www/views/test_views_blocked.py              |   2 +
 tests/www/views/test_views_cluster_activity.py     |   2 +
 tests/www/views/test_views_configuration.py        |   4 +
 tests/www/views/test_views_connection.py           |   2 +
 tests/www/views/test_views_custom_user_views.py    |   2 +
 tests/www/views/test_views_dagrun.py               |   2 +
 tests/www/views/test_views_dataset.py              |   2 +
 tests/www/views/test_views_decorators.py           |   2 +
 tests/www/views/test_views_extra_links.py          |   2 +
 tests/www/views/test_views_grid.py                 |   3 +
 tests/www/views/test_views_home.py                 |   2 +
 tests/www/views/test_views_log.py                  |   2 +
 tests/www/views/test_views_mount.py                |   2 +
 tests/www/views/test_views_pool.py                 |   2 +
 tests/www/views/test_views_rate_limit.py           |   2 +
 tests/www/views/test_views_rendered.py             |  11 +
 tests/www/views/test_views_robots.py               |   4 +
 tests/www/views/test_views_task_norun.py           |   2 +
 tests/www/views/test_views_tasks.py                |   2 +
 tests/www/views/test_views_trigger_dag.py          |   2 +
 tests/www/views/test_views_variable.py             |   1 +
 456 files changed, 5232 insertions(+), 1620 deletions(-)
 create mode 100644 dev/breeze/tests/test_pytest_args_for_test_types.py
 create mode 100644 images/breeze/output_testing_db-tests.svg
 create mode 100644 images/breeze/output_testing_non-db-tests.svg
 copy licenses/{LICENSE-elasticmock.txt => LICENSE-pytest-capture-warnings.txt} 
(89%)
 copy scripts/ci/docker-compose/{backend-sqlite.yml => backend-none.yml} (84%)
 delete mode 100644 scripts/in_container/filter_out_warnings.py

Reply via email to