You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@airflow.apache.org by as...@apache.org on 2020/12/09 15:40:28 UTC

[airflow] branch v2-0-stable updated (7d37391 -> f96b3df)

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

ash pushed a change to branch v2-0-stable
in repository https://gitbox.apache.org/repos/asf/airflow.git.


    from 7d37391  Fix Multiple Migrations Heads (#12901)
     add 5f65cec  Add docs for new scheduler "clean-up" tunables. (#12899)
     add cb70150  Fix broken MySQL Migration (#12904)
     add 5e0a2d7  Fix failing test in TestSchedulerJob (#12906)
     add ef523b4  Move branch_operator.py to branch.py (#12900)
     add f9e9ad2  Builds prod images on DockerHub from packages (#12908)
     add 85dd092  Make sure perms list isn't None before looking within list (#12915)
     add ff25bd6  Make xcom_pull results order deterministic (#12905)
     add 4d24c5e  Update comments in setup.py (#12903)
     add 9b39f24  Add support for dynamic connection form fields per provider (#12558)
     add e7c1771  Adds predefined providers to install_requires. (#12916)
     add bc4d9d0  Remove duplicate entry in Updating.md (#12919)
     add 7c028f5  ImportErrors are collapsed by default (#12811)
     add 0da5232  Added documentation for Airflow Upgrade Check (#12872)
     add bfbd4bb  Moved subdag_operator.py to subdag.py (#11307)
     add 738c953  Add missing licences. (#12922)
     add ed6eb42  Use "auto" instead of "scroll" to prevent visible (unused) scrollbars in some browsers (#12923)
     add b40dffa  Rename remaing modules to match AIP-21 (#12917)
     add 4939816  Increase timeout for SQLite tests to 80 minutes (#12926)
     add c704293  Warning about unsafe migrations (#10254)
     add d558967  Move dummy_operator.py to dummy.py (#11178) (#11293)
     add abce78c  Disable experimental REST API by default (#12337)
     add 3da939b  Update doc to reflect the changes for DAG-Level access control (#12928)
     add 73843d0  Disable Pause/Unpause switch if user doesn't have edit access for DAG. (#12911)
     add e595d35  Simplify publishing of documentation (#12892)
     add a075b6d  Rename remaining Sensors to match AIP-21 (#12927)
     add bfbe486  Fix typo in metrics doc (#12934)
     add 3835062  Add Clarification to pod_template_file exmaples (#12932)
     add 63ea88d  Apply labels to Docker images in a single instruction (#12931)
     add 53c4847  shorten name of hook re imports of provide_session and create_session (#12936)
     add d7ddf16  Fixed failed pylint in master (#12938)
     add 8d6840b  Fix typo in setup.cfg (#12935)
     add 5c74c3a  Add explanation of the Presto Kerberos + SSL + snowflake problem (#12939)
     add 18a7a35  Enhanced TaskFlow API tutorial to use @dag decorator (#12937)
     add 55573f6  Fix typos/spelling in docs (#12942)
     add 7bd867d  Adds documentation about custom providers. (#12921)
     add 3e40288  Upgrading to Airflow 2.0 doc (#12930)
     add 0bf386f  Rename airflow.operators.dagrun_operator to airflow.operators.trigger_dagrun (#12933)
     add 1d91ca7  Infer multiple outputs from dict annotations in TaskFlow API (#10349)
     add d2b4dea  Update theme to show hidden ToC in sidebar (#12949)
     add 62a5b2d  Fix return type in prev-date context variables (#12910)
     add ec3b159  Clean up redirects.txt (#12948)
     add 5eeb66c  Fix case of GitHub (#12950)
     add f96b3df  Update version to 2.0.0 (#12954)

No new revisions were added by this update.

Summary of changes:
 .github/workflows/ci.yml                           |    2 +-
 .pre-commit-config.yaml                            |    8 +-
 .rat-excludes                                      |    6 +-
 CI.rst                                             |    2 +-
 Dockerfile                                         |   47 +-
 Dockerfile.ci                                      |   18 +-
 UPDATING.md                                        |   58 +-
 UPGRADING_TO_2.0.md                                | 1164 -------------------
 airflow/__init__.py                                |    5 +
 airflow/api/common/experimental/mark_tasks.py      |    2 +-
 airflow/cli/cli_parser.py                          |   24 +-
 airflow/cli/commands/connection_command.py         |    2 +-
 airflow/cli/commands/info_command.py               |    6 +-
 airflow/cli/commands/provider_command.py           |   42 +-
 airflow/config_templates/config.yml                |   27 +-
 airflow/config_templates/default_airflow.cfg       |   19 +-
 airflow/contrib/sensors/weekday_sensor.py          |    2 +-
 .../customized_form_field_behaviours.schema.json   |   32 +
 airflow/example_dags/example_bash_operator.py      |    2 +-
 airflow/example_dags/example_branch_operator.py    |    2 +-
 .../example_branch_python_dop_operator_3.py        |    2 +-
 .../example_external_task_marker_dag.py            |    4 +-
 airflow/example_dags/example_latest_only.py        |    2 +-
 .../example_latest_only_with_trigger.py            |    2 +-
 airflow/example_dags/example_nested_branch_dag.py  |    2 +-
 .../example_dags/example_short_circuit_operator.py |    2 +-
 airflow/example_dags/example_skip_dag.py           |    2 +-
 airflow/example_dags/example_subdag_operator.py    |    4 +-
 airflow/example_dags/example_task_group.py         |    2 +-
 .../example_dags/example_trigger_controller_dag.py |    2 +-
 airflow/example_dags/subdags/subdag.py             |    2 +-
 airflow/example_dags/tutorial_taskflow_api_etl.py  |   57 +-
 airflow/executors/celery_executor.py               |    2 +-
 airflow/hooks/base.py                              |  172 +++
 airflow/hooks/base_hook.py                         |   77 +-
 airflow/hooks/{dbapi_hook.py => dbapi.py}          |    2 +-
 airflow/hooks/dbapi_hook.py                        |  318 +-----
 airflow/hooks/filesystem.py                        |    2 +-
 airflow/jobs/scheduler_job.py                      |    2 +-
 .../dags_in_image_template.yaml                    |    3 +
 .../dags_in_volume_template.yaml                   |    3 +
 .../git_sync_template.yaml                         |    5 +-
 ...ac86c_change_field_in_dagcode_to_mediumtext_.py |    6 +-
 airflow/models/connection.py                       |   12 +-
 airflow/models/dag.py                              |    6 +-
 airflow/models/taskinstance.py                     |   17 +-
 .../operators/{branch_operator.py => branch.py}    |    0
 airflow/operators/branch_operator.py               |   39 +-
 airflow/operators/dagrun_operator.py               |  158 +--
 airflow/operators/{dummy_operator.py => dummy.py}  |    0
 airflow/operators/dummy_operator.py                |   26 +-
 airflow/operators/generic_transfer.py              |    2 +-
 airflow/operators/latest_only.py                   |    2 +-
 airflow/operators/python.py                        |    8 +-
 airflow/operators/sql.py                           |    2 +-
 .../operators/{subdag_operator.py => subdag.py}    |    7 +-
 airflow/operators/subdag_operator.py               |  203 +---
 .../{dagrun_operator.py => trigger_dagrun.py}      |    0
 airflow/plugins_manager.py                         |    2 +-
 .../example_google_api_to_s3_transfer_advanced.py  |    2 +-
 airflow/providers/amazon/aws/hooks/base_aws.py     |    9 +-
 airflow/providers/amazon/aws/hooks/emr.py          |    7 +-
 airflow/providers/amazon/aws/hooks/s3.py           |    3 +
 airflow/providers/amazon/aws/sensors/athena.py     |    2 +-
 .../amazon/aws/sensors/cloud_formation.py          |    2 +-
 .../amazon/aws/sensors/ec2_instance_state.py       |    2 +-
 airflow/providers/amazon/aws/sensors/emr_base.py   |    2 +-
 airflow/providers/amazon/aws/sensors/glacier.py    |    2 +-
 airflow/providers/amazon/aws/sensors/glue.py       |    2 +-
 .../amazon/aws/sensors/glue_catalog_partition.py   |    2 +-
 airflow/providers/amazon/aws/sensors/redshift.py   |    2 +-
 airflow/providers/amazon/aws/sensors/s3_key.py     |    2 +-
 .../amazon/aws/sensors/s3_keys_unchanged.py        |    2 +-
 airflow/providers/amazon/aws/sensors/s3_prefix.py  |    2 +-
 .../providers/amazon/aws/sensors/sagemaker_base.py |    2 +-
 airflow/providers/amazon/aws/sensors/sqs.py        |    2 +-
 .../amazon/aws/sensors/step_function_execution.py  |    2 +-
 airflow/providers/amazon/provider.yaml             |    5 +
 .../providers/apache/cassandra/hooks/cassandra.py  |    3 +-
 .../providers/apache/cassandra/sensors/record.py   |    2 +-
 .../providers/apache/cassandra/sensors/table.py    |    2 +-
 airflow/providers/apache/druid/hooks/druid.py      |    4 +-
 airflow/providers/apache/hdfs/hooks/hdfs.py        |    7 +-
 airflow/providers/apache/hdfs/hooks/webhdfs.py     |    2 +-
 airflow/providers/apache/hdfs/provider.yaml        |    3 +
 airflow/providers/apache/hdfs/sensors/hdfs.py      |    2 +-
 airflow/providers/apache/hdfs/sensors/web_hdfs.py  |    2 +-
 airflow/providers/apache/hive/hooks/hive.py        |   13 +-
 airflow/providers/apache/hive/provider.yaml        |    1 +
 .../apache/hive/sensors/hive_partition.py          |    2 +-
 .../apache/hive/sensors/metastore_partition.py     |    2 +-
 .../apache/hive/sensors/named_hive_partition.py    |    2 +-
 airflow/providers/apache/kylin/hooks/kylin.py      |    2 +-
 airflow/providers/apache/livy/hooks/livy.py        |    7 +-
 airflow/providers/apache/livy/provider.yaml        |    3 +
 airflow/providers/apache/livy/sensors/livy.py      |    2 +-
 airflow/providers/apache/pig/hooks/pig.py          |    3 +-
 airflow/providers/apache/pinot/hooks/pinot.py      |    4 +-
 airflow/providers/apache/spark/hooks/spark_jdbc.py |    7 +-
 airflow/providers/apache/spark/hooks/spark_sql.py  |    9 +-
 .../providers/apache/spark/hooks/spark_submit.py   |   15 +-
 airflow/providers/apache/spark/provider.yaml       |    5 +
 airflow/providers/apache/sqoop/hooks/sqoop.py      |    9 +-
 airflow/providers/apache/sqoop/provider.yaml       |    3 +
 airflow/providers/celery/sensors/celery_queue.py   |    2 +-
 airflow/providers/cloudant/hooks/cloudant.py       |   13 +-
 .../providers/cncf/kubernetes/hooks/kubernetes.py  |   33 +-
 .../cncf/kubernetes/sensors/spark_kubernetes.py    |    2 +-
 airflow/providers/databricks/hooks/databricks.py   |    9 +-
 airflow/providers/databricks/provider.yaml         |    3 +
 airflow/providers/datadog/hooks/datadog.py         |    2 +-
 airflow/providers/datadog/sensors/datadog.py       |    2 +-
 airflow/providers/docker/hooks/docker.py           |   26 +-
 .../providers/elasticsearch/hooks/elasticsearch.py |    3 +-
 airflow/providers/exasol/hooks/exasol.py           |    3 +-
 airflow/providers/facebook/ads/hooks/ads.py        |    9 +-
 airflow/providers/facebook/provider.yaml           |    3 +
 airflow/providers/ftp/hooks/ftp.py                 |    9 +-
 airflow/providers/ftp/provider.yaml                |    3 +
 airflow/providers/ftp/sensors/ftp.py               |    2 +-
 airflow/providers/google/ads/hooks/ads.py          |    2 +-
 airflow/providers/google/cloud/hooks/bigquery.py   |    5 +-
 airflow/providers/google/cloud/hooks/cloud_sql.py  |   15 +-
 .../providers/google/cloud/hooks/compute_ssh.py    |   10 +-
 airflow/providers/google/cloud/hooks/dataprep.py   |    3 +-
 .../providers/google/cloud/operators/cloud_sql.py  |    2 +-
 airflow/providers/google/cloud/sensors/bigquery.py |    2 +-
 .../providers/google/cloud/sensors/bigquery_dts.py |    2 +-
 airflow/providers/google/cloud/sensors/bigtable.py |    2 +-
 .../sensors/cloud_storage_transfer_service.py      |    2 +-
 airflow/providers/google/cloud/sensors/dataflow.py |    2 +-
 airflow/providers/google/cloud/sensors/dataproc.py |    2 +-
 airflow/providers/google/cloud/sensors/gcs.py      |    2 +-
 airflow/providers/google/cloud/sensors/pubsub.py   |    2 +-
 .../google/cloud/transfers/gcs_to_local.py         |    2 +-
 .../providers/google/common/hooks/base_google.py   |   44 +-
 .../marketing_platform/sensors/campaign_manager.py |    2 +-
 .../marketing_platform/sensors/display_video.py    |    2 +-
 .../marketing_platform/sensors/search_ads.py       |    2 +-
 airflow/providers/google/provider.yaml             |    2 +
 airflow/providers/grpc/hooks/grpc.py               |   24 +-
 airflow/providers/hashicorp/hooks/vault.py         |    9 +-
 airflow/providers/hashicorp/provider.yaml          |    3 +
 airflow/providers/http/hooks/http.py               |    9 +-
 airflow/providers/http/provider.yaml               |    3 +
 airflow/providers/http/sensors/http.py             |    2 +-
 airflow/providers/imap/hooks/imap.py               |    3 +-
 airflow/providers/imap/sensors/imap_attachment.py  |    2 +-
 .../jdbc/example_dags/example_jdbc_queries.py      |    2 +-
 airflow/providers/jdbc/hooks/jdbc.py               |   27 +-
 airflow/providers/jenkins/hooks/jenkins.py         |    9 +-
 airflow/providers/jenkins/provider.yaml            |    3 +
 airflow/providers/jira/hooks/jira.py               |    3 +-
 airflow/providers/jira/sensors/jira.py             |    2 +-
 airflow/providers/microsoft/azure/hooks/adx.py     |    9 +-
 .../providers/microsoft/azure/hooks/azure_batch.py |    3 +-
 .../azure/hooks/azure_container_instance.py        |    7 +-
 .../azure/hooks/azure_container_registry.py        |    2 +-
 .../azure/hooks/azure_container_volume.py          |    2 +-
 .../microsoft/azure/hooks/azure_cosmos.py          |    3 +-
 .../microsoft/azure/hooks/azure_data_lake.py       |    3 +-
 .../microsoft/azure/hooks/azure_fileshare.py       |    2 +-
 .../providers/microsoft/azure/hooks/base_azure.py  |    7 +-
 airflow/providers/microsoft/azure/hooks/wasb.py    |    3 +-
 airflow/providers/microsoft/azure/provider.yaml    |    3 +
 .../microsoft/azure/sensors/azure_cosmos.py        |    2 +-
 airflow/providers/microsoft/azure/sensors/wasb.py  |    2 +-
 airflow/providers/microsoft/mssql/hooks/mssql.py   |    3 +-
 .../microsoft/winrm/example_dags/example_winrm.py  |    2 +-
 airflow/providers/microsoft/winrm/hooks/winrm.py   |    2 +-
 airflow/providers/mongo/hooks/mongo.py             |    3 +-
 airflow/providers/mongo/sensors/mongo.py           |    2 +-
 airflow/providers/mysql/hooks/mysql.py             |    3 +-
 airflow/providers/odbc/hooks/odbc.py               |    5 +-
 airflow/providers/openfaas/hooks/openfaas.py       |    2 +-
 airflow/providers/oracle/hooks/oracle.py           |    4 +-
 airflow/providers/pagerduty/hooks/pagerduty.py     |    2 +-
 airflow/providers/plexus/hooks/plexus.py           |    2 +-
 airflow/providers/postgres/hooks/postgres.py       |    3 +-
 .../{cncf/kubernetes => presto}/ADDITIONAL_INFO.md |   12 +-
 airflow/providers/presto/hooks/presto.py           |    3 +-
 .../qubole/example_dags/example_qubole.py          |    2 +-
 airflow/providers/qubole/hooks/qubole.py           |   21 +-
 airflow/providers/qubole/operators/qubole.py       |    2 +-
 airflow/providers/qubole/provider.yaml             |    3 +
 airflow/providers/qubole/sensors/qubole.py         |    4 +-
 airflow/providers/redis/hooks/redis.py             |    3 +-
 airflow/providers/redis/sensors/redis_key.py       |    2 +-
 airflow/providers/redis/sensors/redis_pub_sub.py   |    2 +-
 airflow/providers/salesforce/hooks/salesforce.py   |    2 +-
 airflow/providers/salesforce/hooks/tableau.py      |    3 +-
 .../salesforce/sensors/tableau_job_status.py       |    2 +-
 airflow/providers/samba/hooks/samba.py             |    9 +-
 airflow/providers/samba/provider.yaml              |    3 +
 airflow/providers/segment/hooks/segment.py         |    7 +-
 airflow/providers/segment/provider.yaml            |    3 +
 airflow/providers/sftp/hooks/sftp.py               |   14 +
 airflow/providers/sftp/provider.yaml               |    3 +
 airflow/providers/sftp/sensors/sftp.py             |    2 +-
 airflow/providers/slack/hooks/slack.py             |    2 +-
 airflow/providers/snowflake/hooks/snowflake.py     |    3 +-
 airflow/providers/sqlite/hooks/sqlite.py           |    3 +-
 airflow/providers/ssh/hooks/ssh.py                 |   19 +-
 airflow/providers/ssh/provider.yaml                |    3 +
 airflow/providers/telegram/hooks/telegram.py       |    2 +-
 airflow/providers/vertica/hooks/vertica.py         |    3 +-
 airflow/providers/yandex/hooks/yandex.py           |   68 +-
 airflow/providers/yandex/provider.yaml             |    3 +
 airflow/providers/zendesk/hooks/zendesk.py         |    2 +-
 airflow/providers_manager.py                       |  192 +++-
 .../sensors/{base_sensor_operator.py => base.py}   |    0
 airflow/sensors/base_sensor_operator.py            |  317 +-----
 airflow/sensors/bash.py                            |    2 +-
 .../sensors/{date_time_sensor.py => date_time.py}  |    2 +-
 airflow/sensors/date_time_sensor.py                |   60 +-
 .../{external_task_sensor.py => external_task.py}  |    4 +-
 airflow/sensors/external_task_sensor.py            |  298 +----
 airflow/sensors/filesystem.py                      |    2 +-
 airflow/sensors/python.py                          |    2 +-
 .../{smart_sensor_operator.py => smart_sensor.py}  |    0
 airflow/sensors/{sql_sensor.py => sql.py}          |    4 +-
 airflow/sensors/sql_sensor.py                      |  105 +-
 .../{time_delta_sensor.py => time_delta.py}        |    2 +-
 airflow/sensors/time_delta_sensor.py               |   32 +-
 airflow/sensors/time_sensor.py                     |    2 +-
 airflow/sensors/{weekday_sensor.py => weekday.py}  |    2 +-
 airflow/serialization/serialized_objects.py        |    3 +
 airflow/settings.py                                |    5 +
 airflow/smart_sensor_dags/smart_sensor_group.py    |    2 +-
 airflow/utils/db.py                                |   77 +-
 airflow/www/app.py                                 |    3 +-
 airflow/www/extensions/init_views.py               |   16 +
 airflow/www/forms.py                               |  137 +--
 airflow/www/security.py                            |    2 +-
 airflow/www/static/css/bootstrap-theme.css         |    4 +-
 airflow/www/static/css/dags.css                    |    2 +-
 airflow/www/static/css/main.css                    |    2 +-
 airflow/www/static/css/switch.css                  |   11 +-
 airflow/www/static/js/connection_form.js           |   59 +-
 airflow/www/templates/airflow/conn_create.html     |    1 +
 airflow/www/templates/airflow/conn_edit.html       |    1 +
 airflow/www/templates/airflow/dag.html             |   13 +-
 airflow/www/templates/airflow/dags.html            |   11 +-
 airflow/www/templates/appbuilder/flash.html        |    6 +-
 airflow/www/views.py                               |   74 +-
 dags/test_dag.py                                   |    2 +-
 dev/README_RELEASE_AIRFLOW.md                      |   40 +-
 dev/README_RELEASE_PROVIDER_PACKAGES.md            |   53 +
 dev/provider_packages/prepare_provider_packages.py |    4 +-
 .../refactor_provider_packages.py                  |   11 +
 .../connections/odbc.rst                           |    2 +-
 docs/apache-airflow-providers/index.rst            |  171 ++-
 docs/apache-airflow/backport-providers.rst         |    5 -
 docs/apache-airflow/concepts.rst                   |   57 +-
 docs/apache-airflow/howto/connection.rst           |   25 +
 docs/apache-airflow/howto/custom-operator.rst      |    9 +-
 docs/apache-airflow/howto/define_extra_link.rst    |   26 +-
 .../howto/operator/external_task_sensor.rst        |    2 +-
 docs/apache-airflow/index.rst                      |   11 +-
 docs/apache-airflow/installation.rst               |    5 +-
 docs/apache-airflow/lineage.rst                    |    2 +-
 docs/apache-airflow/logging-monitoring/metrics.rst |    2 +-
 docs/apache-airflow/operators-and-hooks-ref.rst    |   16 +-
 docs/apache-airflow/plugins.rst                    |    2 +-
 docs/apache-airflow/production-deployment.rst      |    2 +-
 docs/apache-airflow/python-api-ref.rst             |   10 +-
 docs/apache-airflow/redirects.txt                  |   69 +-
 docs/apache-airflow/rest-api-ref.rst               |    5 +
 docs/apache-airflow/scheduler.rst                  |   32 +
 docs/apache-airflow/security/access-control.rst    |    5 +-
 docs/apache-airflow/tutorial_taskflow_api.rst      |   29 +-
 docs/apache-airflow/upgrade-check.rst              |  165 +++
 docs/apache-airflow/upgrading-to-2.rst             | 1188 ++++++++++++++++++++
 docs/build_docs.py                                 |  182 +--
 docs/conf.py                                       |    6 +-
 docs/exts/airflow_intersphinx.py                   |   21 +-
 docs/exts/docs_build/code_utils.py                 |   13 +-
 .../exts/docs_build/dev_index_template.html.jinja2 |   18 +
 docs/exts/docs_build/docs_builder.py               |  206 ++++
 .../exts/docs_build/github_action_utils.py         |   26 +-
 .../operators_and_hooks_ref-transfers.rst.jinja2   |   18 +
 docs/exts/operators_and_hooks_ref.rst.jinja2       |   18 +
 docs/publish_docs.py                               |  100 ++
 docs/spelling_wordlist.txt                         |    3 +
 pyproject.toml                                     |   16 +
 scripts/ci/dockerfiles/krb5-kdc-server/Dockerfile  |   16 +
 scripts/ci/dockerfiles/krb5-kdc-server/kadm5.acl   |   16 +
 scripts/ci/dockerfiles/presto/Dockerfile           |   16 +
 scripts/ci/images/ci_build_dockerhub.sh            |   64 +-
 scripts/ci/images/ci_prepare_prod_image_on_ci.sh   |   54 +-
 scripts/ci/libraries/_build_images.sh              |   38 +
 scripts/ci/libraries/_initialization.sh            |   26 +
 scripts/ci/libraries/_kind.sh                      |    3 +-
 .../run_install_and_test_provider_packages.sh      |   56 +-
 scripts/tools/list-integrations.py                 |    4 +-
 setup.cfg                                          |    9 +-
 setup.py                                           |  107 +-
 tests/api/auth/backend/test_basic_auth.py          |    8 +-
 tests/api/common/experimental/test_delete_dag.py   |    2 +-
 tests/api_connexion/endpoints/test_dag_endpoint.py |    2 +-
 .../endpoints/test_event_log_endpoint.py           |    2 +-
 tests/api_connexion/endpoints/test_log_endpoint.py |    2 +-
 .../api_connexion/endpoints/test_task_endpoint.py  |    8 +-
 .../api_connexion/schemas/test_event_log_schema.py |    2 +-
 .../schemas/test_task_instance_schema.py           |    2 +-
 tests/api_connexion/schemas/test_task_schema.py    |    6 +-
 tests/cli/commands/test_plugins_command.py         |    2 +-
 tests/core/test_core.py                            |    4 +-
 tests/core/test_providers_manager.py               |   73 +-
 tests/dags/test_backfill_pooled_tasks.py           |    2 +-
 tests/dags/test_clear_subdag.py                    |    2 +-
 tests/dags/test_dag_with_no_tags.py                |    2 +-
 tests/dags/test_double_trigger.py                  |    2 +-
 tests/dags/test_example_bash_operator.py           |    2 +-
 tests/dags/test_impersonation_subdag.py            |    2 +-
 tests/dags/test_invalid_cron.py                    |    2 +-
 tests/dags/test_issue_1225.py                      |    2 +-
 tests/dags/test_latest_runs.py                     |    2 +-
 tests/dags/test_missing_owner.py                   |    2 +-
 tests/dags/test_on_failure_callback.py             |    2 +-
 tests/dags/test_on_kill.py                         |    2 +-
 tests/dags/test_only_dummy_tasks.py                |    2 +-
 tests/dags/test_prev_dagrun_dep.py                 |    2 +-
 tests/dags/test_scheduler_dags.py                  |    2 +-
 tests/dags/test_subdag.py                          |    4 +-
 tests/dags/test_with_non_default_owner.py          |    2 +-
 .../dags_with_system_exit/b_test_scheduler_dags.py |    2 +-
 tests/deprecated_classes.py                        |   38 +-
 tests/hooks/{test_dbapi_hook.py => test_dbapi.py}  |    2 +-
 tests/jobs/test_backfill_job.py                    |    2 +-
 tests/jobs/test_local_task_job.py                  |    2 +-
 tests/jobs/test_scheduler_job.py                   |    4 +-
 tests/lineage/test_lineage.py                      |    2 +-
 tests/models/test_baseoperator.py                  |    2 +-
 tests/models/test_cleartasks.py                    |    2 +-
 tests/models/test_connection.py                    |    2 +-
 tests/models/test_dag.py                           |    4 +-
 tests/models/test_dagbag.py                        |   14 +-
 tests/models/test_dagrun.py                        |    2 +-
 tests/models/test_pool.py                          |    2 +-
 tests/models/test_skipmixin.py                     |    2 +-
 tests/models/test_taskinstance.py                  |    8 +-
 tests/models/test_timestamp.py                     |    2 +-
 tests/operators/test_branch_operator.py            |    4 +-
 tests/operators/test_latest_only_operator.py       |    2 +-
 tests/operators/test_python.py                     |   90 +-
 tests/operators/test_sql.py                        |    2 +-
 tests/operators/test_subdag_operator.py            |    8 +-
 ...t_dagrun_operator.py => test_trigger_dagrun.py} |    4 +-
 tests/plugins/test_plugin.py                       |    4 +-
 tests/plugins/test_plugins_manager.py              |    2 +-
 .../amazon/aws/log/test_cloudwatch_task_handler.py |    2 +-
 .../amazon/aws/log/test_s3_task_handler.py         |    2 +-
 .../amazon/aws/operators/test_emr_add_steps.py     |    2 +-
 .../elasticsearch/log/test_es_task_handler.py      |    2 +-
 tests/providers/facebook/ads/hooks/test_ads.py     |    2 +-
 tests/providers/google/ads/hooks/test_ads.py       |    2 +-
 .../providers/google/cloud/hooks/test_dataprep.py  |    2 +-
 .../google/cloud/log/test_gcs_task_handler.py      |    2 +-
 .../cloud/log/test_stackdriver_task_handler.py     |    2 +-
 .../google/cloud/operators/test_cloud_sql.py       |    4 +-
 .../cloud/operators/test_kubernetes_engine.py      |    4 +-
 .../common/auth_backend/test_google_openid.py      |    5 +-
 tests/providers/google/suite/hooks/test_drive.py   |    2 +-
 tests/providers/grpc/hooks/test_grpc.py            |   24 +-
 tests/providers/http/hooks/test_http.py            |   44 +-
 tests/providers/jenkins/hooks/test_jenkins.py      |    4 +-
 .../microsoft/azure/log/test_wasb_task_handler.py  |    2 +-
 .../providers/microsoft/mssql/hooks/test_mssql.py  |    6 +-
 .../microsoft/mssql/operators/test_mssql.py        |    2 +-
 tests/providers/openfaas/hooks/test_openfaas.py    |    2 +-
 tests/providers/presto/hooks/test_presto.py        |   19 +-
 tests/providers/samba/hooks/test_samba.py          |    8 +-
 tests/providers/ssh/hooks/test_ssh.py              |    8 +
 tests/providers/vertica/hooks/test_vertica.py      |    2 +-
 tests/providers/yandex/hooks/test_yandex.py        |    6 +-
 .../yandex/hooks/test_yandexcloud_dataproc.py      |    2 +-
 .../yandex/operators/test_yandexcloud_dataproc.py  |   12 +-
 .../sensors/{test_base_sensor.py => test_base.py}  |    4 +-
 ...{test_date_time_sensor.py => test_date_time.py} |    4 +-
 tests/sensors/test_external_task_sensor.py         |    4 +-
 tests/sensors/test_smart_sensor_operator.py        |    6 +-
 tests/sensors/test_sql_sensor.py                   |   18 +-
 ...test_timedelta_sensor.py => test_time_delta.py} |    2 +-
 tests/sensors/test_timeout_sensor.py               |    2 +-
 tests/sensors/test_weekday_sensor.py               |    2 +-
 tests/serialization/test_dag_serialization.py      |    6 +-
 .../test_remote_user_api_auth_backend.py           |    4 +-
 .../deps/test_not_previously_skipped_dep.py        |    2 +-
 tests/ti_deps/deps/test_runnable_exec_date_dep.py  |    2 +-
 tests/ti_deps/deps/test_trigger_rule_dep.py        |    2 +-
 tests/utils/log/test_log_reader.py                 |    2 +-
 tests/utils/test_dag_cycle.py                      |    2 +-
 tests/utils/test_helpers.py                        |    2 +-
 tests/utils/test_log_handlers.py                   |    2 +-
 tests/utils/test_task_group.py                     |    2 +-
 .../test_task_handler_with_custom_formatter.py     |    2 +-
 .../www/api/experimental/test_dag_runs_endpoint.py |    8 +-
 tests/www/api/experimental/test_endpoints.py       |    2 +
 .../api/experimental/test_kerberos_endpoints.py    |    1 +
 tests/www/test_init_views.py                       |   39 +
 tests/www/test_views.py                            |    2 +-
 402 files changed, 4549 insertions(+), 3967 deletions(-)
 delete mode 100644 UPGRADING_TO_2.0.md
 create mode 100644 airflow/customized_form_field_behaviours.schema.json
 create mode 100644 airflow/hooks/base.py
 copy airflow/hooks/{dbapi_hook.py => dbapi.py} (99%)
 copy airflow/operators/{branch_operator.py => branch.py} (100%)
 copy airflow/operators/{dummy_operator.py => dummy.py} (100%)
 copy airflow/operators/{subdag_operator.py => subdag.py} (98%)
 copy airflow/operators/{dagrun_operator.py => trigger_dagrun.py} (100%)
 copy airflow/providers/{cncf/kubernetes => presto}/ADDITIONAL_INFO.md (55%)
 copy airflow/sensors/{base_sensor_operator.py => base.py} (100%)
 copy airflow/sensors/{date_time_sensor.py => date_time.py} (97%)
 copy airflow/sensors/{external_task_sensor.py => external_task.py} (99%)
 rename airflow/sensors/{smart_sensor_operator.py => smart_sensor.py} (100%)
 copy airflow/sensors/{sql_sensor.py => sql.py} (97%)
 copy airflow/sensors/{time_delta_sensor.py => time_delta.py} (96%)
 rename airflow/sensors/{weekday_sensor.py => weekday.py} (98%)
 create mode 100644 docs/apache-airflow/upgrade-check.rst
 create mode 100644 docs/apache-airflow/upgrading-to-2.rst
 create mode 100644 docs/exts/docs_build/docs_builder.py
 copy airflow/www/extensions/init_dagbag.py => docs/exts/docs_build/github_action_utils.py (58%)
 create mode 100755 docs/publish_docs.py
 rename tests/hooks/{test_dbapi_hook.py => test_dbapi.py} (99%)
 rename tests/operators/{test_dagrun_operator.py => test_trigger_dagrun.py} (98%)
 rename tests/sensors/{test_base_sensor.py => test_base.py} (99%)
 rename tests/sensors/{test_date_time_sensor.py => test_date_time.py} (95%)
 rename tests/sensors/{test_timedelta_sensor.py => test_time_delta.py} (96%)
 create mode 100644 tests/www/test_init_views.py