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 2021/05/13 16:56:53 UTC

[airflow] branch v2-1-test updated (66dfa16 -> a51e9a8)

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

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


 discard 66dfa16  Add changelog.
 discard ad06bc8  Add resolution to force dependencies to use patched version of lodash (#15777)
 discard d16ce05  Update default versions v2-1-test in the 2.1 branch
     add 1024c92  Update KubeExecutor pod templates to allow access to IAM permissions (#15669)
     add b7b1764  Add docs to the markdownlint and yamllint config files (#15682)
     add faa4a52  Add note on changes to configuration options (#15696)
     add 0967453  Emit error on duplicated DAG ID (#15302)
     add 15f5bf4  Support jinja2 native Python types (#14603)
     add 3cfcd23  Chart: Update Webserver update strategy based on Airflow Version (#15627)
     add 803850a  Clean up the pre-commit config (#15703)
     add 3b4fdd0  add oracle  connection link (#15632)
     add bdb76be  Run helm chart tests in parallel (#15706)
     add c61af5c  Revert "Clean up the pre-commit config (#15703)" (#15707)
     add b9f6e9c  Fixes syntax of terraform script. (#15710)
     add b8c0fde  Add extra links for google dataproc (#10343)
     add 9dad095  Add rest API to query for providers (#13394)
     add 88aec14  Update breeze (#15717)
     add 9953a04  Add Connection Documentation for the Hive Provider (#15704)
     add deb953d  Refactor tests/www/test_views.py (#15666)
     add 57ad4af  Get rid of Airflow 1.10 in Breeze (#15712)
     add db0e942  Create cross-DAG dependencies view (#13199)
     add 37681bc  Auto-apply apply_default decorator (#15667)
     add e81ec7c  Reduce false-positives when detecting SQLite usage (#15716)
     add 87e440d  Create a DAG Calendar View (#15423)
     add 46d6278  Attempt to upgrade to newer Node version to build UI. (#15718)
     add 3614910  New UI: Add Timezone select (#15674)
     add f3fada9  Add short description to BaseSQLToGCSOperator docstring (#15728)
     add a01567c  Fix sql_to_gcs docstring lint error (#15730)
     add 736a62f  Remove duplicate key from Python dictionary (#15735)
     add d627dfa  Run Airflow package preparation in docker in breeze/CI (#15723)
     add 507bca5  Skip failing for undefined variables in MacOS (#15744)
     add 231d104  Enforce READ COMMITTED isolation when using mysql (#15714)
     add 30eeac7  [Oracle] Add port to DSN (#15589)
     add 7933aaf  Use "apache/airflow" repository as source of constraints (#15746)
     add 41930fd  extra docker-py update to resolve docker op issues (#15731)
     add feddc51  Add missing docstring params (#15741)
     add 350fd62  Remove redundant character escape from regex (#15740)
     add 00336ad  Small changes on "DAGs and Tasks documentation" (#14853)
     add 3711a29  Fix argument ordering and type of bucket and object (#15738)
     add 9c8391a  Fix spelling (#15699)
     add f122e28  Update `SimpleHttpOperator` to take auth object (#15605)
     add e7293b0  Mark test_mark_success_on_success_callback as quarantined (#15756)
     add dab10d9  MongoToS3Operator failed when running with a single query (not aggregate pipeline) (#15680)
     add 25caeda  Remove unused dependency (#15762)
     add 3edcd12  Update croniter to 1.0.x series (#15769)
     add 34cf525  Clean up unnecessary Airflow config in helm chart (#15729)
     add cbc3cb8  Add integration test for other executors in kubernetes cluster (#15695)
     add 996965a  Feature qubole hook support headers (#15683)
     add 533f202  Unset PIP_USER in prod entrypoint. (#15774)
     add 74c1ce0  Add resolution to force dependencies to use patched version of lodash (#15777)
     add 1543bb7  Fixed type annotations in DAG decorator (#15778)
     add c8ef3a3  Fix OdbcHook handling of port (#15772)
     add 303c89f  Return output of last task from task_group wrapper. (#15779)
     add 6690758  Bump stylelint to remove vulnerable sub-dependency (#15784)
     add c9fc587  Update Flask App Builder limit to recently released 3.3 (#15792)
     add 4b473a1  Pin `itsdangerous` to < 2 (#15804)
     add 6d64cc5  Chart: Allow setting annotations on Airflow pods & `Configmap` (#15238)
     add 43b6657  Expand date provider for new UI (#15725)
     add 892ea66  Chart: Use `v2-0-stable` branch for `git-sync` (#15809)
     add 5581631  Chart: Rename `dashboard` to `Webserver` in Installation Notes (#15808)
     add 8137d1e  Update Openapi generator version (#15816)
     add caddbf3  Chart: Avoid `git-sync` sidecar on Websever when Airflow>=2.0.0 (#15814)
     add 6f956dc  Allow S3ToSnowflakeOperator to omit schema (#15817)
     add 1edef28  Refactor tests/www/test_views.py (Part 2/2) (#15719)
     add a51e9a8  Update default versions v2-1-test in the 2.1 branch

This update added new revisions after undoing existing revisions.
That is to say, some revisions that were in the old version of the
branch are not in the new version.  This situation occurs
when a user --force pushes a change and generates a repository
containing something like this:

 * -- * -- B -- O -- O -- O   (66dfa16)
            \
             N -- N -- N   refs/heads/v2-1-test (a51e9a8)

You should already have received notification emails for all of the O
revisions, and so the following emails describe only the N revisions
from the common base, B.

Any revisions marked "omit" are not gone; other references still
refer to them.  Any revisions marked "discard" are gone forever.

No new revisions were added by this update.

Summary of changes:
 .github/workflows/build-images-workflow-run.yml    |    6 +-
 .github/workflows/ci.yml                           |   19 +-
 .markdownlint.yml                                  |   27 +-
 BREEZE.rst                                         |  140 +-
 CHANGELOG.txt                                      |  511 ---
 CI.rst                                             |    6 +-
 Dockerfile                                         |    2 +-
 Dockerfile.ci                                      |    4 +-
 IMAGES.rst                                         |    5 +-
 INSTALL                                            |    2 +-
 README.md                                          |    5 +-
 TESTING.rst                                        |   25 +-
 UPDATING.md                                        |   13 +-
 airflow/api/common/experimental/mark_tasks.py      |    2 +-
 .../api_connexion/endpoints/provider_endpoint.py   |   47 +
 airflow/api_connexion/openapi/v1.yaml              |   47 +-
 .../api_connexion/schemas/provider_schema.py       |   46 +-
 airflow/config_templates/config.yml                |    2 +-
 airflow/config_templates/default_airflow.cfg       |    2 +-
 airflow/contrib/operators/adls_to_gcs.py           |    2 +-
 airflow/contrib/operators/awsbatch_operator.py     |    2 +-
 airflow/contrib/operators/bigquery_operator.py     |    2 +-
 .../operators/bigquery_table_delete_operator.py    |    2 +-
 airflow/contrib/operators/bigquery_to_gcs.py       |    2 +-
 airflow/contrib/operators/cassandra_to_gcs.py      |    2 +-
 airflow/contrib/operators/dataflow_operator.py     |    6 +-
 airflow/contrib/operators/dataproc_operator.py     |   24 +-
 .../contrib/operators/datastore_export_operator.py |    2 +-
 .../contrib/operators/datastore_import_operator.py |    2 +-
 airflow/contrib/operators/file_to_gcs.py           |    2 +-
 airflow/contrib/operators/gcp_bigtable_operator.py |   12 +-
 airflow/contrib/operators/gcp_compute_operator.py  |   12 +-
 .../contrib/operators/gcp_container_operator.py    |    6 +-
 airflow/contrib/operators/gcp_dlp_operator.py      |    8 +-
 airflow/contrib/operators/gcp_function_operator.py |    4 +-
 .../operators/gcp_natural_language_operator.py     |    8 +-
 airflow/contrib/operators/gcp_spanner_operator.py  |   12 +-
 .../operators/gcp_speech_to_text_operator.py       |    2 +-
 airflow/contrib/operators/gcp_sql_operator.py      |   20 +-
 .../operators/gcp_text_to_speech_operator.py       |    2 +-
 airflow/contrib/operators/gcp_transfer_operator.py |   20 +-
 .../operators/gcp_translate_speech_operator.py     |    2 +-
 airflow/contrib/operators/gcp_vision_operator.py   |   22 +-
 airflow/contrib/operators/gcs_acl_operator.py      |    4 +-
 airflow/contrib/operators/gcs_delete_operator.py   |    2 +-
 airflow/contrib/operators/gcs_download_operator.py |    2 +-
 airflow/contrib/operators/gcs_list_operator.py     |    2 +-
 airflow/contrib/operators/gcs_operator.py          |    2 +-
 airflow/contrib/operators/gcs_to_bq.py             |    2 +-
 airflow/contrib/operators/gcs_to_gcs.py            |    2 +-
 airflow/contrib/operators/gcs_to_s3.py             |    2 +-
 airflow/contrib/operators/mlengine_operator.py     |    8 +-
 airflow/contrib/operators/mssql_to_gcs.py          |    2 +-
 airflow/contrib/operators/mysql_to_gcs.py          |    2 +-
 .../contrib/operators/oracle_to_oracle_transfer.py |    2 +-
 .../contrib/operators/postgres_to_gcs_operator.py  |    2 +-
 airflow/contrib/operators/pubsub_operator.py       |   10 +-
 airflow/contrib/operators/sql_to_gcs.py            |    2 +-
 airflow/contrib/operators/vertica_to_hive.py       |    2 +-
 airflow/contrib/operators/vertica_to_mysql.py      |    2 +-
 airflow/contrib/sensors/bigquery_sensor.py         |    2 +-
 airflow/contrib/sensors/gcp_transfer_sensor.py     |    2 +-
 airflow/contrib/sensors/gcs_sensor.py              |    8 +-
 airflow/contrib/sensors/hdfs_sensor.py             |    4 +-
 airflow/decorators/base.py                         |    2 -
 airflow/decorators/python.py                       |    2 -
 airflow/decorators/python_virtualenv.py            |    2 -
 airflow/decorators/task_group.py                   |    7 +-
 airflow/example_dags/tutorial.py                   |    9 +-
 .../tutorial_taskflow_api_etl_virtualenv.py        |    4 +-
 airflow/exceptions.py                              |   13 +
 airflow/jobs/local_task_job.py                     |    2 +-
 airflow/kubernetes/pod_generator.py                |    2 +-
 .../dags_in_image_template.yaml                    |    1 +
 .../dags_in_volume_template.yaml                   |    1 +
 .../git_sync_template.yaml                         |    3 +-
 airflow/models/baseoperator.py                     |  117 +-
 airflow/models/dag.py                              |   13 +-
 airflow/models/dagbag.py                           |   64 +-
 airflow/models/serialized_dag.py                   |   37 +-
 airflow/models/taskinstance.py                     |   14 +-
 airflow/operators/bash.py                          |    2 -
 airflow/operators/check_operator.py                |    8 +-
 airflow/operators/datetime.py                      |    2 -
 airflow/operators/dummy.py                         |    2 -
 airflow/operators/email.py                         |    2 -
 airflow/operators/generic_transfer.py              |    2 -
 airflow/operators/presto_check_operator.py         |    6 +-
 airflow/operators/python.py                        |    4 +-
 airflow/operators/sql.py                           |    7 -
 airflow/operators/sql_branch_operator.py           |    2 +-
 airflow/operators/subdag.py                        |    2 -
 airflow/operators/trigger_dagrun.py                |    2 -
 airflow/operators/weekday.py                       |    2 -
 airflow/providers/airbyte/hooks/airbyte.py         |    2 +-
 airflow/providers/airbyte/operators/airbyte.py     |    2 -
 airflow/providers/airbyte/sensors/airbyte.py       |    2 -
 airflow/providers/amazon/aws/hooks/glue.py         |    2 +-
 airflow/providers/amazon/aws/operators/athena.py   |    2 -
 airflow/providers/amazon/aws/operators/batch.py    |    2 -
 .../amazon/aws/operators/cloud_formation.py        |    3 -
 airflow/providers/amazon/aws/operators/datasync.py |    2 -
 .../amazon/aws/operators/ec2_start_instance.py     |    2 -
 .../amazon/aws/operators/ec2_stop_instance.py      |    2 -
 airflow/providers/amazon/aws/operators/ecs.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 -
 airflow/providers/amazon/aws/operators/glacier.py  |    2 -
 airflow/providers/amazon/aws/operators/glue.py     |    2 -
 .../providers/amazon/aws/operators/glue_crawler.py |    2 -
 .../providers/amazon/aws/operators/s3_bucket.py    |    2 -
 .../amazon/aws/operators/s3_copy_object.py         |    2 -
 .../amazon/aws/operators/s3_delete_objects.py      |    2 -
 .../amazon/aws/operators/s3_file_transform.py      |    2 -
 airflow/providers/amazon/aws/operators/s3_list.py  |    2 -
 .../amazon/aws/operators/sagemaker_base.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 -
 airflow/providers/amazon/aws/operators/sns.py      |    2 -
 airflow/providers/amazon/aws/operators/sqs.py      |    2 -
 .../step_function_get_execution_output.py          |    2 -
 .../aws/operators/step_function_start_execution.py |    2 -
 airflow/providers/amazon/aws/sensors/athena.py     |    2 -
 .../amazon/aws/sensors/cloud_formation.py          |    3 -
 .../amazon/aws/sensors/ec2_instance_state.py       |    2 -
 airflow/providers/amazon/aws/sensors/emr_base.py   |    2 -
 .../providers/amazon/aws/sensors/emr_job_flow.py   |    2 -
 airflow/providers/amazon/aws/sensors/emr_step.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 -
 .../providers/amazon/aws/sensors/glue_crawler.py   |    2 -
 airflow/providers/amazon/aws/sensors/redshift.py   |    2 -
 airflow/providers/amazon/aws/sensors/s3_key.py     |    3 -
 .../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 -
 .../amazon/aws/sensors/sagemaker_endpoint.py       |    2 -
 .../amazon/aws/sensors/sagemaker_training.py       |    2 -
 .../amazon/aws/sensors/sagemaker_transform.py      |    2 -
 .../amazon/aws/sensors/sagemaker_tuning.py         |    2 -
 airflow/providers/amazon/aws/sensors/sqs.py        |    2 -
 .../amazon/aws/sensors/step_function_execution.py  |    2 -
 .../amazon/aws/transfers/dynamodb_to_s3.py         |    2 -
 .../providers/amazon/aws/transfers/exasol_to_s3.py |    2 -
 .../providers/amazon/aws/transfers/ftp_to_s3.py    |    2 -
 .../providers/amazon/aws/transfers/gcs_to_s3.py    |    2 -
 .../amazon/aws/transfers/glacier_to_gcs.py         |    2 -
 .../amazon/aws/transfers/google_api_to_s3.py       |    2 -
 .../amazon/aws/transfers/hive_to_dynamodb.py       |    5 +-
 .../amazon/aws/transfers/imap_attachment_to_s3.py  |    2 -
 .../providers/amazon/aws/transfers/mongo_to_s3.py  |    9 +-
 .../providers/amazon/aws/transfers/mysql_to_s3.py  |    2 -
 .../amazon/aws/transfers/redshift_to_s3.py         |    2 -
 .../providers/amazon/aws/transfers/s3_to_ftp.py    |    2 -
 .../amazon/aws/transfers/s3_to_redshift.py         |    2 -
 .../providers/amazon/aws/transfers/s3_to_sftp.py   |    2 -
 .../providers/amazon/aws/transfers/sftp_to_s3.py   |    2 -
 airflow/providers/apache/beam/operators/beam.py    |    3 -
 .../providers/apache/cassandra/sensors/record.py   |    2 -
 .../providers/apache/cassandra/sensors/table.py    |    2 -
 airflow/providers/apache/druid/operators/druid.py  |    2 -
 .../apache/druid/operators/druid_check.py          |    2 +-
 .../apache/druid/transfers/hive_to_druid.py        |    2 -
 airflow/providers/apache/hdfs/sensors/hdfs.py      |    2 -
 airflow/providers/apache/hdfs/sensors/web_hdfs.py  |    2 -
 airflow/providers/apache/hive/hooks/hive.py        |   19 +-
 airflow/providers/apache/hive/operators/hive.py    |    5 +-
 .../providers/apache/hive/operators/hive_stats.py  |    5 +-
 .../apache/hive/sensors/hive_partition.py          |    6 +-
 .../apache/hive/sensors/metastore_partition.py     |    2 -
 .../apache/hive/sensors/named_hive_partition.py    |    6 +-
 .../apache/hive/transfers/hive_to_mysql.py         |    7 +-
 .../apache/hive/transfers/hive_to_samba.py         |    5 +-
 .../apache/hive/transfers/mssql_to_hive.py         |    7 +-
 .../apache/hive/transfers/mysql_to_hive.py         |    7 +-
 .../providers/apache/hive/transfers/s3_to_hive.py  |    5 +-
 .../apache/hive/transfers/vertica_to_hive.py       |    7 +-
 .../providers/apache/kylin/operators/kylin_cube.py |    2 -
 airflow/providers/apache/livy/operators/livy.py    |    2 -
 airflow/providers/apache/livy/sensors/livy.py      |    2 -
 airflow/providers/apache/pig/operators/pig.py      |    2 -
 .../providers/apache/spark/operators/spark_jdbc.py |    2 -
 .../providers/apache/spark/operators/spark_sql.py  |    2 -
 .../apache/spark/operators/spark_submit.py         |    2 -
 airflow/providers/apache/sqoop/operators/sqoop.py  |    2 -
 airflow/providers/celery/sensors/celery_queue.py   |    2 -
 .../cncf/kubernetes/operators/kubernetes_pod.py    |    2 -
 .../cncf/kubernetes/operators/spark_kubernetes.py  |    2 -
 .../cncf/kubernetes/sensors/spark_kubernetes.py    |    2 -
 .../providers/databricks/operators/databricks.py   |    3 -
 airflow/providers/datadog/sensors/datadog.py       |    2 -
 airflow/providers/dingding/operators/dingding.py   |    2 -
 .../providers/discord/operators/discord_webhook.py |    2 -
 airflow/providers/docker/operators/docker.py       |    2 -
 airflow/providers/docker/operators/docker_swarm.py |    2 -
 airflow/providers/exasol/operators/exasol.py       |    2 -
 airflow/providers/ftp/sensors/ftp.py               |    2 -
 airflow/providers/google/CHANGELOG.rst             |    6 +
 airflow/providers/google/ads/operators/ads.py      |    2 -
 .../providers/google/ads/transfers/ads_to_gcs.py   |    2 -
 .../providers/google/cloud/hooks/compute_ssh.py    |    2 +-
 airflow/providers/google/cloud/hooks/gcs.py        |    6 +-
 airflow/providers/google/cloud/operators/automl.py |   24 +-
 .../providers/google/cloud/operators/bigquery.py   |   19 -
 .../google/cloud/operators/bigquery_dts.py         |    4 -
 .../providers/google/cloud/operators/bigtable.py   |    7 -
 .../google/cloud/operators/cloud_build.py          |    2 -
 .../google/cloud/operators/cloud_memorystore.py    |   19 -
 .../providers/google/cloud/operators/cloud_sql.py  |   30 -
 .../operators/cloud_storage_transfer_service.py    |   10 -
 .../providers/google/cloud/operators/compute.py    |   49 -
 .../google/cloud/operators/datacatalog.py          |   22 -
 .../providers/google/cloud/operators/dataflow.py   |    6 -
 .../providers/google/cloud/operators/datafusion.py |   11 -
 .../providers/google/cloud/operators/dataprep.py   |    3 -
 .../providers/google/cloud/operators/dataproc.py   |  119 +-
 .../providers/google/cloud/operators/datastore.py  |   10 -
 airflow/providers/google/cloud/operators/dlp.py    |   31 -
 .../providers/google/cloud/operators/functions.py  |    4 -
 airflow/providers/google/cloud/operators/gcs.py    |   10 -
 .../google/cloud/operators/kubernetes_engine.py    |    4 -
 .../google/cloud/operators/life_sciences.py        |    2 -
 .../providers/google/cloud/operators/mlengine.py   |   13 -
 .../google/cloud/operators/natural_language.py     |    5 -
 airflow/providers/google/cloud/operators/pubsub.py |    7 -
 .../providers/google/cloud/operators/spanner.py    |    7 -
 .../google/cloud/operators/speech_to_text.py       |    2 -
 .../google/cloud/operators/stackdriver.py          |   11 -
 airflow/providers/google/cloud/operators/tasks.py  |   14 -
 .../google/cloud/operators/text_to_speech.py       |    2 -
 .../providers/google/cloud/operators/translate.py  |    2 -
 .../google/cloud/operators/translate_speech.py     |    2 -
 .../google/cloud/operators/video_intelligence.py   |    4 -
 airflow/providers/google/cloud/operators/vision.py |   14 -
 airflow/providers/google/cloud/sensors/bigquery.py |    3 -
 .../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 |    5 -
 airflow/providers/google/cloud/sensors/dataproc.py |    2 -
 airflow/providers/google/cloud/sensors/gcs.py      |    5 -
 airflow/providers/google/cloud/sensors/pubsub.py   |    2 -
 .../google/cloud/transfers/adls_to_gcs.py          |    2 -
 .../cloud/transfers/azure_fileshare_to_gcs.py      |    2 -
 .../google/cloud/transfers/bigquery_to_bigquery.py |    2 -
 .../google/cloud/transfers/bigquery_to_gcs.py      |    2 -
 .../google/cloud/transfers/bigquery_to_mysql.py    |    2 -
 .../google/cloud/transfers/cassandra_to_gcs.py     |    2 -
 .../google/cloud/transfers/facebook_ads_to_gcs.py  |    2 -
 .../google/cloud/transfers/gcs_to_bigquery.py      |    4 +-
 .../providers/google/cloud/transfers/gcs_to_gcs.py |    2 -
 .../google/cloud/transfers/gcs_to_local.py         |    2 -
 .../google/cloud/transfers/gcs_to_sftp.py          |    2 -
 .../google/cloud/transfers/gdrive_to_gcs.py        |    2 -
 .../google/cloud/transfers/gdrive_to_local.py      |    2 -
 .../google/cloud/transfers/local_to_gcs.py         |    2 -
 .../google/cloud/transfers/mssql_to_gcs.py         |    2 -
 .../google/cloud/transfers/mysql_to_gcs.py         |    2 -
 .../google/cloud/transfers/oracle_to_gcs.py        |    5 +-
 .../google/cloud/transfers/postgres_to_gcs.py      |    2 -
 .../google/cloud/transfers/presto_to_gcs.py        |    2 -
 .../providers/google/cloud/transfers/s3_to_gcs.py  |    2 -
 .../google/cloud/transfers/sftp_to_gcs.py          |    2 -
 .../google/cloud/transfers/sheets_to_gcs.py        |    2 -
 .../providers/google/cloud/transfers/sql_to_gcs.py |    4 +-
 .../google/cloud/transfers/trino_to_gcs.py         |    2 -
 .../google/firebase/operators/firestore.py         |    2 -
 .../providers/google/leveldb/operators/leveldb.py  |    2 -
 .../marketing_platform/operators/analytics.py      |    5 -
 .../operators/campaign_manager.py                  |    7 -
 .../marketing_platform/operators/display_video.py  |    9 -
 .../marketing_platform/operators/search_ads.py     |    3 -
 .../marketing_platform/sensors/campaign_manager.py |    2 -
 .../marketing_platform/sensors/search_ads.py       |    2 -
 airflow/providers/google/provider.yaml             |    2 +
 airflow/providers/google/suite/operators/sheets.py |    2 -
 airflow/providers/google/suite/sensors/drive.py    |    2 -
 .../google/suite/transfers/gcs_to_gdrive.py        |    2 -
 .../google/suite/transfers/gcs_to_sheets.py        |    2 -
 airflow/providers/grpc/operators/grpc.py           |    2 -
 airflow/providers/http/operators/http.py           |   12 +-
 airflow/providers/http/sensors/http.py             |    2 -
 airflow/providers/imap/sensors/imap_attachment.py  |    2 -
 airflow/providers/jdbc/operators/jdbc.py           |    2 -
 .../jenkins/operators/jenkins_job_trigger.py       |    2 -
 airflow/providers/jira/operators/jira.py           |    2 -
 airflow/providers/jira/sensors/jira.py             |    3 -
 .../microsoft/azure/operators/adls_delete.py       |    2 -
 .../microsoft/azure/operators/adls_list.py         |    2 -
 airflow/providers/microsoft/azure/operators/adx.py |    2 -
 .../microsoft/azure/operators/azure_batch.py       |    2 -
 .../azure/operators/azure_container_instances.py   |    2 -
 .../microsoft/azure/operators/azure_cosmos.py      |    2 -
 .../microsoft/azure/operators/wasb_delete_blob.py  |    2 -
 .../microsoft/azure/sensors/azure_cosmos.py        |    2 -
 airflow/providers/microsoft/azure/sensors/wasb.py  |    3 -
 .../microsoft/azure/transfers/azure_blob_to_gcs.py |    2 -
 .../microsoft/azure/transfers/file_to_wasb.py      |    2 -
 .../microsoft/azure/transfers/local_to_adls.py     |    2 -
 .../azure/transfers/oracle_to_azure_data_lake.py   |    4 +-
 .../providers/microsoft/mssql/operators/mssql.py   |    2 -
 .../providers/microsoft/winrm/operators/winrm.py   |    2 -
 airflow/providers/mongo/sensors/mongo.py           |    2 -
 airflow/providers/mysql/operators/mysql.py         |    2 -
 .../providers/mysql/transfers/presto_to_mysql.py   |    2 -
 airflow/providers/mysql/transfers/s3_to_mysql.py   |    2 -
 .../providers/mysql/transfers/trino_to_mysql.py    |    2 -
 .../providers/mysql/transfers/vertica_to_mysql.py  |    2 -
 airflow/providers/neo4j/operators/neo4j.py         |    2 -
 airflow/providers/odbc/hooks/odbc.py               |    2 +-
 .../providers/opsgenie/operators/opsgenie_alert.py |    2 -
 airflow/providers/oracle/hooks/oracle.py           |   37 +-
 airflow/providers/oracle/operators/oracle.py       |    5 +-
 .../providers/oracle/transfers/oracle_to_oracle.py |    4 +-
 .../papermill/example_dags/example_papermill.py    |    2 +-
 airflow/providers/papermill/operators/papermill.py |    2 -
 airflow/providers/plexus/operators/job.py          |    2 -
 airflow/providers/postgres/operators/postgres.py   |    2 -
 airflow/providers/postgres/provider.yaml           |    2 +-
 airflow/providers/qubole/hooks/qubole.py           |    3 +-
 airflow/providers/qubole/hooks/qubole_check.py     |    2 +-
 airflow/providers/qubole/operators/qubole.py       |    2 -
 airflow/providers/qubole/operators/qubole_check.py |    3 -
 airflow/providers/qubole/sensors/qubole.py         |    4 -
 airflow/providers/redis/operators/redis_publish.py |    2 -
 airflow/providers/redis/sensors/redis_key.py       |    2 -
 airflow/providers/redis/sensors/redis_pub_sub.py   |    2 -
 .../segment/operators/segment_track_event.py       |    2 -
 airflow/providers/sftp/operators/sftp.py           |    2 -
 airflow/providers/sftp/sensors/sftp.py             |    2 -
 .../providers/singularity/operators/singularity.py |    2 -
 airflow/providers/slack/operators/slack.py         |    4 -
 airflow/providers/slack/operators/slack_webhook.py |    2 -
 airflow/providers/snowflake/operators/snowflake.py |    2 -
 .../snowflake/transfers/s3_to_snowflake.py         |   44 +-
 .../snowflake/transfers/snowflake_to_slack.py      |    2 -
 airflow/providers/sqlite/operators/sqlite.py       |    2 -
 airflow/providers/ssh/operators/ssh.py             |    2 -
 .../tableau/operators/tableau_refresh_workbook.py  |    2 -
 .../tableau/sensors/tableau_job_status.py          |    2 -
 airflow/providers/telegram/operators/telegram.py   |    2 -
 airflow/providers/vertica/operators/vertica.py     |    2 -
 .../yandex/operators/yandexcloud_dataproc.py       |    7 -
 airflow/security/permissions.py                    |    2 +
 airflow/sensors/base.py                            |    2 -
 airflow/sensors/bash.py                            |    2 -
 airflow/sensors/date_time.py                       |    2 -
 airflow/sensors/external_task.py                   |    3 -
 airflow/sensors/filesystem.py                      |    2 -
 airflow/sensors/python.py                          |    2 -
 airflow/sensors/smart_sensor.py                    |    2 -
 airflow/sensors/sql.py                             |    2 -
 airflow/sensors/time_delta.py                      |    2 -
 airflow/sensors/time_sensor.py                     |    2 -
 airflow/sensors/weekday.py                         |    2 -
 airflow/serialization/schema.json                  |   10 +-
 airflow/serialization/serialized_objects.py        |   66 +-
 airflow/settings.py                                |   11 +-
 airflow/ui/docs/CONTRIBUTING.md                    |    4 +-
 airflow/ui/package.json                            |    5 +-
 .../ui/src/components/AppContainer/AppHeader.tsx   |   34 +-
 .../components/AppContainer/TimezoneDropdown.tsx   |   83 +
 airflow/ui/src/components/MultiSelect.tsx          |  259 ++
 .../{TimezoneProvider.tsx => DateProvider.tsx}     |   38 +-
 airflow/ui/src/providers/auth/PrivateRoute.tsx     |    6 +-
 .../Pipelines/{index.tsx => PipelinesTable.tsx}    |    9 +-
 airflow/ui/src/views/Pipelines/index.tsx           |   60 +-
 airflow/ui/test/Login.test.tsx                     |    6 -
 airflow/ui/test/TimezoneDropdown.test.tsx          |   59 +
 airflow/ui/test/utils.tsx                          |    6 +
 airflow/ui/tsconfig.json                           |    2 +-
 airflow/ui/yarn.lock                               |  947 ++---
 airflow/utils/dag_processing.py                    |    4 +-
 airflow/utils/decorators.py                        |   93 +-
 airflow/utils/log/secrets_masker.py                |    4 +-
 airflow/utils/python_virtualenv.py                 |   15 +-
 airflow/utils/timezone.py                          |    1 +
 airflow/www/extensions/init_views.py               |    5 +
 airflow/www/package.json                           |    1 -
 airflow/www/security.py                            |    2 +
 .../static/css/calendar.css}                       |   43 +-
 airflow/www/static/css/graph.css                   |   27 +
 airflow/www/static/js/calendar.js                  |  342 ++
 airflow/www/static/js/dag_dependencies.js          |  195 ++
 airflow/www/templates/airflow/calendar.html        |   53 +
 airflow/www/templates/airflow/dag.html             |    4 +
 .../www/templates/airflow/dag_dependencies.html    |   75 +
 airflow/www/templates/airflow/dags.html            |    4 +
 airflow/www/utils.py                               |    2 +-
 airflow/www/views.py                               |  137 +
 airflow/www/webpack.config.js                      |    2 +
 airflow/www/yarn.lock                              | 1322 +++----
 breeze                                             |   64 +-
 breeze-complete                                    |    4 +-
 chart/templates/NOTES.txt                          |    4 +-
 chart/templates/configmaps/configmap.yaml          |    6 +
 chart/templates/flower/flower-deployment.yaml      |    6 +-
 chart/templates/jobs/create-user-job.yaml          |    7 +-
 chart/templates/jobs/migrate-database-job.yaml     |    6 +-
 .../templates/scheduler/scheduler-deployment.yaml  |    2 +
 .../templates/webserver/webserver-deployment.yaml  |   24 +-
 chart/templates/workers/worker-deployment.yaml     |    6 +-
 chart/tests/conftest.py                            |   23 +-
 chart/tests/helm_template_generator.py             |    5 +-
 chart/tests/test_configmap.py                      |   47 +
 chart/tests/test_flower.py                         |   37 +
 chart/tests/test_git_sync_webserver.py             |   49 +-
 chart/tests/test_pod_template_file.py              |   44 +-
 chart/tests/test_webserver_deployment.py           |   25 +
 chart/values.schema.json                           |   16 +-
 chart/values.yaml                                  |   94 +-
 clients/gen/common.sh                              |    2 +-
 clients/gen/python.sh                              |    2 +-
 dev/README_RELEASE_AIRFLOW.md                      |  234 +-
 dev/README_RELEASE_PROVIDER_PACKAGES.md            |   12 +-
 dev/provider_packages/README.md                    |    2 +-
 dev/provider_packages/prepare_provider_packages.py |    4 +-
 .../connections/hive_cli.rst                       |   93 +
 .../connections/hive_metastore.rst}                |   43 +-
 .../connections/hiveserver2.rst                    |   78 +
 .../connections/index.rst                          |    0
 .../apache-airflow-providers-apache-hive/index.rst |    6 +
 .../api-auth-backend/google-openid.rst             |    2 +-
 .../connections/gcp.rst                            |    3 +-
 .../connections/imap.rst                           |    2 +-
 .../connections/oracle.rst                         |   34 +-
 .../howto/create-update-providers.rst              |    4 +-
 docs/apache-airflow/concepts/dags.rst              |   18 +
 docs/apache-airflow/concepts/operators.rst         |   60 +-
 docs/apache-airflow/howto/custom-operator.rst      |    9 +-
 docs/apache-airflow/howto/define_extra_link.rst    |    2 -
 docs/apache-airflow/img/dag_doc.png                |  Bin 0 -> 40094 bytes
 docs/apache-airflow/img/task_doc.png               |  Bin 0 -> 245714 bytes
 docs/apache-airflow/installation.rst               |    4 +-
 docs/apache-airflow/security/access-control.rst    |    1 +
 docs/apache-airflow/tutorial.rst                   |    7 +-
 docs/docker-stack/build-arg-ref.rst                |    5 +-
 docs/exts/docroles.py                              |    1 +
 docs/exts/docs_build/errors.py                     |    1 +
 docs/exts/docs_build/lint_checks.py                |    2 +-
 docs/exts/docs_build/spelling_checks.py            |    1 +
 docs/exts/substitution_extensions.py               |    2 +-
 docs/helm-chart/manage-dags-files.rst              |   14 +-
 docs/helm-chart/parameters-ref.rst                 |   49 +-
 .../Postgress.png => postgres/Postgres.png}        |  Bin
 docs/spelling_wordlist.txt                         |    1 +
 .../{test_kubernetes_executor.py => test_base.py}  |   69 +-
 kubernetes_tests/test_kubernetes_executor.py       |  206 +-
 kubernetes_tests/test_kubernetes_pod_operator.py   |    4 +-
 kubernetes_tests/test_other_executors.py           |   89 +
 pylintrc                                           |    2 +-
 pylintrc-tests                                     |    2 +-
 ...low_package.sh => ci_build_airflow_packages.sh} |    6 +-
 scripts/ci/constraints/ci_branch_constraints.sh    |    2 -
 scripts/ci/docker-compose/_docker.env              |    2 +-
 scripts/ci/images/ci_build_dockerhub.sh            |    8 +-
 scripts/ci/libraries/_all_libs.sh                  |    2 -
 scripts/ci/libraries/_build_airflow_packages.sh    |   47 -
 scripts/ci/libraries/_build_images.sh              |   30 +-
 scripts/ci/libraries/_initialization.sh            |    4 -
 scripts/ci/libraries/_md5sum.sh                    |    4 +-
 scripts/ci/libraries/_parameters.sh                |    2 +-
 scripts/ci/libraries/_push_pull_remove_images.sh   |    2 +-
 scripts/ci/libraries/_runs.sh                      |    2 +-
 scripts/ci/libraries/_script_init.sh               |    9 +-
 scripts/ci/libraries/_testing.sh                   |    2 +-
 scripts/ci/selective_ci_checks.sh                  |    4 +-
 scripts/docker/common.sh                           |   13 +-
 scripts/in_container/_in_container_utils.sh        |   21 +
 scripts/in_container/entrypoint_ci.sh              |   20 +-
 scripts/in_container/prod/entrypoint_prod.sh       |    7 +
 .../run_install_and_test_provider_packages.sh      |    2 +-
 .../in_container/run_prepare_airflow_packages.sh   |  113 +
 .../in_container/run_prepare_provider_packages.sh  |   21 -
 setup.cfg                                          |    8 +-
 setup.py                                           |    5 +-
 tests/api_connexion/endpoints/test_log_endpoint.py |    2 +
 .../endpoints/test_provider_endpoint.py            |  123 +
 tests/bats/breeze/test_breeze_complete.bats        |   12 +-
 tests/core/test_core_to_contrib.py                 |   16 +-
 tests/core/test_impersonation_tests.py             |   14 +-
 tests/core/test_logging_config.py                  |    2 +
 tests/core/test_providers_manager.py               |    2 +
 tests/core/test_sqlalchemy_config.py               |    5 +
 tests/dags/test_backfill_pooled_tasks.py           |   37 -
 tests/dags/test_dag_with_no_tags.py                |    2 +-
 tests/jobs/test_local_task_job.py                  |    1 +
 tests/jobs/test_scheduler_job.py                   |    8 +-
 tests/models/test_baseoperator.py                  |  104 +-
 tests/models/test_dagbag.py                        |   32 +
 tests/providers/amazon/aws/hooks/test_datasync.py  |    2 +-
 .../aws/operators/test_sagemaker_processing.py     |    9 +-
 .../amazon/aws/transfers/test_mongo_to_s3.py       |    4 +-
 .../apache/hive/transfers/test_s3_to_hive.py       |   10 +-
 .../google/cloud/operators/test_automl.py          |    3 +-
 .../google/cloud/operators/test_cloud_sql.py       |   15 +-
 .../google/cloud/operators/test_dataflow.py        |   13 +-
 .../google/cloud/operators/test_dataproc.py        |  518 ++-
 .../providers/google/cloud/operators/test_tasks.py |    6 +-
 .../cloud/transfers/test_presto_to_gcs_system.py   |   13 +-
 .../cloud/transfers/test_trino_to_gcs_system.py    |   13 +-
 tests/providers/http/sensors/test_http.py          |   14 +-
 tests/providers/odbc/hooks/test_odbc.py            |    9 +-
 tests/providers/oracle/hooks/test_oracle.py        |   25 +-
 tests/providers/qubole/hooks/test_qubole.py        |   44 +-
 tests/providers/qubole/operators/test_qubole.py    |   18 +-
 .../snowflake/transfers/test_s3_to_snowflake.py    |   31 +-
 tests/sensors/test_timeout_sensor.py               |    2 -
 tests/serialization/test_dag_serialization.py      |    9 +-
 tests/test_utils/mock_operators.py                 |    6 +-
 tests/test_utils/perf/dags/elastic_dag.py          |    2 +-
 .../perf/scheduler_dag_execution_timing.py         |    8 +-
 tests/test_utils/www.py                            |   47 +
 tests/utils/log/test_secrets_masker.py             |    4 +-
 tests/utils/test_decorators.py                     |   74 -
 tests/utils/test_process_utils.py                  |    4 +-
 tests/utils/test_task_group.py                     |   38 +-
 tests/www/api/experimental/test_endpoints.py       |    2 +-
 tests/www/test_app.py                              |    2 +
 tests/www/test_security.py                         |    1 +
 tests/www/test_views.py                            | 3646 --------------------
 tests/www/views/conftest.py                        |  195 ++
 tests/www/views/test_views.py                      |  147 +
 tests/www/views/test_views_acl.py                  |  762 ++++
 tests/www/views/test_views_base.py                 |  437 +++
 tests/www/views/test_views_connection.py           |   56 +
 tests/www/views/test_views_dagrun.py               |  165 +
 tests/www/views/test_views_decorators.py           |  152 +
 tests/www/views/test_views_extra_links.py          |  312 ++
 tests/www/views/test_views_graph_gantt.py          |  206 ++
 tests/www/views/test_views_log.py                  |  405 +++
 tests/www/views/test_views_mount.py                |   57 +
 tests/www/views/test_views_pool.py                 |   79 +
 tests/www/views/test_views_rendered.py             |  145 +
 tests/www/views/test_views_tasks.py                |  576 ++++
 tests/www/views/test_views_trigger_dag.py          |  173 +
 tests/www/views/test_views_variable.py             |  104 +
 yamllint-config.yml                                |    1 +
 546 files changed, 9567 insertions(+), 7820 deletions(-)
 create mode 100644 airflow/api_connexion/endpoints/provider_endpoint.py
 copy .markdownlint.yml => airflow/api_connexion/schemas/provider_schema.py (54%)
 create mode 100644 airflow/ui/src/components/AppContainer/TimezoneDropdown.tsx
 create mode 100644 airflow/ui/src/components/MultiSelect.tsx
 rename airflow/ui/src/providers/{TimezoneProvider.tsx => DateProvider.tsx} (58%)
 copy airflow/ui/src/views/Pipelines/{index.tsx => PipelinesTable.tsx} (92%)
 create mode 100644 airflow/ui/test/TimezoneDropdown.test.tsx
 copy airflow/{ui/src/providers/auth/PrivateRoute.tsx => www/static/css/calendar.css} (61%)
 create mode 100644 airflow/www/static/js/calendar.js
 create mode 100644 airflow/www/static/js/dag_dependencies.js
 create mode 100644 airflow/www/templates/airflow/calendar.html
 create mode 100644 airflow/www/templates/airflow/dag_dependencies.html
 create mode 100644 chart/tests/test_configmap.py
 create mode 100644 docs/apache-airflow-providers-apache-hive/connections/hive_cli.rst
 copy docs/{apache-airflow-providers-imap/connections/imap.rst => apache-airflow-providers-apache-hive/connections/hive_metastore.rst} (50%)
 create mode 100644 docs/apache-airflow-providers-apache-hive/connections/hiveserver2.rst
 copy docs/{apache-airflow-providers-microsoft-azure => apache-airflow-providers-apache-hive}/connections/index.rst (100%)
 create mode 100644 docs/apache-airflow/img/dag_doc.png
 create mode 100644 docs/apache-airflow/img/task_doc.png
 rename docs/integration-logos/{postgress/Postgress.png => postgres/Postgres.png} (100%)
 copy kubernetes_tests/{test_kubernetes_executor.py => test_base.py} (80%)
 create mode 100644 kubernetes_tests/test_other_executors.py
 rename scripts/ci/build_airflow/{ci_build_airflow_package.sh => ci_build_airflow_packages.sh} (88%)
 delete mode 100644 scripts/ci/libraries/_build_airflow_packages.sh
 create mode 100755 scripts/in_container/run_prepare_airflow_packages.sh
 create mode 100644 tests/api_connexion/endpoints/test_provider_endpoint.py
 delete mode 100644 tests/dags/test_backfill_pooled_tasks.py
 create mode 100644 tests/test_utils/www.py
 delete mode 100644 tests/utils/test_decorators.py
 delete mode 100644 tests/www/test_views.py
 create mode 100644 tests/www/views/conftest.py
 create mode 100644 tests/www/views/test_views.py
 create mode 100644 tests/www/views/test_views_acl.py
 create mode 100644 tests/www/views/test_views_base.py
 create mode 100644 tests/www/views/test_views_connection.py
 create mode 100644 tests/www/views/test_views_dagrun.py
 create mode 100644 tests/www/views/test_views_decorators.py
 create mode 100644 tests/www/views/test_views_extra_links.py
 create mode 100644 tests/www/views/test_views_graph_gantt.py
 create mode 100644 tests/www/views/test_views_log.py
 create mode 100644 tests/www/views/test_views_mount.py
 create mode 100644 tests/www/views/test_views_pool.py
 create mode 100644 tests/www/views/test_views_rendered.py
 create mode 100644 tests/www/views/test_views_tasks.py
 create mode 100644 tests/www/views/test_views_trigger_dag.py
 create mode 100644 tests/www/views/test_views_variable.py