You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by po...@apache.org on 2021/01/23 05:19:55 UTC

[airflow] branch master updated (9592be8 -> a9ac2b0)

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

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


    from 9592be8  Fix Google Spanner example dag (#13842)
     add a9ac2b0  Switch to f-strings using flynt. (#13732)

No new revisions were added by this update.

Summary of changes:
 .pre-commit-config.yaml                            |  7 ++++
 BREEZE.rst                                         |  2 +-
 STATIC_CODE_CHECKS.rst                             |  2 +
 airflow/api/common/experimental/get_code.py        |  2 +-
 airflow/api/common/experimental/pool.py            |  6 +--
 .../api_connexion/endpoints/connection_endpoint.py |  2 +-
 airflow/cli/commands/dag_command.py                |  2 +-
 airflow/cli/commands/task_command.py               | 11 ++----
 airflow/cli/commands/user_command.py               |  8 ++--
 airflow/cli/commands/variable_command.py           |  2 +-
 airflow/configuration.py                           |  2 +-
 .../example_passing_params_via_test_command.py     |  6 +--
 airflow/example_dags/example_trigger_target_dag.py |  2 +-
 airflow/example_dags/subdags/subdag.py             |  2 +-
 airflow/example_dags/tutorial_taskflow_api_etl.py  |  2 +-
 airflow/hooks/dbapi.py                             |  2 +-
 airflow/kubernetes/refresh_config.py               |  2 +-
 airflow/models/connection.py                       |  6 +--
 airflow/models/dag.py                              |  2 +-
 airflow/models/taskinstance.py                     |  4 +-
 airflow/models/xcom.py                             |  4 +-
 airflow/operators/sql.py                           | 14 +++----
 airflow/providers/amazon/aws/hooks/datasync.py     |  4 +-
 airflow/providers/amazon/aws/hooks/dynamodb.py     |  4 +-
 airflow/providers/amazon/aws/hooks/sagemaker.py    |  4 +-
 .../providers/amazon/aws/log/s3_task_handler.py    |  2 +-
 airflow/providers/amazon/aws/operators/datasync.py |  2 +-
 .../amazon/aws/operators/emr_add_steps.py          |  2 +-
 .../amazon/aws/operators/emr_create_job_flow.py    |  2 +-
 .../amazon/aws/operators/emr_modify_cluster.py     |  2 +-
 .../amazon/aws/operators/emr_terminate_job_flow.py |  2 +-
 .../amazon/aws/operators/sagemaker_endpoint.py     |  2 +-
 .../aws/operators/sagemaker_endpoint_config.py     |  2 +-
 .../amazon/aws/operators/sagemaker_model.py        |  2 +-
 .../amazon/aws/operators/sagemaker_processing.py   |  2 +-
 .../amazon/aws/operators/sagemaker_training.py     |  2 +-
 .../amazon/aws/operators/sagemaker_transform.py    |  2 +-
 .../amazon/aws/operators/sagemaker_tuning.py       |  2 +-
 .../providers/amazon/aws/sensors/sagemaker_base.py |  2 +-
 airflow/providers/apache/druid/hooks/druid.py      |  4 +-
 airflow/providers/apache/hdfs/sensors/hdfs.py      |  2 +-
 airflow/providers/apache/hive/hooks/hive.py        |  8 +---
 .../providers/apache/hive/operators/hive_stats.py  | 24 +++++-------
 airflow/providers/apache/spark/hooks/spark_jdbc.py |  2 +-
 .../providers/apache/spark/hooks/spark_submit.py   |  8 ++--
 .../providers/cncf/kubernetes/hooks/kubernetes.py  |  6 +--
 .../cncf/kubernetes/operators/kubernetes_pod.py    |  3 +-
 .../cncf/kubernetes/sensors/spark_kubernetes.py    |  2 +-
 airflow/providers/databricks/hooks/databricks.py   |  2 +-
 airflow/providers/docker/operators/docker_swarm.py |  2 +-
 airflow/providers/ftp/hooks/ftp.py                 |  4 +-
 airflow/providers/google/cloud/hooks/bigquery.py   |  4 +-
 airflow/providers/google/cloud/hooks/compute.py    | 20 +++-------
 airflow/providers/google/cloud/hooks/dataflow.py   | 12 +++---
 airflow/providers/google/cloud/hooks/functions.py  |  4 +-
 .../google/cloud/hooks/kubernetes_engine.py        |  2 +-
 .../providers/google/cloud/log/gcs_task_handler.py |  4 +-
 .../providers/google/cloud/operators/bigquery.py   |  4 +-
 .../providers/google/cloud/operators/dataproc.py   |  2 +-
 .../jenkins/operators/jenkins_job_trigger.py       |  6 +--
 airflow/providers/jira/hooks/jira.py               |  4 +-
 airflow/providers/jira/operators/jira.py           |  4 +-
 .../microsoft/azure/hooks/azure_data_lake.py       |  2 +-
 .../azure/operators/azure_container_instances.py   |  2 +-
 .../providers/microsoft/winrm/operators/winrm.py   |  2 +-
 airflow/providers/mysql/hooks/mysql.py             | 21 +++-------
 airflow/providers/opsgenie/hooks/opsgenie_alert.py |  2 +-
 airflow/providers/oracle/hooks/oracle.py           |  2 +-
 airflow/providers/pagerduty/hooks/pagerduty.py     |  2 +-
 airflow/providers/plexus/operators/job.py          |  4 +-
 airflow/providers/postgres/hooks/postgres.py       |  2 +-
 airflow/providers/qubole/hooks/qubole.py           |  4 +-
 airflow/providers/salesforce/hooks/salesforce.py   |  2 +-
 airflow/providers/sftp/operators/sftp.py           |  2 +-
 .../snowflake/transfers/s3_to_snowflake.py         |  8 ++--
 airflow/providers/ssh/operators/ssh.py             |  2 +-
 airflow/security/kerberos.py                       |  4 +-
 airflow/security/utils.py                          |  2 +-
 airflow/sensors/date_time.py                       |  2 +-
 airflow/sensors/sql.py                             |  2 +-
 airflow/utils/cli.py                               |  2 +-
 airflow/utils/code_utils.py                        |  2 +-
 airflow/utils/log/file_task_handler.py             |  6 +--
 airflow/utils/timezone.py                          |  2 +-
 airflow/www/utils.py                               | 10 ++---
 airflow/www/validators.py                          |  4 +-
 airflow/www/views.py                               | 19 +++------
 breeze-complete                                    |  1 +
 docs/exts/airflow_intersphinx.py                   |  2 +-
 docs/exts/exampleinclude.py                        |  2 +-
 docs/exts/redirects.py                             |  2 +-
 metastore_browser/hive_metastore.py                | 14 +++----
 .../pre_commit_check_provider_yaml_files.py        |  8 ++--
 scripts/ci/pre_commit/pre_commit_yaml_to_cfg.py    |  6 +--
 setup.py                                           |  2 +-
 tests/api/common/experimental/test_pool.py         |  2 +-
 tests/cli/commands/test_connection_command.py      | 14 +++----
 tests/core/test_core.py                            |  2 +-
 tests/dags/test_subdag.py                          |  2 +-
 tests/dags_corrupted/test_impersonation_custom.py  |  2 +-
 tests/executors/test_celery_executor.py            |  2 +-
 tests/hooks/test_dbapi.py                          |  2 +-
 tests/models/test_baseoperator.py                  |  4 +-
 tests/models/test_connection.py                    |  2 +-
 tests/models/test_dag.py                           |  4 +-
 tests/models/test_dagbag.py                        |  6 +--
 tests/models/test_renderedtifields.py              |  2 +-
 .../amazon/aws/hooks/test_batch_waiters.py         |  2 +-
 tests/providers/amazon/aws/hooks/test_s3.py        |  4 +-
 tests/providers/apache/hive/hooks/test_hive.py     |  4 +-
 .../apache/hive/operators/test_hive_stats.py       | 14 +++----
 .../apache/hive/transfers/test_mysql_to_hive.py    | 24 +++++-------
 .../providers/apache/spark/hooks/test_spark_sql.py | 10 ++---
 tests/providers/apache/sqoop/hooks/test_sqoop.py   | 45 +++++++++-------------
 .../elasticsearch/log/elasticmock/__init__.py      |  2 +-
 .../providers/google/cloud/hooks/test_cloud_sql.py |  4 +-
 tests/providers/google/cloud/hooks/test_pubsub.py  | 32 +++++++--------
 .../google/cloud/operators/test_dataflow.py        |  2 +-
 .../google/cloud/operators/test_mlengine_utils.py  |  6 +--
 .../google/cloud/operators/test_pubsub.py          |  2 +-
 tests/providers/google/cloud/sensors/test_gcs.py   |  2 +-
 .../providers/google/cloud/sensors/test_pubsub.py  |  2 +-
 .../cloud/transfers/test_bigquery_to_bigquery.py   |  2 +-
 .../google/cloud/transfers/test_gcs_to_gcs.py      |  2 +-
 .../cloud/utils/test_mlengine_operator_utils.py    |  6 +--
 tests/providers/mysql/hooks/test_mysql.py          |  6 +--
 tests/serialization/test_dag_serialization.py      |  4 +-
 tests/test_utils/gcp_system_helpers.py             |  2 +-
 tests/test_utils/logging_command_executor.py       |  2 +-
 tests/test_utils/mock_operators.py                 |  2 +-
 tests/utils/test_helpers.py                        |  4 +-
 tests/www/api/experimental/test_endpoints.py       |  2 +-
 tests/www/test_views.py                            | 16 ++++----
 133 files changed, 288 insertions(+), 373 deletions(-)