You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by ka...@apache.org on 2020/10/22 12:24:06 UTC

[airflow] branch master updated (8045cc2 -> 7c6dfcb)

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

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


    from 8045cc2  Stop scheduler from thinking that upstream_failed tasks are running (#11730)
     add 7c6dfcb  Use unittest.mock instead of backported mock library (#11643)

No new revisions were added by this update.

Summary of changes:
 tests/api_connexion/endpoints/test_config_endpoint.py             | 2 +-
 tests/cli/commands/test_celery_command.py                         | 7 ++++---
 tests/cli/commands/test_dag_command.py                            | 3 +--
 tests/core/test_logging_config.py                                 | 3 +--
 tests/core/test_sqlalchemy_config.py                              | 2 +-
 tests/executors/test_celery_kubernetes_executor.py                | 2 +-
 tests/executors/test_executor_loader.py                           | 2 +-
 tests/executors/test_kubernetes_executor.py                       | 2 +-
 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/kubernetes/test_client.py                                   | 2 +-
 tests/kubernetes/test_pod_launcher.py                             | 2 +-
 tests/models/test_dagcode.py                                      | 3 +--
 tests/models/test_dagrun.py                                       | 2 +-
 tests/models/test_taskinstance.py                                 | 2 +-
 tests/operators/test_bash.py                                      | 6 ++----
 tests/operators/test_sql.py                                       | 2 +-
 tests/providers/amazon/aws/hooks/test_base_aws.py                 | 2 +-
 tests/providers/amazon/aws/hooks/test_batch_client.py             | 2 +-
 tests/providers/amazon/aws/hooks/test_batch_waiters.py            | 2 +-
 tests/providers/amazon/aws/hooks/test_datasync.py                 | 2 +-
 tests/providers/amazon/aws/hooks/test_glacier.py                  | 2 +-
 tests/providers/amazon/aws/hooks/test_glue.py                     | 2 +-
 tests/providers/amazon/aws/hooks/test_glue_catalog.py             | 2 +-
 tests/providers/amazon/aws/hooks/test_s3.py                       | 2 +-
 tests/providers/amazon/aws/hooks/test_sagemaker.py                | 2 +-
 tests/providers/amazon/aws/operators/test_athena.py               | 2 +-
 tests/providers/amazon/aws/operators/test_batch.py                | 2 +-
 tests/providers/amazon/aws/operators/test_ecs.py                  | 2 +-
 tests/providers/amazon/aws/operators/test_glacier.py              | 2 +-
 tests/providers/amazon/aws/operators/test_glue.py                 | 2 +-
 tests/providers/amazon/aws/operators/test_s3_bucket.py            | 2 +-
 tests/providers/amazon/aws/operators/test_s3_list.py              | 2 +-
 tests/providers/amazon/aws/operators/test_sagemaker_endpoint.py   | 2 +-
 .../amazon/aws/operators/test_sagemaker_endpoint_config.py        | 2 +-
 tests/providers/amazon/aws/operators/test_sagemaker_model.py      | 2 +-
 tests/providers/amazon/aws/operators/test_sagemaker_processing.py | 2 +-
 tests/providers/amazon/aws/operators/test_sagemaker_training.py   | 2 +-
 tests/providers/amazon/aws/operators/test_sagemaker_transform.py  | 2 +-
 tests/providers/amazon/aws/operators/test_sagemaker_tuning.py     | 2 +-
 tests/providers/amazon/aws/sensors/test_athena.py                 | 2 +-
 tests/providers/amazon/aws/sensors/test_cloud_formation.py        | 2 +-
 tests/providers/amazon/aws/sensors/test_glacier.py                | 2 +-
 tests/providers/amazon/aws/sensors/test_glue.py                   | 2 +-
 tests/providers/amazon/aws/sensors/test_glue_catalog_partition.py | 2 +-
 tests/providers/amazon/aws/sensors/test_sagemaker_endpoint.py     | 2 +-
 tests/providers/amazon/aws/sensors/test_sagemaker_training.py     | 2 +-
 tests/providers/amazon/aws/sensors/test_sagemaker_transform.py    | 2 +-
 tests/providers/amazon/aws/sensors/test_sagemaker_tuning.py       | 2 +-
 tests/providers/amazon/aws/transfers/test_gcs_to_s3.py            | 5 +++--
 tests/providers/amazon/aws/transfers/test_glacier_to_gcs.py       | 2 +-
 tests/providers/amazon/aws/transfers/test_mongo_to_s3.py          | 2 +-
 tests/providers/apache/cassandra/hooks/test_cassandra.py          | 2 +-
 tests/providers/apache/druid/operators/test_druid_check.py        | 2 +-
 tests/providers/apache/hive/transfers/test_s3_to_hive.py          | 2 +-
 tests/providers/apache/pig/hooks/test_pig.py                      | 2 +-
 tests/providers/apache/pig/operators/test_pig.py                  | 2 +-
 tests/providers/apache/spark/hooks/test_spark_jdbc_script.py      | 2 +-
 tests/providers/cloudant/hooks/test_cloudant.py                   | 2 +-
 tests/providers/databricks/hooks/test_databricks.py               | 2 +-
 tests/providers/databricks/operators/test_databricks.py           | 2 +-
 tests/providers/datadog/sensors/test_datadog.py                   | 2 +-
 tests/providers/docker/hooks/test_docker.py                       | 2 +-
 tests/providers/docker/operators/test_docker.py                   | 8 ++++----
 tests/providers/docker/operators/test_docker_swarm.py             | 2 +-
 tests/providers/elasticsearch/log/elasticmock/__init__.py         | 2 +-
 tests/providers/exasol/hooks/test_exasol.py                       | 2 +-
 tests/providers/exasol/operators/test_exasol.py                   | 2 +-
 tests/providers/facebook/ads/hooks/test_ads.py                    | 2 +-
 tests/providers/google/ads/hooks/test_ads.py                      | 2 +-
 tests/providers/google/cloud/hooks/test_automl.py                 | 2 +-
 tests/providers/google/cloud/hooks/test_bigquery_dts.py           | 2 +-
 tests/providers/google/cloud/hooks/test_bigtable.py               | 4 ++--
 tests/providers/google/cloud/hooks/test_cloud_build.py            | 2 +-
 tests/providers/google/cloud/hooks/test_cloud_memorystore.py      | 2 +-
 tests/providers/google/cloud/hooks/test_cloud_sql.py              | 4 ++--
 .../google/cloud/hooks/test_cloud_storage_transfer_service.py     | 4 ++--
 tests/providers/google/cloud/hooks/test_compute.py                | 4 ++--
 tests/providers/google/cloud/hooks/test_dataflow.py               | 4 ++--
 tests/providers/google/cloud/hooks/test_dataprep.py               | 2 +-
 tests/providers/google/cloud/hooks/test_dataproc.py               | 2 +-
 tests/providers/google/cloud/hooks/test_datastore.py              | 2 +-
 tests/providers/google/cloud/hooks/test_dlp.py                    | 4 ++--
 tests/providers/google/cloud/hooks/test_functions.py              | 4 ++--
 tests/providers/google/cloud/hooks/test_kms.py                    | 2 +-
 tests/providers/google/cloud/hooks/test_kubernetes_engine.py      | 4 ++--
 tests/providers/google/cloud/hooks/test_life_sciences.py          | 2 +-
 tests/providers/google/cloud/hooks/test_natural_language.py       | 2 +-
 tests/providers/google/cloud/hooks/test_pubsub.py                 | 2 +-
 tests/providers/google/cloud/hooks/test_secret_manager.py         | 2 +-
 tests/providers/google/cloud/hooks/test_spanner.py                | 4 ++--
 tests/providers/google/cloud/hooks/test_speech_to_text.py         | 2 +-
 tests/providers/google/cloud/hooks/test_stackdriver.py            | 2 +-
 tests/providers/google/cloud/hooks/test_tasks.py                  | 2 +-
 tests/providers/google/cloud/hooks/test_text_to_speech.py         | 2 +-
 tests/providers/google/cloud/hooks/test_translate.py              | 2 +-
 tests/providers/google/cloud/hooks/test_video_intelligence.py     | 2 +-
 tests/providers/google/cloud/hooks/test_vision.py                 | 2 +-
 tests/providers/google/cloud/operators/test_automl.py             | 2 +-
 tests/providers/google/cloud/operators/test_bigquery.py           | 2 +-
 tests/providers/google/cloud/operators/test_bigquery_dts.py       | 2 +-
 tests/providers/google/cloud/operators/test_bigtable.py           | 2 +-
 tests/providers/google/cloud/operators/test_cloud_build.py        | 2 +-
 tests/providers/google/cloud/operators/test_cloud_sql.py          | 2 +-
 .../google/cloud/operators/test_cloud_storage_transfer_service.py | 2 +-
 tests/providers/google/cloud/operators/test_compute.py            | 2 +-
 tests/providers/google/cloud/operators/test_dataflow.py           | 2 +-
 tests/providers/google/cloud/operators/test_datafusion.py         | 2 +-
 tests/providers/google/cloud/operators/test_dlp.py                | 2 +-
 tests/providers/google/cloud/operators/test_functions.py          | 2 +-
 tests/providers/google/cloud/operators/test_gcs.py                | 2 +-
 tests/providers/google/cloud/operators/test_kubernetes_engine.py  | 4 ++--
 tests/providers/google/cloud/operators/test_life_sciences.py      | 2 +-
 tests/providers/google/cloud/operators/test_mlengine_utils.py     | 2 +-
 tests/providers/google/cloud/operators/test_natural_language.py   | 2 +-
 tests/providers/google/cloud/operators/test_pubsub.py             | 2 +-
 tests/providers/google/cloud/operators/test_spanner.py            | 2 +-
 tests/providers/google/cloud/operators/test_speech_to_text.py     | 2 +-
 tests/providers/google/cloud/operators/test_stackdriver.py        | 2 +-
 tests/providers/google/cloud/operators/test_tasks.py              | 2 +-
 tests/providers/google/cloud/operators/test_text_to_speech.py     | 2 +-
 tests/providers/google/cloud/operators/test_translate.py          | 2 +-
 tests/providers/google/cloud/operators/test_translate_speech.py   | 2 +-
 tests/providers/google/cloud/operators/test_video_intelligence.py | 2 +-
 tests/providers/google/cloud/operators/test_vision.py             | 2 +-
 tests/providers/google/cloud/sensors/test_bigquery_dts.py         | 2 +-
 tests/providers/google/cloud/sensors/test_bigtable.py             | 2 +-
 .../google/cloud/sensors/test_cloud_storage_transfer_service.py   | 2 +-
 tests/providers/google/cloud/sensors/test_pubsub.py               | 2 +-
 tests/providers/google/cloud/transfers/test_adls_to_gcs.py        | 2 +-
 .../google/cloud/transfers/test_azure_fileshare_to_gcs.py         | 2 +-
 .../providers/google/cloud/transfers/test_bigquery_to_bigquery.py | 2 +-
 tests/providers/google/cloud/transfers/test_bigquery_to_gcs.py    | 2 +-
 tests/providers/google/cloud/transfers/test_bigquery_to_mysql.py  | 2 +-
 tests/providers/google/cloud/transfers/test_cassandra_to_gcs.py   | 2 +-
 tests/providers/google/cloud/transfers/test_gcs_to_bigquery.py    | 2 +-
 tests/providers/google/cloud/transfers/test_gcs_to_gcs.py         | 2 +-
 tests/providers/google/cloud/transfers/test_gcs_to_local.py       | 2 +-
 tests/providers/google/cloud/transfers/test_gcs_to_sftp.py        | 2 +-
 tests/providers/google/cloud/transfers/test_local_to_gcs.py       | 2 +-
 tests/providers/google/cloud/transfers/test_mssql_to_gcs.py       | 2 +-
 tests/providers/google/cloud/transfers/test_mysql_to_gcs.py       | 2 +-
 tests/providers/google/cloud/transfers/test_postgres_to_gcs.py    | 2 +-
 tests/providers/google/cloud/transfers/test_presto_to_gcs.py      | 2 +-
 tests/providers/google/cloud/transfers/test_s3_to_gcs.py          | 2 +-
 tests/providers/google/cloud/transfers/test_sftp_to_gcs.py        | 2 +-
 tests/providers/google/cloud/transfers/test_sheets_to_gcs.py      | 2 +-
 tests/providers/google/cloud/transfers/test_sql_to_gcs.py         | 2 +-
 tests/providers/google/cloud/utils/test_credentials_provider.py   | 2 +-
 .../providers/google/cloud/utils/test_mlengine_operator_utils.py  | 2 +-
 .../google/cloud/utils/test_mlengine_prediction_summary.py        | 2 +-
 tests/providers/google/common/hooks/test_base_google.py           | 2 +-
 tests/providers/google/firebase/hooks/test_firestore.py           | 2 +-
 tests/providers/google/suite/hooks/test_drive.py                  | 2 +-
 tests/providers/google/suite/hooks/test_sheets.py                 | 2 +-
 tests/providers/google/suite/operators/test_sheets.py             | 2 +-
 tests/providers/google/suite/transfers/test_gcs_to_sheets.py      | 2 +-
 tests/providers/grpc/hooks/test_grpc.py                           | 2 +-
 tests/providers/grpc/operators/test_grpc.py                       | 2 +-
 tests/providers/hashicorp/_internal_client/test_vault_client.py   | 2 +-
 tests/providers/hashicorp/hooks/test_vault.py                     | 2 +-
 tests/providers/http/hooks/test_http.py                           | 2 +-
 tests/providers/http/operators/test_http.py                       | 2 +-
 tests/providers/http/sensors/test_http.py                         | 2 +-
 tests/providers/jenkins/operators/test_jenkins_job_trigger.py     | 2 +-
 tests/providers/microsoft/azure/hooks/test_azure_batch.py         | 2 +-
 tests/providers/microsoft/azure/hooks/test_azure_cosmos.py        | 2 +-
 tests/providers/microsoft/azure/hooks/test_azure_data_lake.py     | 2 +-
 tests/providers/microsoft/azure/hooks/test_azure_fileshare.py     | 2 +-
 tests/providers/microsoft/azure/hooks/test_wasb.py                | 2 +-
 tests/providers/microsoft/azure/operators/test_adls_list.py       | 2 +-
 tests/providers/microsoft/azure/operators/test_azure_batch.py     | 2 +-
 .../microsoft/azure/operators/test_azure_container_instances.py   | 2 +-
 tests/providers/microsoft/azure/operators/test_azure_cosmos.py    | 2 +-
 .../providers/microsoft/azure/operators/test_wasb_delete_blob.py  | 2 +-
 tests/providers/microsoft/azure/sensors/test_wasb.py              | 2 +-
 .../providers/microsoft/azure/transfers/test_azure_blob_to_gcs.py | 2 +-
 tests/providers/microsoft/azure/transfers/test_file_to_wasb.py    | 2 +-
 tests/providers/microsoft/azure/transfers/test_local_to_adls.py   | 2 +-
 .../microsoft/azure/transfers/test_oracle_to_azure_data_lake.py   | 4 ++--
 tests/providers/microsoft/mssql/hooks/test_mssql.py               | 2 +-
 tests/providers/microsoft/mssql/operators/test_mssql.py           | 2 +-
 tests/providers/openfaas/hooks/test_openfaas.py                   | 2 +-
 tests/providers/oracle/hooks/test_oracle.py                       | 2 +-
 tests/providers/oracle/operators/test_oracle.py                   | 2 +-
 tests/providers/oracle/transfers/test_oracle_to_oracle.py         | 2 +-
 tests/providers/plexus/hooks/test_plexus.py                       | 5 +++--
 tests/providers/plexus/operators/test_job.py                      | 4 ++--
 tests/providers/qubole/operators/test_qubole_check.py             | 2 +-
 tests/providers/redis/operators/test_redis_publish.py             | 2 +-
 tests/providers/samba/hooks/test_samba.py                         | 2 +-
 tests/providers/sendgrid/utils/test_emailer.py                    | 2 +-
 tests/providers/singularity/operators/test_singularity.py         | 2 +-
 tests/providers/slack/hooks/test_slack.py                         | 2 +-
 tests/providers/slack/operators/test_slack.py                     | 2 +-
 tests/providers/snowflake/operators/test_snowflake.py             | 2 +-
 tests/providers/ssh/hooks/test_ssh.py                             | 2 +-
 tests/sensors/test_date_time_sensor.py                            | 3 ++-
 tests/sensors/test_smart_sensor_operator.py                       | 2 +-
 tests/sensors/test_time_sensor.py                                 | 2 +-
 tests/ti_deps/deps/test_dagrun_id_dep.py                          | 3 +--
 tests/ti_deps/deps/test_pool_slots_available_dep.py               | 3 +--
 tests/utils/test_dot_renderer.py                                  | 3 +--
 tests/utils/test_email.py                                         | 3 +--
 tests/utils/test_python_virtualenv.py                             | 3 +--
 207 files changed, 232 insertions(+), 238 deletions(-)